Skip navigation links
A B C D E F G H I J K L M N O P Q R S T U V W X Z 

A

abbreviate(TimeUnit) - Static method in class com.google.common.base.Stopwatch
 
aboutToAcquire(CycleDetectingLockFactory.CycleDetectingLock) - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory
CycleDetectingLock implementations must call this method before attempting to acquire the lock.
aboveAll() - Static method in class com.google.common.collect.Cut
 
AboveAll() - Constructor for class com.google.common.collect.Cut.AboveAll
 
aboveValue(C) - Static method in class com.google.common.collect.Cut
 
AboveValue(C) - Constructor for class com.google.common.collect.Cut.AboveValue
 
Absent<T> - Class in com.google.common.base
Implementation of an Optional not containing a reference.
Absent() - Constructor for class com.google.common.base.Absent
 
absent() - Static method in class com.google.common.base.Optional
Returns an Optional instance with no contained reference.
AbstractBiMap<K,V> - Class in com.google.common.collect
A general-purpose bimap implementation using any two backing Map instances.
AbstractBiMap(Map<K, V>, Map<V, K>) - Constructor for class com.google.common.collect.AbstractBiMap
Package-private constructor for creating a map-backed bimap.
AbstractBiMap(Map<K, V>, AbstractBiMap<V, K>) - Constructor for class com.google.common.collect.AbstractBiMap
Private constructor for inverse bimap.
AbstractBiMap.EntrySet - Class in com.google.common.collect
 
AbstractBiMap.Inverse<K,V> - Class in com.google.common.collect
The inverse of any other AbstractBiMap subclass.
AbstractBiMap.KeySet - Class in com.google.common.collect
 
AbstractBiMap.ValueSet - Class in com.google.common.collect
 
AbstractByteHasher - Class in com.google.common.hash
Abstract Hasher that handles converting primitives to bytes using a scratch ByteBuffer and streams all bytes to a sink to compute the hash.
AbstractByteHasher() - Constructor for class com.google.common.hash.AbstractByteHasher
 
AbstractCache<K,V> - Class in com.google.common.cache
This class provides a skeletal implementation of the Cache interface to minimize the effort required to implement this interface.
AbstractCache() - Constructor for class com.google.common.cache.AbstractCache
Constructor for use by subclasses.
AbstractCache.SimpleStatsCounter - Class in com.google.common.cache
A thread-safe AbstractCache.StatsCounter implementation for use by Cache implementors.
AbstractCache.StatsCounter - Interface in com.google.common.cache
Accumulates statistics during the operation of a Cache for presentation by Cache.stats().
AbstractCacheSet(ConcurrentMap<?, ?>) - Constructor for class com.google.common.cache.LocalCache.AbstractCacheSet
 
AbstractCell() - Constructor for class com.google.common.collect.Tables.AbstractCell
 
AbstractCheckedFuture<V,X extends java.lang.Exception> - Class in com.google.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.google.common.util.concurrent.AbstractCheckedFuture
Constructs an AbstractCheckedFuture that wraps a delegate.
AbstractCompositeHashFunction - Class in com.google.common.hash
An abstract composition of multiple hash functions.
AbstractCompositeHashFunction(HashFunction...) - Constructor for class com.google.common.hash.AbstractCompositeHashFunction
 
AbstractEntry() - Constructor for class com.google.common.collect.Multisets.AbstractEntry
 
AbstractExecutionThreadService - Class in com.google.common.util.concurrent
AbstractExecutionThreadService() - Constructor for class com.google.common.util.concurrent.AbstractExecutionThreadService
Constructor for use by subclasses.
AbstractFilteredMap(Map<K, V>, Predicate<? super Map.Entry<K, V>>) - Constructor for class com.google.common.collect.Maps.AbstractFilteredMap
 
AbstractFuture<V> - Class in com.google.common.util.concurrent
An abstract implementation of the ListenableFuture interface.
AbstractFuture() - Constructor for class com.google.common.util.concurrent.AbstractFuture
Constructor for use by subclasses.
AbstractFuture.Sync<V> - Class in com.google.common.util.concurrent
Following the contract of AbstractQueuedSynchronizer we create a private subclass to hold the synchronizer.
AbstractHasher - Class in com.google.common.hash
AbstractHasher() - Constructor for class com.google.common.hash.AbstractHasher
 
AbstractIdleService - Class in com.google.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.google.common.util.concurrent.AbstractIdleService
Constructor for use by subclasses.
AbstractIndexedListIterator<E> - Class in com.google.common.collect
This class provides a skeletal implementation of the ListIterator interface across a fixed number of elements that may be retrieved by position.
AbstractIndexedListIterator(int) - Constructor for class com.google.common.collect.AbstractIndexedListIterator
Constructs an iterator across a sequence of the given size whose initial position is 0.
AbstractIndexedListIterator(int, int) - Constructor for class com.google.common.collect.AbstractIndexedListIterator
Constructs an iterator across a sequence of the given size with the given initial position.
AbstractInvocationHandler - Class in com.google.common.reflect
Abstract implementation of InvocationHandler that handles Object.equals(java.lang.Object), Object.hashCode() and Object.toString().
AbstractInvocationHandler() - Constructor for class com.google.common.reflect.AbstractInvocationHandler
 
AbstractIterator<T> - Class in com.google.common.base
Note this class is a copy of AbstractIterator (for dependency reasons).
AbstractIterator() - Constructor for class com.google.common.base.AbstractIterator
 
AbstractIterator<T> - Class in com.google.common.collect
This class provides a skeletal implementation of the Iterator interface, to make this interface easier to implement for certain types of data sources.
AbstractIterator() - Constructor for class com.google.common.collect.AbstractIterator
Constructor for use by subclasses.
AbstractIterator.State - Enum in com.google.common.base
 
AbstractIterator.State - Enum in com.google.common.collect
 
AbstractListeningExecutorService - Class in com.google.common.util.concurrent
Abstract ListeningExecutorService implementation that creates ListenableFutureTask instances for each Runnable and Callable submitted to it.
AbstractListeningExecutorService() - Constructor for class com.google.common.util.concurrent.AbstractListeningExecutorService
 
AbstractListMultimap<K,V> - Class in com.google.common.collect
Basic implementation of the ListMultimap interface.
AbstractListMultimap(Map<K, Collection<V>>) - Constructor for class com.google.common.collect.AbstractListMultimap
Creates a new multimap that uses the provided map.
AbstractListWrapper(List<E>) - Constructor for class com.google.common.collect.Lists.AbstractListWrapper
 
AbstractLoadingCache<K,V> - Class in com.google.common.cache
This class provides a skeletal implementation of the Cache interface to minimize the effort required to implement this interface.
AbstractLoadingCache() - Constructor for class com.google.common.cache.AbstractLoadingCache
Constructor for use by subclasses.
AbstractMapBasedMultimap<K,V> - Class in com.google.common.collect
Basic implementation of the Multimap interface.
AbstractMapBasedMultimap(Map<K, Collection<V>>) - Constructor for class com.google.common.collect.AbstractMapBasedMultimap
Creates a new multimap that uses the provided map.
AbstractMapBasedMultimap.AsMap - Class in com.google.common.collect
 
AbstractMapBasedMultimap.AsMap.AsMapEntries - Class in com.google.common.collect
 
AbstractMapBasedMultimap.AsMap.AsMapIterator - Class in com.google.common.collect
Iterator across all keys and value collections.
AbstractMapBasedMultimap.Itr<T> - Class in com.google.common.collect
 
AbstractMapBasedMultimap.KeySet - Class in com.google.common.collect
 
AbstractMapBasedMultimap.NavigableAsMap - Class in com.google.common.collect
 
AbstractMapBasedMultimap.NavigableKeySet - Class in com.google.common.collect
 
AbstractMapBasedMultimap.RandomAccessWrappedList - Class in com.google.common.collect
List decorator that stays in sync with the multimap values for a key and supports rapid random access.
AbstractMapBasedMultimap.SortedAsMap - Class in com.google.common.collect
 
AbstractMapBasedMultimap.SortedKeySet - Class in com.google.common.collect
 
AbstractMapBasedMultimap.WrappedCollection - Class in com.google.common.collect
Collection decorator that stays in sync with the multimap values for a key.
AbstractMapBasedMultimap.WrappedCollection.WrappedIterator - Class in com.google.common.collect
Collection iterator for WrappedCollection.
AbstractMapBasedMultimap.WrappedList - Class in com.google.common.collect
List decorator that stays in sync with the multimap values for a key.
AbstractMapBasedMultimap.WrappedList.WrappedListIterator - Class in com.google.common.collect
ListIterator decorator.
AbstractMapBasedMultimap.WrappedNavigableSet - Class in com.google.common.collect
 
AbstractMapBasedMultimap.WrappedSet - Class in com.google.common.collect
Set decorator that stays in sync with the multimap values for a key.
AbstractMapBasedMultimap.WrappedSortedSet - Class in com.google.common.collect
SortedSet decorator that stays in sync with the multimap values for a key.
AbstractMapBasedMultiset<E> - Class in com.google.common.collect
Basic implementation of Multiset<E> backed by an instance of Map<E, Count>.
AbstractMapBasedMultiset(Map<E, Count>) - Constructor for class com.google.common.collect.AbstractMapBasedMultiset
Standard constructor.
AbstractMapBasedMultiset.MapBasedMultisetIterator - Class in com.google.common.collect
 
AbstractMapEntry<K,V> - Class in com.google.common.collect
Implementation of the equals, hashCode, and toString methods of Entry.
AbstractMapEntry() - Constructor for class com.google.common.collect.AbstractMapEntry
 
AbstractMultimap<K,V> - Class in com.google.common.collect
A skeleton Multimap implementation, not necessarily in terms of a Map.
AbstractMultimap() - Constructor for class com.google.common.collect.AbstractMultimap
 
AbstractMultimap.Entries - Class in com.google.common.collect
 
AbstractMultimap.EntrySet - Class in com.google.common.collect
 
AbstractMultimap.Values - Class in com.google.common.collect
 
AbstractMultiset<E> - Class in com.google.common.collect
This class provides a skeletal implementation of the Multiset interface.
AbstractMultiset() - Constructor for class com.google.common.collect.AbstractMultiset
 
AbstractMultiset.ElementSet - Class in com.google.common.collect
 
AbstractMultiset.EntrySet - Class in com.google.common.collect
 
AbstractNavigableMap<K,V> - Class in com.google.common.collect
Skeletal implementation of NavigableMap.
AbstractNavigableMap() - Constructor for class com.google.common.collect.AbstractNavigableMap
 
AbstractNavigableMap.DescendingMap - Class in com.google.common.collect
 
AbstractNonStreamingHashFunction - Class in com.google.common.hash
Skeleton implementation of HashFunction, appropriate for non-streaming algorithms.
AbstractNonStreamingHashFunction() - Constructor for class com.google.common.hash.AbstractNonStreamingHashFunction
 
AbstractNonStreamingHashFunction.BufferingHasher - Class in com.google.common.hash
In-memory stream-based implementation of Hasher.
AbstractNonStreamingHashFunction.ExposedByteArrayOutputStream - Class in com.google.common.hash
 
AbstractRangeSet<C extends java.lang.Comparable> - Class in com.google.common.collect
A skeletal implementation of RangeSet.
AbstractRangeSet() - Constructor for class com.google.common.collect.AbstractRangeSet
 
AbstractReferenceEntry() - Constructor for class com.google.common.cache.LocalCache.AbstractReferenceEntry
 
AbstractReferenceEntry() - Constructor for class com.google.common.collect.MapMakerInternalMap.AbstractReferenceEntry
 
AbstractScheduledService - Class in com.google.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.google.common.util.concurrent.AbstractScheduledService
Constructor for use by subclasses.
AbstractScheduledService.CustomScheduler - Class in com.google.common.util.concurrent
A AbstractScheduledService.Scheduler that provides a convenient way for the AbstractScheduledService to use a dynamically changing schedule.
AbstractScheduledService.CustomScheduler.ReschedulableCallable - Class in com.google.common.util.concurrent
A callable class that can reschedule itself using a AbstractScheduledService.CustomScheduler.
AbstractScheduledService.CustomScheduler.Schedule - Class in com.google.common.util.concurrent
A value object that represents an absolute delay until a task should be invoked.
AbstractScheduledService.Scheduler - Class in com.google.common.util.concurrent
A scheduler defines the policy for how the AbstractScheduledService should run its task.
AbstractSequentialIterator<T> - Class in com.google.common.collect
This class provides a skeletal implementation of the Iterator interface for sequences whose next element can always be derived from the previous element.
AbstractSequentialIterator(T) - Constructor for class com.google.common.collect.AbstractSequentialIterator
Creates a new iterator with the given first element, or, if firstOrNull is null, creates a new empty iterator.
AbstractSerializationProxy(MapMakerInternalMap.Strength, MapMakerInternalMap.Strength, Equivalence<Object>, Equivalence<Object>, long, long, int, int, MapMaker.RemovalListener<? super K, ? super V>, ConcurrentMap<K, V>) - Constructor for class com.google.common.collect.MapMakerInternalMap.AbstractSerializationProxy
 
AbstractService - Class in com.google.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.google.common.util.concurrent.AbstractService
Constructor for use by subclasses.
AbstractService.StateSnapshot - Class in com.google.common.util.concurrent
An immutable snapshot of the current state of the service.
AbstractSetMultimap<K,V> - Class in com.google.common.collect
Basic implementation of the SetMultimap interface.
AbstractSetMultimap(Map<K, Collection<V>>) - Constructor for class com.google.common.collect.AbstractSetMultimap
Creates a new multimap that uses the provided map.
AbstractSortedKeySortedSetMultimap<K,V> - Class in com.google.common.collect
Basic implementation of a SortedSetMultimap with a sorted key set.
AbstractSortedKeySortedSetMultimap(SortedMap<K, Collection<V>>) - Constructor for class com.google.common.collect.AbstractSortedKeySortedSetMultimap
 
AbstractSortedMultiset<E> - Class in com.google.common.collect
This class provides a skeletal implementation of the SortedMultiset interface.
AbstractSortedMultiset() - Constructor for class com.google.common.collect.AbstractSortedMultiset
 
AbstractSortedMultiset(Comparator<? super E>) - Constructor for class com.google.common.collect.AbstractSortedMultiset
 
AbstractSortedSetMultimap<K,V> - Class in com.google.common.collect
Basic implementation of the SortedSetMultimap interface.
AbstractSortedSetMultimap(Map<K, Collection<V>>) - Constructor for class com.google.common.collect.AbstractSortedSetMultimap
Creates a new multimap that uses the provided map.
AbstractStreamingHasher(int) - Constructor for class com.google.common.hash.AbstractStreamingHashFunction.AbstractStreamingHasher
Constructor for use by subclasses.
AbstractStreamingHasher(int, int) - Constructor for class com.google.common.hash.AbstractStreamingHashFunction.AbstractStreamingHasher
Constructor for use by subclasses.
AbstractStreamingHashFunction - Class in com.google.common.hash
Skeleton implementation of HashFunction.
AbstractStreamingHashFunction() - Constructor for class com.google.common.hash.AbstractStreamingHashFunction
 
AbstractStreamingHashFunction.AbstractStreamingHasher - Class in com.google.common.hash
A convenience base class for implementors of Hasher; handles accumulating data until an entire "chunk" (of implementation-dependent length) is ready to be hashed.
AbstractTable<R,C,V> - Class in com.google.common.collect
Skeletal, implementation-agnostic implementation of the Table interface.
AbstractTable() - Constructor for class com.google.common.collect.AbstractTable
 
AbstractTable.CellSet - Class in com.google.common.collect
 
AbstractTable.Values - Class in com.google.common.collect
 
accept(File, String) - Method in class com.google.common.io.PatternFilenameFilter
 
ACCEPT - Static variable in class com.google.common.net.HttpHeaders
The HTTP Accept header field name.
ACCEPT_CHARSET - Static variable in class com.google.common.net.HttpHeaders
The HTTP Accept-Charset header field name.
ACCEPT_ENCODING - Static variable in class com.google.common.net.HttpHeaders
The HTTP Accept-Encoding header field name.
ACCEPT_LANGUAGE - Static variable in class com.google.common.net.HttpHeaders
The HTTP Accept-Language header field name.
ACCEPT_RANGES - Static variable in class com.google.common.net.HttpHeaders
The HTTP Accept-Ranges header field name.
ACCESS_CONTROL_ALLOW_CREDENTIALS - Static variable in class com.google.common.net.HttpHeaders
The HTTP Access-Control-Allow-Credentials header field name.
ACCESS_CONTROL_ALLOW_HEADERS - Static variable in class com.google.common.net.HttpHeaders
The HTTP Access-Control-Allow-Headers header field name.
ACCESS_CONTROL_ALLOW_METHODS - Static variable in class com.google.common.net.HttpHeaders
The HTTP Access-Control-Allow-Methods header field name.
ACCESS_CONTROL_ALLOW_ORIGIN - Static variable in class com.google.common.net.HttpHeaders
The HTTP Access-Control-Allow-Origin header field name.
ACCESS_CONTROL_EXPOSE_HEADERS - Static variable in class com.google.common.net.HttpHeaders
The HTTP Access-Control-Expose-Headers header field name.
ACCESS_CONTROL_MAX_AGE - Static variable in class com.google.common.net.HttpHeaders
The HTTP Access-Control-Max-Age header field name.
ACCESS_CONTROL_REQUEST_HEADERS - Static variable in class com.google.common.net.HttpHeaders
The HTTP Access-Control-Request-Headers header field name.
ACCESS_CONTROL_REQUEST_METHOD - Static variable in class com.google.common.net.HttpHeaders
The HTTP Access-Control-Request-Method header field name.
ACCESS_MASK - Static variable in enum com.google.common.cache.LocalCache.EntryFactory
Masks used to compute indices in the following table.
AccessDurationParser() - Constructor for class com.google.common.cache.CacheBuilderSpec.AccessDurationParser
 
accessExpirationDuration - Variable in class com.google.common.cache.CacheBuilderSpec
 
accessExpirationTimeUnit - Variable in class com.google.common.cache.CacheBuilderSpec
 
accessibleObject - Variable in class com.google.common.reflect.Element
 
AccessQueue() - Constructor for class com.google.common.cache.LocalCache.AccessQueue
 
accessQueue - Variable in class com.google.common.cache.LocalCache.Segment
A queue of elements currently in the map, ordered by access time.
accessTime - Variable in class com.google.common.cache.LocalCache.StrongAccessEntry
 
accessTime - Variable in class com.google.common.cache.LocalCache.StrongAccessWriteEntry
 
accessTime - Variable in class com.google.common.cache.LocalCache.WeakAccessEntry
 
accessTime - Variable in class com.google.common.cache.LocalCache.WeakAccessWriteEntry
 
accordingTo(Type) - Static method in class com.google.common.reflect.TypeResolver
 
ACK - Static variable in class com.google.common.base.Ascii
Acknowledge: A communication control character transmitted by a receiver as an affirmative response to a sender.
acquire() - Method in class com.google.common.util.concurrent.RateLimiter
Acquires a single permit from this RateLimiter, blocking until the request can be granted.
acquire(int) - Method in class com.google.common.util.concurrent.RateLimiter
Acquires the given number of permits from this RateLimiter, blocking until the request can be granted.
acquiredLocks - Static variable in class com.google.common.util.concurrent.CycleDetectingLockFactory
Tracks the currently acquired locks for each Thread, kept up to date by calls to CycleDetectingLockFactory.aboutToAcquire(CycleDetectingLock) and CycleDetectingLockFactory.lockStateChanged(CycleDetectingLock).
ACTIVE - Static variable in class com.google.common.collect.ComparisonChain
 
activeGuards - Variable in class com.google.common.util.concurrent.Monitor
The guards associated with this monitor that currently have waiters (waiterCount > 0).
adapterExecutor - Variable in class com.google.common.util.concurrent.JdkFutureAdapters.ListenableFutureAdapter
 
add(String, Object) - Method in class com.google.common.base.MoreObjects.ToStringHelper
Adds a name/value pair to the formatted output in name=value format.
add(String, boolean) - Method in class com.google.common.base.MoreObjects.ToStringHelper
Adds a name/value pair to the formatted output in name=value format.
add(String, char) - Method in class com.google.common.base.MoreObjects.ToStringHelper
Adds a name/value pair to the formatted output in name=value format.
add(String, double) - Method in class com.google.common.base.MoreObjects.ToStringHelper
Adds a name/value pair to the formatted output in name=value format.
add(String, float) - Method in class com.google.common.base.MoreObjects.ToStringHelper
Adds a name/value pair to the formatted output in name=value format.
add(String, int) - Method in class com.google.common.base.MoreObjects.ToStringHelper
Adds a name/value pair to the formatted output in name=value format.
add(String, long) - Method in class com.google.common.base.MoreObjects.ToStringHelper
Adds a name/value pair to the formatted output in name=value format.
add(String, Object) - Method in class com.google.common.base.Objects.ToStringHelper
Deprecated.
Adds a name/value pair to the formatted output in name=value format.
add(String, boolean) - Method in class com.google.common.base.Objects.ToStringHelper
Deprecated.
Adds a name/value pair to the formatted output in name=value format.
add(String, char) - Method in class com.google.common.base.Objects.ToStringHelper
Deprecated.
Adds a name/value pair to the formatted output in name=value format.
add(String, double) - Method in class com.google.common.base.Objects.ToStringHelper
Deprecated.
Adds a name/value pair to the formatted output in name=value format.
add(String, float) - Method in class com.google.common.base.Objects.ToStringHelper
Deprecated.
Adds a name/value pair to the formatted output in name=value format.
add(String, int) - Method in class com.google.common.base.Objects.ToStringHelper
Deprecated.
Adds a name/value pair to the formatted output in name=value format.
add(String, long) - Method in class com.google.common.base.Objects.ToStringHelper
Deprecated.
Adds a name/value pair to the formatted output in name=value format.
add(long) - Method in interface com.google.common.cache.LongAddable
 
add(long) - Method in class com.google.common.cache.LongAddables.PureJavaLongAddable
 
add(long) - Method in class com.google.common.cache.LongAdder
Adds the given value.
add(V) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection
 
add(int, V) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedList
 
add(V) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedList.WrappedListIterator
 
add(E, int) - Method in class com.google.common.collect.AbstractMapBasedMultiset
Adds a number of occurrences of an element to this multiset.
add(E) - Method in class com.google.common.collect.AbstractMultiset
 
add(E, int) - Method in class com.google.common.collect.AbstractMultiset
 
add(Range<C>) - Method in class com.google.common.collect.AbstractRangeSet
 
add(E) - Method in class com.google.common.collect.Collections2.FilteredCollection
 
add(E, int) - Method in class com.google.common.collect.ConcurrentHashMultiset
Adds a number of occurrences of the specified element to this multiset.
add(E) - Method in class com.google.common.collect.Constraints.ConstrainedCollection
 
add(E) - Method in class com.google.common.collect.Constraints.ConstrainedList
 
add(int, E) - Method in class com.google.common.collect.Constraints.ConstrainedList
 
add(E) - Method in class com.google.common.collect.Constraints.ConstrainedListIterator
 
add(E) - Method in class com.google.common.collect.Constraints.ConstrainedSet
 
add(E) - Method in class com.google.common.collect.Constraints.ConstrainedSortedSet
 
add(E) - Method in class com.google.common.collect.EvictingQueue
Adds the given element to this queue.
add(V) - Method in class com.google.common.collect.FilteredKeyMultimap.AddRejectingList
 
add(int, V) - Method in class com.google.common.collect.FilteredKeyMultimap.AddRejectingList
 
add(V) - Method in class com.google.common.collect.FilteredKeyMultimap.AddRejectingSet
 
add(E) - Method in class com.google.common.collect.ForwardingCollection
 
add(int, E) - Method in class com.google.common.collect.ForwardingList
 
add(E) - Method in class com.google.common.collect.ForwardingListIterator
 
add(E, int) - Method in class com.google.common.collect.ForwardingMultiset
 
add(E) - Method in class com.google.common.collect.ImmutableCollection
Deprecated.
Unsupported operation.
add(E) - Method in class com.google.common.collect.ImmutableCollection.ArrayBasedBuilder
 
add(E...) - Method in class com.google.common.collect.ImmutableCollection.ArrayBasedBuilder
 
add(E) - Method in class com.google.common.collect.ImmutableCollection.Builder
Adds element to the ImmutableCollection being built.
add(E...) - Method in class com.google.common.collect.ImmutableCollection.Builder
Adds each element of elements to the ImmutableCollection being built.
add(int, E) - Method in class com.google.common.collect.ImmutableList
Deprecated.
Unsupported operation.
add(E) - Method in class com.google.common.collect.ImmutableList.Builder
Adds element to the ImmutableList.
add(E...) - Method in class com.google.common.collect.ImmutableList.Builder
Adds each element of elements to the ImmutableList.
add(E, int) - Method in class com.google.common.collect.ImmutableMultiset
Deprecated.
Unsupported operation.
add(E) - Method in class com.google.common.collect.ImmutableMultiset.Builder
Adds element to the ImmutableMultiset.
add(E...) - Method in class com.google.common.collect.ImmutableMultiset.Builder
Adds each element of elements to the ImmutableMultiset.
add(Range<C>) - Method in class com.google.common.collect.ImmutableRangeSet
 
add(Range<C>) - Method in class com.google.common.collect.ImmutableRangeSet.Builder
Add the specified range to this builder.
add(E) - Method in class com.google.common.collect.ImmutableSet.Builder
Adds element to the ImmutableSet.
add(E...) - Method in class com.google.common.collect.ImmutableSet.Builder
Adds each element of elements to the ImmutableSet, ignoring duplicate elements (only the first duplicate element is added).
add(E) - Method in class com.google.common.collect.ImmutableSortedMultiset.Builder
Adds element to the ImmutableSortedMultiset.
add(E...) - Method in class com.google.common.collect.ImmutableSortedMultiset.Builder
Adds each element of elements to the ImmutableSortedMultiset.
add(E) - Method in class com.google.common.collect.ImmutableSortedSet.Builder
Adds element to the ImmutableSortedSet.
add(E...) - Method in class com.google.common.collect.ImmutableSortedSet.Builder
Adds each element of elements to the ImmutableSortedSet, ignoring duplicate elements (only the first duplicate element is added).
add(V) - Method in class com.google.common.collect.LinkedHashMultimap.ValueSet
 
add(Map.Entry<K, V>) - Method in class com.google.common.collect.LinkedListMultimap.NodeIterator
 
add(V) - Method in class com.google.common.collect.LinkedListMultimap.ValueForKeyIterator
 
add(int, E) - Method in class com.google.common.collect.Lists.AbstractListWrapper
 
add(int, T) - Method in class com.google.common.collect.Lists.ReverseList
 
add(E) - Method in class com.google.common.collect.MinMaxPriorityQueue
Adds the given element to this queue.
add(E, int) - Method in interface com.google.common.collect.Multiset
Adds a number of occurrences of an element to this multiset.
add(E) - Method in interface com.google.common.collect.Multiset
Adds a single occurrence of the specified element to this multiset.
add(E, int) - Method in class com.google.common.collect.Multisets.FilteredMultiset
 
add(E) - Method in class com.google.common.collect.Multisets.UnmodifiableMultiset
 
add(E, int) - Method in class com.google.common.collect.Multisets.UnmodifiableMultiset
 
add(Range<C>) - Method in interface com.google.common.collect.RangeSet
Adds the specified range to this RangeSet (optional operation).
add(E) - Method in class com.google.common.collect.Synchronized.SynchronizedCollection
 
add(int, E) - Method in class com.google.common.collect.Synchronized.SynchronizedList
 
add(E, int) - Method in class com.google.common.collect.Synchronized.SynchronizedMultiset
 
add(T) - Method in class com.google.common.collect.TransformedListIterator
 
add(E, int) - Method in class com.google.common.collect.TreeMultiset
 
add(Comparator<? super E>, E, int, int[]) - Method in class com.google.common.collect.TreeMultiset.AvlNode
 
add(Range<C>) - Method in class com.google.common.collect.TreeRangeSet
 
add(Range<C>) - Method in class com.google.common.collect.TreeRangeSet.Complement
 
add(Range<C>) - Method in class com.google.common.collect.TreeRangeSet.SubRangeSet
 
add(E) - Method in class com.google.common.collect.UnmodifiableListIterator
Deprecated.
Unsupported operation.
add(char[], int, int) - Method in class com.google.common.io.LineBuffer
Process additional characters from the stream.
add(double) - Method in class com.google.common.math.DoubleMath.MeanAccumulator
 
add(Map<Class<?>, Class<?>>, Map<Class<?>, Class<?>>, Class<?>, Class<?>) - Static method in class com.google.common.primitives.Primitives
 
add(Runnable, Executor) - Method in class com.google.common.util.concurrent.ExecutionList
Adds the Runnable and accompanying Executor to the list of listeners to execute.
add(ListenerCallQueue.Callback<L>) - Method in class com.google.common.util.concurrent.ListenerCallQueue
Enqueues a task to be run.
addAll(Collection<? extends V>) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection
 
addAll(int, Collection<? extends V>) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedList
 
addAll(Collection<? extends E>) - Method in class com.google.common.collect.AbstractMultiset
addAll(RangeSet<C>) - Method in class com.google.common.collect.AbstractRangeSet
 
addAll(Collection<? extends E>) - Method in class com.google.common.collect.Collections2.FilteredCollection
 
addAll(Collection<? extends E>) - Method in class com.google.common.collect.Constraints.ConstrainedCollection
 
addAll(Collection<? extends E>) - Method in class com.google.common.collect.Constraints.ConstrainedList
 
addAll(int, Collection<? extends E>) - Method in class com.google.common.collect.Constraints.ConstrainedList
 
addAll(Collection<? extends E>) - Method in class com.google.common.collect.Constraints.ConstrainedSet
 
addAll(Collection<? extends E>) - Method in class com.google.common.collect.Constraints.ConstrainedSortedSet
 
addAll(Collection<? extends E>) - Method in class com.google.common.collect.EvictingQueue
 
addAll(Collection<? extends V>) - Method in class com.google.common.collect.FilteredKeyMultimap.AddRejectingList
 
addAll(int, Collection<? extends V>) - Method in class com.google.common.collect.FilteredKeyMultimap.AddRejectingList
 
addAll(Collection<? extends V>) - Method in class com.google.common.collect.FilteredKeyMultimap.AddRejectingSet
 
addAll(Collection<? extends E>) - Method in class com.google.common.collect.ForwardingCollection
 
addAll(int, Collection<? extends E>) - Method in class com.google.common.collect.ForwardingList
 
addAll(Collection<? extends E>) - Method in class com.google.common.collect.ImmutableCollection
Deprecated.
Unsupported operation.
addAll(Iterable<? extends E>) - Method in class com.google.common.collect.ImmutableCollection.ArrayBasedBuilder
 
addAll(Iterable<? extends E>) - Method in class com.google.common.collect.ImmutableCollection.Builder
Adds each element of elements to the ImmutableCollection being built.
addAll(Iterator<? extends E>) - Method in class com.google.common.collect.ImmutableCollection.Builder
Adds each element of elements to the ImmutableCollection being built.
addAll(int, Collection<? extends E>) - Method in class com.google.common.collect.ImmutableList
Deprecated.
Unsupported operation.
addAll(Iterable<? extends E>) - Method in class com.google.common.collect.ImmutableList.Builder
Adds each element of elements to the ImmutableList.
addAll(Iterator<? extends E>) - Method in class com.google.common.collect.ImmutableList.Builder
Adds each element of elements to the ImmutableList.
addAll(Iterable<? extends E>) - Method in class com.google.common.collect.ImmutableMultiset.Builder
Adds each element of elements to the ImmutableMultiset.
addAll(Iterator<? extends E>) - Method in class com.google.common.collect.ImmutableMultiset.Builder
Adds each element of elements to the ImmutableMultiset.
addAll(RangeSet<C>) - Method in class com.google.common.collect.ImmutableRangeSet
 
addAll(RangeSet<C>) - Method in class com.google.common.collect.ImmutableRangeSet.Builder
Add all ranges from the specified range set to this builder.
addAll(Iterable<? extends E>) - Method in class com.google.common.collect.ImmutableSet.Builder
Adds each element of elements to the ImmutableSet, ignoring duplicate elements (only the first duplicate element is added).
addAll(Iterator<? extends E>) - Method in class com.google.common.collect.ImmutableSet.Builder
Adds each element of elements to the ImmutableSet, ignoring duplicate elements (only the first duplicate element is added).
addAll(Iterable<? extends E>) - Method in class com.google.common.collect.ImmutableSortedMultiset.Builder
Adds each element of elements to the ImmutableSortedMultiset.
addAll(Iterator<? extends E>) - Method in class com.google.common.collect.ImmutableSortedMultiset.Builder
Adds each element of elements to the ImmutableSortedMultiset.
addAll(Iterable<? extends E>) - Method in class com.google.common.collect.ImmutableSortedSet.Builder
Adds each element of elements to the ImmutableSortedSet, ignoring duplicate elements (only the first duplicate element is added).
addAll(Iterator<? extends E>) - Method in class com.google.common.collect.ImmutableSortedSet.Builder
Adds each element of elements to the ImmutableSortedSet, ignoring duplicate elements (only the first duplicate element is added).
addAll(Collection<T>, Iterable<? extends T>) - Static method in class com.google.common.collect.Iterables
Adds all elements in iterable to collection.
addAll(Collection<T>, Iterator<? extends T>) - Static method in class com.google.common.collect.Iterators
Adds all elements in iterator to collection.
addAll(int, Collection<? extends E>) - Method in class com.google.common.collect.Lists.AbstractListWrapper
 
addAll(Collection<? extends E>) - Method in class com.google.common.collect.MinMaxPriorityQueue
 
addAll(Collection<? extends E>) - Method in class com.google.common.collect.Multisets.UnmodifiableMultiset
 
addAll(RangeSet<C>) - Method in interface com.google.common.collect.RangeSet
Adds all of the ranges from the specified range set to this range set (optional operation).
addAll(Collection<? extends E>) - Method in class com.google.common.collect.Synchronized.SynchronizedCollection
 
addAll(int, Collection<? extends E>) - Method in class com.google.common.collect.Synchronized.SynchronizedList
 
addAllImpl(List<E>, int, Iterable<? extends E>) - Static method in class com.google.common.collect.Lists
An implementation of List.addAll(int, Collection).
addAllImpl(Multiset<E>, Collection<? extends E>) - Static method in class com.google.common.collect.Multisets
An implementation of Collection.addAll(java.util.Collection<? extends E>).
addAndGet(int) - Method in class com.google.common.collect.Count
 
addAndGet(double) - Method in class com.google.common.util.concurrent.AtomicDouble
Atomically adds the given value to the current value.
addAndGet(int, double) - Method in class com.google.common.util.concurrent.AtomicDoubleArray
Atomically adds the given value to the element at index i.
addAndGet(K, long) - Method in class com.google.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.google.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.google.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.
addCopies(E, int) - Method in class com.google.common.collect.ImmutableMultiset.Builder
Adds a number of occurrences of an element to this ImmutableMultiset.
addCopies(E, int) - Method in class com.google.common.collect.ImmutableSortedMultiset.Builder
Adds a number of occurrences of an element to this ImmutableSortedMultiset.
addDelayedShutdownHook(ExecutorService, long, TimeUnit) - Static method in class com.google.common.util.concurrent.MoreExecutors
Add a shutdown hook to wait for thread completion in the given service.
addDelayedShutdownHook(ExecutorService, long, TimeUnit) - Method in class com.google.common.util.concurrent.MoreExecutors.Application
 
addEscape(char, String) - Method in class com.google.common.escape.CharEscaperBuilder
Add a new mapping from an index to an object to the escaping.
addEscape(char, String) - Method in class com.google.common.escape.Escapers.Builder
Adds a replacement string for the given input character.
addEscapes(char[], String) - Method in class com.google.common.escape.CharEscaperBuilder
Add multiple mappings at once for a particular index.
addFirst(E) - Method in class com.google.common.collect.ForwardingDeque
 
addFirst(E) - Method in class com.google.common.collect.Synchronized.SynchronizedDeque
 
addHolder() - Method in class com.google.common.base.MoreObjects.ToStringHelper
 
addHolder(Object) - Method in class com.google.common.base.MoreObjects.ToStringHelper
 
addHolder(String, Object) - Method in class com.google.common.base.MoreObjects.ToStringHelper
 
addHolder() - Method in class com.google.common.base.Objects.ToStringHelper
Deprecated.
 
addHolder(Object) - Method in class com.google.common.base.Objects.ToStringHelper
Deprecated.
 
addHolder(String, Object) - Method in class com.google.common.base.Objects.ToStringHelper
Deprecated.
 
addKnownType(MediaType) - Static method in class com.google.common.net.MediaType
 
addLast(E) - Method in class com.google.common.collect.ForwardingDeque
 
addLast(E) - Method in class com.google.common.collect.Synchronized.SynchronizedDeque
 
addLeftChild(E, int) - Method in class com.google.common.collect.TreeMultiset.AvlNode
 
addListener(Service.Listener, Executor) - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
 
addListener(Runnable, Executor) - Method in class com.google.common.util.concurrent.AbstractFuture
Registers a listener to be run on the given executor.
addListener(Service.Listener, Executor) - Method in class com.google.common.util.concurrent.AbstractIdleService
 
addListener(Service.Listener, Executor) - Method in class com.google.common.util.concurrent.AbstractScheduledService
 
addListener(Service.Listener, Executor) - Method in class com.google.common.util.concurrent.AbstractService
 
addListener(Runnable, Executor) - Method in class com.google.common.util.concurrent.ForwardingListenableFuture
 
addListener(Runnable, Executor) - Method in class com.google.common.util.concurrent.Futures.ImmediateFuture
 
addListener(Runnable, Executor) - Method in class com.google.common.util.concurrent.JdkFutureAdapters.ListenableFutureAdapter
 
addListener(Runnable, Executor) - Method in interface com.google.common.util.concurrent.ListenableFuture
Registers a listener to be run on the given executor.
addListener(Runnable, Executor) - Method in class com.google.common.util.concurrent.ListenableFutureTask
 
addListener(Service.Listener, Executor) - Method in interface com.google.common.util.concurrent.Service
Registers a Service.Listener to be executed on the given executor.
addListener(ServiceManager.Listener, Executor) - Method in class com.google.common.util.concurrent.ServiceManager
Registers a ServiceManager.Listener to be executed on the given executor.
addListener(ServiceManager.Listener) - Method in class com.google.common.util.concurrent.ServiceManager
Registers a ServiceManager.Listener to be run when this ServiceManager changes state.
addListener(ServiceManager.Listener, Executor) - Method in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState
 
addNode(K, V, LinkedListMultimap.Node<K, V>) - Method in class com.google.common.collect.LinkedListMultimap
Adds a new node for the specified key-value pair before the specified nextSibling element, or at the end of the list if nextSibling is null.
AddRejectingList(K) - Constructor for class com.google.common.collect.FilteredKeyMultimap.AddRejectingList
 
AddRejectingSet(K) - Constructor for class com.google.common.collect.FilteredKeyMultimap.AddRejectingSet
 
addRightChild(E, int) - Method in class com.google.common.collect.TreeMultiset.AvlNode
 
addShutdownHook(Thread) - Method in class com.google.common.util.concurrent.MoreExecutors.Application
 
addSuppressed - Static variable in class com.google.common.io.Closer.SuppressingSuppressor
 
addToMap() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection
Add the delegate to the map.
addValue(Object) - Method in class com.google.common.base.MoreObjects.ToStringHelper
Adds an unnamed value to the formatted output.
addValue(boolean) - Method in class com.google.common.base.MoreObjects.ToStringHelper
Adds an unnamed value to the formatted output.
addValue(char) - Method in class com.google.common.base.MoreObjects.ToStringHelper
Adds an unnamed value to the formatted output.
addValue(double) - Method in class com.google.common.base.MoreObjects.ToStringHelper
Adds an unnamed value to the formatted output.
addValue(float) - Method in class com.google.common.base.MoreObjects.ToStringHelper
Adds an unnamed value to the formatted output.
addValue(int) - Method in class com.google.common.base.MoreObjects.ToStringHelper
Adds an unnamed value to the formatted output.
addValue(long) - Method in class com.google.common.base.MoreObjects.ToStringHelper
Adds an unnamed value to the formatted output.
addValue(Object) - Method in class com.google.common.base.Objects.ToStringHelper
Deprecated.
Adds an unnamed value to the formatted output.
addValue(boolean) - Method in class com.google.common.base.Objects.ToStringHelper
Deprecated.
Adds an unnamed value to the formatted output.
addValue(char) - Method in class com.google.common.base.Objects.ToStringHelper
Deprecated.
Adds an unnamed value to the formatted output.
addValue(double) - Method in class com.google.common.base.Objects.ToStringHelper
Deprecated.
Adds an unnamed value to the formatted output.
addValue(float) - Method in class com.google.common.base.Objects.ToStringHelper
Deprecated.
Adds an unnamed value to the formatted output.
addValue(int) - Method in class com.google.common.base.Objects.ToStringHelper
Deprecated.
Adds an unnamed value to the formatted output.
addValue(long) - Method in class com.google.common.base.Objects.ToStringHelper
Deprecated.
Adds an unnamed value to the formatted output.
adler32() - Static method in class com.google.common.hash.Hashing
Returns a hash function implementing the Adler-32 checksum algorithm (32 hash bits) by delegating to the Adler32 Checksum.
Adler32Holder() - Constructor for class com.google.common.hash.Hashing.Adler32Holder
 
ADLER_32 - Static variable in class com.google.common.hash.Hashing.Adler32Holder
 
advance() - Method in class com.google.common.cache.LocalCache.HashIterator
 
advance(Iterator<?>, int) - Static method in class com.google.common.collect.Iterators
Calls next() on iterator, either numberToAdvance times or until hasNext() returns false, whichever comes first.
advance() - Method in class com.google.common.collect.MapMakerInternalMap.HashIterator
 
advance() - Method in class com.google.common.io.MultiInputStream
Closes the current input stream and opens the next one, if any.
advance() - Method in class com.google.common.io.MultiReader
Closes the current reader and opens the next one, if any.
advanceTo(LocalCache.ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.HashIterator
Advances to the given entry.
advanceTo(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.HashIterator
Advances to the given entry.
afterEveryChars - Variable in class com.google.common.io.BaseEncoding.SeparatedBaseEncoding
 
AGE - Static variable in class com.google.common.net.HttpHeaders
The HTTP Age header field name.
Aggregate() - Constructor for enum com.google.common.collect.TreeMultiset.Aggregate
 
aggregateAboveRange(TreeMultiset.Aggregate, TreeMultiset.AvlNode<E>) - Method in class com.google.common.collect.TreeMultiset
 
aggregateBelowRange(TreeMultiset.Aggregate, TreeMultiset.AvlNode<E>) - Method in class com.google.common.collect.TreeMultiset
 
aggregateForEntries(TreeMultiset.Aggregate) - Method in class com.google.common.collect.TreeMultiset
 
algorithmName - Variable in class com.google.common.hash.MessageDigestHashFunction.SerializedForm
 
all(Comparator<? super T>) - Static method in class com.google.common.collect.GeneralRange
Returns the whole range relative to the specified comparator.
ALL - Static variable in class com.google.common.collect.ImmutableRangeSet
 
all() - Static method in class com.google.common.collect.ImmutableRangeSet
Returns an immutable range set containing the single range Range.all().
all(Iterable<T>, Predicate<? super T>) - Static method in class com.google.common.collect.Iterables
Returns true if every element in iterable satisfies the predicate.
all(Iterator<T>, Predicate<? super T>) - Static method in class com.google.common.collect.Iterators
Returns true if every element returned by iterator satisfies the given predicate.
ALL - Static variable in class com.google.common.collect.Range
 
all() - Static method in class com.google.common.collect.Range
Returns a range that contains every value of type C.
ALL_SET - Static variable in class com.google.common.util.concurrent.Striped
A bit mask were all bits are set.
allAsList(ListenableFuture<? extends V>...) - Static method in class com.google.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.google.common.util.concurrent.Futures
Creates a new ListenableFuture whose value is a list containing the values of all its input futures, if all succeed.
allEqual() - Static method in class com.google.common.collect.Ordering
Returns an ordering which treats all values as equal, indicating "no ordering." Passing this ordering to any stable sort algorithm results in no change to the order of elements.
AllEqualOrdering - Class in com.google.common.collect
An ordering that treats all references as equals, even nulls.
AllEqualOrdering() - Constructor for class com.google.common.collect.AllEqualOrdering
 
allMatch(Predicate<? super E>) - Method in class com.google.common.collect.FluentIterable
Returns true if every element in this fluent iterable satisfies the predicate.
allMustSucceed - Variable in class com.google.common.util.concurrent.Futures.CombinedFuture
 
ALLOW - Static variable in class com.google.common.net.HttpHeaders
The HTTP Allow header field name.
AllowConcurrentEvents - Annotation Type in com.google.common.eventbus
Marks an event subscriber method as being thread-safe.
allowedPriorLocks - Variable in class com.google.common.util.concurrent.CycleDetectingLockFactory.LockGraphNode
The map tracking the locks that are known to be acquired before this lock, each associated with an example stack trace.
allPrimitiveTypes() - Static method in class com.google.common.primitives.Primitives
Returns an immutable set of all nine primitive types (including void).
allTypes - Variable in class com.google.common.reflect.TypeToken.InterfaceSet
 
allWrapperTypes() - Static method in class com.google.common.primitives.Primitives
Returns an immutable set of all nine primitive-wrapper types (including Void).
Alphabet(String, char[]) - Constructor for class com.google.common.io.BaseEncoding.Alphabet
 
alphabet - Variable in class com.google.common.io.BaseEncoding.StandardBaseEncoding
 
alwaysFalse() - Static method in class com.google.common.base.Predicates
Returns a predicate that always evaluates to false.
alwaysTrue() - Static method in class com.google.common.base.Predicates
Returns a predicate that always evaluates to true.
ancestor - Variable in class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection
 
ancestor(int) - Method in class com.google.common.net.InternetDomainName
Returns the ancestor of the current domain at the given number of levels "higher" (rightward) in the subdomain list.
ancestorDelegate - Variable in class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection
 
and(CharMatcher) - Method in class com.google.common.base.CharMatcher
Returns a matcher that matches any character matched by both this matcher and other.
And(CharMatcher, CharMatcher) - Constructor for class com.google.common.base.CharMatcher.And
 
And(CharMatcher, CharMatcher, String) - Constructor for class com.google.common.base.CharMatcher.And
 
and(Iterable<? extends Predicate<? super T>>) - Static method in class com.google.common.base.Predicates
Returns a predicate that evaluates to true if each of its components evaluates to true.
and(Predicate<? super T>...) - Static method in class com.google.common.base.Predicates
Returns a predicate that evaluates to true if each of its components evaluates to true.
and(Predicate<? super T>, Predicate<? super T>) - Static method in class com.google.common.base.Predicates
Returns a predicate that evaluates to true if both of its components evaluate to true.
AndPredicate(List<? extends Predicate<? super T>>) - Constructor for class com.google.common.base.Predicates.AndPredicate
 
andThen(Converter<B, C>) - Method in class com.google.common.base.Converter
Returns a converter whose convert method applies secondConverter to the result of this converter.
AnnotatedSubscriberFinder - Class in com.google.common.eventbus
A SubscriberFindingStrategy for collecting all event subscriber methods that are marked with the Subscribe annotation.
AnnotatedSubscriberFinder() - Constructor for class com.google.common.eventbus.AnnotatedSubscriberFinder
 
AnnotatedSubscriberFinder.MethodIdentifier - Class in com.google.common.eventbus
 
annotations - Variable in class com.google.common.reflect.Parameter
 
ANY - Static variable in class com.google.common.base.CharMatcher
Matches any character.
any(Iterable<T>, Predicate<? super T>) - Static method in class com.google.common.collect.Iterables
Returns true if any element in iterable satisfies the predicate.
any(Iterator<T>, Predicate<? super T>) - Static method in class com.google.common.collect.Iterators
Returns true if one or more elements returned by iterator satisfy the given predicate.
ANY4 - Static variable in class com.google.common.net.InetAddresses
 
ANY_APPLICATION_TYPE - Static variable in class com.google.common.net.MediaType
 
ANY_AUDIO_TYPE - Static variable in class com.google.common.net.MediaType
 
ANY_IMAGE_TYPE - Static variable in class com.google.common.net.MediaType
 
ANY_TEXT_TYPE - Static variable in class com.google.common.net.MediaType
 
ANY_TYPE - Static variable in class com.google.common.net.MediaType
 
ANY_VIDEO_TYPE - Static variable in class com.google.common.net.MediaType
 
anyMatch(Predicate<? super E>) - Method in class com.google.common.collect.FluentIterable
Returns true if any element in this fluent iterable satisfies the predicate.
anyOf(CharSequence) - Static method in class com.google.common.base.CharMatcher
Returns a char matcher that matches any character present in the given character sequence.
append(Iterable<? extends E>) - Method in class com.google.common.collect.FluentIterable
Returns a fluent iterable whose iterators traverse first the elements of this fluent iterable, followed by those of other.
append(E...) - Method in class com.google.common.collect.FluentIterable
Returns a fluent iterable whose iterators traverse first the elements of this fluent iterable, followed by elements.
append(char) - Method in class com.google.common.io.AppendableWriter
 
append(CharSequence) - Method in class com.google.common.io.AppendableWriter
 
append(CharSequence, int, int) - Method in class com.google.common.io.AppendableWriter
 
append(CharSequence) - Method in class com.google.common.io.CharStreams.NullWriter
 
append(CharSequence, int, int) - Method in class com.google.common.io.CharStreams.NullWriter
 
append(char) - Method in class com.google.common.io.CharStreams.NullWriter
 
append(CharSequence, File, Charset) - Static method in class com.google.common.io.Files
Appends a character sequence (such as a string) to a file using the given character set.
AppendableWriter - Class in com.google.common.io
Writer that places all output on an Appendable target.
AppendableWriter(Appendable) - Constructor for class com.google.common.io.AppendableWriter
Creates a new writer that appends everything it writes to target.
appendTo(A, Iterable<?>) - Method in class com.google.common.base.Joiner
Appends the string representation of each of parts, using the previously configured separator between each, to appendable.
appendTo(A, Iterator<?>) - Method in class com.google.common.base.Joiner
Appends the string representation of each of parts, using the previously configured separator between each, to appendable.
appendTo(A, Object[]) - Method in class com.google.common.base.Joiner
Appends the string representation of each of parts, using the previously configured separator between each, to appendable.
appendTo(A, Object, Object, Object...) - Method in class com.google.common.base.Joiner
Appends to appendable the string representation of each of the remaining arguments.
appendTo(StringBuilder, Iterable<?>) - Method in class com.google.common.base.Joiner
Appends the string representation of each of parts, using the previously configured separator between each, to builder.
appendTo(StringBuilder, Iterator<?>) - Method in class com.google.common.base.Joiner
Appends the string representation of each of parts, using the previously configured separator between each, to builder.
appendTo(StringBuilder, Object[]) - Method in class com.google.common.base.Joiner
Appends the string representation of each of parts, using the previously configured separator between each, to builder.
appendTo(StringBuilder, Object, Object, Object...) - Method in class com.google.common.base.Joiner
Appends to builder the string representation of each of the remaining arguments.
appendTo(A, Map<?, ?>) - Method in class com.google.common.base.Joiner.MapJoiner
Appends the string representation of each entry of map, using the previously configured separator and key-value separator, to appendable.
appendTo(StringBuilder, Map<?, ?>) - Method in class com.google.common.base.Joiner.MapJoiner
Appends the string representation of each entry of map, using the previously configured separator and key-value separator, to builder.
appendTo(A, Iterable<? extends Map.Entry<?, ?>>) - Method in class com.google.common.base.Joiner.MapJoiner
Appends the string representation of each entry in entries, using the previously configured separator and key-value separator, to appendable.
appendTo(A, Iterator<? extends Map.Entry<?, ?>>) - Method in class com.google.common.base.Joiner.MapJoiner
Appends the string representation of each entry in entries, using the previously configured separator and key-value separator, to appendable.
appendTo(StringBuilder, Iterable<? extends Map.Entry<?, ?>>) - Method in class com.google.common.base.Joiner.MapJoiner
Appends the string representation of each entry in entries, using the previously configured separator and key-value separator, to builder.
appendTo(StringBuilder, Iterator<? extends Map.Entry<?, ?>>) - Method in class com.google.common.base.Joiner.MapJoiner
Appends the string representation of each entry in entries, using the previously configured separator and key-value separator, to builder.
APPLE_MOBILE_CONFIG - Static variable in class com.google.common.net.MediaType
Application() - Constructor for class com.google.common.util.concurrent.MoreExecutors.Application
 
APPLICATION_BINARY - Static variable in class com.google.common.net.MediaType
This is a non-standard media type, but is commonly used in serving hosted binary files as it is known not to trigger content sniffing in current browsers.
APPLICATION_TYPE - Static variable in class com.google.common.net.MediaType
 
APPLICATION_XML_UTF_8 - Static variable in class com.google.common.net.MediaType
As described in RFC 3023, this constant (application/xml) is used for XML documents that are "unreadable by casual users." MediaType.XML_UTF_8 is provided for documents that may be read by users.
apply(Character) - Method in class com.google.common.base.CharMatcher
Deprecated.
Provided only to satisfy the Predicate interface; use CharMatcher.matches(char) instead.
apply(A) - Method in class com.google.common.base.Converter
Deprecated.
Provided to satisfy the Function interface; use Converter.convert(A) instead.
apply(T) - Method in class com.google.common.base.Equivalence.EquivalentToPredicate
 
apply(F) - Method in interface com.google.common.base.Function
Returns the result of applying this function to input.
apply(Object) - Method in class com.google.common.base.Functions.ConstantFunction
 
apply(K) - Method in class com.google.common.base.Functions.ForMapWithDefault
 
apply(A) - Method in class com.google.common.base.Functions.FunctionComposition
 
apply(K) - Method in class com.google.common.base.Functions.FunctionForMapNoDefault
 
apply(Object) - Method in enum com.google.common.base.Functions.IdentityFunction
 
apply(T) - Method in class com.google.common.base.Functions.PredicateFunction
 
apply(Object) - Method in class com.google.common.base.Functions.SupplierFunction
 
apply(Object) - Method in enum com.google.common.base.Functions.ToStringFunction
 
apply(T) - Method in interface com.google.common.base.Predicate
Returns the result of applying this predicate to input.
apply(T) - Method in class com.google.common.base.Predicates.AndPredicate
 
apply(Class<?>) - Method in class com.google.common.base.Predicates.AssignableFromPredicate
 
apply(A) - Method in class com.google.common.base.Predicates.CompositionPredicate
 
apply(CharSequence) - Method in class com.google.common.base.Predicates.ContainsPatternPredicate
 
apply(T) - Method in class com.google.common.base.Predicates.InPredicate
 
apply(Object) - Method in class com.google.common.base.Predicates.InstanceOfPredicate
 
apply(T) - Method in class com.google.common.base.Predicates.IsEqualToPredicate
 
apply(T) - Method in class com.google.common.base.Predicates.NotPredicate
 
apply(T) - Method in class com.google.common.base.Predicates.OrPredicate
 
apply(Supplier<Object>) - Method in enum com.google.common.base.Suppliers.SupplierFunctionImpl
 
apply(K) - Method in class com.google.common.cache.AbstractLoadingCache
 
apply(K) - Method in class com.google.common.cache.ForwardingLoadingCache
 
apply(K) - Method in interface com.google.common.cache.LoadingCache
Deprecated.
Provided to satisfy the Function interface; use LoadingCache.get(K) or LoadingCache.getUnchecked(K) instead.
apply(K) - Method in class com.google.common.cache.LocalCache.LoadingSerializationProxy
 
apply(K) - Method in class com.google.common.cache.LocalCache.LocalLoadingCache
 
apply(V) - Method in class com.google.common.collect.FilteredEntryMultimap.ValuePredicate
 
apply(Iterable<E>) - Method in class com.google.common.collect.FluentIterable.FromIterableFunction
 
apply(E) - Method in class com.google.common.collect.Interners.InternerFunction
 
apply(Object, V) - Method in class com.google.common.collect.Maps.AbstractFilteredMap
 
apply(C) - Method in class com.google.common.collect.Range
Deprecated.
Provided only to satisfy the Predicate interface; use Range.contains(C) instead.
apply(T) - Method in class com.google.common.hash.BloomFilter
Deprecated.
Provided only to satisfy the Predicate interface; use BloomFilter.mightContain(T) instead.
apply(I) - Method in interface com.google.common.util.concurrent.AsyncFunction
Returns an output Future to use in place of the given input.
arbitrary() - Static method in class com.google.common.collect.Ordering
Returns an arbitrary ordering over all objects, for which compare(a, b) == 0 implies a == b (identity equality).
ARBITRARY_ORDERING - Static variable in class com.google.common.collect.Ordering.ArbitraryOrderingHolder
 
ArbitraryOrdering() - Constructor for class com.google.common.collect.Ordering.ArbitraryOrdering
 
ArbitraryOrderingHolder() - Constructor for class com.google.common.collect.Ordering.ArbitraryOrderingHolder
 
areEqual() - Method in interface com.google.common.collect.MapDifference
Returns true if there are no differences between the two maps; that is, if the maps are equal.
areEqual() - Method in class com.google.common.collect.Maps.MapDifferenceImpl
 
argumentsList - Variable in class com.google.common.reflect.Types.ParameterizedTypeImpl
 
array - Variable in class com.google.common.collect.ArrayTable
 
array - Variable in class com.google.common.collect.RegularImmutableList
 
array - Variable in class com.google.common.primitives.Booleans.BooleanArrayAsList
 
array - Variable in class com.google.common.primitives.Bytes.ByteArrayAsList
 
array - Variable in class com.google.common.primitives.Chars.CharArrayAsList
 
array - Variable in class com.google.common.primitives.Doubles.DoubleArrayAsList
 
array - Variable in class com.google.common.primitives.Floats.FloatArrayAsList
 
array - Variable in class com.google.common.primitives.Ints.IntArrayAsList
 
array - Variable in class com.google.common.primitives.Longs.LongArrayAsList
 
array - Variable in class com.google.common.primitives.Shorts.ShortArrayAsList
 
array - Variable in class com.google.common.util.concurrent.Striped.CompactStriped
Size is a power of two.
ArrayBasedBuilder(int) - Constructor for class com.google.common.collect.ImmutableCollection.ArrayBasedBuilder
 
ArrayBasedCharEscaper - Class in com.google.common.escape
A CharEscaper that uses an array to quickly look up replacement characters for a given char value.
ArrayBasedCharEscaper(Map<Character, String>, char, char) - Constructor for class com.google.common.escape.ArrayBasedCharEscaper
Creates a new ArrayBasedCharEscaper instance with the given replacement map and specified safe range.
ArrayBasedCharEscaper(ArrayBasedEscaperMap, char, char) - Constructor for class com.google.common.escape.ArrayBasedCharEscaper
Creates a new ArrayBasedCharEscaper instance with the given replacement map and specified safe range.
ArrayBasedEscaperMap - Class in com.google.common.escape
An implementation-specific parameter class suitable for initializing ArrayBasedCharEscaper or ArrayBasedUnicodeEscaper instances.
ArrayBasedEscaperMap(char[][]) - Constructor for class com.google.common.escape.ArrayBasedEscaperMap
 
ArrayBasedUnicodeEscaper - Class in com.google.common.escape
A UnicodeEscaper that uses an array to quickly look up replacement characters for a given code point.
ArrayBasedUnicodeEscaper(Map<Character, String>, int, int, String) - Constructor for class com.google.common.escape.ArrayBasedUnicodeEscaper
Creates a new ArrayBasedUnicodeEscaper instance with the given replacement map and specified safe range.
ArrayBasedUnicodeEscaper(ArrayBasedEscaperMap, int, int, String) - Constructor for class com.google.common.escape.ArrayBasedUnicodeEscaper
Creates a new ArrayBasedUnicodeEscaper instance with the given replacement map and specified safe range.
ArrayListMultimap<K,V> - Class in com.google.common.collect
Implementation of Multimap that uses an ArrayList to store the values for a given key.
ArrayListMultimap() - Constructor for class com.google.common.collect.ArrayListMultimap
 
ArrayListMultimap(int, int) - Constructor for class com.google.common.collect.ArrayListMultimap
 
ArrayListMultimap(Multimap<? extends K, ? extends V>) - Constructor for class com.google.common.collect.ArrayListMultimap
 
ArrayListSupplier(int) - Constructor for class com.google.common.collect.MultimapBuilder.ArrayListSupplier
 
arrayListValues() - Method in class com.google.common.collect.MultimapBuilder.MultimapBuilderWithKeys
Uses an ArrayList to store value collections.
arrayListValues(int) - Method in class com.google.common.collect.MultimapBuilder.MultimapBuilderWithKeys
Uses an ArrayList to store value collections, initialized to expect the specified number of values per key.
ArrayMap(ImmutableMap<K, Integer>) - Constructor for class com.google.common.collect.ArrayTable.ArrayMap
 
ArrayReference(L, int, ReferenceQueue<L>) - Constructor for class com.google.common.util.concurrent.Striped.SmallLazyStriped.ArrayReference
 
arraysCopyOf(T[], int) - Static method in class com.google.common.collect.ObjectArrays
GWT safe version of Arrays.copyOf.
ArrayTable<R,C,V> - Class in com.google.common.collect
Fixed-size Table implementation backed by a two-dimensional array.
ArrayTable(Iterable<? extends R>, Iterable<? extends C>) - Constructor for class com.google.common.collect.ArrayTable
 
ArrayTable(Table<R, C, V>) - Constructor for class com.google.common.collect.ArrayTable
 
ArrayTable(ArrayTable<R, C, V>) - Constructor for class com.google.common.collect.ArrayTable
 
ArrayTable.ArrayMap<K,V> - Class in com.google.common.collect
 
ArrayTable.Column - Class in com.google.common.collect
 
ArrayTable.ColumnMap - Class in com.google.common.collect
 
ArrayTable.Row - Class in com.google.common.collect
 
ArrayTable.RowMap - Class in com.google.common.collect
 
asAsyncFunction(Function<? super I, ? extends O>) - Static method in class com.google.common.util.concurrent.Futures
Wraps the given function as an AsyncFunction.
asBytes() - Method in class com.google.common.hash.HashCode
Returns the value of this hash code as a byte array.
asBytes() - Method in class com.google.common.hash.HashCode.BytesHashCode
 
asBytes() - Method in class com.google.common.hash.HashCode.IntHashCode
 
asBytes() - Method in class com.google.common.hash.HashCode.LongHashCode
 
asByteSink(File, FileWriteMode...) - Static method in class com.google.common.io.Files
Returns a new ByteSink for writing bytes to the given file.
asByteSource() - Method in class com.google.common.io.FileBackedOutputStream
Returns a readable ByteSource view of the data that has been written to this stream.
asByteSource(File) - Static method in class com.google.common.io.Files
Returns a new ByteSource for reading bytes from the given file.
asByteSource(URL) - Static method in class com.google.common.io.Resources
Returns a ByteSource that reads from the given URL.
asCharInput(Reader) - Static method in class com.google.common.io.GwtWorkarounds
Views a Reader as a CharInput.
asCharInput(CharSequence) - Static method in class com.google.common.io.GwtWorkarounds
Views a CharSequence as a CharInput.
asCharOutput(Writer) - Static method in class com.google.common.io.GwtWorkarounds
Views a Writer as a CharOutput.
asCharSink(Charset) - Method in class com.google.common.io.ByteSink
Returns a CharSink view of this ByteSink that writes characters to this sink as bytes encoded with the given charset.
AsCharSink(Charset) - Constructor for class com.google.common.io.ByteSink.AsCharSink
 
asCharSink(File, Charset, FileWriteMode...) - Static method in class com.google.common.io.Files
Returns a new CharSink for writing character data to the given file using the given character set.
asCharSource(Charset) - Method in class com.google.common.io.ByteSource
Returns a CharSource view of this byte source that decodes bytes read from this source as characters using the given Charset.
AsCharSource(Charset) - Constructor for class com.google.common.io.ByteSource.AsCharSource
 
asCharSource(Charset) - Method in class com.google.common.io.ByteSource.EmptyByteSource
 
asCharSource(File, Charset) - Static method in class com.google.common.io.Files
Returns a new CharSource for reading character data from the given file using the given character set.
asCharSource(URL, Charset) - Static method in class com.google.common.io.Resources
Returns a CharSource that reads from the given URL using the given character set.
Ascii - Class in com.google.common.base
Static methods pertaining to ASCII characters (those in the range of values 0x00 through 0x7F), and to strings containing such characters.
Ascii() - Constructor for class com.google.common.base.Ascii
 
ASCII - Static variable in class com.google.common.base.CharMatcher
Determines whether a character is ASCII, meaning that its code point is less than 128.
asciiDigits - Static variable in class com.google.common.primitives.Ints
 
asConverter(BiMap<A, B>) - Static method in class com.google.common.collect.Maps
Returns a Converter that converts values using bimap.get(), and whose inverse view converts values using bimap.inverse().get().
asEntryToEntryFunction(Maps.EntryTransformer<? super K, ? super V1, V2>) - Static method in class com.google.common.collect.Maps
Views an entry transformer as a function from entries to entries.
asEntryToValueFunction(Maps.EntryTransformer<? super K, ? super V1, V2>) - Static method in class com.google.common.collect.Maps
Views an entry transformer as a function from Entry to values.
asEntryTransformer(Function<? super V1, V2>) - Static method in class com.google.common.collect.Maps
Views a function as an entry transformer that ignores the entry key.
asEnumeration(Iterator<T>) - Static method in class com.google.common.collect.Iterators
Adapts an Iterator to the Enumeration interface.
asFunction(Interner<E>) - Static method in class com.google.common.collect.Interners
Returns a function that delegates to the Interner.intern(E) method of the given interner.
asFunction - Variable in class com.google.common.escape.Escaper
 
asFunction() - Method in class com.google.common.escape.Escaper
Returns a Function that invokes Escaper.escape(String) on this escaper.
asImmutable(EnumMap<K, V>) - Static method in class com.google.common.collect.ImmutableEnumMap
 
asImmutable(EnumSet<E>) - Static method in class com.google.common.collect.ImmutableEnumSet
 
asImmutableList(Object[]) - Static method in class com.google.common.collect.ImmutableList
Views the array as an immutable list.
asImmutableList(Object[], int) - Static method in class com.google.common.collect.ImmutableList
Views the array as an immutable list.
asInputStream(GwtWorkarounds.ByteInput) - Static method in class com.google.common.io.GwtWorkarounds
Views a ByteInput as an InputStream.
asInt() - Method in class com.google.common.hash.HashCode
Returns the first four bytes of this hashcode's bytes, converted to an int value in little-endian order.
asInt() - Method in class com.google.common.hash.HashCode.BytesHashCode
 
asInt() - Method in class com.google.common.hash.HashCode.IntHashCode
 
asInt() - Method in class com.google.common.hash.HashCode.LongHashCode
 
asList(Predicate<? super T>, Predicate<? super T>) - Static method in class com.google.common.base.Predicates
 
asList() - Method in class com.google.common.collect.EmptyContiguousSet
 
asList() - Method in class com.google.common.collect.EmptyImmutableSet
 
asList() - Method in class com.google.common.collect.EmptyImmutableSortedMultiset
 
asList() - Method in class com.google.common.collect.EmptyImmutableSortedSet
 
asList - Variable in class com.google.common.collect.ImmutableCollection
 
asList() - Method in class com.google.common.collect.ImmutableCollection
Returns a list view of the collection.
asList() - Method in class com.google.common.collect.ImmutableList
Returns this list instance.
asList(E, E[]) - Static method in class com.google.common.collect.Lists
Returns an unmodifiable list containing the specified first element and backed by the specified array of additional elements.
asList(E, E, E[]) - Static method in class com.google.common.collect.Lists
Returns an unmodifiable list containing the specified first and second element, and backed by the specified array of additional elements.
asList(boolean...) - Static method in class com.google.common.primitives.Booleans
Returns a fixed-size list backed by the specified array, similar to Arrays.asList(Object[]).
asList(byte...) - Static method in class com.google.common.primitives.Bytes
Returns a fixed-size list backed by the specified array, similar to Arrays.asList(Object[]).
asList(char...) - Static method in class com.google.common.primitives.Chars
Returns a fixed-size list backed by the specified array, similar to Arrays.asList(Object[]).
asList(double...) - Static method in class com.google.common.primitives.Doubles
Returns a fixed-size list backed by the specified array, similar to Arrays.asList(Object[]).
asList(float...) - Static method in class com.google.common.primitives.Floats
Returns a fixed-size list backed by the specified array, similar to Arrays.asList(Object[]).
asList(int...) - Static method in class com.google.common.primitives.Ints
Returns a fixed-size list backed by the specified array, similar to Arrays.asList(Object[]).
asList(long...) - Static method in class com.google.common.primitives.Longs
Returns a fixed-size list backed by the specified array, similar to Arrays.asList(Object[]).
asList(short...) - Static method in class com.google.common.primitives.Shorts
Returns a fixed-size list backed by the specified array, similar to Arrays.asList(Object[]).
asLong() - Method in class com.google.common.hash.HashCode
Returns the first eight bytes of this hashcode's bytes, converted to a long value in little-endian order.
asLong() - Method in class com.google.common.hash.HashCode.BytesHashCode
 
asLong() - Method in class com.google.common.hash.HashCode.IntHashCode
 
asLong() - Method in class com.google.common.hash.HashCode.LongHashCode
 
asMap() - Method in class com.google.common.cache.AbstractCache
 
asMap() - Method in interface com.google.common.cache.Cache
Returns a view of the entries stored in this cache as a thread-safe map.
asMap() - Method in class com.google.common.cache.ForwardingCache
 
asMap() - Method in interface com.google.common.cache.LoadingCache
Returns a view of the entries stored in this cache as a thread-safe map.
asMap() - Method in class com.google.common.cache.LocalCache.LocalManualCache
 
asMap() - Method in class com.google.common.collect.AbstractListMultimap
Returns a view of this multimap as a Map from each distinct key to the nonempty collection of that key's associated values.
AsMap(Map<K, Collection<V>>) - Constructor for class com.google.common.collect.AbstractMapBasedMultimap.AsMap
 
asMap - Variable in class com.google.common.collect.AbstractMultimap
 
asMap() - Method in class com.google.common.collect.AbstractMultimap
 
asMap() - Method in class com.google.common.collect.AbstractSetMultimap
Returns a view of this multimap as a Map from each distinct key to the nonempty collection of that key's associated values.
asMap() - Method in class com.google.common.collect.AbstractSortedKeySortedSetMultimap
 
asMap() - Method in class com.google.common.collect.AbstractSortedSetMultimap
Returns a map view that associates each key with the corresponding values in the multimap.
AsMap() - Constructor for class com.google.common.collect.FilteredEntryMultimap.AsMap
 
asMap() - Method in class com.google.common.collect.ForwardingMultimap
 
asMap() - Method in class com.google.common.collect.ImmutableMultimap
Returns an immutable map that associates each key with its corresponding values in the multimap.
asMap() - Method in interface com.google.common.collect.ListMultimap
Returns a view of this multimap as a Map from each distinct key to the nonempty collection of that key's associated values.
asMap - Variable in class com.google.common.collect.MapConstraints.ConstrainedMultimap
 
asMap() - Method in class com.google.common.collect.MapConstraints.ConstrainedMultimap
 
asMap(Set<K>, Function<? super K, V>) - Static method in class com.google.common.collect.Maps
Returns a live Map view whose keys are the contents of set and whose values are computed on demand using function.
asMap(SortedSet<K>, Function<? super K, V>) - Static method in class com.google.common.collect.Maps
Returns a view of the sorted set as a map, mapping keys from the set according to the specified function.
asMap(NavigableSet<K>, Function<? super K, V>) - Static method in class com.google.common.collect.Maps
Returns a view of the navigable set as a map, mapping keys from the set according to the specified function.
asMap() - Method in interface com.google.common.collect.Multimap
Returns a view of this multimap as a Map from each distinct key to the nonempty collection of that key's associated values.
asMap(ListMultimap<K, V>) - Static method in class com.google.common.collect.Multimaps
Returns multimap.asMap(), with its type corrected from Map<K, Collection<V>> to Map<K, List<V>>.
asMap(SetMultimap<K, V>) - Static method in class com.google.common.collect.Multimaps
Returns multimap.asMap(), with its type corrected from Map<K, Collection<V>> to Map<K, Set<V>>.
asMap(SortedSetMultimap<K, V>) - Static method in class com.google.common.collect.Multimaps
Returns multimap.asMap(), with its type corrected from Map<K, Collection<V>> to Map<K, SortedSet<V>>.
asMap(Multimap<K, V>) - Static method in class com.google.common.collect.Multimaps
AsMap(Multimap<K, V>) - Constructor for class com.google.common.collect.Multimaps.AsMap
 
asMap() - Method in class com.google.common.collect.Multimaps.UnmodifiableMultimap
 
asMap() - Method in interface com.google.common.collect.SetMultimap
Returns a view of this multimap as a Map from each distinct key to the nonempty collection of that key's associated values.
asMap() - Method in interface com.google.common.collect.SortedSetMultimap
Returns a map view that associates each key with the corresponding values in the multimap.
asMap - Variable in class com.google.common.collect.Synchronized.SynchronizedMultimap
 
asMap() - Method in class com.google.common.collect.Synchronized.SynchronizedMultimap
 
asMap() - Method in class com.google.common.collect.TreeMultimap
Returns a map view that associates each key with the corresponding values in the multimap.
asMap - Variable in class com.google.common.util.concurrent.AtomicLongMap
 
asMap() - Method in class com.google.common.util.concurrent.AtomicLongMap
Returns a live, read-only view of the map backing this AtomicLongMap.
AsMapEntries() - Constructor for class com.google.common.collect.AbstractMapBasedMultimap.AsMap.AsMapEntries
 
asMapEntryIterator(Set<K>, Function<? super K, V>) - Static method in class com.google.common.collect.Maps
 
asMapEntrySet - Variable in class com.google.common.collect.Synchronized.SynchronizedAsMap
 
AsMapIterator() - Constructor for class com.google.common.collect.AbstractMapBasedMultimap.AsMap.AsMapIterator
 
asMapOfRanges() - Method in class com.google.common.collect.ImmutableRangeMap
 
asMapOfRanges() - Method in interface com.google.common.collect.RangeMap
Returns a view of this range map as an unmodifiable Map<Range<K>, V>.
asMapOfRanges() - Method in class com.google.common.collect.TreeRangeMap
 
AsMapOfRanges() - Constructor for class com.google.common.collect.TreeRangeMap.AsMapOfRanges
 
asMapOfRanges() - Method in class com.google.common.collect.TreeRangeMap.SubRangeMap
 
asMapSortedIgnoreNavigable(SortedSet<K>, Function<? super K, V>) - Static method in class com.google.common.collect.Maps
 
asMapValues - Variable in class com.google.common.collect.Synchronized.SynchronizedAsMap
 
AsMapView(Set<K>, Function<? super K, V>) - Constructor for class com.google.common.collect.Maps.AsMapView
 
asMultimap() - Method in class com.google.common.collect.EmptyImmutableBiMap
 
asMultimap() - Method in class com.google.common.collect.EmptyImmutableSortedMap
 
asMultimap() - Method in class com.google.common.collect.ImmutableMap
Returns a multimap view of the map.
asOutputStream(PrimitiveSink) - Static method in class com.google.common.hash.Funnels
Wraps a PrimitiveSink as an OutputStream, so it is easy to funnel an object to a PrimitiveSink if there is already a way to write the contents of the object to an OutputStream.
asOutputStream(GwtWorkarounds.ByteOutput) - Static method in class com.google.common.io.GwtWorkarounds
Views a ByteOutput as an OutputStream.
asRanges() - Method in class com.google.common.collect.ImmutableRangeSet
 
asRanges() - Method in interface com.google.common.collect.RangeSet
Returns a view of the disconnected ranges that make up this range set.
asRanges - Variable in class com.google.common.collect.TreeRangeSet
 
asRanges() - Method in class com.google.common.collect.TreeRangeSet
 
AsRanges() - Constructor for class com.google.common.collect.TreeRangeSet.AsRanges
 
asReader(Readable) - Static method in class com.google.common.io.CharStreams
 
asSet() - Method in class com.google.common.base.Absent
 
asSet() - Method in class com.google.common.base.Optional
Returns an immutable singleton Set whose only element is the contained instance if it is present; an empty immutable Set otherwise.
asSet() - Method in class com.google.common.base.Present
 
asSet(DiscreteDomain<C>) - Method in class com.google.common.collect.ImmutableRangeSet
Returns an ImmutableSortedSet containing the same values in the given domain contained by this range set.
AsSet(DiscreteDomain<C>) - Constructor for class com.google.common.collect.ImmutableRangeSet.AsSet
 
AsSetSerializedForm(ImmutableList<Range<C>>, DiscreteDomain<C>) - Constructor for class com.google.common.collect.ImmutableRangeSet.AsSetSerializedForm
 
assignableFrom(Class<?>) - Static method in class com.google.common.base.Predicates
Returns a predicate that evaluates to true if the class being tested is assignable from the given class.
AssignableFromPredicate(Class<?>) - Constructor for class com.google.common.base.Predicates.AssignableFromPredicate
 
asUnicodeEscaper(Escaper) - Static method in class com.google.common.escape.Escapers
Returns a UnicodeEscaper equivalent to the given escaper instance.
asValueToValueFunction(Maps.EntryTransformer<? super K, V1, V2>, K) - Static method in class com.google.common.collect.Maps
 
asWriter(Appendable) - Static method in class com.google.common.io.CharStreams
Returns a Writer that sends all output to the given Appendable target.
AsyncEventBus - Class in com.google.common.eventbus
An EventBus that takes the Executor of your choice and uses it to dispatch events, allowing dispatch to occur asynchronously.
AsyncEventBus(String, Executor) - Constructor for class com.google.common.eventbus.AsyncEventBus
Creates a new AsyncEventBus that will use executor to dispatch events.
AsyncEventBus(Executor, SubscriberExceptionHandler) - Constructor for class com.google.common.eventbus.AsyncEventBus
Creates a new AsyncEventBus that will use executor to dispatch events.
AsyncEventBus(Executor) - Constructor for class com.google.common.eventbus.AsyncEventBus
Creates a new AsyncEventBus that will use executor to dispatch events.
AsyncFunction<I,O> - Interface in com.google.common.util.concurrent
Transforms a value, possibly asynchronously.
asynchronous(RemovalListener<K, V>, Executor) - Static method in class com.google.common.cache.RemovalListeners
Returns a RemovalListener which processes all eviction notifications using executor.
asyncReloading(CacheLoader<K, V>, Executor) - Static method in class com.google.common.cache.CacheLoader
Returns a CacheLoader which wraps loader, executing calls to CacheLoader.reload(K, V) using executor.
AsyncSettableFuture<V> - Class in com.google.common.util.concurrent
AsyncSettableFuture() - Constructor for class com.google.common.util.concurrent.AsyncSettableFuture
 
AsyncSettableFuture.NestedFuture<V> - Class in com.google.common.util.concurrent
 
at(int, int) - Method in class com.google.common.collect.ArrayTable
Returns the value corresponding to the specified row and column indices.
atLeast(C) - Static method in class com.google.common.collect.Range
Returns a range that contains all values greater than or equal to endpoint.
atMost(C) - Static method in class com.google.common.collect.Range
Returns a range that contains all values less than or equal to endpoint.
ATOM_UTF_8 - Static variable in class com.google.common.net.MediaType
 
AtomicDouble - Class in com.google.common.util.concurrent
A double value that may be updated atomically.
AtomicDouble(double) - Constructor for class com.google.common.util.concurrent.AtomicDouble
Creates a new AtomicDouble with the given initial value.
AtomicDouble() - Constructor for class com.google.common.util.concurrent.AtomicDouble
Creates a new AtomicDouble with initial value 0.0.
AtomicDoubleArray - Class in com.google.common.util.concurrent
A double array in which elements may be updated atomically.
AtomicDoubleArray(int) - Constructor for class com.google.common.util.concurrent.AtomicDoubleArray
Creates a new AtomicDoubleArray of the given length, with all elements initially zero.
AtomicDoubleArray(double[]) - Constructor for class com.google.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.google.common.util.concurrent
A map containing long values that can be atomically updated.
AtomicLongMap(ConcurrentHashMap<K, AtomicLong>) - Constructor for class com.google.common.util.concurrent.AtomicLongMap
 
Atomics - Class in com.google.common.util.concurrent
Static utility methods pertaining to classes in the java.util.concurrent.atomic package.
Atomics() - Constructor for class com.google.common.util.concurrent.Atomics
 
AUDIO_TYPE - Static variable in class com.google.common.net.MediaType
 
AUTHORIZATION - Static variable in class com.google.common.net.HttpHeaders
The HTTP Authorization header field name.
autoDelegate - Variable in class com.google.common.cache.LocalCache.LoadingSerializationProxy
 
available() - Method in class com.google.common.io.ByteStreams.LimitedInputStream
 
available() - Method in class com.google.common.io.MultiInputStream
 
averageLoadPenalty() - Method in class com.google.common.cache.CacheStats
Returns the average time spent loading new values.
AvlNode(E, int) - Constructor for class com.google.common.collect.TreeMultiset.AvlNode
 
await(Monitor.Guard, boolean) - Method in class com.google.common.util.concurrent.Monitor
 
awaitHealthGuard - Variable in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState
Controls how long to wait for all the services to either become healthy or reach a state from which it is guaranteed that it can never become healthy.
awaitHealthy() - Method in class com.google.common.util.concurrent.ServiceManager
Waits for the ServiceManager to become healthy.
awaitHealthy(long, TimeUnit) - Method in class com.google.common.util.concurrent.ServiceManager
Waits for the ServiceManager to become healthy for no more than the given time.
awaitHealthy() - Method in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState
 
awaitHealthy(long, TimeUnit) - Method in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState
 
awaitNanos(Monitor.Guard, long, boolean) - Method in class com.google.common.util.concurrent.Monitor
 
awaitRunning() - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
 
awaitRunning(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
 
awaitRunning() - Method in class com.google.common.util.concurrent.AbstractIdleService
 
awaitRunning(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractIdleService
 
awaitRunning() - Method in class com.google.common.util.concurrent.AbstractScheduledService
 
awaitRunning(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractScheduledService
 
awaitRunning() - Method in class com.google.common.util.concurrent.AbstractService
 
awaitRunning(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractService
 
awaitRunning() - Method in interface com.google.common.util.concurrent.Service
Waits for the Service to reach the running state.
awaitRunning(long, TimeUnit) - Method in interface com.google.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.google.common.util.concurrent.ServiceManager
Waits for the all the services to reach a terminal state.
awaitStopped(long, TimeUnit) - Method in class com.google.common.util.concurrent.ServiceManager
Waits for the all the services to reach a terminal state for no more than the given time.
awaitStopped() - Method in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState
 
awaitStopped(long, TimeUnit) - Method in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState
 
awaitTerminated() - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
 
awaitTerminated(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
 
awaitTerminated() - Method in class com.google.common.util.concurrent.AbstractIdleService
 
awaitTerminated(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractIdleService
 
awaitTerminated() - Method in class com.google.common.util.concurrent.AbstractScheduledService
 
awaitTerminated(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractScheduledService
 
awaitTerminated() - Method in class com.google.common.util.concurrent.AbstractService
 
awaitTerminated(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractService
 
awaitTerminated() - Method in interface com.google.common.util.concurrent.Service
Waits for the Service to reach the terminated state.
awaitTerminated(long, TimeUnit) - Method in interface com.google.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.google.common.util.concurrent.ForwardingExecutorService
 
awaitTermination(long, TimeUnit) - Method in class com.google.common.util.concurrent.MoreExecutors.DirectExecutorService
 
awaitTermination(long, TimeUnit) - Method in class com.google.common.util.concurrent.MoreExecutors.ListeningDecorator
 
awaitTermination(long, TimeUnit) - Method in class com.google.common.util.concurrent.WrappingExecutorService
 
awaitUninterruptibly(Monitor.Guard, boolean) - Method in class com.google.common.util.concurrent.Monitor
 
awaitUninterruptibly(CountDownLatch) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes latch.await() uninterruptibly.
awaitUninterruptibly(CountDownLatch, long, TimeUnit) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes latch.await(timeout, unit) uninterruptibly.
axes - Variable in class com.google.common.collect.CartesianList
 
axes - Variable in class com.google.common.collect.Sets.CartesianSet
 
axesSizeProduct - Variable in class com.google.common.collect.CartesianList
 

B

b - Variable in class com.google.common.hash.SipHashFunction.SipHasher
 
backingIterator - Variable in class com.google.common.collect.TransformedIterator
 
backingIterator() - Method in class com.google.common.collect.TransformedListIterator
 
backingList - Variable in class com.google.common.collect.Lists.AbstractListWrapper
 
backingMap() - Method in class com.google.common.collect.AbstractMapBasedMultimap
 
backingMap - Variable in class com.google.common.collect.AbstractMapBasedMultiset
 
backingMap() - Method in class com.google.common.collect.AbstractSortedKeySortedSetMultimap
 
backingMap - Variable in class com.google.common.collect.StandardTable
 
backingMap() - Method in class com.google.common.collect.TreeMultimap
 
backingMap - Variable in class com.google.common.reflect.MutableTypeToInstanceMap
 
backingRowMap - Variable in class com.google.common.collect.StandardTable.Row
 
backingRowMap() - Method in class com.google.common.collect.StandardTable.Row
 
backingRowMap() - Method in class com.google.common.collect.TreeBasedTable.TreeRow
 
backingSet() - Method in class com.google.common.collect.Maps.AsMapView
 
backingSet() - Method in class com.google.common.collect.Maps.SortedAsMapView
 
backingThreadFactory - Variable in class com.google.common.util.concurrent.ThreadFactoryBuilder
 
backwardFunction - Variable in class com.google.common.base.Converter.FunctionBasedConverter
 
badElementIndex(int, int, String) - Static method in class com.google.common.base.Preconditions
 
badPositionIndex(int, int, String) - Static method in class com.google.common.base.Preconditions
 
badPositionIndexes(int, int, int) - Static method in class com.google.common.base.Preconditions
 
balanceFactor() - Method in class com.google.common.collect.TreeMultiset.AvlNode
 
base - Variable in class com.google.common.cache.Striped64
Base value, used mainly when there is no contention, but also as a fallback during table initialization races.
BASE16 - Static variable in class com.google.common.io.BaseEncoding
 
base16() - Static method in class com.google.common.io.BaseEncoding
The "base16" encoding specified by RFC 4648 section 8, Base 16 Encoding.
BASE32 - Static variable in class com.google.common.io.BaseEncoding
 
base32() - Static method in class com.google.common.io.BaseEncoding
The "base32" encoding specified by RFC 4648 section 6, Base 32 Encoding.
BASE32_HEX - Static variable in class com.google.common.io.BaseEncoding
 
base32Hex() - Static method in class com.google.common.io.BaseEncoding
The "base32hex" encoding specified by RFC 4648 section 7, Base 32 Encoding with Extended Hex Alphabet.
BASE64 - Static variable in class com.google.common.io.BaseEncoding
 
base64() - Static method in class com.google.common.io.BaseEncoding
The "base64" base encoding specified by RFC 4648 section 4, Base 64 Encoding.
BASE64_URL - Static variable in class com.google.common.io.BaseEncoding
 
base64Url() - Static method in class com.google.common.io.BaseEncoding
The "base64url" encoding specified by RFC 4648 section 5, Base 64 Encoding with URL and Filename Safe Alphabet, also sometimes referred to as the "web safe Base64." (This is the same as the base 64 encoding with URL and filename safe alphabet from RFC 3548.)
BaseEncoding - Class in com.google.common.io
A binary encoding scheme for reversibly translating between byte sequences and printable ASCII strings.
BaseEncoding() - Constructor for class com.google.common.io.BaseEncoding
 
BaseEncoding.Alphabet - Class in com.google.common.io
 
BaseEncoding.DecodingException - Exception in com.google.common.io
Exception indicating invalid base-encoded input encountered while decoding.
BaseEncoding.SeparatedBaseEncoding - Class in com.google.common.io
 
BaseEncoding.StandardBaseEncoding - Class in com.google.common.io
 
baseOffset - Static variable in class com.google.common.cache.Striped64
 
beginWaitingFor(Monitor.Guard) - Method in class com.google.common.util.concurrent.Monitor
Records that the current thread is about to wait on the specified guard.
BEL - Static variable in class com.google.common.base.Ascii
Bell ('\a'): A character for use when there is a need to call for human attention.
belowAll() - Static method in class com.google.common.collect.Cut
 
BelowAll() - Constructor for class com.google.common.collect.Cut.BelowAll
 
belowValue(C) - Static method in class com.google.common.collect.Cut
 
BelowValue(C) - Constructor for class com.google.common.collect.Cut.BelowValue
 
BEST_COMPARATOR - Static variable in class com.google.common.primitives.UnsignedBytes.LexicographicalComparatorHolder
 
Beta - Annotation Type in com.google.common.annotations
Signifies that a public API (public class, method or field) is subject to incompatible changes, or even removal, in a future release.
BiEntry(K, int, V, int) - Constructor for class com.google.common.collect.HashBiMap.BiEntry
 
BIG_ENDIAN - Static variable in enum com.google.common.primitives.UnsignedBytes.LexicographicalComparatorHolder.UnsafeComparator
 
biggestBinomials - Static variable in class com.google.common.math.IntMath
 
biggestBinomials - Static variable in class com.google.common.math.LongMath
 
biggestSimpleBinomials - Static variable in class com.google.common.math.LongMath
 
BigIntegerDomain() - Constructor for class com.google.common.collect.DiscreteDomain.BigIntegerDomain
 
BigIntegerMath - Class in com.google.common.math
A class for arithmetic on values of type BigInteger.
BigIntegerMath() - Constructor for class com.google.common.math.BigIntegerMath
 
bigIntegers() - Static method in class com.google.common.collect.DiscreteDomain
Returns the discrete domain for values of type BigInteger.
bigIntegerValue() - Method in class com.google.common.primitives.UnsignedInteger
Returns the value of this UnsignedInteger as a BigInteger.
bigIntegerValue() - Method in class com.google.common.primitives.UnsignedLong
Returns the value of this UnsignedLong as a BigInteger.
bigToDouble(BigInteger) - Static method in class com.google.common.math.DoubleUtils
 
BiMap<K,V> - Interface in com.google.common.collect
A bimap (or "bidirectional map") is a map that preserves the uniqueness of its values as well as that of its keys.
bimap - Variable in class com.google.common.collect.HashBiMap.InverseSerializedForm
 
bimap - Variable in class com.google.common.collect.Maps.BiMapConverter
 
biMap(BiMap<K, V>, Object) - Static method in class com.google.common.collect.Synchronized
 
BiMapConverter(BiMap<A, B>) - Constructor for class com.google.common.collect.Maps.BiMapConverter
 
binarySearch(List<? extends T>, T) - Method in class com.google.common.collect.Ordering
Searches sortedList for key using the binary search algorithm.
binarySearch(List<? extends E>, E, SortedLists.KeyPresentBehavior, SortedLists.KeyAbsentBehavior) - Static method in class com.google.common.collect.SortedLists
Searches the specified naturally ordered list for the specified object using the binary search algorithm.
binarySearch(List<E>, Function<? super E, K>, K, SortedLists.KeyPresentBehavior, SortedLists.KeyAbsentBehavior) - Static method in class com.google.common.collect.SortedLists
Binary searches the list for the specified key, using the specified key function.
binarySearch(List<E>, Function<? super E, K>, K, Comparator<? super K>, SortedLists.KeyPresentBehavior, SortedLists.KeyAbsentBehavior) - Static method in class com.google.common.collect.SortedLists
Binary searches the list for the specified key, using the specified key function.
binarySearch(List<? extends E>, E, Comparator<? super E>, SortedLists.KeyPresentBehavior, SortedLists.KeyAbsentBehavior) - Static method in class com.google.common.collect.SortedLists
Searches the specified list for the specified object using the binary search algorithm.
BinaryTreeTraverser<T> - Class in com.google.common.collect
A variant of TreeTraverser for binary trees, providing additional traversals specific to binary trees.
BinaryTreeTraverser() - Constructor for class com.google.common.collect.BinaryTreeTraverser
 
BinaryTreeTraverser.InOrderIterator - Class in com.google.common.collect
 
BinaryTreeTraverser.PostOrderIterator - Class in com.google.common.collect
 
BinaryTreeTraverser.PreOrderIterator - Class in com.google.common.collect
 
binomial(int, int) - Static method in class com.google.common.math.BigIntegerMath
Returns n choose k, also known as the binomial coefficient of n and k, that is, n! / (k! (n - k)!).
binomial(int, int) - Static method in class com.google.common.math.IntMath
Returns n choose k, also known as the binomial coefficient of n and k, or Integer.MAX_VALUE if the result does not fit in an int.
binomial(int, int) - Static method in class com.google.common.math.LongMath
Returns n choose k, also known as the binomial coefficient of n and k, or Long.MAX_VALUE if the result does not fit in a long.
BitArray(long) - Constructor for class com.google.common.hash.BloomFilterStrategies.BitArray
 
BitArray(long[]) - Constructor for class com.google.common.hash.BloomFilterStrategies.BitArray
 
bitCount - Variable in class com.google.common.hash.BloomFilterStrategies.BitArray
 
bitCount() - Method in class com.google.common.hash.BloomFilterStrategies.BitArray
Number of set bits (1s)
bits - Variable in class com.google.common.hash.BloomFilter
The bit set of the BloomFilter (not necessarily power of 2!)
bits - Variable in class com.google.common.hash.ChecksumHashFunction
 
bits() - Method in class com.google.common.hash.ChecksumHashFunction
 
bits() - Method in class com.google.common.hash.Crc32cHashFunction
 
bits() - Method in class com.google.common.hash.HashCode
Returns the number of bits in this hash code; a positive multiple of 8.
bits() - Method in class com.google.common.hash.HashCode.BytesHashCode
 
bits() - Method in class com.google.common.hash.HashCode.IntHashCode
 
bits() - Method in class com.google.common.hash.HashCode.LongHashCode
 
bits() - Method in interface com.google.common.hash.HashFunction
Returns the number of bits (a multiple of 32) that each hash code produced by this hash function has.
bits - Variable in enum com.google.common.hash.Hashing.ChecksumType
 
bits - Variable in class com.google.common.hash.Hashing.ConcatenatedHashFunction
 
bits() - Method in class com.google.common.hash.Hashing.ConcatenatedHashFunction
 
bits() - Method in class com.google.common.hash.MessageDigestHashFunction
 
bits() - Method in class com.google.common.hash.Murmur3_128HashFunction
 
bits() - Method in class com.google.common.hash.Murmur3_32HashFunction
 
bits() - Method in class com.google.common.hash.SipHashFunction
 
BitSetMatcher(BitSet, String) - Constructor for class com.google.common.base.CharMatcher.BitSetMatcher
 
bitSize() - Method in class com.google.common.hash.BloomFilter
Returns the number of bits in the underlying bit array.
bitSize() - Method in class com.google.common.hash.BloomFilterStrategies.BitArray
Number of bits
bitsPerChar - Variable in class com.google.common.io.BaseEncoding.Alphabet
 
BloomFilter<T> - Class in com.google.common.hash
A Bloom filter for instances of T.
BloomFilter(BloomFilterStrategies.BitArray, int, Funnel<? super T>, BloomFilter.Strategy) - Constructor for class com.google.common.hash.BloomFilter
Creates a BloomFilter.
BloomFilter.SerialForm<T> - Class in com.google.common.hash
 
BloomFilter.Strategy - Interface in com.google.common.hash
A strategy to translate T instances, to numHashFunctions bit indexes.
BloomFilterStrategies - Enum in com.google.common.hash
Collections of strategies of generating the k * log(M) bits required for an element to be mapped to a BloomFilter of M bits and k hash functions.
BloomFilterStrategies() - Constructor for enum com.google.common.hash.BloomFilterStrategies
 
BloomFilterStrategies.BitArray - Class in com.google.common.hash
 
bmix64(long, long) - Method in class com.google.common.hash.Murmur3_128HashFunction.Murmur3_128Hasher
 
BMP - Static variable in class com.google.common.net.MediaType
 
BooleanArrayAsList(boolean[]) - Constructor for class com.google.common.primitives.Booleans.BooleanArrayAsList
 
BooleanArrayAsList(boolean[], int, int) - Constructor for class com.google.common.primitives.Booleans.BooleanArrayAsList
 
Booleans - Class in com.google.common.primitives
Static utility methods pertaining to boolean primitives, that are not already found in either Boolean or Arrays.
Booleans() - Constructor for class com.google.common.primitives.Booleans
 
Booleans.BooleanArrayAsList - Class in com.google.common.primitives
 
Booleans.LexicographicalComparator - Enum in com.google.common.primitives
 
BOTTOM_BYTE - Static variable in class com.google.common.hash.AbstractNonStreamingHashFunction.BufferingHasher
 
boundAsSuperclass(Type) - Method in class com.google.common.reflect.TypeToken
 
bounds - Variable in class com.google.common.reflect.Types.TypeVariableImpl
 
boundsAsInterfaces(Type[]) - Method in class com.google.common.reflect.TypeToken
 
BoundType - Enum in com.google.common.collect
Indicates whether an endpoint of some range is contained in the range itself ("closed") or not ("open").
BoundType() - Constructor for enum com.google.common.collect.BoundType
 
BreadthFirstIterator(T) - Constructor for class com.google.common.collect.TreeTraverser.BreadthFirstIterator
 
breadthFirstTraversal(T) - Method in class com.google.common.collect.TreeTraverser
Returns an unmodifiable iterable over the nodes in a tree structure, using breadth-first traversal.
BREAKING_WHITESPACE - Static variable in class com.google.common.base.CharMatcher
Determines whether a character is a breaking whitespace (that is, a whitespace which can be interpreted as a break between words for formatting purposes).
BS - Static variable in class com.google.common.base.Ascii
Backspace ('\b'): A format effector which controls the movement of the printing position one printing space backward on the same printing line.
bubbleUp(int, E) - Method in class com.google.common.collect.MinMaxPriorityQueue.Heap
Bubbles a value from index up the appropriate heap if required.
bubbleUpAlternatingLevels(int, E) - Method in class com.google.common.collect.MinMaxPriorityQueue.Heap
Bubbles a value from index up the levels of this heap, and returns the index the element ended up at.
buf - Variable in class com.google.common.io.LineReader
 
BUF_SIZE - Static variable in class com.google.common.io.ByteSource
 
BUF_SIZE - Static variable in class com.google.common.io.ByteStreams
 
BUF_SIZE - Static variable in class com.google.common.io.CharStreams
 
buffer - Variable in class com.google.common.hash.AbstractStreamingHashFunction.AbstractStreamingHasher
Buffer via which we pass data to the hash algorithm (the implementor)
BufferingHasher(int) - Constructor for class com.google.common.hash.AbstractNonStreamingHashFunction.BufferingHasher
 
bufferSize - Variable in class com.google.common.hash.AbstractStreamingHashFunction.AbstractStreamingHasher
Number of bytes to be filled before process() invocation(s).
build(CacheLoader<? super K1, V1>) - Method in class com.google.common.cache.CacheBuilder
Builds a cache, which either returns an already-loaded value for a given key or atomically computes or retrieves it using the supplied CacheLoader.
build() - Method in class com.google.common.cache.CacheBuilder
Builds a cache which does not automatically load values when keys are requested.
build() - Method in class com.google.common.collect.ImmutableBiMap.Builder
Returns a newly-created immutable bimap.
build() - Method in class com.google.common.collect.ImmutableClassToInstanceMap.Builder
Returns a new immutable class-to-instance map containing the entries provided to this builder.
build() - Method in class com.google.common.collect.ImmutableCollection.Builder
Returns a newly-created ImmutableCollection of the appropriate type, containing the elements provided to this builder.
build() - Method in class com.google.common.collect.ImmutableList.Builder
Returns a newly-created ImmutableList based on the contents of the Builder.
build() - Method in class com.google.common.collect.ImmutableListMultimap.Builder
Returns a newly-created immutable list multimap.
build() - Method in class com.google.common.collect.ImmutableMap.Builder
Returns a newly-created immutable map.
build() - Method in class com.google.common.collect.ImmutableMultimap.Builder
Returns a newly-created immutable multimap.
build() - Method in class com.google.common.collect.ImmutableMultiset.Builder
Returns a newly-created ImmutableMultiset based on the contents of the Builder.
build() - Method in class com.google.common.collect.ImmutableRangeMap.Builder
Returns an ImmutableRangeMap containing the associations previously added to this builder.
build() - Method in class com.google.common.collect.ImmutableRangeSet.Builder
Returns an ImmutableRangeSet containing the ranges added to this builder.
build() - Method in class com.google.common.collect.ImmutableSet.Builder
Returns a newly-created ImmutableSet based on the contents of the Builder.
build() - Method in class com.google.common.collect.ImmutableSetMultimap.Builder
Returns a newly-created immutable set multimap.
build() - Method in class com.google.common.collect.ImmutableSortedMap.Builder
Returns a newly-created immutable sorted map.
build() - Method in class com.google.common.collect.ImmutableSortedMultiset.Builder
Returns a newly-created ImmutableSortedMultiset based on the contents of the Builder.
build() - Method in class com.google.common.collect.ImmutableSortedSet.Builder
Returns a newly-created ImmutableSortedSet based on the contents of the Builder and its comparator.
build() - Method in class com.google.common.collect.ImmutableTable.Builder
Returns a newly-created immutable table.
build() - Method in class com.google.common.collect.MultimapBuilder
Returns a new, empty Multimap with the specified implementation.
build(Multimap<? extends K, ? extends V>) - Method in class com.google.common.collect.MultimapBuilder
Returns a Multimap with the specified implementation, initialized with the entries of multimap.
build() - Method in class com.google.common.collect.MultimapBuilder.ListMultimapBuilder
 
build(Multimap<? extends K, ? extends V>) - Method in class com.google.common.collect.MultimapBuilder.ListMultimapBuilder
 
build() - Method in class com.google.common.collect.MultimapBuilder.SetMultimapBuilder
 
build(Multimap<? extends K, ? extends V>) - Method in class com.google.common.collect.MultimapBuilder.SetMultimapBuilder
 
build() - Method in class com.google.common.collect.MultimapBuilder.SortedSetMultimapBuilder
 
build(Multimap<? extends K, ? extends V>) - Method in class com.google.common.collect.MultimapBuilder.SortedSetMultimapBuilder
 
build() - Method in class com.google.common.escape.Escapers.Builder
Returns a new escaper based on the current state of the builder.
build() - Method in class com.google.common.reflect.ImmutableTypeToInstanceMap.Builder
Returns a new immutable type-to-instance map containing the entries provided to this builder.
build() - Method in class com.google.common.util.concurrent.ThreadFactoryBuilder
Returns a new thread factory using the options supplied during the building process.
build(ThreadFactoryBuilder) - Static method in class com.google.common.util.concurrent.ThreadFactoryBuilder
 
builder() - Static method in class com.google.common.collect.ContiguousSet
builder() - Static method in class com.google.common.collect.ImmutableBiMap
Returns a new builder.
Builder() - Constructor for class com.google.common.collect.ImmutableBiMap.Builder
Creates a new builder.
builder() - Static method in class com.google.common.collect.ImmutableClassToInstanceMap
Returns a new builder.
Builder() - Constructor for class com.google.common.collect.ImmutableClassToInstanceMap.Builder
 
Builder() - Constructor for class com.google.common.collect.ImmutableCollection.Builder
 
builder() - Static method in class com.google.common.collect.ImmutableList
Returns a new builder.
Builder() - Constructor for class com.google.common.collect.ImmutableList.Builder
Creates a new builder.
Builder(int) - Constructor for class com.google.common.collect.ImmutableList.Builder
 
builder() - Static method in class com.google.common.collect.ImmutableListMultimap
Returns a new builder.
Builder() - Constructor for class com.google.common.collect.ImmutableListMultimap.Builder
Creates a new builder.
builder() - Static method in class com.google.common.collect.ImmutableMap
Returns a new builder.
Builder() - Constructor for class com.google.common.collect.ImmutableMap.Builder
Creates a new builder.
Builder(int) - Constructor for class com.google.common.collect.ImmutableMap.Builder
 
builder() - Static method in class com.google.common.collect.ImmutableMultimap
Returns a new builder.
Builder() - Constructor for class com.google.common.collect.ImmutableMultimap.Builder
Creates a new builder.
builder() - Static method in class com.google.common.collect.ImmutableMultiset
Returns a new builder.
Builder() - Constructor for class com.google.common.collect.ImmutableMultiset.Builder
Creates a new builder.
Builder(Multiset<E>) - Constructor for class com.google.common.collect.ImmutableMultiset.Builder
 
builder() - Static method in class com.google.common.collect.ImmutableRangeMap
Returns a new builder for an immutable range map.
Builder() - Constructor for class com.google.common.collect.ImmutableRangeMap.Builder
 
builder() - Static method in class com.google.common.collect.ImmutableRangeSet
Returns a new builder for an immutable range set.
Builder() - Constructor for class com.google.common.collect.ImmutableRangeSet.Builder
 
builder() - Static method in class com.google.common.collect.ImmutableSet
Returns a new builder.
Builder() - Constructor for class com.google.common.collect.ImmutableSet.Builder
Creates a new builder.
Builder(int) - Constructor for class com.google.common.collect.ImmutableSet.Builder
 
builder() - Static method in class com.google.common.collect.ImmutableSetMultimap
Builder() - Constructor for class com.google.common.collect.ImmutableSetMultimap.Builder
Creates a new builder.
Builder(Comparator<? super K>) - Constructor for class com.google.common.collect.ImmutableSortedMap.Builder
Creates a new builder.
builder() - Static method in class com.google.common.collect.ImmutableSortedMapFauxverideShim
Deprecated.
Use ImmutableSortedMap.naturalOrder(), which offers better type-safety.
Builder(Comparator<? super E>) - Constructor for class com.google.common.collect.ImmutableSortedMultiset.Builder
Creates a new builder.
builder() - Static method in class com.google.common.collect.ImmutableSortedMultisetFauxverideShim
Deprecated.
Use ImmutableSortedMultiset.naturalOrder(), which offers better type-safety.
Builder(Comparator<? super E>) - Constructor for class com.google.common.collect.ImmutableSortedSet.Builder
Creates a new builder.
builder() - Static method in class com.google.common.collect.ImmutableSortedSetFauxverideShim
Deprecated.
Use ImmutableSortedSet.naturalOrder(), which offers better type-safety.
builder() - Static method in class com.google.common.collect.ImmutableTable
Returns a new builder.
Builder() - Constructor for class com.google.common.collect.ImmutableTable.Builder
Creates a new builder.
Builder(Comparator<B>) - Constructor for class com.google.common.collect.MinMaxPriorityQueue.Builder
 
builder() - Static method in class com.google.common.escape.Escapers
Returns a builder for creating simple, fast escapers.
Builder() - Constructor for class com.google.common.escape.Escapers.Builder
 
builder() - Static method in class com.google.common.reflect.ImmutableTypeToInstanceMap
Returns a new builder.
Builder() - Constructor for class com.google.common.reflect.ImmutableTypeToInstanceMap.Builder
 
builderMultimap - Variable in class com.google.common.collect.ImmutableMultimap.Builder
 
BuilderMultimap() - Constructor for class com.google.common.collect.ImmutableMultimap.BuilderMultimap
 
BuilderMultimap() - Constructor for class com.google.common.collect.ImmutableSetMultimap.BuilderMultimap
 
buildRankMap(List<T>) - Static method in class com.google.common.collect.ExplicitOrdering
 
bulkGet(Iterable<?>) - Method in class com.google.common.util.concurrent.Striped
Returns the stripes that correspond to the passed objects, in ascending (as per Striped.getAt(int)) order.
busy - Variable in class com.google.common.cache.Striped64
Spinlock (locked via CAS) used when resizing and/or creating Cells.
busyOffset - Static variable in class com.google.common.cache.Striped64
 
ByFunctionOrdering<F,T> - Class in com.google.common.collect
An ordering that orders elements by applying an order to the result of a function on those elements.
ByFunctionOrdering(Function<F, ? extends T>, Ordering<T>) - Constructor for class com.google.common.collect.ByFunctionOrdering
 
BYTE_ARRAY_BASE_OFFSET - Static variable in enum com.google.common.primitives.UnsignedBytes.LexicographicalComparatorHolder.UnsafeComparator
The offset to the first element in a byte array.
byteArray() - Method in class com.google.common.hash.AbstractNonStreamingHashFunction.ExposedByteArrayOutputStream
 
ByteArrayAsList(byte[]) - Constructor for class com.google.common.primitives.Bytes.ByteArrayAsList
 
ByteArrayAsList(byte[], int, int) - Constructor for class com.google.common.primitives.Bytes.ByteArrayAsList
 
ByteArrayByteSource(byte[]) - Constructor for class com.google.common.io.ByteSource.ByteArrayByteSource
 
ByteArrayDataInput - Interface in com.google.common.io
An extension of DataInput for reading from in-memory byte arrays; its methods offer identical functionality but do not throw IOException.
ByteArrayDataInputStream(ByteArrayInputStream) - Constructor for class com.google.common.io.ByteStreams.ByteArrayDataInputStream
 
ByteArrayDataOutput - Interface in com.google.common.io
An extension of DataOutput for writing to in-memory byte arrays; its methods offer identical functionality but do not throw IOException.
ByteArrayDataOutputStream(ByteArrayOutputStream) - Constructor for class com.google.common.io.ByteStreams.ByteArrayDataOutputStream
 
byteArrayFunnel() - Static method in class com.google.common.hash.Funnels
Returns a funnel that extracts the bytes from a byte array.
ByteArrayFunnel() - Constructor for enum com.google.common.hash.Funnels.ByteArrayFunnel
 
byteArrayOutputSteam - Variable in class com.google.common.io.ByteStreams.ByteArrayDataOutputStream
 
ByteProcessor<T> - Interface in com.google.common.io
A callback interface to process bytes from a stream.
bytes - Variable in class com.google.common.hash.HashCode.BytesHashCode
 
bytes - Variable in class com.google.common.hash.MessageDigestHashFunction
 
bytes - Variable in class com.google.common.hash.MessageDigestHashFunction.MessageDigestHasher
 
bytes - Variable in class com.google.common.hash.MessageDigestHashFunction.SerializedForm
 
bytes - Variable in class com.google.common.io.ByteSource.ByteArrayByteSource
 
Bytes - Class in com.google.common.primitives
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.
Bytes() - Constructor for class com.google.common.primitives.Bytes
 
BYTES - Static variable in class com.google.common.primitives.Chars
The number of bytes required to represent a primitive char value.
BYTES - Static variable in class com.google.common.primitives.Doubles
The number of bytes required to represent a primitive double value.
BYTES - Static variable in class com.google.common.primitives.Floats
The number of bytes required to represent a primitive float value.
BYTES - Static variable in class com.google.common.primitives.Ints
The number of bytes required to represent a primitive int value.
BYTES - Static variable in class com.google.common.primitives.Longs
The number of bytes required to represent a primitive long value.
BYTES - Static variable in class com.google.common.primitives.Shorts
The number of bytes required to represent a primitive short value.
Bytes.ByteArrayAsList - Class in com.google.common.primitives
 
BytesHashCode(byte[]) - Constructor for class com.google.common.hash.HashCode.BytesHashCode
 
ByteSink - Class in com.google.common.io
A destination to which bytes can be written, such as a file.
ByteSink() - Constructor for class com.google.common.io.ByteSink
Constructor for use by subclasses.
ByteSink.AsCharSink - Class in com.google.common.io
A char sink that encodes written characters with a charset and writes resulting bytes to this byte sink.
ByteSource - Class in com.google.common.io
A readable source of bytes, such as a file.
ByteSource() - Constructor for class com.google.common.io.ByteSource
Constructor for use by subclasses.
ByteSource.AsCharSource - Class in com.google.common.io
A char source that reads bytes from this source and decodes them as characters using a charset.
ByteSource.ByteArrayByteSource - Class in com.google.common.io
 
ByteSource.ConcatenatedByteSource - Class in com.google.common.io
 
ByteSource.EmptyByteSource - Class in com.google.common.io
 
ByteSource.SlicedByteSource - Class in com.google.common.io
A view of a subsection of the containing byte source.
bytesPerChunk - Variable in class com.google.common.io.BaseEncoding.Alphabet
 
bytesToInetAddress(byte[]) - Static method in class com.google.common.net.InetAddresses
Convert a byte array into an InetAddress.
ByteStreams - Class in com.google.common.io
Provides utility methods for working with byte arrays and I/O streams.
ByteStreams() - Constructor for class com.google.common.io.ByteStreams
 
ByteStreams.ByteArrayDataInputStream - Class in com.google.common.io
 
ByteStreams.ByteArrayDataOutputStream - Class in com.google.common.io
 
ByteStreams.FastByteArrayOutputStream - Class in com.google.common.io
BAOS that provides limited access to its internal byte array.
ByteStreams.LimitedInputStream - Class in com.google.common.io
 
BZIP2 - Static variable in class com.google.common.net.MediaType
 

C

c - Variable in class com.google.common.collect.Collections2.PermutationIterator
 
c - Variable in class com.google.common.hash.SipHashFunction
 
c - Variable in class com.google.common.hash.SipHashFunction.SipHasher
 
C1 - Static variable in class com.google.common.base.SmallCharMatcher
 
C1 - Static variable in class com.google.common.collect.Hashing
 
C1 - Static variable in class com.google.common.hash.Murmur3_128HashFunction.Murmur3_128Hasher
 
C1 - Static variable in class com.google.common.hash.Murmur3_32HashFunction
 
C2 - Static variable in class com.google.common.base.SmallCharMatcher
 
C2 - Static variable in class com.google.common.collect.Hashing
 
C2 - Static variable in class com.google.common.hash.Murmur3_128HashFunction.Murmur3_128Hasher
 
C2 - Static variable in class com.google.common.hash.Murmur3_32HashFunction
 
Cache<K,V> - Interface in com.google.common.cache
A semi-persistent mapping from keys to values.
CACHE_CONTROL - Static variable in class com.google.common.net.HttpHeaders
The HTTP Cache-Control header field name.
CACHE_MANIFEST_UTF_8 - Static variable in class com.google.common.net.MediaType
 
CACHE_STATS_COUNTER - Static variable in class com.google.common.cache.CacheBuilder
 
CacheBuilder<K,V> - Class in com.google.common.cache
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
CacheBuilder() - Constructor for class com.google.common.cache.CacheBuilder
 
CacheBuilder.NullListener - Enum in com.google.common.cache
 
CacheBuilder.OneWeigher - Enum in com.google.common.cache
 
CacheBuilderSpec - Class in com.google.common.cache
A specification of a CacheBuilder configuration.
CacheBuilderSpec(String) - Constructor for class com.google.common.cache.CacheBuilderSpec
 
CacheBuilderSpec.AccessDurationParser - Class in com.google.common.cache
Parse expireAfterAccess
CacheBuilderSpec.ConcurrencyLevelParser - Class in com.google.common.cache
Parse concurrencyLevel
CacheBuilderSpec.DurationParser - Class in com.google.common.cache
Base class for parsing times with durations
CacheBuilderSpec.InitialCapacityParser - Class in com.google.common.cache
Parse initialCapacity
CacheBuilderSpec.IntegerParser - Class in com.google.common.cache
Base class for parsing integers.
CacheBuilderSpec.KeyStrengthParser - Class in com.google.common.cache
Parse weakKeys
CacheBuilderSpec.LongParser - Class in com.google.common.cache
Base class for parsing integers.
CacheBuilderSpec.MaximumSizeParser - Class in com.google.common.cache
Parse maximumSize
CacheBuilderSpec.MaximumWeightParser - Class in com.google.common.cache
Parse maximumWeight
CacheBuilderSpec.RecordStatsParser - Class in com.google.common.cache
Parse recordStats
CacheBuilderSpec.RefreshDurationParser - Class in com.google.common.cache
Parse refreshAfterWrite
CacheBuilderSpec.ValueParser - Interface in com.google.common.cache
Parses a single value.
CacheBuilderSpec.ValueStrengthParser - Class in com.google.common.cache
Parse weakValues and softValues
CacheBuilderSpec.WriteDurationParser - Class in com.google.common.cache
Parse expireAfterWrite
cachedHashCode - Variable in class com.google.common.collect.SingletonImmutableSet
 
CacheLoader<K,V> - Class in com.google.common.cache
Computes or retrieves values, based on a key, for use in populating a LoadingCache.
CacheLoader() - Constructor for class com.google.common.cache.CacheLoader
Constructor for use by subclasses.
CacheLoader.FunctionToCacheLoader<K,V> - Class in com.google.common.cache
 
CacheLoader.InvalidCacheLoadException - Exception in com.google.common.cache
Thrown to indicate that an invalid response was returned from a call to CacheLoader.
CacheLoader.SupplierToCacheLoader<V> - Class in com.google.common.cache
 
CacheLoader.UnsupportedLoadingOperationException - Exception in com.google.common.cache
 
CacheStats - Class in com.google.common.cache
Statistics about the performance of a Cache.
CacheStats(long, long, long, long, long, long) - Constructor for class com.google.common.cache.CacheStats
Constructs a new CacheStats instance.
calculateNewCapacity() - Method in class com.google.common.collect.MinMaxPriorityQueue
Returns ~2x the old capacity if small; ~1.5x otherwise.
calculateNextPermutation() - Method in class com.google.common.collect.Collections2.OrderedPermutationIterator
 
calculateNextPermutation() - Method in class com.google.common.collect.Collections2.PermutationIterator
 
calculateSize(List<E>, Comparator<? super E>) - Static method in class com.google.common.collect.Collections2.OrderedPermutationCollection
The number of permutations with repeated elements is calculated as follows: For an empty list, it is 1 (base case). When r numbers are added to a list of n-r elements, the number of permutations is increased by a factor of (n choose r).
call() - Method in class com.google.common.util.concurrent.AbstractScheduledService.CustomScheduler.ReschedulableCallable
 
call() - Method in class com.google.common.util.concurrent.Futures.WrappedCombiner
 
call(L) - Method in class com.google.common.util.concurrent.ListenerCallQueue.Callback
 
Callables - Class in com.google.common.util.concurrent
Static utility methods pertaining to the Callable interface.
Callables() - Constructor for class com.google.common.util.concurrent.Callables
 
Callback(String) - Constructor for class com.google.common.util.concurrent.ListenerCallQueue.Callback
 
callWithTimeout(Callable<T>, long, TimeUnit, boolean) - Method in class com.google.common.util.concurrent.FakeTimeLimiter
 
callWithTimeout(Callable<T>, long, TimeUnit, boolean) - Method in class com.google.common.util.concurrent.SimpleTimeLimiter
 
callWithTimeout(Callable<T>, long, TimeUnit, boolean) - Method in interface com.google.common.util.concurrent.TimeLimiter
Invokes a specified Callable, timing out after the specified time limit.
CAN - Static variable in class com.google.common.base.Ascii
Cancel: A control character used to indicate that the data with which it is sent is in error or is to be disregarded.
canAcquire(long, long) - Method in class com.google.common.util.concurrent.RateLimiter
 
cancel(boolean) - Method in class com.google.common.util.concurrent.AbstractFuture
 
cancel(boolean) - Method in class com.google.common.util.concurrent.AbstractFuture.Sync
Transition to the CANCELLED or INTERRUPTED state.
cancel(boolean) - Method in class com.google.common.util.concurrent.AbstractScheduledService.CustomScheduler.ReschedulableCallable
 
cancel(boolean) - Method in class com.google.common.util.concurrent.ForwardingFuture
 
cancel(boolean) - Method in class com.google.common.util.concurrent.Futures.ChainingListenableFuture
 
cancel(Future<?>, boolean) - Method in class com.google.common.util.concurrent.Futures.ChainingListenableFuture
 
cancel(boolean) - Method in class com.google.common.util.concurrent.Futures.CombinerFuture
 
cancel(boolean) - Method in class com.google.common.util.concurrent.Futures.FallbackFuture
 
cancel(boolean) - Method in class com.google.common.util.concurrent.Futures.ImmediateFuture
 
cancel(boolean) - Method in class com.google.common.util.concurrent.MoreExecutors.ScheduledListeningDecorator.ListenableScheduledTask
 
cancellationExceptionWithCause(String, Throwable) - Static method in class com.google.common.util.concurrent.AbstractFuture
 
CANCELLED - Static variable in class com.google.common.util.concurrent.AbstractFuture.Sync
 
canonical(DiscreteDomain<C>) - Method in class com.google.common.collect.Cut.AboveValue
 
canonical(DiscreteDomain<Comparable<?>>) - Method in class com.google.common.collect.Cut.BelowAll
 
canonical(DiscreteDomain<C>) - Method in class com.google.common.collect.Cut
 
canonical(DiscreteDomain<C>) - Method in class com.google.common.collect.Range
Returns the canonical form of this range in the given domain.
canonicalForm - Variable in class com.google.common.net.HostSpecifier
 
canRemove - Variable in class com.google.common.collect.AbstractMapBasedMultiset.MapBasedMultisetIterator
 
canRemove - Variable in class com.google.common.collect.MinMaxPriorityQueue.QueueIterator
 
canRemove - Variable in class com.google.common.collect.Multisets.MultisetIteratorImpl
 
capacity(int) - Static method in class com.google.common.collect.Maps
Returns a capacity that is sufficient to keep the map from being resized as long as it grows no larger than expectedSize and the load factor is >= its default (0.75).
capacity() - Method in class com.google.common.collect.MinMaxPriorityQueue
 
capAtMaximumSize(int, int) - Static method in class com.google.common.collect.MinMaxPriorityQueue
There's no reason for the queueSize to ever be more than maxSize + 1
capture() - Method in class com.google.common.reflect.TypeCapture
Returns the captured type.
capture(Type) - Method in class com.google.common.reflect.TypeResolver.WildcardCapturer
 
capture(Type[]) - Method in class com.google.common.reflect.TypeResolver.WildcardCapturer
 
captureNullable(Type) - Method in class com.google.common.reflect.TypeResolver.WildcardCapturer
 
CartesianList<E> - Class in com.google.common.collect
Implementation of Lists.cartesianProduct(List).
CartesianList(ImmutableList<List<E>>) - Constructor for class com.google.common.collect.CartesianList
 
cartesianProduct(List<? extends List<? extends B>>) - Static method in class com.google.common.collect.Lists
Returns every possible list that can be formed by choosing one element from each of the given lists in order; the "n-ary Cartesian product" of the lists.
cartesianProduct(List<? extends B>...) - Static method in class com.google.common.collect.Lists
Returns every possible list that can be formed by choosing one element from each of the given lists in order; the "n-ary Cartesian product" of the lists.
cartesianProduct(List<? extends Set<? extends B>>) - Static method in class com.google.common.collect.Sets
Returns every possible list that can be formed by choosing one element from each of the given sets in order; the "n-ary Cartesian product" of the sets.
cartesianProduct(Set<? extends B>...) - Static method in class com.google.common.collect.Sets
Returns every possible list that can be formed by choosing one element from each of the given sets in order; the "n-ary Cartesian product" of the sets.
CartesianSet(ImmutableList<ImmutableSet<E>>, CartesianList<E>) - Constructor for class com.google.common.collect.Sets.CartesianSet
 
cas(long, long) - Method in class com.google.common.cache.Striped64.Cell
 
casBase(long, long) - Method in class com.google.common.cache.Striped64
CASes the base field.
casBusy() - Method in class com.google.common.cache.Striped64
CASes the busy field from 0 to 1 to acquire lock.
CaseFormat - Enum in com.google.common.base
Utility class for converting between various ASCII case formats.
CaseFormat(CharMatcher, String) - Constructor for enum com.google.common.base.CaseFormat
 
CaseFormat.StringConverter - Class in com.google.common.base
 
cast(Iterable<T>) - Static method in class com.google.common.collect.Collections2
Used to avoid http://bugs.sun.com/view_bug.do?bug_id=6558557
cast(Class<T>, B) - Static method in class com.google.common.collect.ImmutableClassToInstanceMap.Builder
 
cast(Iterator<T>) - Static method in class com.google.common.collect.Iterators
Used to avoid http://bugs.sun.com/view_bug.do?bug_id=6558557
cast(Iterable<T>) - Static method in class com.google.common.collect.Lists
Used to avoid http://bugs.sun.com/view_bug.do?bug_id=6558557
cast(Iterable<T>) - Static method in class com.google.common.collect.Multisets
Used to avoid http://bugs.sun.com/view_bug.do?bug_id=6558557
cast(Class<T>, B) - Static method in class com.google.common.collect.MutableClassToInstanceMap
 
cast(Iterable<T>) - Static method in class com.google.common.collect.Range
Used to avoid http://bugs.sun.com/view_bug.do?bug_id=6558557
cause - Variable in class com.google.common.cache.RemovalNotification
 
cause - Variable in class com.google.common.collect.MapMaker.RemovalNotification
 
cbuf - Variable in class com.google.common.io.LineReader
 
ceiling(K) - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableKeySet
 
ceiling(V) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedNavigableSet
 
ceiling(E) - Method in class com.google.common.collect.DescendingImmutableSortedSet
 
ceiling(E) - Method in class com.google.common.collect.ForwardingNavigableSet
 
ceiling(E) - Method in class com.google.common.collect.ImmutableSortedSet
 
ceiling(K) - Method in class com.google.common.collect.Maps.NavigableKeySet
 
ceiling(E) - Method in class com.google.common.collect.RegularImmutableSortedSet
 
ceiling(E) - Method in class com.google.common.collect.Sets.DescendingSet
 
ceiling(E) - Method in class com.google.common.collect.Sets.FilteredNavigableSet
 
ceiling(E) - Method in class com.google.common.collect.Sets.UnmodifiableNavigableSet
 
ceiling(E) - Method in class com.google.common.collect.SortedMultisets.NavigableElementSet
 
ceiling(E) - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableSet
 
ceiling(Comparator<? super E>, E) - Method in class com.google.common.collect.TreeMultiset.AvlNode
 
ceilingEntry(K) - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableAsMap
 
ceilingEntry(K) - Method in class com.google.common.collect.AbstractNavigableMap
 
ceilingEntry(K) - Method in class com.google.common.collect.ForwardingNavigableMap
 
ceilingEntry(K) - Method in class com.google.common.collect.ImmutableSortedMap
 
ceilingEntry(K) - Method in class com.google.common.collect.Maps.DescendingMap
 
ceilingEntry(K) - Method in class com.google.common.collect.Maps.TransformedEntriesNavigableMap
 
ceilingEntry(K) - Method in class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
ceilingEntry(K) - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableMap
 
ceilingKey(K) - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableAsMap
 
ceilingKey(K) - Method in class com.google.common.collect.AbstractNavigableMap
 
ceilingKey(K) - Method in class com.google.common.collect.ForwardingNavigableMap
 
ceilingKey(K) - Method in class com.google.common.collect.ImmutableSortedMap
 
ceilingKey(K) - Method in class com.google.common.collect.Maps.DescendingMap
 
ceilingKey(K) - Method in class com.google.common.collect.Maps.TransformedEntriesNavigableMap
 
ceilingKey(K) - Method in class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
ceilingKey(K) - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableMap
 
ceilToPowerOfTwo(int) - Static method in class com.google.common.util.concurrent.Striped
 
Cell(long) - Constructor for class com.google.common.cache.Striped64.Cell
 
cellFunction() - Method in class com.google.common.collect.Tables.TransformedTable
 
cellIterator() - Method in class com.google.common.collect.AbstractTable
 
cellIterator() - Method in class com.google.common.collect.ArrayTable
 
cellIterator() - Method in class com.google.common.collect.ImmutableTable
 
cellIterator() - Method in class com.google.common.collect.StandardTable
 
CellIterator() - Constructor for class com.google.common.collect.StandardTable.CellIterator
 
cellIterator() - Method in class com.google.common.collect.Tables.TransformedTable
 
cellIterator() - Method in class com.google.common.collect.Tables.TransposeTable
 
cellOf(R, C, V) - Static method in class com.google.common.collect.ImmutableTable
Verifies that rowKey, columnKey and value are non-null, and returns a new entry with those values.
cells - Variable in class com.google.common.cache.Striped64
Table of cells.
cells - Variable in class com.google.common.collect.ImmutableTable.Builder
 
cellSet - Variable in class com.google.common.collect.AbstractTable
 
cellSet() - Method in class com.google.common.collect.AbstractTable
 
CellSet() - Constructor for class com.google.common.collect.AbstractTable.CellSet
 
cellSet() - Method in class com.google.common.collect.ArrayTable
Returns an unmodifiable set of all row key / column key / value triplets.
cellSet() - Method in class com.google.common.collect.ForwardingTable
 
cellSet() - Method in class com.google.common.collect.ImmutableTable
 
CellSet() - Constructor for class com.google.common.collect.RegularImmutableTable.CellSet
 
cellSet() - Method in class com.google.common.collect.StandardTable
Returns a set of all row key / column key / value triplets.
cellSet() - Method in interface com.google.common.collect.Table
Returns a set of all row key / column key / value triplets.
cellSet() - Method in class com.google.common.collect.Tables.UnmodifiableTable
 
ChainingListenableFuture(AsyncFunction<? super I, ? extends O>, ListenableFuture<? extends I>) - Constructor for class com.google.common.util.concurrent.Futures.ChainingListenableFuture
 
charactersOf(String) - Static method in class com.google.common.collect.Lists
Returns a view of the specified string as an immutable list of Character values.
charactersOf(CharSequence) - Static method in class com.google.common.collect.Lists
Returns a view of the specified CharSequence as a List<Character>, viewing sequence as a sequence of Unicode code units.
CharArrayAsList(char[]) - Constructor for class com.google.common.primitives.Chars.CharArrayAsList
 
CharArrayAsList(char[], int, int) - Constructor for class com.google.common.primitives.Chars.CharArrayAsList
 
CharArrayDecorator(char[][]) - Constructor for class com.google.common.escape.CharEscaperBuilder.CharArrayDecorator
 
charBufferFromThreadLocal() - Static method in class com.google.common.escape.Platform
Returns a thread-local 1024-char array.
CharEscaper - Class in com.google.common.escape
An object that converts literal text into a format safe for inclusion in a particular context (such as an XML document).
CharEscaper() - Constructor for class com.google.common.escape.CharEscaper
Constructor for use by subclasses.
CharEscaperBuilder - Class in com.google.common.escape
Simple helper class to build a "sparse" array of objects based on the indexes that were added to it.
CharEscaperBuilder() - Constructor for class com.google.common.escape.CharEscaperBuilder
Construct a new sparse array builder.
CharEscaperBuilder.CharArrayDecorator - Class in com.google.common.escape
Simple decorator that turns an array of replacement char[]s into a CharEscaper, this results in a very fast escape method.
CharMatcher - Class in com.google.common.base
Determines a true or false value for any Java char value, just as Predicate does for any Object.
CharMatcher(String) - Constructor for class com.google.common.base.CharMatcher
Sets the toString() from the given description.
CharMatcher() - Constructor for class com.google.common.base.CharMatcher
Constructor for use by subclasses.
CharMatcher.And - Class in com.google.common.base
 
CharMatcher.BitSetMatcher - Class in com.google.common.base
 
CharMatcher.FastMatcher - Class in com.google.common.base
A matcher for which precomputation will not yield any significant benefit.
CharMatcher.NegatedFastMatcher - Class in com.google.common.base
 
CharMatcher.NegatedMatcher - Class in com.google.common.base
 
CharMatcher.Or - Class in com.google.common.base
 
CharMatcher.RangesMatcher - Class in com.google.common.base
 
chars - Variable in class com.google.common.io.BaseEncoding.Alphabet
 
Chars - Class in com.google.common.primitives
Static utility methods pertaining to char primitives, that are not already found in either Character or Arrays.
Chars() - Constructor for class com.google.common.primitives.Chars
 
Chars.CharArrayAsList - Class in com.google.common.primitives
 
Chars.LexicographicalComparator - Enum in com.google.common.primitives
 
CharSequenceAsList(CharSequence) - Constructor for class com.google.common.collect.Lists.CharSequenceAsList
 
CharSequenceCharSource(CharSequence) - Constructor for class com.google.common.io.CharSource.CharSequenceCharSource
 
CharSequenceReader - Class in com.google.common.io
A Reader that reads the characters in a CharSequence.
CharSequenceReader(CharSequence) - Constructor for class com.google.common.io.CharSequenceReader
Creates a new reader wrapping the given character sequence.
charset - Variable in class com.google.common.hash.Funnels.StringCharsetFunnel
 
charset - Variable in class com.google.common.io.ByteSink.AsCharSink
 
charset - Variable in class com.google.common.io.ByteSource.AsCharSource
 
charset() - Method in class com.google.common.net.MediaType
Returns an optional charset for the value of the charset parameter if it is specified.
CHARSET_ATTRIBUTE - Static variable in class com.google.common.net.MediaType
 
charsetCanonicalName - Variable in class com.google.common.hash.Funnels.StringCharsetFunnel.SerializedForm
 
Charsets - Class in com.google.common.base
Contains constant definitions for the six standard Charset instances, which are guaranteed to be supported by all Java platform implementations.
Charsets() - Constructor for class com.google.common.base.Charsets
 
CharSink - Class in com.google.common.io
A destination to which characters can be written, such as a text file.
CharSink() - Constructor for class com.google.common.io.CharSink
Constructor for use by subclasses.
CharSource - Class in com.google.common.io
A readable source of characters, such as a text file.
CharSource() - Constructor for class com.google.common.io.CharSource
Constructor for use by subclasses.
CharSource.CharSequenceCharSource - Class in com.google.common.io
 
CharSource.ConcatenatedCharSource - Class in com.google.common.io
 
CharSource.EmptyCharSource - Class in com.google.common.io
 
charsPerChunk - Variable in class com.google.common.io.BaseEncoding.Alphabet
 
CharStreams - Class in com.google.common.io
Provides utility methods for working with character streams.
CharStreams() - Constructor for class com.google.common.io.CharStreams
 
CharStreams.NullWriter - Class in com.google.common.io
 
checkAcquiredLock(CycleDetectingLockFactory.Policy, CycleDetectingLockFactory.LockGraphNode) - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory.LockGraphNode
Checks the acquisition-ordering between this, which is about to be acquired, and the specified acquiredLock.
checkAcquiredLocks(CycleDetectingLockFactory.Policy, List<CycleDetectingLockFactory.LockGraphNode>) - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory.LockGraphNode
 
checkAndSet(T, T) - Method in class com.google.common.collect.TreeMultiset.Reference
 
checkArgument(boolean) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, Object) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, Object...) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkCurrentState(Service.State) - Method in class com.google.common.util.concurrent.AbstractService
Checks that the current state is equal to the expected state.
checkedAdd(int, int) - Static method in class com.google.common.math.IntMath
Returns the sum of a and b, provided it does not overflow.
checkedAdd(long, long) - Static method in class com.google.common.math.LongMath
Returns the sum of a and b, provided it does not overflow.
checkedCast(long) - Static method in class com.google.common.primitives.Chars
Returns the char value that is equal to value, if possible.
checkedCast(long) - Static method in class com.google.common.primitives.Ints
Returns the int value that is equal to value, if possible.
checkedCast(long) - Static method in class com.google.common.primitives.Shorts
Returns the short value that is equal to value, if possible.
checkedCast(long) - Static method in class com.google.common.primitives.SignedBytes
Returns the byte value that is equal to value, if possible.
checkedCast(long) - Static method in class com.google.common.primitives.UnsignedBytes
Returns the byte value that, when treated as unsigned, is equal to value, if possible.
CheckedFuture<V,X extends java.lang.Exception> - Interface in com.google.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.google.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.google.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.google.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.google.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.google.common.util.concurrent.ForwardingCheckedFuture
 
checkedGet(long, TimeUnit) - Method in class com.google.common.util.concurrent.ForwardingCheckedFuture
 
checkedGet() - Method in class com.google.common.util.concurrent.Futures.ImmediateFailedCheckedFuture
 
checkedGet(long, TimeUnit) - Method in class com.google.common.util.concurrent.Futures.ImmediateFailedCheckedFuture
 
checkedGet() - Method in class com.google.common.util.concurrent.Futures.ImmediateSuccessfulCheckedFuture
 
checkedGet(long, TimeUnit) - Method in class com.google.common.util.concurrent.Futures.ImmediateSuccessfulCheckedFuture
 
checkedMultiply(int, int) - Static method in class com.google.common.math.IntMath
Returns the product of a and b, provided it does not overflow.
checkedMultiply(long, long) - Static method in class com.google.common.math.LongMath
Returns the product of a and b, provided it does not overflow.
checkedPow(int, int) - Static method in class com.google.common.math.IntMath
Returns the b to the kth power, provided it does not overflow.
checkedPow(long, int) - Static method in class com.google.common.math.LongMath
Returns the b to the kth power, provided it does not overflow.
checkedSubtract(int, int) - Static method in class com.google.common.math.IntMath
Returns the difference of a and b, provided it does not overflow.
checkedSubtract(long, long) - Static method in class com.google.common.math.LongMath
Returns the difference of a and b, provided it does not overflow.
checkElement(E) - Method in interface com.google.common.collect.Constraint
Throws a suitable RuntimeException if the specified element is illegal.
checkElement(Object) - Static method in class com.google.common.collect.LinkedListMultimap
Helper method for verifying that an iterator element is present.
checkElementIndex(int, int) - Static method in class com.google.common.base.Preconditions
Ensures that index specifies a valid element in an array, list or string of size size.
checkElementIndex(int, int, String) - Static method in class com.google.common.base.Preconditions
Ensures that index specifies a valid element in an array, list or string of size size.
checkElementNotNull(Object, int) - Static method in class com.google.common.collect.ObjectArrays
 
checkElements(Collection<E>, Constraint<? super E>) - Static method in class com.google.common.collect.Constraints
 
checkElementsNotNull(Object...) - Static method in class com.google.common.collect.ObjectArrays
 
checkElementsNotNull(Object[], int) - Static method in class com.google.common.collect.ObjectArrays
 
checkEntryNotNull(Object, Object) - Static method in class com.google.common.collect.CollectPreconditions
 
checkExpiration(long, TimeUnit) - Method in class com.google.common.collect.MapMaker
 
checkFilter(int) - Method in class com.google.common.base.SmallCharMatcher
 
checkForConcurrentModification() - Method in class com.google.common.collect.HashBiMap.Itr
 
checkForConcurrentModification() - Method in class com.google.common.collect.LinkedListMultimap.DistinctKeyIterator
 
checkForConcurrentModification() - Method in class com.google.common.collect.LinkedListMultimap.NodeIterator
 
checkHealthy() - Method in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState
 
checkInRange(boolean) - Static method in class com.google.common.math.MathPreconditions
 
checkKey(K) - Method in class com.google.common.collect.AbstractBiMap
Returns its input, or throws an exception if this is not a valid key.
checkKey(K) - Method in class com.google.common.collect.AbstractBiMap.Inverse
 
checkKey(K) - Method in class com.google.common.collect.EnumBiMap
 
checkKey(K) - Method in class com.google.common.collect.EnumHashBiMap
 
checkKeyValue(K, V) - Method in interface com.google.common.collect.MapConstraint
Throws a suitable RuntimeException if the specified key or value is illegal.
checkKeyValue(K, V) - Method in class com.google.common.collect.MapConstraints.InverseConstraint
 
checkKeyValue(Object, Object) - Method in enum com.google.common.collect.MapConstraints.NotNullMapConstraint
 
checkMap(Map<? extends K, ? extends V>, MapConstraint<? super K, ? super V>) - Static method in class com.google.common.collect.MapConstraints
 
checkModCount() - Method in class com.google.common.collect.MinMaxPriorityQueue.QueueIterator
 
checkNoConflict(boolean, String, Map.Entry<?, ?>, Map.Entry<?, ?>) - Static method in class com.google.common.collect.ImmutableMap
 
checkNoConflictInBucket(K, ImmutableMapEntry<K, V>, ImmutableMapEntry<K, V>) - Method in class com.google.common.collect.RegularImmutableMap
 
checkNonLoadingCache() - Method in class com.google.common.cache.CacheBuilder
 
checkNonnegative(int, String) - Static method in class com.google.common.collect.CollectPreconditions
 
checkNonnegative(int) - Static method in class com.google.common.collect.Iterators
 
checkNonNegative(String, int) - Static method in class com.google.common.math.MathPreconditions
 
checkNonNegative(String, long) - Static method in class com.google.common.math.MathPreconditions
 
checkNonNegative(String, BigInteger) - Static method in class com.google.common.math.MathPreconditions
 
checkNonNegative(String, double) - Static method in class com.google.common.math.MathPreconditions
 
checkNoOverflow(boolean) - Static method in class com.google.common.math.MathPreconditions
 
checkNotClosed() - Method in class com.google.common.io.AppendableWriter
 
checkNotDone() - Method in class com.google.common.hash.MessageDigestHashFunction.MessageDigestHasher
 
checkNotNull(T) - Static method in class com.google.common.base.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, Object) - Static method in class com.google.common.base.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, Object...) - Static method in class com.google.common.base.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkOpen() - Method in class com.google.common.io.CharSequenceReader
 
checkPermits(int) - Static method in class com.google.common.util.concurrent.RateLimiter
 
checkPositionIndex(int, int) - Static method in class com.google.common.base.Preconditions
Ensures that index specifies a valid position in an array, list or string of size size.
checkPositionIndex(int, int, String) - Static method in class com.google.common.base.Preconditions
Ensures that index specifies a valid position in an array, list or string of size size.
checkPositionIndexes(int, int, int) - Static method in class com.google.common.base.Preconditions
Ensures that start and end specify a valid positions in an array, list or string of size size, and are in order.
checkPositive(String, int) - Static method in class com.google.common.math.MathPreconditions
 
checkPositive(String, long) - Static method in class com.google.common.math.MathPreconditions
 
checkPositive(String, BigInteger) - Static method in class com.google.common.math.MathPreconditions
 
checkPositiveAndMakeMultipleOf32(int) - Static method in class com.google.common.hash.Hashing
Checks that the passed argument is positive, and ceils it to a multiple of 32.
checkRemove(boolean) - Static method in class com.google.common.collect.CollectPreconditions
Precondition tester for Iterator.remove() that throws an exception with a consistent error message.
checkRoundingUnnecessary(boolean) - Static method in class com.google.common.math.MathPreconditions
 
checkState(boolean) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, Object) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, Object...) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checksum - Variable in class com.google.common.hash.ChecksumHashFunction.ChecksumHasher
 
ChecksumHasher(Checksum) - Constructor for class com.google.common.hash.ChecksumHashFunction.ChecksumHasher
 
ChecksumHashFunction - Class in com.google.common.hash
HashFunction adapter for Checksum instances.
ChecksumHashFunction(Supplier<? extends Checksum>, int, String) - Constructor for class com.google.common.hash.ChecksumHashFunction
 
checksumHashFunction(Hashing.ChecksumType, String) - Static method in class com.google.common.hash.Hashing
 
ChecksumHashFunction.ChecksumHasher - Class in com.google.common.hash
Hasher that updates a checksum.
checksumSupplier - Variable in class com.google.common.hash.ChecksumHashFunction
 
ChecksumType(int) - Constructor for enum com.google.common.hash.Hashing.ChecksumType
 
checkValue(V) - Method in class com.google.common.collect.AbstractBiMap
Returns its input, or throws an exception if this is not a valid value.
checkValue(V) - Method in class com.google.common.collect.AbstractBiMap.Inverse
 
checkValue(V) - Method in class com.google.common.collect.EnumBiMap
 
checkValues(K, Iterable<? extends V>, MapConstraint<? super K, ? super V>) - Static method in class com.google.common.collect.MapConstraints
 
checkWeightWithWeigher() - Method in class com.google.common.cache.CacheBuilder
 
child(String) - Method in class com.google.common.net.InternetDomainName
Creates and returns a new InternetDomainName by prepending the argument and a dot to the current name.
childIterator - Variable in class com.google.common.collect.TreeTraverser.PostOrderNode
 
children(T) - Method in class com.google.common.collect.BinaryTreeTraverser
Returns the children of this node, in left-to-right order.
children(T) - Method in class com.google.common.collect.TreeTraverser
Returns the children of the specified node.
chooseTableSize(int) - Static method in class com.google.common.base.SmallCharMatcher
Returns an array size suitable for the backing array of a hash table that uses open addressing with linear probing in its implementation.
chooseTableSize(int) - Static method in class com.google.common.collect.ImmutableSet
Returns an array size suitable for the backing array of a hash table that uses open addressing with linear probing in its implementation.
chooseUnit(long) - Static method in class com.google.common.base.Stopwatch
 
CHUNK_SIZE - Static variable in class com.google.common.hash.Murmur3_128HashFunction.Murmur3_128Hasher
 
CHUNK_SIZE - Static variable in class com.google.common.hash.Murmur3_32HashFunction.Murmur3_32Hasher
 
CHUNK_SIZE - Static variable in class com.google.common.hash.SipHashFunction.SipHasher
 
chunkSize - Variable in class com.google.common.hash.AbstractStreamingHashFunction.AbstractStreamingHasher
Number of bytes processed per process() invocation.
CLASS_FILE_NAME_EXTENSION - Static variable in class com.google.common.reflect.ClassPath
 
CLASS_PATH_ATTRIBUTE_SEPARATOR - Static variable in class com.google.common.reflect.ClassPath
Separator for the Class-Path manifest attribute value in jar files.
classes - Variable in class com.google.common.reflect.TypeToken.ClassSet
 
classes() - Method in class com.google.common.reflect.TypeToken.ClassSet
 
classes() - Method in class com.google.common.reflect.TypeToken.InterfaceSet
 
classes() - Method in class com.google.common.reflect.TypeToken.TypeSet
Returns the types that are classes.
classesOnly() - Method in class com.google.common.reflect.TypeToken.TypeCollector
For just classes, we don't have to traverse interfaces.
ClassInfo(String, ClassLoader) - Constructor for class com.google.common.reflect.ClassPath.ClassInfo
 
className - Variable in class com.google.common.base.MoreObjects.ToStringHelper
 
className - Variable in class com.google.common.base.Objects.ToStringHelper
Deprecated.
 
className - Variable in class com.google.common.reflect.ClassPath.ClassInfo
 
ClassOwnership() - Constructor for enum com.google.common.reflect.Types.ClassOwnership
 
ClassPath - Class in com.google.common.reflect
Scans the source of a ClassLoader and finds all loadable classes and resources.
ClassPath(ImmutableSet<ClassPath.ResourceInfo>) - Constructor for class com.google.common.reflect.ClassPath
 
ClassPath.ClassInfo - Class in com.google.common.reflect
Represents a class that can be loaded through ClassPath.ClassInfo.load().
ClassPath.ResourceInfo - Class in com.google.common.reflect
Represents a class path resource that can be either a class file or any other resource file loadable from the class path.
ClassPath.Scanner - Class in com.google.common.reflect
 
ClassSet() - Constructor for class com.google.common.reflect.TypeToken.ClassSet
 
ClassToInstanceMap<B> - Interface in com.google.common.collect
A map, each entry of which maps a Java raw type to an instance of that type.
clazz - Variable in class com.google.common.base.Predicates.AssignableFromPredicate
 
clazz - Variable in class com.google.common.base.Predicates.InstanceOfPredicate
 
clazz - Variable in class com.google.common.collect.MultimapBuilder.EnumSetSupplier
 
cleanUp() - Method in class com.google.common.base.FinalizableReferenceQueue
Repeatedly dequeues references from the queue and invokes FinalizableReference.finalizeReferent() on them until the queue is empty.
cleanUp(Reference<?>) - Method in class com.google.common.base.internal.Finalizer
Cleans up a single reference.
cleanUp() - Method in class com.google.common.cache.AbstractCache
 
cleanUp() - Method in interface com.google.common.cache.Cache
Performs any pending maintenance operations needed by the cache.
cleanUp() - Method in class com.google.common.cache.ForwardingCache
 
cleanUp() - Method in class com.google.common.cache.LocalCache
 
cleanUp() - Method in class com.google.common.cache.LocalCache.LocalManualCache
 
cleanUp() - Method in class com.google.common.cache.LocalCache.Segment
 
CLEANUP_EXECUTOR_DELAY_SECS - Static variable in class com.google.common.collect.MapMakerInternalMap
 
CleanupMapTask(MapMakerInternalMap<?, ?>) - Constructor for class com.google.common.collect.MapMakerInternalMap.CleanupMapTask
 
clear() - Method in class com.google.common.cache.LocalCache.AbstractCacheSet
 
clear() - Method in class com.google.common.cache.LocalCache.AccessQueue
 
clear() - Method in class com.google.common.cache.LocalCache
 
clear() - Method in class com.google.common.cache.LocalCache.Segment
 
clear() - Method in class com.google.common.cache.LocalCache.Values
 
clear() - Method in class com.google.common.cache.LocalCache.WriteQueue
 
clear() - Method in class com.google.common.collect.AbstractBiMap
 
clear() - Method in class com.google.common.collect.AbstractBiMap.EntrySet
 
clear() - Method in class com.google.common.collect.AbstractBiMap.KeySet
 
clear() - Method in class com.google.common.collect.AbstractMapBasedMultimap.AsMap
 
clear() - Method in class com.google.common.collect.AbstractMapBasedMultimap
 
clear() - Method in class com.google.common.collect.AbstractMapBasedMultimap.KeySet
 
clear() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection
 
clear() - Method in class com.google.common.collect.AbstractMapBasedMultiset
 
clear() - Method in class com.google.common.collect.AbstractMultimap.Values
 
clear() - Method in class com.google.common.collect.AbstractMultiset
 
clear() - Method in class com.google.common.collect.AbstractRangeSet
 
clear() - Method in class com.google.common.collect.AbstractTable.CellSet
 
clear() - Method in class com.google.common.collect.AbstractTable
 
clear() - Method in class com.google.common.collect.AbstractTable.Values
 
clear() - Method in class com.google.common.collect.ArrayTable.ArrayMap
 
clear() - Method in class com.google.common.collect.ArrayTable
Deprecated.
clear() - Method in class com.google.common.collect.Collections2.FilteredCollection
 
clear() - Method in class com.google.common.collect.Collections2.TransformedCollection
 
clear(MapMakerInternalMap.ValueReference<K, V>) - Method in class com.google.common.collect.ComputingConcurrentHashMap.ComputationExceptionReference
 
clear(MapMakerInternalMap.ValueReference<K, V>) - Method in class com.google.common.collect.ComputingConcurrentHashMap.ComputedReference
 
clear(MapMakerInternalMap.ValueReference<K, V>) - Method in class com.google.common.collect.ComputingConcurrentHashMap.ComputingValueReference
 
clear() - Method in class com.google.common.collect.ConcurrentHashMultiset
 
clear() - Method in class com.google.common.collect.FilteredEntryMultimap.AsMap
 
clear() - Method in class com.google.common.collect.FilteredEntryMultimap
 
clear() - Method in class com.google.common.collect.FilteredKeyMultimap
 
clear() - Method in class com.google.common.collect.FilteredMultimapValues
 
clear() - Method in class com.google.common.collect.ForwardingCollection
 
clear() - Method in class com.google.common.collect.ForwardingMap
 
clear() - Method in class com.google.common.collect.ForwardingMultimap
 
clear() - Method in class com.google.common.collect.ForwardingTable
 
clear() - Method in class com.google.common.collect.HashBiMap
 
clear() - Method in class com.google.common.collect.HashBiMap.Inverse
 
clear() - Method in class com.google.common.collect.ImmutableCollection
Deprecated.
Unsupported operation.
clear() - Method in class com.google.common.collect.ImmutableMap
Deprecated.
Unsupported operation.
clear() - Method in class com.google.common.collect.ImmutableMultimap
Deprecated.
Unsupported operation.
clear() - Method in class com.google.common.collect.ImmutableRangeMap
 
clear() - Method in class com.google.common.collect.ImmutableTable
Deprecated.
Unsupported operation.
clear(Iterator<?>) - Static method in class com.google.common.collect.Iterators
Clears the iterator using its remove method.
clear() - Method in class com.google.common.collect.LinkedHashMultimap
 
clear() - Method in class com.google.common.collect.LinkedHashMultimap.ValueSet
 
clear() - Method in class com.google.common.collect.LinkedListMultimap
 
clear() - Method in class com.google.common.collect.Lists.ReverseList
 
clear() - Method in class com.google.common.collect.Lists.TransformingRandomAccessList
 
clear() - Method in class com.google.common.collect.Lists.TransformingSequentialList
The default implementation inherited is based on iteration and removal of each element which can be overkill.
clear() - Method in class com.google.common.collect.MapMakerInternalMap
 
clear() - Method in class com.google.common.collect.MapMakerInternalMap.EntrySet
 
clear() - Method in class com.google.common.collect.MapMakerInternalMap.EvictionQueue
 
clear() - Method in class com.google.common.collect.MapMakerInternalMap.ExpirationQueue
 
clear() - Method in class com.google.common.collect.MapMakerInternalMap.KeySet
 
clear() - Method in class com.google.common.collect.MapMakerInternalMap.Segment
 
clear(MapMakerInternalMap.ValueReference<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.SoftValueReference
 
clear(MapMakerInternalMap.ValueReference<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.StrongValueReference
 
clear(MapMakerInternalMap.ValueReference<K, V>) - Method in interface com.google.common.collect.MapMakerInternalMap.ValueReference
Clears this reference object.
clear() - Method in class com.google.common.collect.MapMakerInternalMap.Values
 
clear(MapMakerInternalMap.ValueReference<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.WeakValueReference
 
clear() - Method in class com.google.common.collect.Maps.AsMapView
 
clear() - Method in class com.google.common.collect.Maps.EntrySet
 
clear() - Method in class com.google.common.collect.Maps.FilteredEntryNavigableMap
 
clear() - Method in class com.google.common.collect.Maps.KeySet
 
clear() - Method in class com.google.common.collect.Maps.NavigableAsMapView
 
clear() - Method in class com.google.common.collect.Maps.TransformedEntriesMap
 
clear() - Method in class com.google.common.collect.Maps.Values
 
clear() - Method in class com.google.common.collect.MinMaxPriorityQueue
 
clear() - Method in interface com.google.common.collect.Multimap
Removes all key-value pairs from the multimap, leaving it empty.
clear() - Method in class com.google.common.collect.Multimaps.AsMap
 
clear() - Method in class com.google.common.collect.Multimaps.Entries
 
clear() - Method in class com.google.common.collect.Multimaps.Keys
 
clear() - Method in class com.google.common.collect.Multimaps.MapMultimap
 
clear() - Method in class com.google.common.collect.Multimaps.TransformedEntriesMultimap
 
clear() - Method in class com.google.common.collect.Multimaps.UnmodifiableMultimap
 
clear() - Method in class com.google.common.collect.Multisets.ElementSet
 
clear() - Method in class com.google.common.collect.Multisets.EntrySet
 
clear() - Method in class com.google.common.collect.Multisets.FilteredMultiset
 
clear() - Method in class com.google.common.collect.Multisets.UnmodifiableMultiset
 
clear() - Method in interface com.google.common.collect.RangeMap
Removes all associations from this range map (optional operation).
clear() - Method in interface com.google.common.collect.RangeSet
Removes all ranges from this RangeSet (optional operation).
clear() - Method in class com.google.common.collect.StandardTable
 
clear() - Method in class com.google.common.collect.StandardTable.Column.EntrySet
 
clear() - Method in class com.google.common.collect.StandardTable.Row
 
clear() - Method in class com.google.common.collect.StandardTable.TableSet
 
clear() - Method in class com.google.common.collect.Synchronized.SynchronizedCollection
 
clear() - Method in class com.google.common.collect.Synchronized.SynchronizedMap
 
clear() - Method in class com.google.common.collect.Synchronized.SynchronizedMultimap
 
clear() - Method in interface com.google.common.collect.Table
Removes all mappings from the table.
clear() - Method in class com.google.common.collect.Tables.TransformedTable
 
clear() - Method in class com.google.common.collect.Tables.TransposeTable
 
clear() - Method in class com.google.common.collect.Tables.UnmodifiableTable
 
clear() - Method in class com.google.common.collect.TreeRangeMap
 
clear() - Method in class com.google.common.collect.TreeRangeMap.SubRangeMap
 
clear() - Method in class com.google.common.collect.TreeRangeMap.SubRangeMap.SubRangeMapAsMap
 
clear() - Method in class com.google.common.collect.TreeRangeSet.SubRangeSet
 
clear() - Method in class com.google.common.util.concurrent.AtomicLongMap
Removes all of the mappings from this map.
clearKeyReferenceQueue() - Method in class com.google.common.cache.LocalCache.Segment
 
clearKeyReferenceQueue() - Method in class com.google.common.collect.MapMakerInternalMap.Segment
 
clearReferenceQueues() - Method in class com.google.common.cache.LocalCache.Segment
Clears all entries from the key and value reference queues.
clearReferenceQueues() - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Clears all entries from the key and value reference queues.
clearValue(K, int, MapMakerInternalMap.ValueReference<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Clears a value that has not yet been set, and thus does not require count to be modified.
clearValueReferenceQueue() - Method in class com.google.common.cache.LocalCache.Segment
 
clearValueReferenceQueue() - Method in class com.google.common.collect.MapMakerInternalMap.Segment
 
client - Variable in class com.google.common.net.InetAddresses.TeredoInfo
 
close() - Method in class com.google.common.base.FinalizableReferenceQueue
 
close() - Method in class com.google.common.hash.HashingOutputStream
 
close() - Method in class com.google.common.io.AppendableWriter
 
close() - Method in class com.google.common.io.CharSequenceReader
 
close() - Method in class com.google.common.io.CharStreams.NullWriter
 
close(Closeable, boolean) - Static method in class com.google.common.io.Closeables
Closes a Closeable, with control over whether an IOException may be thrown.
close() - Method in class com.google.common.io.Closer
Closes all Closeable instances that have been added to this Closer.
close() - Method in class com.google.common.io.CountingOutputStream
 
close() - Method in class com.google.common.io.FileBackedOutputStream
 
close() - Method in interface com.google.common.io.GwtWorkarounds.ByteInput
 
close() - Method in interface com.google.common.io.GwtWorkarounds.ByteOutput
 
close() - Method in interface com.google.common.io.GwtWorkarounds.CharInput
 
close() - Method in interface com.google.common.io.GwtWorkarounds.CharOutput
 
close() - Method in class com.google.common.io.LittleEndianDataOutputStream
 
close() - Method in class com.google.common.io.MultiInputStream
 
close() - Method in class com.google.common.io.MultiReader
 
Closeables - Class in com.google.common.io
Utility methods for working with Closeable objects.
Closeables() - Constructor for class com.google.common.io.Closeables
 
closed(C, C) - Static method in class com.google.common.collect.Range
Returns a range that contains all values greater than or equal to lower and less than or equal to upper.
closed - Variable in class com.google.common.io.AppendableWriter
 
closedOpen(C, C) - Static method in class com.google.common.collect.Range
Returns a range that contains all values greater than or equal to lower and strictly less than upper.
closedTableSize(int, double) - Static method in class com.google.common.collect.Hashing
 
closeQuietly(InputStream) - Static method in class com.google.common.io.Closeables
Closes the given InputStream, logging any IOException that's thrown rather than propagating it.
closeQuietly(Reader) - Static method in class com.google.common.io.Closeables
Closes the given Reader, logging any IOException that's thrown rather than propagating it.
Closer - Class in com.google.common.io
A Closeable that collects Closeable resources and closes them all when it is closed.
Closer(Closer.Suppressor) - Constructor for class com.google.common.io.Closer
 
Closer.LoggingSuppressor - Class in com.google.common.io
Suppresses exceptions by logging them.
Closer.SuppressingSuppressor - Class in com.google.common.io
Suppresses exceptions by adding them to the exception that will be thrown using JDK7's addSuppressed(Throwable) mechanism.
Closer.Suppressor - Interface in com.google.common.io
Suppression strategy interface.
codePointAt(CharSequence, int, int) - Static method in class com.google.common.escape.UnicodeEscaper
Returns the Unicode code point of the character at the given index.
coerceToInteger(InetAddress) - Static method in class com.google.common.net.InetAddresses
Returns an integer representing an IPv4 address regardless of whether the supplied argument is an IPv4 address or not.
collapseFrom(CharSequence, char) - Method in class com.google.common.base.CharMatcher
Returns a string copy of the input character sequence, with each group of consecutive characters that match this matcher replaced by a single replacement character.
collection - Variable in class com.google.common.collect.AbstractMapBasedMultimap.AsMap.AsMapIterator
 
collection - Variable in class com.google.common.collect.AbstractMapBasedMultimap.Itr
 
collection - Variable in class com.google.common.collect.ImmutableAsList.SerializedForm
 
collection(Collection<E>, Object) - Static method in class com.google.common.collect.Synchronized
 
Collections2 - Class in com.google.common.collect
Provides static methods for working with Collection instances.
Collections2() - Constructor for class com.google.common.collect.Collections2
 
Collections2.FilteredCollection<E> - Class in com.google.common.collect
 
Collections2.OrderedPermutationCollection<E> - Class in com.google.common.collect
 
Collections2.OrderedPermutationIterator<E> - Class in com.google.common.collect
 
Collections2.PermutationCollection<E> - Class in com.google.common.collect
 
Collections2.PermutationIterator<E> - Class in com.google.common.collect
 
Collections2.TransformedCollection<F,T> - Class in com.google.common.collect
 
CollectPreconditions - Class in com.google.common.collect
Precondition checks useful in collection implementations.
CollectPreconditions() - Constructor for class com.google.common.collect.CollectPreconditions
 
collectTypes(K) - Method in class com.google.common.reflect.TypeToken.TypeCollector
 
collectTypes(Iterable<? extends K>) - Method in class com.google.common.reflect.TypeToken.TypeCollector
 
collectTypes(K, Map<? super K, Integer>) - Method in class com.google.common.reflect.TypeToken.TypeCollector
Collects all types to map, and returns the total depth from T up to Object.
column(C) - Method in class com.google.common.collect.ArrayTable
Returns a view of all mappings that have the given column key.
Column(int) - Constructor for class com.google.common.collect.ArrayTable.Column
 
Column(int) - Constructor for class com.google.common.collect.DenseImmutableTable.Column
 
column(C) - Method in class com.google.common.collect.ForwardingTable
 
column(C) - Method in class com.google.common.collect.ImmutableTable
Returns a view of all mappings that have the given column key.
column(C) - Method in class com.google.common.collect.SingletonImmutableTable
 
column(C) - Method in class com.google.common.collect.StandardTable
Returns a view of all mappings that have the given column key.
Column(C) - Constructor for class com.google.common.collect.StandardTable.Column
 
column(C) - Method in interface com.google.common.collect.Table
Returns a view of all mappings that have the given column key.
column(C) - Method in class com.google.common.collect.Tables.TransformedTable
 
column(R) - Method in class com.google.common.collect.Tables.TransposeTable
 
column(C) - Method in class com.google.common.collect.Tables.UnmodifiableTable
 
columnComparator - Variable in class com.google.common.collect.ImmutableTable.Builder
 
columnComparator - Variable in class com.google.common.collect.TreeBasedTable
 
columnComparator() - Method in class com.google.common.collect.TreeBasedTable
Returns the comparator that orders the columns.
columnCounts - Variable in class com.google.common.collect.DenseImmutableTable
 
columnIndex - Variable in class com.google.common.collect.ArrayTable.Column
 
columnIndex - Variable in class com.google.common.collect.DenseImmutableTable.Column
 
columnIterator - Variable in class com.google.common.collect.StandardTable.CellIterator
 
columnKey - Variable in class com.google.common.collect.StandardTable.Column
 
columnKey - Variable in class com.google.common.collect.Tables.ImmutableCell
 
ColumnKeyIterator() - Constructor for class com.google.common.collect.StandardTable.ColumnKeyIterator
 
columnKeyList() - Method in class com.google.common.collect.ArrayTable
Returns, as an immutable list, the column keys provided when the table was constructed, including those that are mapped to null values only.
columnKeySet() - Method in class com.google.common.collect.AbstractTable
 
columnKeySet() - Method in class com.google.common.collect.ArrayTable
Returns an immutable set of the valid column keys, including those that are associated with null values only.
columnKeySet() - Method in class com.google.common.collect.ForwardingTable
 
columnKeySet() - Method in class com.google.common.collect.ImmutableTable
 
columnKeySet - Variable in class com.google.common.collect.StandardTable
 
columnKeySet() - Method in class com.google.common.collect.StandardTable
Returns a set of column keys that have one or more values in the table.
ColumnKeySet() - Constructor for class com.google.common.collect.StandardTable.ColumnKeySet
 
columnKeySet() - Method in interface com.google.common.collect.Table
Returns a set of column keys that have one or more values in the table.
columnKeySet() - Method in class com.google.common.collect.Tables.TransformedTable
 
columnKeySet() - Method in class com.google.common.collect.Tables.TransposeTable
 
columnKeySet() - Method in class com.google.common.collect.Tables.UnmodifiableTable
 
columnKeyToIndex - Variable in class com.google.common.collect.ArrayTable
 
columnKeyToIndex - Variable in class com.google.common.collect.DenseImmutableTable
 
columnList - Variable in class com.google.common.collect.ArrayTable
 
columnMap - Variable in class com.google.common.collect.ArrayTable
 
columnMap() - Method in class com.google.common.collect.ArrayTable
 
ColumnMap() - Constructor for class com.google.common.collect.ArrayTable.ColumnMap
 
columnMap - Variable in class com.google.common.collect.DenseImmutableTable
 
columnMap() - Method in class com.google.common.collect.DenseImmutableTable
 
ColumnMap() - Constructor for class com.google.common.collect.DenseImmutableTable.ColumnMap
 
columnMap() - Method in class com.google.common.collect.ForwardingTable
 
columnMap() - Method in class com.google.common.collect.ImmutableTable
Returns a view that associates each column key with the corresponding map from row keys to values.
columnMap() - Method in class com.google.common.collect.SingletonImmutableTable
 
columnMap - Variable in class com.google.common.collect.SparseImmutableTable
 
columnMap() - Method in class com.google.common.collect.SparseImmutableTable
 
columnMap - Variable in class com.google.common.collect.StandardTable
 
columnMap() - Method in class com.google.common.collect.StandardTable
 
ColumnMap() - Constructor for class com.google.common.collect.StandardTable.ColumnMap
 
columnMap() - Method in interface com.google.common.collect.Table
Returns a view that associates each column key with the corresponding map from row keys to values.
columnMap() - Method in class com.google.common.collect.Tables.TransformedTable
 
columnMap() - Method in class com.google.common.collect.Tables.TransposeTable
 
columnMap() - Method in class com.google.common.collect.Tables.UnmodifiableTable
 
ColumnMapEntrySet() - Constructor for class com.google.common.collect.StandardTable.ColumnMap.ColumnMapEntrySet
 
ColumnMapValues() - Constructor for class com.google.common.collect.StandardTable.ColumnMap.ColumnMapValues
 
com.google.common.annotations - package com.google.common.annotations
Common annotation types.
com.google.common.base - package com.google.common.base
Basic utility libraries and interfaces.
com.google.common.base.internal - package com.google.common.base.internal
 
com.google.common.cache - package com.google.common.cache
This package contains caching utilities.
com.google.common.collect - package com.google.common.collect
This package contains generic collection interfaces and implementations, and other utilities for working with collections.
com.google.common.escape - package com.google.common.escape
Interfaces, utilities, and simple implementations of escapers and encoders.
com.google.common.eventbus - package com.google.common.eventbus
The EventBus allows publish-subscribe-style communication between components without requiring the components to explicitly register with one another (and thus be aware of each other).
com.google.common.hash - package com.google.common.hash
Hash functions and related structures.
com.google.common.html - package com.google.common.html
Escapers for HTML.
com.google.common.io - package com.google.common.io
This package contains utility methods and classes for working with Java I/O; for example input streams, output streams, readers, writers, and files.
com.google.common.math - package com.google.common.math
Arithmetic functions operating on primitive values and BigInteger instances.
com.google.common.net - package com.google.common.net
This package contains utility methods and classes for working with net addresses (numeric IP and domain names).
com.google.common.primitives - package com.google.common.primitives
Static utilities for working with the eight primitive types and void, and value types for treating them as unsigned.
com.google.common.reflect - package com.google.common.reflect
This package contains utilities to work with Java reflection.
com.google.common.util.concurrent - package com.google.common.util.concurrent
Concurrency utilities.
com.google.common.xml - package com.google.common.xml
Escapers for XML.
com.google.thirdparty.publicsuffix - package com.google.thirdparty.publicsuffix
 
combine(List<Optional<V>>) - Method in interface com.google.common.util.concurrent.Futures.FutureCombiner
 
CombinedFuture(ImmutableCollection<? extends ListenableFuture<? extends V>>, boolean, Executor, Futures.FutureCombiner<V, C>) - Constructor for class com.google.common.util.concurrent.Futures.CombinedFuture
 
combineOrdered(Iterable<HashCode>) - Static method in class com.google.common.hash.Hashing
Returns a hash code, having the same bit length as each of the input hash codes, that combines the information of these hash codes in an ordered fashion.
combiner - Variable in class com.google.common.util.concurrent.Futures.CombinedFuture
 
CombinerFuture(Callable<V>, ImmutableList<ListenableFuture<?>>) - Constructor for class com.google.common.util.concurrent.Futures.CombinerFuture
 
combineUnordered(Iterable<HashCode>) - Static method in class com.google.common.hash.Hashing
Returns a hash code, having the same bit length as each of the input hash codes, that combines the information of these hash codes in an unordered fashion.
COMMA_JOINER - Static variable in class com.google.common.base.Predicates
 
COMMA_JOINER - Static variable in class com.google.common.reflect.Types
 
commonPrefix(CharSequence, CharSequence) - Static method in class com.google.common.base.Strings
Returns the longest string prefix such that a.toString().startsWith(prefix) && b.toString().startsWith(prefix), taking care not to split surrogate pairs.
commonSuffix(CharSequence, CharSequence) - Static method in class com.google.common.base.Strings
Returns the longest string suffix such that a.toString().endsWith(suffix) && b.toString().endsWith(suffix), taking care not to split surrogate pairs.
CompactStriped(int, Supplier<L>) - Constructor for class com.google.common.util.concurrent.Striped.CompactStriped
 
comparator() - Method in class com.google.common.collect.AbstractMapBasedMultimap.SortedAsMap
 
comparator() - Method in class com.google.common.collect.AbstractMapBasedMultimap.SortedKeySet
 
comparator() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedSortedSet
 
comparator - Variable in class com.google.common.collect.AbstractSortedMultiset
 
comparator() - Method in class com.google.common.collect.AbstractSortedMultiset
 
comparator - Variable in class com.google.common.collect.Collections2.OrderedPermutationCollection
 
comparator - Variable in class com.google.common.collect.Collections2.OrderedPermutationIterator
 
comparator - Variable in class com.google.common.collect.ComparatorOrdering
 
comparator - Variable in class com.google.common.collect.DescendingMultiset
 
comparator() - Method in class com.google.common.collect.DescendingMultiset
 
comparator() - Method in class com.google.common.collect.ForwardingSortedMap
 
comparator() - Method in class com.google.common.collect.ForwardingSortedMultiset
 
comparator() - Method in class com.google.common.collect.ForwardingSortedSet
 
comparator - Variable in class com.google.common.collect.GeneralRange
 
comparator() - Method in class com.google.common.collect.GeneralRange
 
comparator() - Method in class com.google.common.collect.ImmutableSortedAsList
 
comparator - Variable in class com.google.common.collect.ImmutableSortedMap.Builder
 
comparator() - Method in class com.google.common.collect.ImmutableSortedMap
Returns the comparator that orders the keys, which is Ordering.natural() when the natural ordering of the keys is used.
comparator - Variable in class com.google.common.collect.ImmutableSortedMap.SerializedForm
 
comparator() - Method in class com.google.common.collect.ImmutableSortedMultiset
 
comparator - Variable in class com.google.common.collect.ImmutableSortedMultiset.SerializedForm
 
comparator - Variable in class com.google.common.collect.ImmutableSortedSet.Builder
 
comparator - Variable in class com.google.common.collect.ImmutableSortedSet
 
comparator() - Method in class com.google.common.collect.ImmutableSortedSet
Returns the comparator that orders the elements, which is Ordering.natural() when the natural ordering of the elements is used.
comparator - Variable in class com.google.common.collect.ImmutableSortedSet.SerializedForm
 
comparator - Variable in class com.google.common.collect.Maps.DescendingMap
 
comparator() - Method in class com.google.common.collect.Maps.DescendingMap
 
comparator() - Method in class com.google.common.collect.Maps.FilteredEntryNavigableMap
 
comparator() - Method in class com.google.common.collect.Maps.FilteredEntrySortedMap
 
comparator() - Method in class com.google.common.collect.Maps.FilteredEntrySortedMap.SortedKeySet
 
comparator() - Method in class com.google.common.collect.Maps.NavigableAsMapView
 
comparator() - Method in class com.google.common.collect.Maps.SortedAsMapView
 
comparator() - Method in class com.google.common.collect.Maps.SortedKeySet
 
comparator() - Method in class com.google.common.collect.Maps.TransformedEntriesSortedMap
 
comparator - Variable in class com.google.common.collect.MinMaxPriorityQueue.Builder
 
comparator() - Method in class com.google.common.collect.MinMaxPriorityQueue
Returns the comparator used to order the elements in this queue.
comparator - Variable in class com.google.common.collect.MultimapBuilder.TreeSetSupplier
 
comparator() - Method in class com.google.common.collect.Sets.DescendingSet
 
comparator() - Method in class com.google.common.collect.Sets.FilteredSortedSet
 
comparator() - Method in interface com.google.common.collect.SortedIterable
Returns the Comparator by which the elements of this iterable are ordered, or Ordering.natural() if the elements are ordered by their natural ordering.
comparator(SortedSet<E>) - Static method in class com.google.common.collect.SortedIterables
 
comparator() - Method in interface com.google.common.collect.SortedMultiset
Returns the comparator that orders this multiset, or Ordering.natural() if the natural ordering of the elements is used.
comparator() - Method in class com.google.common.collect.SortedMultisets.ElementSet
 
comparator() - Method in class com.google.common.collect.StandardRowSortedTable.RowSortedMap
 
comparator() - Method in class com.google.common.collect.Synchronized.SynchronizedSortedMap
 
comparator() - Method in class com.google.common.collect.Synchronized.SynchronizedSortedSet
 
comparator - Variable in class com.google.common.collect.TreeBasedTable.Factory
 
comparator() - Method in class com.google.common.collect.TreeBasedTable.TreeRow
 
comparator() - Method in class com.google.common.collect.TreeRangeSet.ComplementRangesByLowerBound
 
comparator() - Method in class com.google.common.collect.TreeRangeSet.RangesByUpperBound
 
comparator() - Method in class com.google.common.collect.TreeRangeSet.SubRangeSetRangesByLowerBound
 
comparator() - Method in class com.google.common.collect.UnmodifiableSortedMultiset
 
ComparatorOrdering<T> - Class in com.google.common.collect
An ordering for a pre-existing comparator.
ComparatorOrdering(Comparator<T>) - Constructor for class com.google.common.collect.ComparatorOrdering
 
comparators - Variable in class com.google.common.collect.CompoundOrdering
 
compare(Object, Object) - Method in class com.google.common.collect.AllEqualOrdering
 
compare(F, F) - Method in class com.google.common.collect.ByFunctionOrdering
 
compare(T, T) - Method in class com.google.common.collect.ComparatorOrdering
 
compare(Comparable<?>, Comparable<?>) - Method in class com.google.common.collect.ComparisonChain
Compares two comparable objects as specified by Comparable.compareTo(T), if the result of this comparison chain has not already been determined.
compare(T, T, Comparator<T>) - Method in class com.google.common.collect.ComparisonChain
Compares two objects using a comparator, if the result of this comparison chain has not already been determined.
compare(int, int) - Method in class com.google.common.collect.ComparisonChain
Compares two int values as specified by Ints.compare(int, int), if the result of this comparison chain has not already been determined.
compare(long, long) - Method in class com.google.common.collect.ComparisonChain
Compares two long values as specified by Longs.compare(long, long), if the result of this comparison chain has not already been determined.
compare(float, float) - Method in class com.google.common.collect.ComparisonChain
Compares two float values as specified by Float.compare(float, float), if the result of this comparison chain has not already been determined.
compare(double, double) - Method in class com.google.common.collect.ComparisonChain
Compares two double values as specified by Double.compare(double, double), if the result of this comparison chain has not already been determined.
compare(Comparable, Comparable) - Method in class com.google.common.collect.ComparisonChain.InactiveComparisonChain
 
compare(T, T, Comparator<T>) - Method in class com.google.common.collect.ComparisonChain.InactiveComparisonChain
 
compare(int, int) - Method in class com.google.common.collect.ComparisonChain.InactiveComparisonChain
 
compare(long, long) - Method in class com.google.common.collect.ComparisonChain.InactiveComparisonChain
 
compare(float, float) - Method in class com.google.common.collect.ComparisonChain.InactiveComparisonChain
 
compare(double, double) - Method in class com.google.common.collect.ComparisonChain.InactiveComparisonChain
 
compare(T, T) - Method in class com.google.common.collect.CompoundOrdering
 
compare(T, T) - Method in class com.google.common.collect.ExplicitOrdering
 
compare(Iterable<T>, Iterable<T>) - Method in class com.google.common.collect.LexicographicalOrdering
 
compare(Comparable, Comparable) - Method in class com.google.common.collect.NaturalOrdering
 
compare(T, T) - Method in class com.google.common.collect.NullsFirstOrdering
 
compare(T, T) - Method in class com.google.common.collect.NullsLastOrdering
 
compare(Object, Object) - Method in class com.google.common.collect.Ordering.ArbitraryOrdering
 
compare(T, T) - Method in class com.google.common.collect.Ordering
 
compare(Comparable, Comparable) - Method in class com.google.common.collect.ReverseNaturalOrdering
 
compare(T, T) - Method in class com.google.common.collect.ReverseOrdering
 
compare(Object, Object) - Method in class com.google.common.collect.TreeBasedTable.TreeRow
 
compare(Object, Object) - Method in class com.google.common.collect.UsingToStringOrdering
 
compare(boolean, boolean) - Static method in class com.google.common.primitives.Booleans
Compares the two specified boolean values in the standard way (false is considered less than true).
compare(boolean[], boolean[]) - Method in enum com.google.common.primitives.Booleans.LexicographicalComparator
 
compare(char, char) - Static method in class com.google.common.primitives.Chars
Compares the two specified char values.
compare(char[], char[]) - Method in enum com.google.common.primitives.Chars.LexicographicalComparator
 
compare(double, double) - Static method in class com.google.common.primitives.Doubles
Compares the two specified double values.
compare(double[], double[]) - Method in enum com.google.common.primitives.Doubles.LexicographicalComparator
 
compare(float, float) - Static method in class com.google.common.primitives.Floats
Compares the two specified float values using Float.compare(float, float).
compare(float[], float[]) - Method in enum com.google.common.primitives.Floats.LexicographicalComparator
 
compare(int, int) - Static method in class com.google.common.primitives.Ints
Compares the two specified int values.
compare(int[], int[]) - Method in enum com.google.common.primitives.Ints.LexicographicalComparator
 
compare(long, long) - Static method in class com.google.common.primitives.Longs
Compares the two specified long values.
compare(long[], long[]) - Method in enum com.google.common.primitives.Longs.LexicographicalComparator
 
compare(short, short) - Static method in class com.google.common.primitives.Shorts
Compares the two specified short values.
compare(short[], short[]) - Method in enum com.google.common.primitives.Shorts.LexicographicalComparator
 
compare(byte, byte) - Static method in class com.google.common.primitives.SignedBytes
Compares the two specified byte values.
compare(byte[], byte[]) - Method in enum com.google.common.primitives.SignedBytes.LexicographicalComparator
 
compare(byte, byte) - Static method in class com.google.common.primitives.UnsignedBytes
Compares the two specified byte values, treating them as unsigned values between 0 and 255 inclusive.
compare(byte[], byte[]) - Method in enum com.google.common.primitives.UnsignedBytes.LexicographicalComparatorHolder.PureJavaComparator
 
compare(byte[], byte[]) - Method in enum com.google.common.primitives.UnsignedBytes.LexicographicalComparatorHolder.UnsafeComparator
 
compare(int, int) - Static method in class com.google.common.primitives.UnsignedInts
Compares the two specified int values, treating them as unsigned values between 0 and 2^32 - 1 inclusive.
compare(int[], int[]) - Method in enum com.google.common.primitives.UnsignedInts.LexicographicalComparator
 
compare(long, long) - Static method in class com.google.common.primitives.UnsignedLongs
Compares the two specified long values, treating them as unsigned values between 0 and 2^64 - 1 inclusive.
compare(long[], long[]) - Method in enum com.google.common.primitives.UnsignedLongs.LexicographicalComparator
 
compareAndSet(double, double) - Method in class com.google.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.google.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.
compareElements(int, int) - Method in class com.google.common.collect.MinMaxPriorityQueue.Heap
 
compareFalseFirst(boolean, boolean) - Method in class com.google.common.collect.ComparisonChain
Compares two boolean values, considering false to be less than true, if the result of this comparison chain has not already been determined.
compareFalseFirst(boolean, boolean) - Method in class com.google.common.collect.ComparisonChain.InactiveComparisonChain
 
compareOrThrow(Comparable, Comparable) - Static method in class com.google.common.collect.Range
 
compareTo(Cut<Comparable<?>>) - Method in class com.google.common.collect.Cut.AboveAll
 
compareTo(Cut<Comparable<?>>) - Method in class com.google.common.collect.Cut.BelowAll
 
compareTo(Cut<C>) - Method in class com.google.common.collect.Cut
 
compareTo(UnsignedInteger) - Method in class com.google.common.primitives.UnsignedInteger
Compares this unsigned integer to another unsigned integer.
compareTo(UnsignedLong) - Method in class com.google.common.primitives.UnsignedLong
 
compareTo(Delayed) - Method in class com.google.common.util.concurrent.MoreExecutors.ScheduledListeningDecorator.ListenableScheduledTask
 
compareTrueFirst(boolean, boolean) - Method in class com.google.common.collect.ComparisonChain
Compares two boolean values, considering true to be less than false, if the result of this comparison chain has not already been determined.
compareTrueFirst(boolean, boolean) - Method in class com.google.common.collect.ComparisonChain.InactiveComparisonChain
 
ComparisonChain - Class in com.google.common.collect
A utility for performing a chained comparison statement.
ComparisonChain() - Constructor for class com.google.common.collect.ComparisonChain
 
ComparisonChain.InactiveComparisonChain - Class in com.google.common.collect
 
complement - Variable in class com.google.common.collect.ImmutableRangeSet
 
complement() - Method in class com.google.common.collect.ImmutableRangeSet
 
complement() - Method in interface com.google.common.collect.RangeSet
Returns a view of the complement of this RangeSet.
complement - Variable in class com.google.common.collect.TreeRangeSet
 
complement() - Method in class com.google.common.collect.TreeRangeSet
 
Complement() - Constructor for class com.google.common.collect.TreeRangeSet.Complement
 
complement() - Method in class com.google.common.collect.TreeRangeSet.Complement
 
complementLowerBoundWindow - Variable in class com.google.common.collect.TreeRangeSet.ComplementRangesByLowerBound
complementLowerBoundWindow represents the headMap/subMap/tailMap view of the entire "complement ranges by lower bound" map; it's a constraint on the *keys*, and does not affect the values.
complementOf(Collection<E>) - Static method in class com.google.common.collect.Sets
Creates an EnumSet consisting of all enum values that are not in the specified collection.
complementOf(Collection<E>, Class<E>) - Static method in class com.google.common.collect.Sets
Creates an EnumSet consisting of all enum values that are not in the specified collection.
ComplementRanges() - Constructor for class com.google.common.collect.ImmutableRangeSet.ComplementRanges
 
ComplementRangesByLowerBound(NavigableMap<Cut<C>, Range<C>>) - Constructor for class com.google.common.collect.TreeRangeSet.ComplementRangesByLowerBound
 
ComplementRangesByLowerBound(NavigableMap<Cut<C>, Range<C>>, Range<Cut<C>>) - Constructor for class com.google.common.collect.TreeRangeSet.ComplementRangesByLowerBound
 
complete(V, Throwable, int) - Method in class com.google.common.util.concurrent.AbstractFuture.Sync
Implementation of completing a task.
COMPLETED - Static variable in class com.google.common.util.concurrent.AbstractFuture.Sync
 
COMPLETING - Static variable in class com.google.common.util.concurrent.AbstractFuture.Sync
 
components - Variable in class com.google.common.base.Predicates.AndPredicate
 
components - Variable in class com.google.common.base.Predicates.OrPredicate
 
componentType - Variable in class com.google.common.reflect.Types.GenericArrayTypeImpl
 
compose(Function<B, C>, Function<A, ? extends B>) - Static method in class com.google.common.base.Functions
Returns the composition of two functions.
compose(Predicate<B>, Function<A, ? extends B>) - Static method in class com.google.common.base.Predicates
Returns the composition of a function and a predicate.
compose(Function<? super F, T>, Supplier<F>) - Static method in class com.google.common.base.Suppliers
Returns a new supplier which is the composition of the provided function and supplier.
CompositionPredicate(Predicate<B>, Function<A, ? extends B>) - Constructor for class com.google.common.base.Predicates.CompositionPredicate
 
compound(Comparator<? super U>) - Method in class com.google.common.collect.Ordering
Returns an ordering which first uses the ordering this, but which in the event of a "tie", then delegates to secondaryComparator.
compound(Iterable<? extends Comparator<? super T>>) - Static method in class com.google.common.collect.Ordering
Returns an ordering which tries each given comparator in order until a non-zero result is found, returning that result, and returning zero only if all comparators return zero.
CompoundOrdering<T> - Class in com.google.common.collect
An ordering that tries several comparators in order.
CompoundOrdering(Comparator<? super T>, Comparator<? super T>) - Constructor for class com.google.common.collect.CompoundOrdering
 
CompoundOrdering(Iterable<? extends Comparator<? super T>>) - Constructor for class com.google.common.collect.CompoundOrdering
 
compressLongestRunOfZeroes(int[]) - Static method in class com.google.common.net.InetAddresses
Identify and mark the longest run of zeroes in an IPv6 address.
ComputationException - Exception in com.google.common.collect
Wraps an exception that occurred during a computation.
ComputationException(Throwable) - Constructor for exception com.google.common.collect.ComputationException
Creates a new instance with the given cause.
ComputationExceptionReference(Throwable) - Constructor for class com.google.common.collect.ComputingConcurrentHashMap.ComputationExceptionReference
 
compute(K, int, MapMakerInternalMap.ReferenceEntry<K, V>, ComputingConcurrentHashMap.ComputingValueReference<K, V>) - Method in class com.google.common.collect.ComputingConcurrentHashMap.ComputingSegment
 
compute(K, int) - Method in class com.google.common.collect.ComputingConcurrentHashMap.ComputingValueReference
 
compute(K) - Method in class com.google.common.collect.MapMaker.NullComputingConcurrentMap
 
computeArrayListCapacity(int) - Static method in class com.google.common.collect.Lists
 
computeBackingRowMap() - Method in class com.google.common.collect.StandardTable.Row
 
computeBackingRowMap() - Method in class com.google.common.collect.TreeBasedTable.TreeRow
 
ComputedReference(V) - Constructor for class com.google.common.collect.ComputingConcurrentHashMap.ComputedReference
 
computedReference - Variable in class com.google.common.collect.ComputingConcurrentHashMap.ComputingValueReference
 
computeNext() - Method in class com.google.common.base.AbstractIterator
 
computeNext() - Method in class com.google.common.base.Splitter.SplittingIterator
 
computeNext() - Method in class com.google.common.collect.AbstractIterator
Returns the next element.
computeNext(T) - Method in class com.google.common.collect.AbstractSequentialIterator
Returns the element that follows previous, or returns null if no elements remain.
computeNext() - Method in class com.google.common.collect.BinaryTreeTraverser.InOrderIterator
 
computeNext() - Method in class com.google.common.collect.Collections2.OrderedPermutationIterator
 
computeNext() - Method in class com.google.common.collect.Collections2.PermutationIterator
 
computeNext() - Method in class com.google.common.collect.Iterables.ConsumingQueueIterator
 
computeNext() - Method in class com.google.common.collect.StandardTable.Column.EntrySetIterator
 
computeNext() - Method in class com.google.common.collect.StandardTable.ColumnKeyIterator
 
computeNext() - Method in class com.google.common.collect.TreeTraverser.PostOrderIterator
 
computeReplacement(CharEscaper, char) - Static method in class com.google.common.escape.Escapers
Returns a string that would replace the given character in the specified escaper, or null if no replacement should be made.
computeReplacement(UnicodeEscaper, int) - Static method in class com.google.common.escape.Escapers
Returns a string that would replace the given character in the specified escaper, or null if no replacement should be made.
ComputingConcurrentHashMap<K,V> - Class in com.google.common.collect
Adds computing functionality to MapMakerInternalMap.
ComputingConcurrentHashMap(MapMaker, Function<? super K, ? extends V>) - Constructor for class com.google.common.collect.ComputingConcurrentHashMap
Creates a new, empty map with the specified strategy, initial capacity, load factor and concurrency level.
ComputingConcurrentHashMap.ComputationExceptionReference<K,V> - Class in com.google.common.collect
Used to provide computation exceptions to other threads.
ComputingConcurrentHashMap.ComputedReference<K,V> - Class in com.google.common.collect
Used to provide computation result to other threads.
ComputingConcurrentHashMap.ComputingSegment<K,V> - Class in com.google.common.collect
 
ComputingConcurrentHashMap.ComputingSerializationProxy<K,V> - Class in com.google.common.collect
 
ComputingConcurrentHashMap.ComputingValueReference<K,V> - Class in com.google.common.collect
 
computingFunction - Variable in class com.google.common.cache.CacheLoader.FunctionToCacheLoader
 
computingFunction - Variable in class com.google.common.collect.ComputingConcurrentHashMap
 
computingFunction - Variable in class com.google.common.collect.ComputingConcurrentHashMap.ComputingSerializationProxy
 
computingFunction - Variable in class com.google.common.collect.ComputingConcurrentHashMap.ComputingValueReference
 
computingFunction - Variable in class com.google.common.collect.MapMaker.NullComputingConcurrentMap
 
ComputingMapAdapter(MapMaker, Function<? super K, ? extends V>) - Constructor for class com.google.common.collect.MapMaker.ComputingMapAdapter
 
ComputingSegment(MapMakerInternalMap<K, V>, int, int) - Constructor for class com.google.common.collect.ComputingConcurrentHashMap.ComputingSegment
 
ComputingSerializationProxy(MapMakerInternalMap.Strength, MapMakerInternalMap.Strength, Equivalence<Object>, Equivalence<Object>, long, long, int, int, MapMaker.RemovalListener<? super K, ? super V>, ConcurrentMap<K, V>, Function<? super K, ? extends V>) - Constructor for class com.google.common.collect.ComputingConcurrentHashMap.ComputingSerializationProxy
 
computingSupplier - Variable in class com.google.common.cache.CacheLoader.SupplierToCacheLoader
 
ComputingValueReference(Function<? super K, ? extends V>) - Constructor for class com.google.common.collect.ComputingConcurrentHashMap.ComputingValueReference
 
concat(Iterable<? extends T>, Iterable<? extends T>) - Static method in class com.google.common.collect.Iterables
Combines two iterables into a single iterable.
concat(Iterable<? extends T>, Iterable<? extends T>, Iterable<? extends T>) - Static method in class com.google.common.collect.Iterables
Combines three iterables into a single iterable.
concat(Iterable<? extends T>, Iterable<? extends T>, Iterable<? extends T>, Iterable<? extends T>) - Static method in class com.google.common.collect.Iterables
Combines four iterables into a single iterable.
concat(Iterable<? extends T>...) - Static method in class com.google.common.collect.Iterables
Combines multiple iterables into a single iterable.
concat(Iterable<? extends Iterable<? extends T>>) - Static method in class com.google.common.collect.Iterables
Combines multiple iterables into a single iterable.
concat(Iterator<? extends T>, Iterator<? extends T>) - Static method in class com.google.common.collect.Iterators
Combines two iterators into a single iterator.
concat(Iterator<? extends T>, Iterator<? extends T>, Iterator<? extends T>) - Static method in class com.google.common.collect.Iterators
Combines three iterators into a single iterator.
concat(Iterator<? extends T>, Iterator<? extends T>, Iterator<? extends T>, Iterator<? extends T>) - Static method in class com.google.common.collect.Iterators
Combines four iterators into a single iterator.
concat(Iterator<? extends T>...) - Static method in class com.google.common.collect.Iterators
Combines multiple iterators into a single iterator.
concat(Iterator<? extends Iterator<? extends T>>) - Static method in class com.google.common.collect.Iterators
Combines multiple iterators into a single iterator.
concat(T[], T[], Class<T>) - Static method in class com.google.common.collect.ObjectArrays
Returns a new array that contains the concatenated contents of two arrays.
concat(T, T[]) - Static method in class com.google.common.collect.ObjectArrays
Returns a new array that prepends element to array.
concat(T[], T) - Static method in class com.google.common.collect.ObjectArrays
Returns a new array that appends element to array.
concat(Iterable<? extends ByteSource>) - Static method in class com.google.common.io.ByteSource
Concatenates multiple ByteSource instances into a single source.
concat(Iterator<? extends ByteSource>) - Static method in class com.google.common.io.ByteSource
Concatenates multiple ByteSource instances into a single source.
concat(ByteSource...) - Static method in class com.google.common.io.ByteSource
Concatenates multiple ByteSource instances into a single source.
concat(Iterable<? extends CharSource>) - Static method in class com.google.common.io.CharSource
Concatenates multiple CharSource instances into a single source.
concat(Iterator<? extends CharSource>) - Static method in class com.google.common.io.CharSource
Concatenates multiple CharSource instances into a single source.
concat(CharSource...) - Static method in class com.google.common.io.CharSource
Concatenates multiple CharSource instances into a single source.
concat(boolean[]...) - Static method in class com.google.common.primitives.Booleans
Returns the values from each provided array combined into a single array.
concat(byte[]...) - Static method in class com.google.common.primitives.Bytes
Returns the values from each provided array combined into a single array.
concat(char[]...) - Static method in class com.google.common.primitives.Chars
Returns the values from each provided array combined into a single array.
concat(double[]...) - Static method in class com.google.common.primitives.Doubles
Returns the values from each provided array combined into a single array.
concat(float[]...) - Static method in class com.google.common.primitives.Floats
Returns the values from each provided array combined into a single array.
concat(int[]...) - Static method in class com.google.common.primitives.Ints
Returns the values from each provided array combined into a single array.
concat(long[]...) - Static method in class com.google.common.primitives.Longs
Returns the values from each provided array combined into a single array.
concat(short[]...) - Static method in class com.google.common.primitives.Shorts
Returns the values from each provided array combined into a single array.
ConcatenatedByteSource(Iterable<? extends ByteSource>) - Constructor for class com.google.common.io.ByteSource.ConcatenatedByteSource
 
ConcatenatedCharSource(Iterable<? extends CharSource>) - Constructor for class com.google.common.io.CharSource.ConcatenatedCharSource
 
ConcatenatedHashFunction(HashFunction...) - Constructor for class com.google.common.hash.Hashing.ConcatenatedHashFunction
 
concurrencyLevel - Variable in class com.google.common.cache.CacheBuilder
 
concurrencyLevel(int) - Method in class com.google.common.cache.CacheBuilder
Guides the allowed concurrency among update operations.
concurrencyLevel - Variable in class com.google.common.cache.CacheBuilderSpec
 
concurrencyLevel - Variable in class com.google.common.cache.LocalCache
The concurrency level.
concurrencyLevel - Variable in class com.google.common.cache.LocalCache.ManualSerializationProxy
 
concurrencyLevel(int) - Method in class com.google.common.collect.GenericMapMaker
Deprecated.
concurrencyLevel - Variable in class com.google.common.collect.MapMaker
 
concurrencyLevel(int) - Method in class com.google.common.collect.MapMaker
Guides the allowed concurrency among update operations.
concurrencyLevel - Variable in class com.google.common.collect.MapMakerInternalMap.AbstractSerializationProxy
 
concurrencyLevel - Variable in class com.google.common.collect.MapMakerInternalMap
The concurrency level.
ConcurrencyLevelParser() - Constructor for class com.google.common.cache.CacheBuilderSpec.ConcurrencyLevelParser
 
ConcurrentHashMultiset<E> - Class in com.google.common.collect
A multiset that supports concurrent modifications and that provides atomic versions of most Multiset operations (exceptions where noted).
ConcurrentHashMultiset(ConcurrentMap<E, AtomicInteger>) - Constructor for class com.google.common.collect.ConcurrentHashMultiset
Creates an instance using countMap to store elements and their counts.
ConcurrentHashMultiset.EntrySet - Class in com.google.common.collect
 
ConcurrentHashMultiset.FieldSettersHolder - Class in com.google.common.collect
 
condition - Variable in class com.google.common.util.concurrent.Monitor.Guard
 
conflictingStackTrace - Variable in exception com.google.common.util.concurrent.CycleDetectingLockFactory.PotentialDeadlockException
 
connectAccessOrder(LocalCache.ReferenceEntry<K, V>, LocalCache.ReferenceEntry<K, V>) - Static method in class com.google.common.cache.LocalCache
 
connectEvictables(MapMakerInternalMap.ReferenceEntry<K, V>, MapMakerInternalMap.ReferenceEntry<K, V>) - Static method in class com.google.common.collect.MapMakerInternalMap
Links the evitables together.
connectExpirables(MapMakerInternalMap.ReferenceEntry<K, V>, MapMakerInternalMap.ReferenceEntry<K, V>) - Static method in class com.google.common.collect.MapMakerInternalMap
 
CONNECTION - Static variable in class com.google.common.net.HttpHeaders
The HTTP Connection header field name.
connectWriteOrder(LocalCache.ReferenceEntry<K, V>, LocalCache.ReferenceEntry<K, V>) - Static method in class com.google.common.cache.LocalCache
 
consistentHash(HashCode, int) - Static method in class com.google.common.hash.Hashing
Assigns to hashCode a "bucket" in the range [0, buckets), in a uniform manner that minimizes the need for remapping as buckets grows.
consistentHash(long, int) - Static method in class com.google.common.hash.Hashing
Assigns to input a "bucket" in the range [0, buckets), in a uniform manner that minimizes the need for remapping as buckets grows.
constant(E) - Static method in class com.google.common.base.Functions
Creates a function that returns value for any input.
ConstantFunction(E) - Constructor for class com.google.common.base.Functions.ConstantFunction
 
constrainedAsMapEntries(Set<Map.Entry<K, Collection<V>>>, MapConstraint<? super K, ? super V>) - Static method in class com.google.common.collect.MapConstraints
Returns a constrained view of the specified set of asMap entries, using the specified constraint.
ConstrainedAsMapEntries(Set<Map.Entry<K, Collection<V>>>, MapConstraint<? super K, ? super V>) - Constructor for class com.google.common.collect.MapConstraints.ConstrainedAsMapEntries
 
constrainedAsMapEntry(Map.Entry<K, Collection<V>>, MapConstraint<? super K, ? super V>) - Static method in class com.google.common.collect.MapConstraints
Returns a constrained view of the specified asMap entry, using the specified constraint.
ConstrainedAsMapValues(Collection<Collection<V>>, Set<Map.Entry<K, Collection<V>>>) - Constructor for class com.google.common.collect.MapConstraints.ConstrainedAsMapValues
 
constrainedBiMap(BiMap<K, V>, MapConstraint<? super K, ? super V>) - Static method in class com.google.common.collect.MapConstraints
Returns a constrained view of the specified bimap, using the specified constraint.
ConstrainedBiMap(BiMap<K, V>, BiMap<V, K>, MapConstraint<? super K, ? super V>) - Constructor for class com.google.common.collect.MapConstraints.ConstrainedBiMap
 
constrainedCollection(Collection<E>, Constraint<? super E>) - Static method in class com.google.common.collect.Constraints
Returns a constrained view of the specified collection, using the specified constraint.
ConstrainedCollection(Collection<E>, Constraint<? super E>) - Constructor for class com.google.common.collect.Constraints.ConstrainedCollection
 
constrainedEntries(Collection<Map.Entry<K, V>>, MapConstraint<? super K, ? super V>) - Static method in class com.google.common.collect.MapConstraints
Returns a constrained view of the specified collection (or set) of entries, using the specified constraint.
ConstrainedEntries(Collection<Map.Entry<K, V>>, MapConstraint<? super K, ? super V>) - Constructor for class com.google.common.collect.MapConstraints.ConstrainedEntries
 
constrainedEntry(Map.Entry<K, V>, MapConstraint<? super K, ? super V>) - Static method in class com.google.common.collect.MapConstraints
Returns a constrained view of the specified entry, using the specified constraint.
constrainedEntrySet(Set<Map.Entry<K, V>>, MapConstraint<? super K, ? super V>) - Static method in class com.google.common.collect.MapConstraints
Returns a constrained view of the specified set of entries, using the specified constraint.
ConstrainedEntrySet(Set<Map.Entry<K, V>>, MapConstraint<? super K, ? super V>) - Constructor for class com.google.common.collect.MapConstraints.ConstrainedEntrySet
 
constrainedList(List<E>, Constraint<? super E>) - Static method in class com.google.common.collect.Constraints
Returns a constrained view of the specified list, using the specified constraint.
ConstrainedList(List<E>, Constraint<? super E>) - Constructor for class com.google.common.collect.Constraints.ConstrainedList
 
constrainedListIterator(ListIterator<E>, Constraint<? super E>) - Static method in class com.google.common.collect.Constraints
Returns a constrained view of the specified list iterator, using the specified constraint.
ConstrainedListIterator(ListIterator<E>, Constraint<? super E>) - Constructor for class com.google.common.collect.Constraints.ConstrainedListIterator
 
constrainedListMultimap(ListMultimap<K, V>, MapConstraint<? super K, ? super V>) - Static method in class com.google.common.collect.MapConstraints
Returns a constrained view of the specified list multimap, using the specified constraint.
ConstrainedListMultimap(ListMultimap<K, V>, MapConstraint<? super K, ? super V>) - Constructor for class com.google.common.collect.MapConstraints.ConstrainedListMultimap
 
constrainedMap(Map<K, V>, MapConstraint<? super K, ? super V>) - Static method in class com.google.common.collect.MapConstraints
Returns a constrained view of the specified map, using the specified constraint.
ConstrainedMap(Map<K, V>, MapConstraint<? super K, ? super V>) - Constructor for class com.google.common.collect.MapConstraints.ConstrainedMap
 
constrainedMultimap(Multimap<K, V>, MapConstraint<? super K, ? super V>) - Static method in class com.google.common.collect.MapConstraints
Returns a constrained view of the specified multimap, using the specified constraint.
ConstrainedMultimap(Multimap<K, V>, MapConstraint<? super K, ? super V>) - Constructor for class com.google.common.collect.MapConstraints.ConstrainedMultimap
 
ConstrainedRandomAccessList(List<E>, Constraint<? super E>) - Constructor for class com.google.common.collect.Constraints.ConstrainedRandomAccessList
 
constrainedSet(Set<E>, Constraint<? super E>) - Static method in class com.google.common.collect.Constraints
Returns a constrained view of the specified set, using the specified constraint.
ConstrainedSet(Set<E>, Constraint<? super E>) - Constructor for class com.google.common.collect.Constraints.ConstrainedSet
 
constrainedSetMultimap(SetMultimap<K, V>, MapConstraint<? super K, ? super V>) - Static method in class com.google.common.collect.MapConstraints
Returns a constrained view of the specified set multimap, using the specified constraint.
ConstrainedSetMultimap(SetMultimap<K, V>, MapConstraint<? super K, ? super V>) - Constructor for class com.google.common.collect.MapConstraints.ConstrainedSetMultimap
 
constrainedSortedSet(SortedSet<E>, Constraint<? super E>) - Static method in class com.google.common.collect.Constraints
Returns a constrained view of the specified sorted set, using the specified constraint.
ConstrainedSortedSet(SortedSet<E>, Constraint<? super E>) - Constructor for class com.google.common.collect.Constraints.ConstrainedSortedSet
 
constrainedSortedSetMultimap(SortedSetMultimap<K, V>, MapConstraint<? super K, ? super V>) - Static method in class com.google.common.collect.MapConstraints
Returns a constrained view of the specified sorted-set multimap, using the specified constraint.
ConstrainedSortedSetMultimap(SortedSetMultimap<K, V>, MapConstraint<? super K, ? super V>) - Constructor for class com.google.common.collect.MapConstraints.ConstrainedSortedSetMultimap
 
constrainedTypePreservingCollection(Collection<E>, Constraint<E>) - Static method in class com.google.common.collect.Constraints
 
Constraint<E> - Interface in com.google.common.collect
A constraint that an element must satisfy in order to be added to a collection.
constraint - Variable in class com.google.common.collect.Constraints.ConstrainedCollection
 
constraint - Variable in class com.google.common.collect.Constraints.ConstrainedList
 
constraint - Variable in class com.google.common.collect.Constraints.ConstrainedListIterator
 
constraint - Variable in class com.google.common.collect.Constraints.ConstrainedSet
 
constraint - Variable in class com.google.common.collect.Constraints.ConstrainedSortedSet
 
constraint - Variable in class com.google.common.collect.MapConstraints.ConstrainedAsMapEntries
 
constraint - Variable in class com.google.common.collect.MapConstraints.ConstrainedEntries
 
constraint - Variable in class com.google.common.collect.MapConstraints.ConstrainedMap
 
constraint - Variable in class com.google.common.collect.MapConstraints.ConstrainedMultimap
 
constraint - Variable in class com.google.common.collect.MapConstraints.InverseConstraint
 
Constraints - Class in com.google.common.collect
Factories and utilities pertaining to the Constraint interface.
Constraints() - Constructor for class com.google.common.collect.Constraints
 
Constraints.ConstrainedCollection<E> - Class in com.google.common.collect
 
Constraints.ConstrainedList<E> - Class in com.google.common.collect
 
Constraints.ConstrainedListIterator<E> - Class in com.google.common.collect
 
Constraints.ConstrainedRandomAccessList<E> - Class in com.google.common.collect
 
Constraints.ConstrainedSet<E> - Class in com.google.common.collect
 
Constraints.ConstrainedSortedSet<E> - Class in com.google.common.collect
 
construct(Object...) - Static method in class com.google.common.collect.ImmutableList
Views the array as an immutable list.
construct(int, Object...) - Static method in class com.google.common.collect.ImmutableSet
Constructs an ImmutableSet from the first n elements of the specified array.
construct(Comparator<? super E>, int, E...) - Static method in class com.google.common.collect.ImmutableSortedSet
Constructs an ImmutableSortedSet from the first n elements of contents.
constructor - Variable in class com.google.common.reflect.Invokable.ConstructorInvokable
 
constructor(Constructor<?>) - Method in class com.google.common.reflect.TypeToken
Returns the Invokable for constructor, which must be a member of T.
ConstructorInvokable(Constructor<?>) - Constructor for class com.google.common.reflect.Invokable.ConstructorInvokable
 
consumeCharacter(CharMatcher) - Method in class com.google.common.net.MediaType.Tokenizer
 
consumeCharacter(char) - Method in class com.google.common.net.MediaType.Tokenizer
 
consumeToken(CharMatcher) - Method in class com.google.common.net.MediaType.Tokenizer
 
consumeTokenIfPresent(CharMatcher) - Method in class com.google.common.net.MediaType.Tokenizer
 
consumingIterable(Iterable<T>) - Static method in class com.google.common.collect.Iterables
Returns a view of the supplied iterable that wraps each generated Iterator through Iterators.consumingIterator(Iterator).
consumingIterator(Iterator<T>) - Static method in class com.google.common.collect.Iterators
Returns a view of the supplied iterator that removes each element from the supplied iterator as it is returned.
ConsumingQueueIterator(Queue<T>) - Constructor for class com.google.common.collect.Iterables.ConsumingQueueIterator
 
contains(Pattern) - Static method in class com.google.common.base.Predicates
Returns a predicate that evaluates to true if the CharSequence being tested contains any match for the given regular expression pattern.
contains(Object) - Method in class com.google.common.cache.LocalCache.AccessQueue
 
contains(Object) - Method in class com.google.common.cache.LocalCache.EntrySet
 
contains(Object) - Method in class com.google.common.cache.LocalCache.KeySet
 
contains(Object) - Method in class com.google.common.cache.LocalCache.Values
 
contains(Object) - Method in class com.google.common.cache.LocalCache.WriteQueue
 
contains(Object) - Method in class com.google.common.collect.AbstractBiMap.EntrySet
 
contains(Object) - Method in class com.google.common.collect.AbstractMapBasedMultimap.AsMap.AsMapEntries
 
contains(Object) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection
 
contains(Object) - Method in class com.google.common.collect.AbstractMultimap.Values
 
contains(Object) - Method in class com.google.common.collect.AbstractMultiset
 
contains(C) - Method in class com.google.common.collect.AbstractRangeSet
 
contains(Object) - Method in class com.google.common.collect.AbstractTable.CellSet
 
contains(Object, Object) - Method in class com.google.common.collect.AbstractTable
 
contains(Object) - Method in class com.google.common.collect.AbstractTable.Values
 
contains(Object, Object) - Method in class com.google.common.collect.ArrayTable
Returns true if the provided keys are among the keys provided when the table was constructed.
contains(Object) - Method in class com.google.common.collect.CartesianList
 
contains(Object) - Method in class com.google.common.collect.Collections2.FilteredCollection
 
contains(Object) - Method in class com.google.common.collect.Collections2.OrderedPermutationCollection
 
contains(Object) - Method in class com.google.common.collect.Collections2.PermutationCollection
 
contains(Object) - Method in class com.google.common.collect.EmptyImmutableSet
 
contains(Object) - Method in class com.google.common.collect.EmptyImmutableSortedSet
 
contains(Object) - Method in class com.google.common.collect.EvictingQueue
 
contains(Object) - Method in class com.google.common.collect.FilteredMultimapValues
 
contains(Object) - Method in class com.google.common.collect.FluentIterable
Returns true if this fluent iterable contains any object for which equals(element) is true.
contains(Object) - Method in class com.google.common.collect.ForwardingCollection
 
contains(Object, Object) - Method in class com.google.common.collect.ForwardingTable
 
contains(T) - Method in class com.google.common.collect.GeneralRange
 
contains(Object, Object) - Method in class com.google.common.collect.HashBasedTable
 
contains(Object) - Method in class com.google.common.collect.ImmutableAsList
 
contains(Object) - Method in class com.google.common.collect.ImmutableCollection
 
contains(Object) - Method in class com.google.common.collect.ImmutableEnumSet
 
contains(Object) - Method in class com.google.common.collect.ImmutableList
 
contains(Object) - Method in class com.google.common.collect.ImmutableList.ReverseImmutableList
 
contains(Object) - Method in class com.google.common.collect.ImmutableMapEntrySet
 
contains(Object) - Method in class com.google.common.collect.ImmutableMapKeySet
 
contains(Object) - Method in class com.google.common.collect.ImmutableMapValues
 
contains(Object) - Method in class com.google.common.collect.ImmutableMultimap.EntryCollection
 
contains(Object) - Method in class com.google.common.collect.ImmutableMultimap.Keys
 
contains(Object) - Method in class com.google.common.collect.ImmutableMultimap.Values
 
contains(Object) - Method in class com.google.common.collect.ImmutableMultiset
 
contains(Object) - Method in class com.google.common.collect.ImmutableMultiset.EntrySet
 
contains(Object) - Method in class com.google.common.collect.ImmutableRangeSet.AsSet
 
contains(Object) - Method in class com.google.common.collect.ImmutableSetMultimap.EntrySet
 
contains(Object) - Method in class com.google.common.collect.ImmutableSortedAsList
 
contains(Object, Object) - Method in class com.google.common.collect.ImmutableTable
 
contains(Iterable<?>, Object) - Static method in class com.google.common.collect.Iterables
Returns true if iterable contains any object for which equals(element) is true.
contains(Iterator<?>, Object) - Static method in class com.google.common.collect.Iterators
Returns true if iterator contains element.
contains(Object) - Method in class com.google.common.collect.LinkedHashMultimap.ValueSet
 
contains(Object) - Method in class com.google.common.collect.Lists.AbstractListWrapper
 
contains(Object) - Method in class com.google.common.collect.MapConstraints.ConstrainedAsMapEntries
 
contains(Object) - Method in class com.google.common.collect.MapConstraints.ConstrainedAsMapValues
 
contains(Object) - Method in class com.google.common.collect.MapConstraints.ConstrainedEntries
 
contains(Object) - Method in class com.google.common.collect.MapMakerInternalMap.EntrySet
 
contains(Object) - Method in class com.google.common.collect.MapMakerInternalMap.EvictionQueue
 
contains(Object) - Method in class com.google.common.collect.MapMakerInternalMap.ExpirationQueue
 
contains(Object) - Method in class com.google.common.collect.MapMakerInternalMap.KeySet
 
contains(Object) - Method in class com.google.common.collect.MapMakerInternalMap.Values
 
contains(Object) - Method in class com.google.common.collect.Maps.EntrySet
 
contains(Object) - Method in class com.google.common.collect.Maps.KeySet
 
contains(Object) - Method in class com.google.common.collect.Maps.Values
 
contains(Object) - Method in class com.google.common.collect.Multimaps.Entries
 
contains(Object) - Method in class com.google.common.collect.Multimaps.Keys
 
contains(Object) - Method in class com.google.common.collect.Multimaps.Keys.KeysEntrySet
 
contains(Object) - Method in interface com.google.common.collect.Multiset
Determines whether this multiset contains the specified element.
contains(Object) - Method in class com.google.common.collect.Multisets.ElementSet
 
contains(Object) - Method in class com.google.common.collect.Multisets.EntrySet
 
contains(C) - Method in class com.google.common.collect.Range
Returns true if value is within the bounds of this range.
contains(C) - Method in interface com.google.common.collect.RangeSet
Determines whether any of this range set's member ranges contains value.
contains(Object) - Method in class com.google.common.collect.RegularContiguousSet
 
contains(Object) - Method in class com.google.common.collect.RegularImmutableMultiset
 
contains(Object) - Method in class com.google.common.collect.RegularImmutableSet
 
contains(Object) - Method in class com.google.common.collect.RegularImmutableSortedSet
 
contains(Object) - Method in class com.google.common.collect.RegularImmutableTable.CellSet
 
contains(Object) - Method in class com.google.common.collect.Sets.PowerSet
 
contains(Object) - Method in class com.google.common.collect.Sets.SubSet
 
contains(Object) - Method in class com.google.common.collect.SingletonImmutableList
 
contains(Object) - Method in class com.google.common.collect.SingletonImmutableSet
 
contains(Object) - Method in class com.google.common.collect.StandardTable.Column.EntrySet
 
contains(Object) - Method in class com.google.common.collect.StandardTable.Column.KeySet
 
contains(Object) - Method in class com.google.common.collect.StandardTable.ColumnKeySet
 
contains(Object) - Method in class com.google.common.collect.StandardTable.ColumnMap.ColumnMapEntrySet
 
contains(Object, Object) - Method in class com.google.common.collect.StandardTable
 
contains(Object) - Method in class com.google.common.collect.StandardTable.RowMap.EntrySet
 
contains(Object) - Method in class com.google.common.collect.Synchronized.SynchronizedAsMapEntries
 
contains(Object) - Method in class com.google.common.collect.Synchronized.SynchronizedCollection
 
contains(Object, Object) - Method in interface com.google.common.collect.Table
Returns true if the table contains a mapping with the specified row and column keys.
contains(Object, Object) - Method in class com.google.common.collect.Tables.TransformedTable
 
contains(Object, Object) - Method in class com.google.common.collect.Tables.TransposeTable
 
contains(K) - Method in class com.google.common.collect.TreeRangeMap.RangeMapEntry
 
contains(C) - Method in class com.google.common.collect.TreeRangeSet.Complement
 
contains(C) - Method in class com.google.common.collect.TreeRangeSet.SubRangeSet
 
contains(Object) - Method in class com.google.common.primitives.Booleans.BooleanArrayAsList
 
contains(boolean[], boolean) - Static method in class com.google.common.primitives.Booleans
Returns true if target is present as an element anywhere in array.
contains(Object) - Method in class com.google.common.primitives.Bytes.ByteArrayAsList
 
contains(byte[], byte) - Static method in class com.google.common.primitives.Bytes
Returns true if target is present as an element anywhere in array.
contains(Object) - Method in class com.google.common.primitives.Chars.CharArrayAsList
 
contains(char[], char) - Static method in class com.google.common.primitives.Chars
Returns true if target is present as an element anywhere in array.
contains(double[], double) - Static method in class com.google.common.primitives.Doubles
Returns true if target is present as an element anywhere in array.
contains(Object) - Method in class com.google.common.primitives.Doubles.DoubleArrayAsList
 
contains(float[], float) - Static method in class com.google.common.primitives.Floats
Returns true if target is present as an element anywhere in array.
contains(Object) - Method in class com.google.common.primitives.Floats.FloatArrayAsList
 
contains(int[], int) - Static method in class com.google.common.primitives.Ints
Returns true if target is present as an element anywhere in array.
contains(Object) - Method in class com.google.common.primitives.Ints.IntArrayAsList
 
contains(long[], long) - Static method in class com.google.common.primitives.Longs
Returns true if target is present as an element anywhere in array.
contains(Object) - Method in class com.google.common.primitives.Longs.LongArrayAsList
 
contains(short[], short) - Static method in class com.google.common.primitives.Shorts
Returns true if target is present as an element anywhere in array.
contains(Object) - Method in class com.google.common.primitives.Shorts.ShortArrayAsList
 
CONTAINS_VALUE_RETRIES - Static variable in class com.google.common.cache.LocalCache
Number of (unsynchronized) retries in the containsValue method.
CONTAINS_VALUE_RETRIES - Static variable in class com.google.common.collect.MapMakerInternalMap
Number of (unsynchronized) retries in the containsValue method.
containsAll(Collection<?>) - Method in class com.google.common.collect.AbstractBiMap.EntrySet
 
containsAll(Collection<?>) - Method in class com.google.common.collect.AbstractMapBasedMultimap.KeySet
 
containsAll(Collection<?>) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection
 
containsAll(Collection<?>) - Method in class com.google.common.collect.Collections2.FilteredCollection
 
containsAll(Collection<?>) - Method in class com.google.common.collect.EmptyImmutableSet
 
containsAll(Collection<?>) - Method in class com.google.common.collect.EmptyImmutableSortedMultiset
 
containsAll(Collection<?>) - Method in class com.google.common.collect.EmptyImmutableSortedSet
 
containsAll(Collection<?>) - Method in class com.google.common.collect.ForwardingCollection
 
containsAll(Collection<?>) - Method in class com.google.common.collect.ImmutableEnumSet
 
containsAll(Collection<?>) - Method in class com.google.common.collect.ImmutableMultiset
 
containsAll(Collection<?>) - Method in class com.google.common.collect.MapConstraints.ConstrainedAsMapEntries
 
containsAll(Collection<?>) - Method in class com.google.common.collect.MapConstraints.ConstrainedAsMapValues
 
containsAll(Collection<?>) - Method in class com.google.common.collect.MapConstraints.ConstrainedEntries
 
containsAll(Collection<?>) - Method in interface com.google.common.collect.Multiset
Returns true if this multiset contains at least one occurrence of each element in the specified collection.
containsAll(Collection<?>) - Method in class com.google.common.collect.Multisets.ElementSet
 
containsAll(Iterable<? extends C>) - Method in class com.google.common.collect.Range
Returns true if every element in values is contained in this range.
containsAll(Collection<?>) - Method in class com.google.common.collect.RegularContiguousSet
 
containsAll(Collection<?>) - Method in class com.google.common.collect.RegularImmutableSortedSet
 
containsAll(Collection<?>) - Method in class com.google.common.collect.Synchronized.SynchronizedAsMapEntries
 
containsAll(Collection<?>) - Method in class com.google.common.collect.Synchronized.SynchronizedCollection
 
containsAllImpl(Collection<?>, Collection<?>) - Static method in class com.google.common.collect.Collections2
Returns true if the collection self contains all of the elements in the collection c.
containsColumn(Object) - Method in class com.google.common.collect.AbstractTable
 
containsColumn(Object) - Method in class com.google.common.collect.ArrayTable
Returns true if the provided column key is among the column keys provided when the table was constructed.
containsColumn(Object) - Method in class com.google.common.collect.ForwardingTable
 
containsColumn(Object) - Method in class com.google.common.collect.HashBasedTable
 
containsColumn(Object) - Method in class com.google.common.collect.StandardTable
 
containsColumn(Object) - Method in interface com.google.common.collect.Table
Returns true if the table contains a mapping with the specified column.
containsColumn(Object) - Method in class com.google.common.collect.Tables.TransposeTable
 
containsEntry(Object, Object) - Method in class com.google.common.collect.AbstractMultimap
 
containsEntry(Object, Object) - Method in class com.google.common.collect.ForwardingMultimap
 
containsEntry(Object, Object) - Method in interface com.google.common.collect.Multimap
Returns true if this multimap contains at least one key-value pair with the key key and the value value.
containsEntry(Object, Object) - Method in class com.google.common.collect.Multimaps.MapMultimap
 
containsEntry(Object, Object) - Method in class com.google.common.collect.Synchronized.SynchronizedMultimap
 
containsEntryImpl(Collection<Map.Entry<K, V>>, Object) - Static method in class com.google.common.collect.Maps
Implements Collection.contains safely for forwarding collections of map entries.
containsExact(Iterable<E>, E) - Method in class com.google.common.collect.MinMaxPriorityQueue.QueueIterator
 
containsKey(Object) - Method in class com.google.common.cache.LocalCache
 
containsKey(Object, int) - Method in class com.google.common.cache.LocalCache.Segment
 
containsKey(Object) - Method in class com.google.common.collect.AbstractMapBasedMultimap.AsMap
 
containsKey(Object) - Method in class com.google.common.collect.AbstractMapBasedMultimap
 
containsKey(Object) - Method in class com.google.common.collect.ArrayTable.ArrayMap
 
containsKey(Object) - Method in class com.google.common.collect.FilteredEntryMultimap.AsMap
 
containsKey(Object) - Method in class com.google.common.collect.FilteredEntryMultimap
 
containsKey(Object) - Method in class com.google.common.collect.FilteredKeyMultimap
 
containsKey(Object) - Method in class com.google.common.collect.ForwardingMap
 
containsKey(Object) - Method in class com.google.common.collect.ForwardingMultimap
 
containsKey(Object) - Method in class com.google.common.collect.HashBiMap
 
containsKey(Object) - Method in class com.google.common.collect.HashBiMap.Inverse
 
containsKey(Object) - Method in class com.google.common.collect.ImmutableEnumMap
 
containsKey(Object) - Method in class com.google.common.collect.ImmutableMap
 
containsKey(Object) - Method in class com.google.common.collect.ImmutableMap.MapViewOfValuesAsSingletonSets
 
containsKey(Object) - Method in class com.google.common.collect.ImmutableMultimap
 
containsKey(Object) - Method in class com.google.common.collect.LinkedListMultimap
 
containsKey(Object) - Method in class com.google.common.collect.MapMaker.NullConcurrentMap
 
containsKey(Object) - Method in class com.google.common.collect.MapMakerInternalMap
 
containsKey(Object, int) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
 
containsKey(Object) - Method in class com.google.common.collect.Maps.AbstractFilteredMap
 
containsKey(Object) - Method in class com.google.common.collect.Maps.AsMapView
 
containsKey(Object) - Method in class com.google.common.collect.Maps.FilteredEntryNavigableMap
 
containsKey(Object) - Method in class com.google.common.collect.Maps.FilteredKeyMap
 
containsKey(Object) - Method in class com.google.common.collect.Maps.TransformedEntriesMap
 
containsKey(Object) - Method in interface com.google.common.collect.Multimap
Returns true if this multimap contains at least one key-value pair with the key key.
containsKey(Object) - Method in class com.google.common.collect.Multimaps.AsMap
 
containsKey(Object) - Method in class com.google.common.collect.Multimaps.MapMultimap
 
containsKey(Object) - Method in class com.google.common.collect.Multimaps.TransformedEntriesMultimap
 
containsKey(Object) - Method in class com.google.common.collect.SingletonImmutableBiMap
 
containsKey(Object) - Method in class com.google.common.collect.StandardTable.Column
 
containsKey(Object) - Method in class com.google.common.collect.StandardTable.ColumnMap
 
containsKey(Object) - Method in class com.google.common.collect.StandardTable.Row
 
containsKey(Object) - Method in class com.google.common.collect.StandardTable.RowMap
 
containsKey(Object) - Method in class com.google.common.collect.Synchronized.SynchronizedMap
 
containsKey(Object) - Method in class com.google.common.collect.Synchronized.SynchronizedMultimap
 
containsKey(Object) - Method in class com.google.common.collect.TreeBasedTable.TreeRow
 
containsKey(Object) - Method in class com.google.common.collect.TreeRangeMap.AsMapOfRanges
 
containsKey(Object) - Method in class com.google.common.collect.TreeRangeMap.SubRangeMap.SubRangeMapAsMap
 
containsKey(Object) - Method in class com.google.common.collect.TreeRangeSet.ComplementRangesByLowerBound
 
containsKey(Object) - Method in class com.google.common.collect.TreeRangeSet.RangesByUpperBound
 
containsKey(Object) - Method in class com.google.common.collect.TreeRangeSet.SubRangeSetRangesByLowerBound
 
containsKey(Object) - Method in class com.google.common.util.concurrent.AtomicLongMap
Returns true if this map contains a mapping for the specified key.
containsKeyImpl(Map<?, ?>, Object) - Static method in class com.google.common.collect.Maps
An admittedly inefficient implementation of Map.containsKey(java.lang.Object).
containsMapping(Object, Object, Object) - Method in class com.google.common.collect.StandardTable
 
containsOccurrences(Multiset<?>, Multiset<?>) - Static method in class com.google.common.collect.Multisets
Returns true if subMultiset.count(o) <= superMultiset.count(o) for all o.
containsPattern(String) - Static method in class com.google.common.base.Predicates
Returns a predicate that evaluates to true if the CharSequence being tested contains any match for the given regular expression pattern.
ContainsPatternFromStringPredicate(String) - Constructor for class com.google.common.base.Predicates.ContainsPatternFromStringPredicate
 
ContainsPatternPredicate(Pattern) - Constructor for class com.google.common.base.Predicates.ContainsPatternPredicate
 
containsRow(Object) - Method in class com.google.common.collect.AbstractTable
 
containsRow(Object) - Method in class com.google.common.collect.ArrayTable
Returns true if the provided row key is among the row keys provided when the table was constructed.
containsRow(Object) - Method in class com.google.common.collect.ForwardingTable
 
containsRow(Object) - Method in class com.google.common.collect.HashBasedTable
 
containsRow(Object) - Method in class com.google.common.collect.StandardTable
 
containsRow(Object) - Method in interface com.google.common.collect.Table
Returns true if the table contains a mapping with the specified row key.
containsRow(Object) - Method in class com.google.common.collect.Tables.TransposeTable
 
containsValue(Object) - Method in class com.google.common.cache.LocalCache
 
containsValue(Object) - Method in class com.google.common.cache.LocalCache.Segment
This method is a convenience for testing.
containsValue(Object) - Method in class com.google.common.collect.AbstractBiMap
 
containsValue(Object) - Method in class com.google.common.collect.AbstractMultimap
 
containsValue(Object) - Method in class com.google.common.collect.AbstractTable
 
containsValue(Object) - Method in class com.google.common.collect.ArrayTable
 
containsValue(Object) - Method in class com.google.common.collect.ForwardingMap
 
containsValue(Object) - Method in class com.google.common.collect.ForwardingMultimap
 
containsValue(Object) - Method in class com.google.common.collect.ForwardingTable
 
containsValue(Object) - Method in class com.google.common.collect.HashBasedTable
 
containsValue(Object) - Method in class com.google.common.collect.HashBiMap
 
containsValue(Object) - Method in class com.google.common.collect.ImmutableMap
 
containsValue(Object) - Method in class com.google.common.collect.ImmutableMultimap
 
containsValue(Object) - Method in class com.google.common.collect.ImmutableSortedMap
 
containsValue(Object) - Method in class com.google.common.collect.ImmutableTable
 
containsValue(Object) - Method in class com.google.common.collect.LinkedListMultimap
 
containsValue(Object) - Method in class com.google.common.collect.MapMaker.NullConcurrentMap
 
containsValue(Object) - Method in class com.google.common.collect.MapMakerInternalMap
 
containsValue(Object) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
This method is a convenience for testing.
containsValue(Object) - Method in interface com.google.common.collect.Multimap
Returns true if this multimap contains at least one key-value pair with the value value.
containsValue(Object) - Method in class com.google.common.collect.Multimaps.MapMultimap
 
containsValue(Object) - Method in class com.google.common.collect.SingletonImmutableBiMap
 
containsValue(Object) - Method in class com.google.common.collect.StandardTable
 
containsValue(Object) - Method in class com.google.common.collect.Synchronized.SynchronizedAsMap
 
containsValue(Object) - Method in class com.google.common.collect.Synchronized.SynchronizedMap
 
containsValue(Object) - Method in class com.google.common.collect.Synchronized.SynchronizedMultimap
 
containsValue(Object) - Method in interface com.google.common.collect.Table
Returns true if the table contains a mapping with the specified value.
containsValue(Object) - Method in class com.google.common.collect.Tables.TransposeTable
 
containsValueImpl(Map<?, ?>, Object) - Static method in class com.google.common.collect.Maps
An implementation of Map.containsValue(java.lang.Object).
containsZero - Variable in class com.google.common.base.SmallCharMatcher
 
CONTENT_DISPOSITION - Static variable in class com.google.common.net.HttpHeaders
The HTTP Content-Disposition header field name.
CONTENT_ENCODING - Static variable in class com.google.common.net.HttpHeaders
The HTTP Content-Encoding header field name.
CONTENT_LANGUAGE - Static variable in class com.google.common.net.HttpHeaders
The HTTP Content-Language header field name.
CONTENT_LENGTH - Static variable in class com.google.common.net.HttpHeaders
The HTTP Content-Length header field name.
CONTENT_LOCATION - Static variable in class com.google.common.net.HttpHeaders
The HTTP Content-Location header field name.
CONTENT_MD5 - Static variable in class com.google.common.net.HttpHeaders
The HTTP Content-MD5 header field name.
CONTENT_RANGE - Static variable in class com.google.common.net.HttpHeaders
The HTTP Content-Range header field name.
CONTENT_SECURITY_POLICY - Static variable in class com.google.common.net.HttpHeaders
The HTTP Content-Security-Policy header field name.
CONTENT_SECURITY_POLICY_REPORT_ONLY - Static variable in class com.google.common.net.HttpHeaders
The HTTP Content-Security-Policy-Report-Only header field name.
CONTENT_TYPE - Static variable in class com.google.common.net.HttpHeaders
The HTTP Content-Type header field name.
contentEquals(ByteSource) - Method in class com.google.common.io.ByteSource
Checks that the contents of this byte source are equal to the contents of the given byte source.
contents - Variable in class com.google.common.collect.ImmutableCollection.ArrayBasedBuilder
 
contents - Variable in class com.google.common.collect.ImmutableMultiset.Builder
 
ContiguousSet<C extends java.lang.Comparable> - Class in com.google.common.collect
A sorted set of contiguous values in a given DiscreteDomain.
ContiguousSet(DiscreteDomain<C>) - Constructor for class com.google.common.collect.ContiguousSet
 
convert(CaseFormat, String) - Method in enum com.google.common.base.CaseFormat
Enum values can override for performance reasons.
convert(A) - Method in class com.google.common.base.Converter
Returns a representation of a as an instance of type B.
convert(BiMap<X, Y>, X) - Static method in class com.google.common.collect.Maps.BiMapConverter
 
convertAll(Iterable<? extends A>) - Method in class com.google.common.base.Converter
Returns an iterable that applies convert to each element of fromIterable.
convertDottedQuadToHex(String) - Static method in class com.google.common.net.InetAddresses
 
Converter<A,B> - Class in com.google.common.base
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.
Converter() - Constructor for class com.google.common.base.Converter
Constructor for use by subclasses.
Converter(boolean) - Constructor for class com.google.common.base.Converter
Constructor used only by LegacyConverter to suspend automatic null-handling.
Converter.ConverterComposition<A,B,C> - Class in com.google.common.base
 
Converter.FunctionBasedConverter<A,B> - Class in com.google.common.base
 
Converter.IdentityConverter<T> - Class in com.google.common.base
A converter that always converts or reverses an object to itself.
Converter.ReverseConverter<A,B> - Class in com.google.common.base
 
ConverterComposition(Converter<A, B>, Converter<B, C>) - Constructor for class com.google.common.base.Converter.ConverterComposition
 
converterTo(CaseFormat) - Method in enum com.google.common.base.CaseFormat
Returns a Converter that converts strings from this format to targetFormat.
COOKIE - Static variable in class com.google.common.net.HttpHeaders
The HTTP Cookie header field name.
copy() - Method in class com.google.common.hash.BloomFilter
Creates a new BloomFilter that's a copy of this instance.
copy() - Method in class com.google.common.hash.BloomFilterStrategies.BitArray
 
copy(InputStream, OutputStream) - Static method in class com.google.common.io.ByteStreams
Copies all bytes from the input stream to the output stream.
copy(ReadableByteChannel, WritableByteChannel) - Static method in class com.google.common.io.ByteStreams
Copies all bytes from the readable channel to the writable channel.
copy(Readable, Appendable) - Static method in class com.google.common.io.CharStreams
Copies all characters between the Readable and Appendable objects.
copy(File, OutputStream) - Static method in class com.google.common.io.Files
Copies all bytes from a file to an output stream.
copy(File, File) - Static method in class com.google.common.io.Files
Copies all the bytes from one file to another.
copy(File, Charset, Appendable) - Static method in class com.google.common.io.Files
Copies all characters from a file to an appendable object, using the given character set.
copy(URL, OutputStream) - Static method in class com.google.common.io.Resources
Copies all bytes from a URL to an output stream.
copyAccessEntry(LocalCache.ReferenceEntry<K, V>, LocalCache.ReferenceEntry<K, V>) - Method in enum com.google.common.cache.LocalCache.EntryFactory
 
copyAsObjectArray(Object[], int, int) - Static method in class com.google.common.collect.ObjectArrays
Returns a copy of the specified subrange of the specified array that is literally an Object[], and not e.g.
copyEntry(LocalCache.ReferenceEntry<K, V>, LocalCache.ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache
This method is a convenience for testing.
copyEntry(LocalCache.Segment<K, V>, LocalCache.ReferenceEntry<K, V>, LocalCache.ReferenceEntry<K, V>) - Method in enum com.google.common.cache.LocalCache.EntryFactory
Copies an entry, assigning it a new next entry.
copyEntry(LocalCache.ReferenceEntry<K, V>, LocalCache.ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.Segment
Copies original into a new entry chained to newNext.
copyEntry(MapMakerInternalMap.ReferenceEntry<K, V>, MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap
This method is a convenience for testing.
copyEntry(MapMakerInternalMap.Segment<K, V>, MapMakerInternalMap.ReferenceEntry<K, V>, MapMakerInternalMap.ReferenceEntry<K, V>) - Method in enum com.google.common.collect.MapMakerInternalMap.EntryFactory
Copies an entry, assigning it a new next entry.
copyEntry(MapMakerInternalMap.ReferenceEntry<K, V>, MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Copies original into a new entry chained to newNext.
copyEvictableEntry(MapMakerInternalMap.ReferenceEntry<K, V>, MapMakerInternalMap.ReferenceEntry<K, V>) - Method in enum com.google.common.collect.MapMakerInternalMap.EntryFactory
 
copyExpirableEntry(MapMakerInternalMap.ReferenceEntry<K, V>, MapMakerInternalMap.ReferenceEntry<K, V>) - Method in enum com.google.common.collect.MapMakerInternalMap.EntryFactory
 
copyFor(ReferenceQueue<V>, V, LocalCache.ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.LoadingValueReference
 
copyFor(ReferenceQueue<V>, V, LocalCache.ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.SoftValueReference
 
copyFor(ReferenceQueue<V>, V, LocalCache.ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.StrongValueReference
 
copyFor(ReferenceQueue<V>, V, LocalCache.ReferenceEntry<K, V>) - Method in interface com.google.common.cache.LocalCache.ValueReference
Creates a copy of this reference for the given entry.
copyFor(ReferenceQueue<V>, V, LocalCache.ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.WeakValueReference
 
copyFor(ReferenceQueue<V>, V, LocalCache.ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.WeightedSoftValueReference
 
copyFor(ReferenceQueue<V>, V, LocalCache.ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.WeightedWeakValueReference
 
copyFor(ReferenceQueue<V>, V, MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.ComputingConcurrentHashMap.ComputationExceptionReference
 
copyFor(ReferenceQueue<V>, V, MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.ComputingConcurrentHashMap.ComputedReference
 
copyFor(ReferenceQueue<V>, V, MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.ComputingConcurrentHashMap.ComputingValueReference
 
copyFor(ReferenceQueue<V>, V, MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.SoftValueReference
 
copyFor(ReferenceQueue<V>, V, MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.StrongValueReference
 
copyFor(ReferenceQueue<V>, V, MapMakerInternalMap.ReferenceEntry<K, V>) - Method in interface com.google.common.collect.MapMakerInternalMap.ValueReference
Creates a copy of this reference for the given entry.
copyFor(ReferenceQueue<V>, V, MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.WeakValueReference
 
copyFromEntries(Collection<? extends Multiset.Entry<? extends E>>) - Static method in class com.google.common.collect.ImmutableMultiset
 
copyHighestCountFirst(Multiset<E>) - Static method in class com.google.common.collect.Multisets
Returns a copy of multiset as an ImmutableMultiset whose iteration order is highest count first, with ties broken by the iteration order of the original multiset.
copyInto(C) - Method in class com.google.common.collect.FluentIterable
Copies all the elements from this fluent iterable to collection.
copyInto(S) - Method in class com.google.common.collect.Sets.SetView
Copies the current contents of this set view into an existing set.
copyIntoArray(Object[], int) - Method in class com.google.common.collect.EmptyImmutableSet
 
copyIntoArray(Object[], int) - Method in class com.google.common.collect.EmptyImmutableSortedMultiset
 
copyIntoArray(Object[], int) - Method in class com.google.common.collect.EmptyImmutableSortedSet
 
copyIntoArray(Object[], int) - Method in class com.google.common.collect.ImmutableCollection
Copies the contents of this immutable collection into the specified array at the specified offset.
copyIntoArray(Object[], int) - Method in class com.google.common.collect.ImmutableList
 
copyIntoArray(Object[], int) - Method in class com.google.common.collect.ImmutableMultimap.Values
 
copyIntoArray(Object[], int) - Method in class com.google.common.collect.ImmutableMultiset
 
copyIntoArray(Object[], int) - Method in class com.google.common.collect.RegularImmutableAsList
 
copyIntoArray(Object[], int) - Method in class com.google.common.collect.RegularImmutableList
 
copyIntoArray(Object[], int) - Method in class com.google.common.collect.RegularImmutableSet
 
copyIntoArray(Object[], int) - Method in class com.google.common.collect.RegularImmutableSortedSet
 
copyIntoArray(Object[], int) - Method in class com.google.common.collect.SingletonImmutableList
 
copyIntoArray(Object[], int) - Method in class com.google.common.collect.SingletonImmutableSet
 
copyOf(Map<? extends K, ? extends V>) - Static method in class com.google.common.collect.ImmutableBiMap
Returns an immutable bimap containing the same entries as map.
copyOf(Map<? extends Class<? extends S>, ? extends S>) - Static method in class com.google.common.collect.ImmutableClassToInstanceMap
Returns an immutable map containing the same entries as map.
copyOf(Iterable<? extends E>) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing the given elements, in order.
copyOf(Collection<? extends E>) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing the given elements, in order.
copyOf(Iterator<? extends E>) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing the given elements, in order.
copyOf(E[]) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing the given elements, in order.
copyOf(Multimap<? extends K, ? extends V>) - Static method in class com.google.common.collect.ImmutableListMultimap
Returns an immutable multimap containing the same mappings as multimap.
copyOf(Map<? extends K, ? extends V>) - Static method in class com.google.common.collect.ImmutableMap
Returns an immutable map containing the same entries as map.
copyOf(Multimap<? extends K, ? extends V>) - Static method in class com.google.common.collect.ImmutableMultimap
Returns an immutable multimap containing the same mappings as multimap.
copyOf(E[]) - Static method in class com.google.common.collect.ImmutableMultiset
Returns an immutable multiset containing the given elements.
copyOf(Iterable<? extends E>) - Static method in class com.google.common.collect.ImmutableMultiset
Returns an immutable multiset containing the given elements.
copyOf(Iterator<? extends E>) - Static method in class com.google.common.collect.ImmutableMultiset
Returns an immutable multiset containing the given elements.
copyOf(RangeMap<K, ? extends V>) - Static method in class com.google.common.collect.ImmutableRangeMap
 
copyOf(RangeSet<C>) - Static method in class com.google.common.collect.ImmutableRangeSet
Returns an immutable copy of the specified RangeSet.
copyOf(E[]) - Static method in class com.google.common.collect.ImmutableSet
Returns an immutable set containing the given elements, in order.
copyOf(Iterable<? extends E>) - Static method in class com.google.common.collect.ImmutableSet
Returns an immutable set containing the given elements, in order.
copyOf(Iterator<? extends E>) - Static method in class com.google.common.collect.ImmutableSet
Returns an immutable set containing the given elements, in order.
copyOf(Collection<? extends E>) - Static method in class com.google.common.collect.ImmutableSet
Returns an immutable set containing the given elements, in order.
copyOf(Multimap<? extends K, ? extends V>) - Static method in class com.google.common.collect.ImmutableSetMultimap
Returns an immutable set multimap containing the same mappings as multimap.
copyOf(Multimap<? extends K, ? extends V>, Comparator<? super V>) - Static method in class com.google.common.collect.ImmutableSetMultimap
 
copyOf(Map<? extends K, ? extends V>) - Static method in class com.google.common.collect.ImmutableSortedMap
Returns an immutable map containing the same entries as map, sorted by the natural ordering of the keys.
copyOf(Map<? extends K, ? extends V>, Comparator<? super K>) - Static method in class com.google.common.collect.ImmutableSortedMap
Returns an immutable map containing the same entries as map, with keys sorted by the provided comparator.
copyOf(E[]) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns an immutable sorted multiset containing the given elements sorted by their natural ordering.
copyOf(Iterable<? extends E>) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns an immutable sorted multiset containing the given elements sorted by their natural ordering.
copyOf(Iterator<? extends E>) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns an immutable sorted multiset containing the given elements sorted by their natural ordering.
copyOf(Comparator<? super E>, Iterator<? extends E>) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns an immutable sorted multiset containing the given elements sorted by the given Comparator.
copyOf(Comparator<? super E>, Iterable<? extends E>) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns an immutable sorted multiset containing the given elements sorted by the given Comparator.
copyOf(E[]) - Static method in class com.google.common.collect.ImmutableSortedMultisetFauxverideShim
Deprecated.
Pass parameters of type Comparable to use ImmutableSortedMultiset.copyOf(Comparable[]).
copyOf(E[]) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by their natural ordering.
copyOf(Iterable<? extends E>) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by their natural ordering.
copyOf(Collection<? extends E>) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by their natural ordering.
copyOf(Iterator<? extends E>) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by their natural ordering.
copyOf(Comparator<? super E>, Iterator<? extends E>) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by the given Comparator.
copyOf(Comparator<? super E>, Iterable<? extends E>) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by the given Comparator.
copyOf(Comparator<? super E>, Collection<? extends E>) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by the given Comparator.
copyOf(E[]) - Static method in class com.google.common.collect.ImmutableSortedSetFauxverideShim
Deprecated.
Pass parameters of type Comparable to use ImmutableSortedSet.copyOf(Comparable[]).
copyOf(Table<? extends R, ? extends C, ? extends V>) - Static method in class com.google.common.collect.ImmutableTable
Returns an immutable copy of the provided table.
copyOf(boolean[], int) - Static method in class com.google.common.primitives.Booleans
 
copyOf(byte[], int) - Static method in class com.google.common.primitives.Bytes
 
copyOf(char[], int) - Static method in class com.google.common.primitives.Chars
 
copyOf(double[], int) - Static method in class com.google.common.primitives.Doubles
 
copyOf(float[], int) - Static method in class com.google.common.primitives.Floats
 
copyOf(int[], int) - Static method in class com.google.common.primitives.Ints
 
copyOf(long[], int) - Static method in class com.google.common.primitives.Longs
 
copyOf(short[], int) - Static method in class com.google.common.primitives.Shorts
 
copyOfEnumMap(Map<K, ? extends V>) - Static method in class com.google.common.collect.ImmutableMap
 
copyOfEnumMapUnsafe(Map<? extends K, ? extends V>) - Static method in class com.google.common.collect.ImmutableMap
 
copyOfEnumSet(EnumSet<E>) - Static method in class com.google.common.collect.ImmutableSet
 
copyOfInternal(E...) - Static method in class com.google.common.collect.ImmutableMultiset
 
copyOfInternal(Multiset<? extends E>) - Static method in class com.google.common.collect.ImmutableMultiset
 
copyOfInternal(Map<? extends K, ? extends V>, Comparator<? super K>) - Static method in class com.google.common.collect.ImmutableSortedMap
 
copyOfSorted(SortedMap<K, ? extends V>) - Static method in class com.google.common.collect.ImmutableSortedMap
Returns an immutable map containing the same entries as the provided sorted map, with the same ordering.
copyOfSorted(SortedMultiset<E>) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns an immutable sorted multiset containing the elements of a sorted multiset, sorted by the same Comparator.
copyOfSorted(SortedSet<E>) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing the elements of a sorted set, sorted by the same Comparator.
copyOfSortedEntries(Comparator<? super E>, Collection<Multiset.Entry<E>>) - Static method in class com.google.common.collect.ImmutableSortedMultiset
 
copyTo(OutputStream) - Method in class com.google.common.io.ByteSource.ByteArrayByteSource
 
copyTo(OutputStream) - Method in class com.google.common.io.ByteSource
Copies the contents of this byte source to the given OutputStream.
copyTo(ByteSink) - Method in class com.google.common.io.ByteSource
Copies the contents of this byte source to the given ByteSink.
copyTo(Appendable) - Method in class com.google.common.io.CharSource
Appends the contents of this source to the given Appendable (such as a Writer).
copyTo(CharSink) - Method in class com.google.common.io.CharSource
Copies the contents of this source to the given sink.
copyWriteEntry(LocalCache.ReferenceEntry<K, V>, LocalCache.ReferenceEntry<K, V>) - Method in enum com.google.common.cache.LocalCache.EntryFactory
 
correctedDoBackward(C) - Method in class com.google.common.base.Converter.ConverterComposition
 
correctedDoBackward(B) - Method in class com.google.common.base.Converter
 
correctedDoBackward(A) - Method in class com.google.common.base.Converter.ReverseConverter
 
correctedDoForward(A) - Method in class com.google.common.base.Converter.ConverterComposition
 
correctedDoForward(A) - Method in class com.google.common.base.Converter
 
correctedDoForward(B) - Method in class com.google.common.base.Converter.ReverseConverter
 
count - Variable in class com.google.common.cache.LocalCache.Segment
The number of live elements in this segment's region.
count(Object) - Method in class com.google.common.collect.AbstractMapBasedMultiset
 
count(Object) - Method in class com.google.common.collect.AbstractMultiset
 
count(Object) - Method in class com.google.common.collect.ConcurrentHashMultiset
Returns the number of occurrences of element in this multiset.
Count - Class in com.google.common.collect
A mutable value of type int, for multisets to use in tracking counts of values.
Count(int) - Constructor for class com.google.common.collect.Count
 
count(Object) - Method in class com.google.common.collect.DescendingImmutableSortedMultiset
 
count(Object) - Method in class com.google.common.collect.EmptyImmutableSortedMultiset
 
count(Object) - Method in class com.google.common.collect.ForwardingMultiset
 
count(Object) - Method in class com.google.common.collect.ImmutableMultimap.Keys
 
count - Variable in class com.google.common.collect.LinkedListMultimap.KeyList
 
count - Variable in class com.google.common.collect.MapMakerInternalMap.Segment
The number of live elements in this segment's region.
count(Object) - Method in class com.google.common.collect.Multimaps.Keys
 
count(Object) - Method in interface com.google.common.collect.Multiset
Returns the number of occurrences of an element in this multiset (the count of the element).
count(Object) - Method in class com.google.common.collect.Multisets.FilteredMultiset
 
count - Variable in class com.google.common.collect.Multisets.ImmutableEntry
 
count(Object) - Method in class com.google.common.collect.RegularImmutableMultiset
 
count(Object) - Method in class com.google.common.collect.RegularImmutableSortedMultiset
 
count(Object) - Method in class com.google.common.collect.Synchronized.SynchronizedMultiset
 
count(Comparator<? super E>, E) - Method in class com.google.common.collect.TreeMultiset.AvlNode
 
count(Object) - Method in class com.google.common.collect.TreeMultiset
 
count - Variable in class com.google.common.io.CountingInputStream
 
count - Variable in class com.google.common.io.CountingOutputStream
 
count - Variable in class com.google.common.math.DoubleMath.MeanAccumulator
 
COUNT_MAP_FIELD_SETTER - Static variable in class com.google.common.collect.ConcurrentHashMultiset.FieldSettersHolder
 
countBuffer - Static variable in class com.google.common.io.ByteSource
 
countByReading(InputStream) - Method in class com.google.common.io.ByteSource
 
countBySkipping(InputStream) - Method in class com.google.common.io.ByteSource
Counts the bytes in the given input stream using skip if possible.
countIn(CharSequence) - Method in class com.google.common.base.CharMatcher
Returns the number of matching characters found in a character sequence.
countIn(CharSequence) - Method in class com.google.common.base.CharMatcher.NegatedMatcher
 
CountingInputStream - Class in com.google.common.io
An InputStream that counts the number of bytes read.
CountingInputStream(InputStream) - Constructor for class com.google.common.io.CountingInputStream
Wraps another input stream, counting the number of bytes read.
CountingOutputStream - Class in com.google.common.io
An OutputStream that counts the number of bytes written.
CountingOutputStream(OutputStream) - Constructor for class com.google.common.io.CountingOutputStream
Wraps another output stream, counting the number of bytes written.
countMap - Variable in class com.google.common.collect.ConcurrentHashMultiset
The number of occurrences of each element.
counts - Variable in class com.google.common.collect.ImmutableMultiset.SerializedForm
 
counts - Variable in class com.google.common.collect.ImmutableSortedMultiset.SerializedForm
 
counts - Variable in class com.google.common.collect.RegularImmutableSortedMultiset
 
countTrue(boolean...) - Static method in class com.google.common.primitives.Booleans
Returns the number of values that are true.
CR - Static variable in class com.google.common.base.Ascii
Carriage Return ('\r'): A format effector which controls the movement of the printing position to the first printing position on the same printing line.
crc - Variable in class com.google.common.hash.Crc32cHashFunction.Crc32cHasher
 
crc32() - Static method in class com.google.common.hash.Hashing
Returns a hash function implementing the CRC-32 checksum algorithm (32 hash bits) by delegating to the CRC32 Checksum.
crc32c() - Static method in class com.google.common.hash.Hashing
Returns a hash function implementing the CRC32C checksum algorithm (32 hash bits) as described by RFC 3720, Section 12.1.
Crc32cHasher() - Constructor for class com.google.common.hash.Crc32cHashFunction.Crc32cHasher
 
Crc32cHashFunction - Class in com.google.common.hash
This class generates a CRC32C checksum, defined by RFC 3720, Section 12.1.
Crc32cHashFunction() - Constructor for class com.google.common.hash.Crc32cHashFunction
 
Crc32cHashFunction.Crc32cHasher - Class in com.google.common.hash
 
Crc32cHolder() - Constructor for class com.google.common.hash.Hashing.Crc32cHolder
 
Crc32Holder() - Constructor for class com.google.common.hash.Hashing.Crc32Holder
 
CRC_32 - Static variable in class com.google.common.hash.Hashing.Crc32Holder
 
CRC_32_C - Static variable in class com.google.common.hash.Hashing.Crc32cHolder
 
CRC_TABLE - Static variable in class com.google.common.hash.Crc32cHashFunction.Crc32cHasher
 
create() - Static method in class com.google.common.cache.LongAddables
 
create() - Static method in class com.google.common.collect.ArrayListMultimap
Creates a new, empty ArrayListMultimap with the default initial capacities.
create(int, int) - Static method in class com.google.common.collect.ArrayListMultimap
Constructs an empty ArrayListMultimap with enough capacity to hold the specified numbers of keys and values without resizing.
create(Multimap<? extends K, ? extends V>) - Static method in class com.google.common.collect.ArrayListMultimap
Constructs an ArrayListMultimap with the same mappings as the specified multimap.
create(Iterable<? extends R>, Iterable<? extends C>) - Static method in class com.google.common.collect.ArrayTable
Creates an empty ArrayTable.
create(Table<R, C, V>) - Static method in class com.google.common.collect.ArrayTable
Creates an ArrayTable with the mappings in the provided table.
create(List<? extends List<? extends E>>) - Static method in class com.google.common.collect.CartesianList
 
create() - Static method in class com.google.common.collect.ConcurrentHashMultiset
Creates a new, empty ConcurrentHashMultiset using the default initial capacity, load factor, and concurrency settings.
create(Iterable<? extends E>) - Static method in class com.google.common.collect.ConcurrentHashMultiset
Creates a new ConcurrentHashMultiset containing the specified elements, using the default initial capacity, load factor, and concurrency settings.
create(MapMaker) - Static method in class com.google.common.collect.ConcurrentHashMultiset
Creates a new, empty ConcurrentHashMultiset using mapMaker to construct the internal backing map.
create(Range<C>, DiscreteDomain<C>) - Static method in class com.google.common.collect.ContiguousSet
Returns a ContiguousSet containing the same values in the given domain contained by the range.
create(Class<K>, Class<V>) - Static method in class com.google.common.collect.EnumBiMap
Returns a new, empty EnumBiMap using the specified key and value types.
create(Map<K, V>) - Static method in class com.google.common.collect.EnumBiMap
Returns a new bimap with the same mappings as the specified map.
create(Class<K>) - Static method in class com.google.common.collect.EnumHashBiMap
Returns a new, empty EnumHashBiMap using the specified key type.
create(Map<K, ? extends V>) - Static method in class com.google.common.collect.EnumHashBiMap
Constructs a new bimap with the same mappings as the specified map.
create(Class<E>) - Static method in class com.google.common.collect.EnumMultiset
Creates an empty EnumMultiset.
create(Iterable<E>) - Static method in class com.google.common.collect.EnumMultiset
Creates a new EnumMultiset containing the specified elements.
create(Iterable<E>, Class<E>) - Static method in class com.google.common.collect.EnumMultiset
Returns a new EnumMultiset instance containing the given elements.
create(int) - Static method in class com.google.common.collect.EvictingQueue
Creates and returns a new evicting queue that will hold up to maxSize elements.
create() - Static method in class com.google.common.collect.HashBasedTable
Creates an empty HashBasedTable.
create(int, int) - Static method in class com.google.common.collect.HashBasedTable
Creates an empty HashBasedTable with the specified map sizes.
create(Table<? extends R, ? extends C, ? extends V>) - Static method in class com.google.common.collect.HashBasedTable
Creates a HashBasedTable with the same mappings as the specified table.
create() - Static method in class com.google.common.collect.HashBiMap
Returns a new, empty HashBiMap with the default initial capacity (16).
create(int) - Static method in class com.google.common.collect.HashBiMap
Constructs a new, empty bimap with the specified expected size.
create(Map<? extends K, ? extends V>) - Static method in class com.google.common.collect.HashBiMap
Constructs a new bimap containing initial values from map.
create() - Static method in class com.google.common.collect.HashMultimap
Creates a new, empty HashMultimap with the default initial capacities.
create(int, int) - Static method in class com.google.common.collect.HashMultimap
Constructs an empty HashMultimap with enough capacity to hold the specified numbers of keys and values without rehashing.
create(Multimap<? extends K, ? extends V>) - Static method in class com.google.common.collect.HashMultimap
Constructs a HashMultimap with the same mappings as the specified multimap.
create() - Static method in class com.google.common.collect.HashMultiset
Creates a new, empty HashMultiset using the default initial capacity.
create(int) - Static method in class com.google.common.collect.HashMultiset
Creates a new, empty HashMultiset with the specified expected number of distinct elements.
create(Iterable<? extends E>) - Static method in class com.google.common.collect.HashMultiset
Creates a new HashMultiset containing the specified elements.
create() - Static method in class com.google.common.collect.LinkedHashMultimap
Creates a new, empty LinkedHashMultimap with the default initial capacities.
create(int, int) - Static method in class com.google.common.collect.LinkedHashMultimap
Constructs an empty LinkedHashMultimap with enough capacity to hold the specified numbers of keys and values without rehashing.
create(Multimap<? extends K, ? extends V>) - Static method in class com.google.common.collect.LinkedHashMultimap
Constructs a LinkedHashMultimap with the same mappings as the specified multimap.
create() - Static method in class com.google.common.collect.LinkedHashMultiset
Creates a new, empty LinkedHashMultiset using the default initial capacity.
create(int) - Static method in class com.google.common.collect.LinkedHashMultiset
Creates a new, empty LinkedHashMultiset with the specified expected number of distinct elements.
create(Iterable<? extends E>) - Static method in class com.google.common.collect.LinkedHashMultiset
Creates a new LinkedHashMultiset containing the specified elements.
create() - Static method in class com.google.common.collect.LinkedListMultimap
Creates a new, empty LinkedListMultimap with the default initial capacity.
create(int) - Static method in class com.google.common.collect.LinkedListMultimap
Constructs an empty LinkedListMultimap with enough capacity to hold the specified number of keys without rehashing.
create(Multimap<? extends K, ? extends V>) - Static method in class com.google.common.collect.LinkedListMultimap
Constructs a LinkedListMultimap with the same mappings as the specified Multimap.
create(V, V) - Static method in class com.google.common.collect.Maps.ValueDifferenceImpl
 
create() - Method in class com.google.common.collect.MinMaxPriorityQueue.Builder
Builds a new min-max priority queue using the previously specified options, and having no initial contents.
create(Iterable<? extends T>) - Method in class com.google.common.collect.MinMaxPriorityQueue.Builder
Builds a new min-max priority queue using the previously specified options, and having the given initial elements.
create() - Static method in class com.google.common.collect.MinMaxPriorityQueue
Creates a new min-max priority queue with default settings: natural order, no maximum size, no initial contents, and an initial expected size of 11.
create(Iterable<? extends E>) - Static method in class com.google.common.collect.MinMaxPriorityQueue
Creates a new min-max priority queue using natural order, no maximum size, and initially containing the given elements.
create() - Static method in class com.google.common.collect.MutableClassToInstanceMap
Returns a new MutableClassToInstanceMap instance backed by a HashMap using the default initial capacity and load factor.
create(Map<Class<? extends B>, B>) - Static method in class com.google.common.collect.MutableClassToInstanceMap
Returns a new MutableClassToInstanceMap instance backed by a given empty backingMap.
create(Cut<C>, Cut<C>) - Static method in class com.google.common.collect.Range
 
create(List<? extends Set<? extends E>>) - Static method in class com.google.common.collect.Sets.CartesianSet
 
create() - Static method in class com.google.common.collect.TreeBasedTable
Creates an empty TreeBasedTable that uses the natural orderings of both row and column keys.
create(Comparator<? super R>, Comparator<? super C>) - Static method in class com.google.common.collect.TreeBasedTable
Creates an empty TreeBasedTable that is ordered by the specified comparators.
create(TreeBasedTable<R, C, ? extends V>) - Static method in class com.google.common.collect.TreeBasedTable
Creates a TreeBasedTable with the same mappings and sort order as the specified TreeBasedTable.
create() - Static method in class com.google.common.collect.TreeMultimap
Creates an empty TreeMultimap ordered by the natural ordering of its keys and values.
create(Comparator<? super K>, Comparator<? super V>) - Static method in class com.google.common.collect.TreeMultimap
Creates an empty TreeMultimap instance using explicit comparators.
create(Multimap<? extends K, ? extends V>) - Static method in class com.google.common.collect.TreeMultimap
Constructs a TreeMultimap, ordered by the natural ordering of its keys and values, with the same mappings as the specified multimap.
create() - Static method in class com.google.common.collect.TreeMultiset
Creates a new, empty multiset, sorted according to the elements' natural order.
create(Comparator<? super E>) - Static method in class com.google.common.collect.TreeMultiset
Creates a new, empty multiset, sorted according to the specified comparator.
create(Iterable<? extends E>) - Static method in class com.google.common.collect.TreeMultiset
Creates an empty multiset containing the given initial elements, sorted according to the elements' natural order.
create() - Static method in class com.google.common.collect.TreeRangeMap
 
create() - Static method in class com.google.common.collect.TreeRangeSet
Creates an empty TreeRangeSet instance.
create(RangeSet<C>) - Static method in class com.google.common.collect.TreeRangeSet
Returns a TreeRangeSet initialized with the ranges in the specified range set.
create(Map<Character, String>) - Static method in class com.google.common.escape.ArrayBasedEscaperMap
Returns a new ArrayBasedEscaperMap for creating ArrayBasedCharEscaper or ArrayBasedUnicodeEscaper instances.
create(Funnel<? super T>, int, double) - Static method in class com.google.common.hash.BloomFilter
Creates a BloomFilter with the expected number of insertions and expected false positive probability.
create(Funnel<? super T>, int, double, BloomFilter.Strategy) - Static method in class com.google.common.hash.BloomFilter
 
create(Funnel<? super T>, int) - Static method in class com.google.common.hash.BloomFilter
Creates a BloomFilter with the expected number of insertions and a default expected false positive probability of 3%.
create() - Static method in class com.google.common.io.Closer
Creates a new Closer.
create(String, String) - Static method in class com.google.common.net.MediaType
Creates a new media type with the given type and subtype.
create(String, String, Multimap<String, String>) - Static method in class com.google.common.net.MediaType
 
create() - Static method in class com.google.common.util.concurrent.AsyncSettableFuture
Creates a new asynchronously-settable future.
create() - Static method in class com.google.common.util.concurrent.AtomicLongMap
Creates an AtomicLongMap.
create(Map<? extends K, ? extends Long>) - Static method in class com.google.common.util.concurrent.AtomicLongMap
Creates an AtomicLongMap with the same mappings as the specified Map.
create(Throwable) - Method in interface com.google.common.util.concurrent.FutureFallback
Returns a Future to be used in place of the Future that failed with the given exception.
create(Callable<V>) - Static method in class com.google.common.util.concurrent.ListenableFutureTask
Creates a ListenableFutureTask that will upon running, execute the given Callable.
create(Runnable, V) - Static method in class com.google.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.google.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(RateLimiter.SleepingStopwatch, double) - Static method in class com.google.common.util.concurrent.RateLimiter
 
create(double, long, TimeUnit) - Static method in class com.google.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(RateLimiter.SleepingStopwatch, double, long, TimeUnit) - Static method in class com.google.common.util.concurrent.RateLimiter
 
create() - Static method in class com.google.common.util.concurrent.SettableFuture
Creates a new SettableFuture in the default state.
createApplicationType(String) - Static method in class com.google.common.net.MediaType
Creates a media type with the "application" type and the given subtype.
createAsList() - Method in class com.google.common.collect.ImmutableCollection
 
createAsList() - Method in class com.google.common.collect.ImmutableMapKeySet
 
createAsList() - Method in class com.google.common.collect.ImmutableMapValues
 
createAsList() - Method in class com.google.common.collect.ImmutableMultiset.EntrySet
 
createAsList() - Method in class com.google.common.collect.RegularImmutableBiMap.Inverse.InverseEntrySet
 
createAsList() - Method in class com.google.common.collect.RegularImmutableMap.EntrySet
 
createAsList() - Method in class com.google.common.collect.RegularImmutableSet
 
createAsList() - Method in class com.google.common.collect.RegularImmutableSortedMap.EntrySet
 
createAsList() - Method in class com.google.common.collect.RegularImmutableSortedSet
 
createAsList() - Method in class com.google.common.collect.RegularImmutableTable.CellSet
 
createAsMap() - Method in class com.google.common.collect.AbstractMapBasedMultimap
 
createAsMap() - Method in class com.google.common.collect.AbstractMultimap
 
createAsMap() - Method in class com.google.common.collect.FilteredEntryMultimap
 
createAsMap() - Method in class com.google.common.collect.FilteredKeyMultimap
 
createAsMap() - Method in class com.google.common.collect.ImmutableMultimap
 
createAsMap() - Method in class com.google.common.collect.LinkedListMultimap
 
createAsMap() - Method in class com.google.common.collect.Multimaps.MapMultimap
 
createAsMap() - Method in class com.google.common.collect.Multimaps.TransformedEntriesMultimap
 
createAsMap() - Method in class com.google.common.collect.TreeMultimap
 
createAsMap() - Method in class com.google.common.util.concurrent.AtomicLongMap
 
createAudioType(String) - Static method in class com.google.common.net.MediaType
Creates a media type with the "audio" type and the given subtype.
createCellSet() - Method in class com.google.common.collect.AbstractTable
 
createCellSet() - Method in class com.google.common.collect.ImmutableTable
 
createCellSet() - Method in class com.google.common.collect.RegularImmutableTable
 
createCellSet() - Method in class com.google.common.collect.SingletonImmutableTable
 
createCollection() - Method in class com.google.common.collect.AbstractListMultimap
 
createCollection() - Method in class com.google.common.collect.AbstractMapBasedMultimap
Creates the collection of values for a single key.
createCollection(K) - Method in class com.google.common.collect.AbstractMapBasedMultimap
Creates the collection of values for an explicitly provided key.
createCollection() - Method in class com.google.common.collect.AbstractSetMultimap
 
createCollection() - Method in class com.google.common.collect.AbstractSortedSetMultimap
 
createCollection() - Method in class com.google.common.collect.ArrayListMultimap
Creates a new, empty ArrayList to hold the collection of values for an arbitrary key.
createCollection() - Method in class com.google.common.collect.HashMultimap
Creates the collection of values for a single key.
createCollection() - Method in class com.google.common.collect.ImmutableMultimap.BuilderMultimap
 
createCollection() - Method in class com.google.common.collect.ImmutableSetMultimap.BuilderMultimap
 
createCollection() - Method in class com.google.common.collect.LinkedHashMultimap
Creates the collection of values for a single key.
createCollection(K) - Method in class com.google.common.collect.LinkedHashMultimap
Creates the collection of values for an explicitly provided key.
createCollection() - Method in class com.google.common.collect.Multimaps.CustomListMultimap
 
createCollection() - Method in class com.google.common.collect.Multimaps.CustomMultimap
 
createCollection() - Method in class com.google.common.collect.Multimaps.CustomSetMultimap
 
createCollection() - Method in class com.google.common.collect.Multimaps.CustomSortedSetMultimap
 
createCollection() - Method in class com.google.common.collect.TreeMultimap
Creates the collection of values for a single key.
createCollection(K) - Method in class com.google.common.collect.TreeMultimap
 
createColumnKeyIterator() - Method in class com.google.common.collect.StandardTable
Creates an iterator that returns each column value with duplicates omitted.
createColumnKeyIterator() - Method in class com.google.common.collect.TreeBasedTable
Overridden column iterator to return columns values in globally sorted order.
createCombined(Predicate<? super E>) - Method in class com.google.common.collect.Collections2.FilteredCollection
 
createConstant(String, String) - Static method in class com.google.common.net.MediaType
 
createConstantUtf8(String, String) - Static method in class com.google.common.net.MediaType
 
createDescendingMap() - Method in class com.google.common.collect.EmptyImmutableSortedMap
 
createDescendingMap() - Method in class com.google.common.collect.ImmutableSortedMap
 
createDescendingMap() - Method in class com.google.common.collect.RegularImmutableSortedMap
 
createDescendingMultiset() - Method in class com.google.common.collect.AbstractSortedMultiset
 
createDescendingSet() - Method in class com.google.common.collect.DescendingImmutableSortedSet
 
createDescendingSet() - Method in class com.google.common.collect.EmptyContiguousSet
 
createDescendingSet() - Method in class com.google.common.collect.EmptyImmutableSortedSet
 
createDescendingSet() - Method in class com.google.common.collect.ImmutableSortedSet
 
createDescendingSet() - Method in class com.google.common.collect.RegularImmutableSortedSet
 
createElementSet() - Method in class com.google.common.collect.AbstractMultiset
Creates a new instance of this multiset's element set, which will be returned by AbstractMultiset.elementSet().
createElementSet() - Method in class com.google.common.collect.AbstractSortedMultiset
 
createElementSet() - Method in class com.google.common.collect.ConcurrentHashMultiset
 
createElementSet() - Method in class com.google.common.collect.Multisets.FilteredMultiset
 
createElementSet() - Method in class com.google.common.collect.Multisets.UnmodifiableMultiset
 
createElementSet() - Method in class com.google.common.collect.UnmodifiableSortedMultiset
 
createEntries() - Method in class com.google.common.collect.AbstractMultimap
 
createEntries() - Method in class com.google.common.collect.FilteredEntryMultimap
 
createEntries() - Method in class com.google.common.collect.FilteredEntrySetMultimap
 
createEntries() - Method in class com.google.common.collect.FilteredKeyMultimap
 
createEntries() - Method in class com.google.common.collect.FilteredKeySetMultimap
 
createEntries() - Method in class com.google.common.collect.ImmutableMultimap
 
createEntries() - Method in class com.google.common.collect.LinkedListMultimap
 
createEntryArray(int) - Static method in class com.google.common.collect.RegularImmutableBiMap
 
createEntryArray(int) - Method in class com.google.common.collect.RegularImmutableMap
Creates an ImmutableMapEntry array to hold parameterized entries.
createEntrySet() - Method in class com.google.common.collect.AbstractMapBasedMultimap.AsMap
 
createEntrySet() - Method in class com.google.common.collect.AbstractMultiset
 
createEntrySet() - Method in class com.google.common.collect.ArrayTable.ArrayMap
 
createEntrySet() - Method in class com.google.common.collect.ConcurrentHashMultiset
 
createEntrySet() - Method in class com.google.common.collect.DenseImmutableTable.ImmutableArrayMap
 
createEntrySet() - Method in class com.google.common.collect.DescendingMultiset
 
createEntrySet() - Method in class com.google.common.collect.EmptyImmutableBiMap
 
createEntrySet() - Method in class com.google.common.collect.EmptyImmutableSortedMap
 
createEntrySet() - Method in class com.google.common.collect.FilteredEntryMultimap.AsMap
 
createEntrySet() - Method in class com.google.common.collect.ImmutableEnumMap
 
createEntrySet() - Method in class com.google.common.collect.ImmutableMap
 
createEntrySet() - Method in class com.google.common.collect.ImmutableMap.MapViewOfValuesAsSingletonSets
 
createEntrySet() - Method in class com.google.common.collect.ImmutableMultiset
 
createEntrySet() - Method in class com.google.common.collect.Maps.AsMapView
 
createEntrySet() - Method in class com.google.common.collect.Maps.DescendingMap
 
createEntrySet() - Method in class com.google.common.collect.Maps.FilteredEntryMap
 
createEntrySet() - Method in class com.google.common.collect.Maps.FilteredKeyMap
 
createEntrySet() - Method in class com.google.common.collect.Maps.ImprovedAbstractMap
Creates the entry set to be returned by Maps.ImprovedAbstractMap.entrySet().
createEntrySet() - Method in class com.google.common.collect.Maps.TransformedEntriesMap
 
createEntrySet() - Method in class com.google.common.collect.Multimaps.AsMap
 
createEntrySet() - Method in class com.google.common.collect.Multimaps.Keys
 
createEntrySet() - Method in class com.google.common.collect.Multisets.FilteredMultiset
 
createEntrySet() - Method in class com.google.common.collect.RegularImmutableBiMap
 
createEntrySet() - Method in class com.google.common.collect.RegularImmutableBiMap.Inverse
 
createEntrySet() - Method in class com.google.common.collect.RegularImmutableMap
 
createEntrySet() - Method in class com.google.common.collect.RegularImmutableSortedMap
 
createEntrySet() - Method in class com.google.common.collect.SingletonImmutableBiMap
 
createEntrySet() - Method in class com.google.common.collect.StandardTable.Column
 
createEntrySet() - Method in class com.google.common.collect.StandardTable.ColumnMap
 
createEntrySet() - Method in class com.google.common.collect.StandardTable.Row
 
createEntrySet() - Method in class com.google.common.collect.StandardTable.RowMap
 
createFromSystemTimer() - Static method in class com.google.common.util.concurrent.RateLimiter.SleepingStopwatch
 
createImageType(String) - Static method in class com.google.common.net.MediaType
Creates a media type with the "image" type and the given subtype.
createKeys() - Method in class com.google.common.collect.AbstractMultimap
 
createKeys() - Method in class com.google.common.collect.FilteredEntryMultimap
 
createKeys() - Method in class com.google.common.collect.FilteredKeyMultimap
 
createKeys() - Method in class com.google.common.collect.ImmutableMultimap
 
createKeySet() - Method in class com.google.common.collect.AbstractMapBasedMultimap
 
createKeySet() - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableAsMap
 
createKeySet() - Method in class com.google.common.collect.AbstractMapBasedMultimap.SortedAsMap
 
createKeySet() - Method in class com.google.common.collect.AbstractMultimap
 
createKeySet() - Method in class com.google.common.collect.DenseImmutableTable.ImmutableArrayMap
 
createKeySet() - Method in class com.google.common.collect.FilteredEntryMultimap.AsMap
 
createKeySet() - Method in class com.google.common.collect.FilteredKeyMultimap
 
createKeySet() - Method in class com.google.common.collect.ImmutableEnumMap
 
createKeySet() - Method in class com.google.common.collect.ImmutableMap
 
createKeySet() - Method in class com.google.common.collect.LinkedListMultimap
 
createKeySet() - Method in class com.google.common.collect.Maps.AsMapView
 
createKeySet() - Method in class com.google.common.collect.Maps.FilteredEntryMap
 
createKeySet() - Method in class com.google.common.collect.Maps.FilteredEntrySortedMap
 
createKeySet() - Method in class com.google.common.collect.Maps.FilteredKeyMap
 
createKeySet() - Method in class com.google.common.collect.Maps.ImprovedAbstractMap
 
createKeySet() - Method in class com.google.common.collect.SingletonImmutableBiMap
 
createKeySet() - Method in class com.google.common.collect.StandardRowSortedTable.RowSortedMap
 
createKeySet() - Method in class com.google.common.collect.StandardTable.Column
 
createKeySet() - Method in class com.google.common.collect.TreeMultimap
 
createMap(ImmutableMap.Builder<Object, Object>) - Method in class com.google.common.collect.ImmutableMap.SerializedForm
 
createMap() - Method in class com.google.common.collect.MultimapBuilder.MultimapBuilderWithKeys
 
createMultimapView() - Method in class com.google.common.collect.ImmutableMap
 
createNodes(Class<E>) - Static method in class com.google.common.util.concurrent.CycleDetectingLockFactory
For a given Enum type, creates an immutable map from each of the Enum's values to a corresponding LockGraphNode, with the allowedPriorLocks and disallowedPriorLocks prepopulated with nodes according to the natural ordering of the associated Enum values.
createParentDirs(File) - Static method in class com.google.common.io.Files
Creates any necessary but nonexistent parent directories of the specified file.
createReplacementArray(Map<Character, String>) - Static method in class com.google.common.escape.ArrayBasedEscaperMap
 
createRowMap() - Method in class com.google.common.collect.StandardRowSortedTable
 
createRowMap() - Method in class com.google.common.collect.StandardTable
 
createSafeOctets(String) - Static method in class com.google.common.net.PercentEscaper
Creates a boolean array with entries corresponding to the character values specified in safeChars set to true.
createSegment(int, long, AbstractCache.StatsCounter) - Method in class com.google.common.cache.LocalCache
 
createSegment(int, int) - Method in class com.google.common.collect.ComputingConcurrentHashMap
 
createSegment(int, int) - Method in class com.google.common.collect.MapMakerInternalMap
 
createStarted() - Static method in class com.google.common.base.Stopwatch
Creates (and starts) a new stopwatch using System.nanoTime() as its time source.
createStarted(Ticker) - Static method in class com.google.common.base.Stopwatch
Creates (and starts) a new stopwatch, using the specified time source.
createTable(int) - Method in class com.google.common.collect.HashBiMap
 
createTempDir() - Static method in class com.google.common.io.Files
Atomically creates a new directory somewhere beneath the system's temporary directory (as defined by the java.io.tmpdir system property), and returns its name.
createTextType(String) - Static method in class com.google.common.net.MediaType
Creates a media type with the "text" type and the given subtype.
createUnmodifiableEmptyCollection() - Method in class com.google.common.collect.AbstractListMultimap
 
createUnmodifiableEmptyCollection() - Method in class com.google.common.collect.AbstractMapBasedMultimap
Creates an unmodifiable, empty collection of values.
createUnmodifiableEmptyCollection() - Method in class com.google.common.collect.AbstractSetMultimap
 
createUnmodifiableEmptyCollection() - Method in class com.google.common.collect.AbstractSortedSetMultimap
 
createUnstarted() - Static method in class com.google.common.base.Stopwatch
Creates (but does not start) a new stopwatch using System.nanoTime() as its time source.
createUnstarted(Ticker) - Static method in class com.google.common.base.Stopwatch
Creates (but does not start) a new stopwatch, using the specified time source.
createValues() - Method in class com.google.common.collect.AbstractMultimap
 
createValues() - Method in class com.google.common.collect.AbstractTable
 
createValues() - Method in class com.google.common.collect.FilteredEntryMultimap.AsMap
 
createValues() - Method in class com.google.common.collect.FilteredEntryMultimap
 
createValues() - Method in class com.google.common.collect.FilteredKeyMultimap
 
createValues() - Method in class com.google.common.collect.ImmutableMultimap
 
createValues() - Method in class com.google.common.collect.ImmutableTable
 
createValues() - Method in class com.google.common.collect.LinkedListMultimap
 
createValues() - Method in class com.google.common.collect.Maps.AbstractFilteredMap
 
createValues() - Method in class com.google.common.collect.Maps.AsMapView
 
createValues() - Method in class com.google.common.collect.Maps.ImprovedAbstractMap
 
createValues() - Method in class com.google.common.collect.Multimaps.TransformedEntriesMultimap
 
createValues() - Method in class com.google.common.collect.RegularImmutableTable
 
createValues() - Method in class com.google.common.collect.SingletonImmutableTable
 
createValues() - Method in class com.google.common.collect.StandardTable.Column
 
createValues() - Method in class com.google.common.collect.StandardTable.ColumnMap
 
createValues() - Method in class com.google.common.collect.Tables.TransformedTable
 
createVideoType(String) - Static method in class com.google.common.net.MediaType
Creates a media type with the "video" type and the given subtype.
crossOver(int, E) - Method in class com.google.common.collect.MinMaxPriorityQueue.Heap
Crosses an element over to the opposite heap by moving it one level down (or up if there are no elements below it).
crossOverUp(int, E) - Method in class com.google.common.collect.MinMaxPriorityQueue.Heap
Moves an element one level up from a min level to a max level (or vice versa).
CRW - Static variable in class com.google.common.net.MediaType
The media type for the Canon Image File Format (crw files), a widely-used "raw image" format for cameras.
CSS_UTF_8 - Static variable in class com.google.common.net.MediaType
 
CSV_UTF_8 - Static variable in class com.google.common.net.MediaType
 
cumulativeCounts - Variable in class com.google.common.collect.RegularImmutableSortedMultiset
 
current - Variable in class com.google.common.collect.LinkedListMultimap.DistinctKeyIterator
 
current - Variable in class com.google.common.collect.LinkedListMultimap.NodeIterator
 
current - Variable in class com.google.common.collect.LinkedListMultimap.ValueForKeyIterator
 
current - Variable in class com.google.common.io.MultiReader
 
CURRENT - Static variable in enum com.google.common.reflect.Types.JavaVersion
 
currentEntry - Variable in class com.google.common.collect.AbstractMapBasedMultiset.MapBasedMultisetIterator
 
currentEntry - Variable in class com.google.common.collect.Multisets.MultisetIteratorImpl
 
currentFuture - Variable in class com.google.common.util.concurrent.AbstractScheduledService.CustomScheduler.ReschedulableCallable
The future that represents the next execution of this task.
currentSegment - Variable in class com.google.common.cache.LocalCache.HashIterator
 
currentSegment - Variable in class com.google.common.collect.MapMakerInternalMap.HashIterator
 
currentTable - Variable in class com.google.common.cache.LocalCache.HashIterator
 
currentTable - Variable in class com.google.common.collect.MapMakerInternalMap.HashIterator
 
cursor - Variable in class com.google.common.collect.MinMaxPriorityQueue.QueueIterator
 
CustomListMultimap(Map<K, Collection<V>>, Supplier<? extends List<V>>) - Constructor for class com.google.common.collect.Multimaps.CustomListMultimap
 
CustomMultimap(Map<K, Collection<V>>, Supplier<? extends Collection<V>>) - Constructor for class com.google.common.collect.Multimaps.CustomMultimap
 
CustomScheduler() - Constructor for class com.google.common.util.concurrent.AbstractScheduledService.CustomScheduler
 
CustomSetMultimap(Map<K, Collection<V>>, Supplier<? extends Set<V>>) - Constructor for class com.google.common.collect.Multimaps.CustomSetMultimap
 
CustomSortedSetMultimap(Map<K, Collection<V>>, Supplier<? extends SortedSet<V>>) - Constructor for class com.google.common.collect.Multimaps.CustomSortedSetMultimap
 
customWeigher() - Method in class com.google.common.cache.LocalCache
 
Cut<C extends java.lang.Comparable> - Class in com.google.common.collect
Implementation detail for the internal structure of Range instances.
Cut(C) - Constructor for class com.google.common.collect.Cut
 
Cut.AboveAll - Class in com.google.common.collect
 
Cut.AboveValue<C extends java.lang.Comparable> - Class in com.google.common.collect
 
Cut.BelowAll - Class in com.google.common.collect
 
Cut.BelowValue<C extends java.lang.Comparable> - Class in com.google.common.collect
 
CUTOFF - Static variable in class com.google.common.collect.ImmutableSet
 
cycle() - Method in class com.google.common.collect.FluentIterable
Returns a fluent iterable whose Iterator cycles indefinitely over the elements of this fluent iterable.
cycle(Iterable<T>) - Static method in class com.google.common.collect.Iterables
Returns an iterable whose iterators cycle indefinitely over the elements of iterable.
cycle(T...) - Static method in class com.google.common.collect.Iterables
Returns an iterable whose iterators cycle indefinitely over the provided elements.
cycle(Iterable<T>) - Static method in class com.google.common.collect.Iterators
Returns an iterator that cycles indefinitely over the elements of iterable.
cycle(T...) - Static method in class com.google.common.collect.Iterators
Returns an iterator that cycles indefinitely over the provided elements.
CycleDetectingLockFactory - Class in com.google.common.util.concurrent
The CycleDetectingLockFactory creates ReentrantLock instances and ReentrantReadWriteLock instances that detect potential deadlock by checking for cycles in lock acquisition order.
CycleDetectingLockFactory(CycleDetectingLockFactory.Policy) - Constructor for class com.google.common.util.concurrent.CycleDetectingLockFactory
 
CycleDetectingLockFactory.CycleDetectingLock - Interface in com.google.common.util.concurrent
Internal Lock implementations implement the CycleDetectingLock interface, allowing the detection logic to treat all locks in the same manner.
CycleDetectingLockFactory.CycleDetectingReentrantLock - Class in com.google.common.util.concurrent
 
CycleDetectingLockFactory.CycleDetectingReentrantReadLock - Class in com.google.common.util.concurrent
 
CycleDetectingLockFactory.CycleDetectingReentrantReadWriteLock - Class in com.google.common.util.concurrent
 
CycleDetectingLockFactory.CycleDetectingReentrantWriteLock - Class in com.google.common.util.concurrent
 
CycleDetectingLockFactory.ExampleStackTrace - Exception in com.google.common.util.concurrent
A Throwable used to record a stack trace that illustrates an example of a specific lock acquisition ordering.
CycleDetectingLockFactory.LockGraphNode - Class in com.google.common.util.concurrent
A LockGraphNode associated with each lock instance keeps track of the directed edges in the lock acquisition graph.
CycleDetectingLockFactory.Policies - Enum in com.google.common.util.concurrent
Pre-defined CycleDetectingLockFactory.Policy implementations.
CycleDetectingLockFactory.Policy - Interface in com.google.common.util.concurrent
Encapsulates the action to be taken when a potential deadlock is encountered.
CycleDetectingLockFactory.PotentialDeadlockException - Exception in com.google.common.util.concurrent
Represents a detected cycle in lock acquisition ordering.
CycleDetectingLockFactory.WithExplicitOrdering<E extends java.lang.Enum<E>> - Class in com.google.common.util.concurrent
A CycleDetectingLockFactory.WithExplicitOrdering provides the additional enforcement of an application-specified ordering of lock acquisitions.
CycleDetectingReentrantLock(CycleDetectingLockFactory.LockGraphNode, boolean) - Constructor for class com.google.common.util.concurrent.CycleDetectingLockFactory.CycleDetectingReentrantLock
 
CycleDetectingReentrantReadLock(CycleDetectingLockFactory.CycleDetectingReentrantReadWriteLock) - Constructor for class com.google.common.util.concurrent.CycleDetectingLockFactory.CycleDetectingReentrantReadLock
 
CycleDetectingReentrantReadWriteLock(CycleDetectingLockFactory.LockGraphNode, boolean) - Constructor for class com.google.common.util.concurrent.CycleDetectingLockFactory.CycleDetectingReentrantReadWriteLock
 
CycleDetectingReentrantWriteLock(CycleDetectingLockFactory.CycleDetectingReentrantReadWriteLock) - Constructor for class com.google.common.util.concurrent.CycleDetectingLockFactory.CycleDetectingReentrantWriteLock
 

D

d - Variable in class com.google.common.hash.SipHashFunction
 
d - Variable in class com.google.common.hash.SipHashFunction.SipHasher
 
daemon - Variable in class com.google.common.util.concurrent.ThreadFactoryBuilder
 
DASH_MATCHER - Static variable in class com.google.common.net.InternetDomainName
 
data - Variable in class com.google.common.hash.BloomFilter.SerialForm
 
data - Variable in class com.google.common.hash.BloomFilterStrategies.BitArray
 
DATE - Static variable in class com.google.common.net.HttpHeaders
The HTTP Date header field name.
DC1 - Static variable in class com.google.common.base.Ascii
Device Control 1.
DC2 - Static variable in class com.google.common.base.Ascii
Device Control 2.
DC3 - Static variable in class com.google.common.base.Ascii
Device Control 3.
DC4 - Static variable in class com.google.common.base.Ascii
Device Control 4.
DeadEvent - Class in com.google.common.eventbus
Wraps an event that was posted, but which had no subscribers and thus could not be delivered.
DeadEvent(Object, Object) - Constructor for class com.google.common.eventbus.DeadEvent
Creates a new DeadEvent.
declaration - Variable in class com.google.common.reflect.Parameter
 
declaresInterruptedEx(Method) - Static method in class com.google.common.util.concurrent.SimpleTimeLimiter
 
decodabet - Variable in class com.google.common.io.BaseEncoding.Alphabet
 
decode(char) - Static method in class com.google.common.hash.HashCode
 
decode(char) - Method in class com.google.common.io.BaseEncoding.Alphabet
 
decode(CharSequence) - Method in class com.google.common.io.BaseEncoding
Decodes the specified character sequence, and returns the resulting byte[].
decode(String) - Static method in class com.google.common.primitives.UnsignedInts
Returns the unsigned int value represented by the given string.
decode(String) - Static method in class com.google.common.primitives.UnsignedLongs
Returns the unsigned long value represented by the given string.
decodeChecked(CharSequence) - Method in class com.google.common.io.BaseEncoding
Decodes the specified character sequence, and returns the resulting byte[].
DecodingException(String) - Constructor for exception com.google.common.io.BaseEncoding.DecodingException
 
DecodingException(Throwable) - Constructor for exception com.google.common.io.BaseEncoding.DecodingException
 
decodingSource(CharSource) - Method in class com.google.common.io.BaseEncoding
Returns a ByteSource that reads base-encoded bytes from the specified CharSource.
decodingStream(Reader) - Method in class com.google.common.io.BaseEncoding
Returns an InputStream that decodes base-encoded input from the specified Reader.
decodingStream(GwtWorkarounds.CharInput) - Method in class com.google.common.io.BaseEncoding
 
decodingStream(GwtWorkarounds.CharInput) - Method in class com.google.common.io.BaseEncoding.SeparatedBaseEncoding
 
decodingStream(GwtWorkarounds.CharInput) - Method in class com.google.common.io.BaseEncoding.StandardBaseEncoding
 
DecoupledLoader() - Constructor for class com.google.common.base.FinalizableReferenceQueue.DecoupledLoader
 
DECREASING_COUNT_ORDERING - Static variable in class com.google.common.collect.Multisets
 
decrement() - Method in class com.google.common.cache.LongAdder
Equivalent to add(-1).
decrement(InetAddress) - Static method in class com.google.common.net.InetAddresses
Returns a new InetAddress that is one less than the passed in address.
decrementAndGet(K) - Method in class com.google.common.util.concurrent.AtomicLongMap
Decrements by one the value currently associated with key, and returns the new value.
DEFAULT_CAPACITY - Static variable in class com.google.common.collect.MinMaxPriorityQueue
 
DEFAULT_CONCURRENCY_LEVEL - Static variable in class com.google.common.cache.CacheBuilder
 
DEFAULT_CONCURRENCY_LEVEL - Static variable in class com.google.common.collect.MapMaker
 
DEFAULT_EXPECTED_KEYS - Static variable in class com.google.common.collect.MultimapBuilder
 
DEFAULT_EXPECTED_VALUES_PER_KEY - Static variable in class com.google.common.collect.MultimapBuilder.MultimapBuilderWithKeys
 
DEFAULT_EXPIRATION_NANOS - Static variable in class com.google.common.cache.CacheBuilder
 
DEFAULT_EXPIRATION_NANOS - Static variable in class com.google.common.collect.MapMaker
 
DEFAULT_INITIAL_CAPACITY - Static variable in class com.google.common.cache.CacheBuilder
 
DEFAULT_INITIAL_CAPACITY - Static variable in class com.google.common.collect.ImmutableCollection.Builder
 
DEFAULT_INITIAL_CAPACITY - Static variable in class com.google.common.collect.MapMaker
 
DEFAULT_KEY_CAPACITY - Static variable in class com.google.common.collect.LinkedHashMultimap
 
DEFAULT_REFRESH_NANOS - Static variable in class com.google.common.cache.CacheBuilder
 
DEFAULT_STRATEGY - Static variable in class com.google.common.hash.BloomFilter
 
DEFAULT_VALUE_SET_CAPACITY - Static variable in class com.google.common.collect.LinkedHashMultimap
 
DEFAULT_VALUES_PER_KEY - Static variable in class com.google.common.collect.ArrayListMultimap
 
DEFAULT_VALUES_PER_KEY - Static variable in class com.google.common.collect.HashMultimap
 
defaultAdapterExecutor - Static variable in class com.google.common.util.concurrent.JdkFutureAdapters.ListenableFutureAdapter
 
defaultEquivalence() - Method in enum com.google.common.cache.LocalCache.Strength
Returns the default equivalence strategy used to compare and hash keys or values referenced at this strength.
defaultEquivalence() - Method in enum com.google.common.collect.MapMakerInternalMap.Strength
Returns the default equivalence strategy used to compare and hash keys or values referenced at this strength.
defaultLoader - Variable in class com.google.common.cache.LocalCache
The default cache loader to use on loading operations.
Defaults - Class in com.google.common.base
This class provides default values for all Java types, as defined by the JLS.
Defaults() - Constructor for class com.google.common.base.Defaults
 
DEFAULTS - Static variable in class com.google.common.base.Defaults
 
defaultValue(Class<T>) - Static method in class com.google.common.base.Defaults
Returns the default value of type as defined by JLS --- 0 for numbers, false for boolean and '\0' for char.
defaultValue - Variable in class com.google.common.base.Functions.ForMapWithDefault
 
defensiveCopy(T...) - Static method in class com.google.common.base.Predicates
 
defensiveCopy(Iterable<T>) - Static method in class com.google.common.base.Predicates
 
DEL - Static variable in class com.google.common.base.Ascii
Delete: This character is used primarily to "erase" or "obliterate" erroneous or unwanted characters in perforated tape.
delay - Variable in class com.google.common.util.concurrent.AbstractScheduledService.CustomScheduler.Schedule
 
delegate - Variable in class com.google.common.base.Suppliers.ExpiringMemoizingSupplier
 
delegate - Variable in class com.google.common.base.Suppliers.MemoizingSupplier
 
delegate - Variable in class com.google.common.base.Suppliers.ThreadSafeSupplier
 
delegate() - Method in class com.google.common.cache.ForwardingCache
 
delegate - Variable in class com.google.common.cache.ForwardingCache.SimpleForwardingCache
 
delegate() - Method in class com.google.common.cache.ForwardingCache.SimpleForwardingCache
 
delegate() - Method in class com.google.common.cache.ForwardingLoadingCache
 
delegate - Variable in class com.google.common.cache.ForwardingLoadingCache.SimpleForwardingLoadingCache
 
delegate() - Method in class com.google.common.cache.ForwardingLoadingCache.SimpleForwardingLoadingCache
 
delegate - Variable in class com.google.common.cache.LocalCache.ManualSerializationProxy
 
delegate() - Method in class com.google.common.cache.LocalCache.ManualSerializationProxy
 
delegate - Variable in class com.google.common.collect.AbstractBiMap
 
delegate() - Method in class com.google.common.collect.AbstractBiMap
 
delegate() - Method in class com.google.common.collect.AbstractBiMap.EntrySet
 
delegate() - Method in class com.google.common.collect.AbstractBiMap.KeySet
 
delegate() - Method in class com.google.common.collect.AbstractBiMap.ValueSet
 
delegate - Variable in class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection
 
delegate - Variable in class com.google.common.collect.Constraints.ConstrainedCollection
 
delegate() - Method in class com.google.common.collect.Constraints.ConstrainedCollection
 
delegate - Variable in class com.google.common.collect.Constraints.ConstrainedList
 
delegate() - Method in class com.google.common.collect.Constraints.ConstrainedList
 
delegate - Variable in class com.google.common.collect.Constraints.ConstrainedListIterator
 
delegate() - Method in class com.google.common.collect.Constraints.ConstrainedListIterator
 
delegate - Variable in class com.google.common.collect.Constraints.ConstrainedSet
 
delegate() - Method in class com.google.common.collect.Constraints.ConstrainedSet
 
delegate - Variable in class com.google.common.collect.Constraints.ConstrainedSortedSet
 
delegate() - Method in class com.google.common.collect.Constraints.ConstrainedSortedSet
 
delegate() - Method in class com.google.common.collect.DescendingMultiset
 
delegate - Variable in class com.google.common.collect.EvictingQueue
 
delegate() - Method in class com.google.common.collect.EvictingQueue
 
delegate() - Method in class com.google.common.collect.FilteredKeyMultimap.AddRejectingList
 
delegate() - Method in class com.google.common.collect.FilteredKeyMultimap.AddRejectingSet
 
delegate() - Method in class com.google.common.collect.FilteredKeyMultimap.Entries
 
delegate() - Method in class com.google.common.collect.ForwardingBlockingDeque
 
delegate() - Method in class com.google.common.collect.ForwardingCollection
 
delegate() - Method in class com.google.common.collect.ForwardingConcurrentMap
 
delegate() - Method in class com.google.common.collect.ForwardingDeque
 
delegate() - Method in class com.google.common.collect.ForwardingIterator
 
delegate() - Method in class com.google.common.collect.ForwardingList
 
delegate() - Method in class com.google.common.collect.ForwardingListIterator
 
delegate() - Method in class com.google.common.collect.ForwardingListMultimap
 
delegate() - Method in class com.google.common.collect.ForwardingMap
 
delegate() - Method in class com.google.common.collect.ForwardingMapEntry
 
delegate() - Method in class com.google.common.collect.ForwardingMultimap
 
delegate() - Method in class com.google.common.collect.ForwardingMultiset
 
delegate() - Method in class com.google.common.collect.ForwardingNavigableMap
 
delegate() - Method in class com.google.common.collect.ForwardingNavigableSet
 
delegate() - Method in class com.google.common.collect.ForwardingObject
Returns the backing delegate instance that methods are forwarded to.
delegate() - Method in class com.google.common.collect.ForwardingQueue
 
delegate() - Method in class com.google.common.collect.ForwardingSet
 
delegate() - Method in class com.google.common.collect.ForwardingSetMultimap
 
delegate() - Method in class com.google.common.collect.ForwardingSortedMap
 
delegate() - Method in class com.google.common.collect.ForwardingSortedMultiset
 
delegate() - Method in class com.google.common.collect.ForwardingSortedSet
 
delegate() - Method in class com.google.common.collect.ForwardingSortedSetMultimap
 
delegate() - Method in class com.google.common.collect.ForwardingTable
 
delegate - Variable in class com.google.common.collect.ImmutableClassToInstanceMap
 
delegate() - Method in class com.google.common.collect.ImmutableClassToInstanceMap
 
delegate - Variable in class com.google.common.collect.ImmutableEnumMap
 
delegate - Variable in class com.google.common.collect.ImmutableEnumMap.EnumSerializedForm
 
delegate - Variable in class com.google.common.collect.ImmutableEnumSet
 
delegate - Variable in class com.google.common.collect.ImmutableEnumSet.EnumSerializedForm
 
delegate - Variable in class com.google.common.collect.ImmutableMap.MapViewOfValuesAsSingletonSets
 
delegate() - Method in class com.google.common.collect.MapConstraints.ConstrainedAsMapEntries
 
delegate - Variable in class com.google.common.collect.MapConstraints.ConstrainedAsMapValues
 
delegate() - Method in class com.google.common.collect.MapConstraints.ConstrainedAsMapValues
 
delegate() - Method in class com.google.common.collect.MapConstraints.ConstrainedBiMap
 
delegate() - Method in class com.google.common.collect.MapConstraints.ConstrainedEntries
 
delegate - Variable in class com.google.common.collect.MapConstraints.ConstrainedMap
 
delegate() - Method in class com.google.common.collect.MapConstraints.ConstrainedMap
 
delegate - Variable in class com.google.common.collect.MapConstraints.ConstrainedMultimap
 
delegate() - Method in class com.google.common.collect.MapConstraints.ConstrainedMultimap
 
delegate - Variable in class com.google.common.collect.MapMakerInternalMap.AbstractSerializationProxy
 
delegate() - Method in class com.google.common.collect.MapMakerInternalMap.AbstractSerializationProxy
 
delegate() - Method in class com.google.common.collect.Maps.DescendingMap
 
delegate() - Method in class com.google.common.collect.Maps.FilteredEntryMap.EntrySet
 
delegate - Variable in class com.google.common.collect.Maps.UnmodifiableBiMap
 
delegate() - Method in class com.google.common.collect.Maps.UnmodifiableBiMap
 
delegate() - Method in class com.google.common.collect.Maps.UnmodifiableEntries
 
delegate - Variable in class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
delegate() - Method in class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
delegate() - Method in class com.google.common.collect.Multimaps.UnmodifiableListMultimap
 
delegate - Variable in class com.google.common.collect.Multimaps.UnmodifiableMultimap
 
delegate() - Method in class com.google.common.collect.Multimaps.UnmodifiableMultimap
 
delegate() - Method in class com.google.common.collect.Multimaps.UnmodifiableSetMultimap
 
delegate() - Method in class com.google.common.collect.Multimaps.UnmodifiableSortedSetMultimap
 
delegate - Variable in class com.google.common.collect.Multisets.UnmodifiableMultiset
 
delegate() - Method in class com.google.common.collect.Multisets.UnmodifiableMultiset
 
delegate - Variable in class com.google.common.collect.RegularImmutableAsList
 
delegate - Variable in class com.google.common.collect.Sets.CartesianSet
 
delegate() - Method in class com.google.common.collect.Sets.CartesianSet
 
delegate() - Method in class com.google.common.collect.Sets.DescendingSet
 
delegate - Variable in class com.google.common.collect.Sets.UnmodifiableNavigableSet
 
delegate() - Method in class com.google.common.collect.Sets.UnmodifiableNavigableSet
 
delegate() - Method in class com.google.common.collect.Synchronized.SynchronizedBiMap
 
delegate() - Method in class com.google.common.collect.Synchronized.SynchronizedCollection
 
delegate() - Method in class com.google.common.collect.Synchronized.SynchronizedDeque
 
delegate() - Method in class com.google.common.collect.Synchronized.SynchronizedEntry
 
delegate() - Method in class com.google.common.collect.Synchronized.SynchronizedList
 
delegate() - Method in class com.google.common.collect.Synchronized.SynchronizedListMultimap
 
delegate() - Method in class com.google.common.collect.Synchronized.SynchronizedMap
 
delegate() - Method in class com.google.common.collect.Synchronized.SynchronizedMultimap
 
delegate() - Method in class com.google.common.collect.Synchronized.SynchronizedMultiset
 
delegate() - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableMap
 
delegate() - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableSet
 
delegate - Variable in class com.google.common.collect.Synchronized.SynchronizedObject
 
delegate() - Method in class com.google.common.collect.Synchronized.SynchronizedObject
 
delegate() - Method in class com.google.common.collect.Synchronized.SynchronizedQueue
 
delegate() - Method in class com.google.common.collect.Synchronized.SynchronizedSet
 
delegate() - Method in class com.google.common.collect.Synchronized.SynchronizedSetMultimap
 
delegate() - Method in class com.google.common.collect.Synchronized.SynchronizedSortedMap
 
delegate() - Method in class com.google.common.collect.Synchronized.SynchronizedSortedSet
 
delegate() - Method in class com.google.common.collect.Synchronized.SynchronizedSortedSetMultimap
 
delegate() - Method in class com.google.common.collect.Tables.UnmodifiableRowSortedMap
 
delegate - Variable in class com.google.common.collect.Tables.UnmodifiableTable
 
delegate() - Method in class com.google.common.collect.Tables.UnmodifiableTable
 
delegate() - Method in class com.google.common.collect.TreeRangeSet.AsRanges
 
delegate() - Method in class com.google.common.collect.UnmodifiableSortedMultiset
 
delegate - Variable in class com.google.common.collect.WellBehavedMap
 
delegate() - Method in class com.google.common.collect.WellBehavedMap
 
delegate - Variable in class com.google.common.io.BaseEncoding.SeparatedBaseEncoding
 
delegate - Variable in class com.google.common.reflect.ImmutableTypeToInstanceMap
 
delegate() - Method in class com.google.common.reflect.ImmutableTypeToInstanceMap
 
delegate() - Method in class com.google.common.reflect.MutableTypeToInstanceMap
 
delegate - Variable in class com.google.common.reflect.MutableTypeToInstanceMap.UnmodifiableEntry
 
delegate() - Method in class com.google.common.reflect.MutableTypeToInstanceMap.UnmodifiableEntry
 
delegate() - Method in class com.google.common.reflect.TypeToken.ClassSet
 
delegate() - Method in class com.google.common.reflect.TypeToken.InterfaceSet
 
delegate - Variable in class com.google.common.reflect.TypeToken.TypeCollector.ForwardingTypeCollector
 
delegate() - Method in class com.google.common.reflect.TypeToken.TypeSet
 
delegate - Variable in class com.google.common.util.concurrent.AbstractExecutionThreadService
 
delegate - Variable in class com.google.common.util.concurrent.AbstractIdleService
 
delegate() - Method in class com.google.common.util.concurrent.AbstractScheduledService.CustomScheduler.ReschedulableCallable
 
delegate - Variable in class com.google.common.util.concurrent.AbstractScheduledService
 
delegate() - Method in class com.google.common.util.concurrent.AsyncSettableFuture
 
delegate() - Method in class com.google.common.util.concurrent.ForwardingBlockingQueue
 
delegate() - Method in class com.google.common.util.concurrent.ForwardingCheckedFuture
 
delegate - Variable in class com.google.common.util.concurrent.ForwardingCheckedFuture.SimpleForwardingCheckedFuture
 
delegate() - Method in class com.google.common.util.concurrent.ForwardingCheckedFuture.SimpleForwardingCheckedFuture
 
delegate() - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
delegate() - Method in class com.google.common.util.concurrent.ForwardingFuture
 
delegate - Variable in class com.google.common.util.concurrent.ForwardingFuture.SimpleForwardingFuture
 
delegate() - Method in class com.google.common.util.concurrent.ForwardingFuture.SimpleForwardingFuture
 
delegate() - Method in class com.google.common.util.concurrent.ForwardingListenableFuture
 
delegate - Variable in class com.google.common.util.concurrent.ForwardingListenableFuture.SimpleForwardingListenableFuture
 
delegate() - Method in class com.google.common.util.concurrent.ForwardingListenableFuture.SimpleForwardingListenableFuture
 
delegate() - Method in class com.google.common.util.concurrent.ForwardingListeningExecutorService
 
delegate - Variable in class com.google.common.util.concurrent.Futures.WrappedCombiner
 
delegate - Variable in class com.google.common.util.concurrent.JdkFutureAdapters.ListenableFutureAdapter
 
delegate() - Method in class com.google.common.util.concurrent.JdkFutureAdapters.ListenableFutureAdapter
 
delegate - Variable in class com.google.common.util.concurrent.MoreExecutors.ListeningDecorator
 
delegate - Variable in class com.google.common.util.concurrent.MoreExecutors.ScheduledListeningDecorator
 
delegate - Variable in class com.google.common.util.concurrent.MoreExecutors.ScheduledListeningDecorator.NeverSuccessfulListenableFutureTask
 
delegate - Variable in class com.google.common.util.concurrent.WrappingExecutorService
 
delegate - Variable in class com.google.common.util.concurrent.WrappingScheduledExecutorService
 
delegateCollection() - Method in class com.google.common.collect.ImmutableAsList
 
delegateCollection() - Method in class com.google.common.collect.ImmutableSortedAsList
 
delegateCollection() - Method in class com.google.common.collect.RegularImmutableAsList
 
delegateIterator - Variable in class com.google.common.collect.AbstractMapBasedMultimap.AsMap.AsMapIterator
 
delegateIterator - Variable in class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection.WrappedIterator
 
delegateList - Variable in class com.google.common.collect.RegularImmutableAsList
 
delegateList() - Method in class com.google.common.collect.RegularImmutableAsList
 
delete(HashBiMap.BiEntry<K, V>) - Method in class com.google.common.collect.HashBiMap
Finds and removes entry from the bucket linked lists in both the key-to-value direction and the value-to-key direction.
deleteFromMultimap(LinkedHashMultimap.ValueEntry<K, V>) - Static method in class com.google.common.collect.LinkedHashMultimap
 
deleteFromValueSet(LinkedHashMultimap.ValueSetLink<K, V>) - Static method in class com.google.common.collect.LinkedHashMultimap
 
deleteMe() - Method in class com.google.common.collect.TreeMultiset.AvlNode
 
DenseImmutableTable<R,C,V> - Class in com.google.common.collect
A RegularImmutableTable optimized for dense data.
DenseImmutableTable(ImmutableList<Table.Cell<R, C, V>>, ImmutableSet<R>, ImmutableSet<C>) - Constructor for class com.google.common.collect.DenseImmutableTable
 
DenseImmutableTable.Column - Class in com.google.common.collect
 
DenseImmutableTable.ColumnMap - Class in com.google.common.collect
 
DenseImmutableTable.ImmutableArrayMap<K,V> - Class in com.google.common.collect
An immutable map implementation backed by an indexed nullable array.
DenseImmutableTable.Row - Class in com.google.common.collect
 
DenseImmutableTable.RowMap - Class in com.google.common.collect
 
deque(Deque<E>, Object) - Static method in class com.google.common.collect.Synchronized
 
dereference(ListenableFuture<? extends ListenableFuture<? extends V>>) - Static method in class com.google.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.
dereferenced - Variable in class com.google.common.util.concurrent.AsyncSettableFuture
 
DEREFERENCER - Static variable in class com.google.common.util.concurrent.Futures
descendingEntryIterator() - Method in class com.google.common.collect.AbstractNavigableMap
 
descendingEntryIterator() - Method in class com.google.common.collect.AbstractSortedMultiset
 
descendingEntryIterator() - Method in class com.google.common.collect.Maps.FilteredEntryNavigableMap
 
descendingEntryIterator() - Method in class com.google.common.collect.Maps.NavigableAsMapView
 
descendingEntryIterator() - Method in class com.google.common.collect.TreeMultiset
 
descendingEntryIterator() - Method in class com.google.common.collect.TreeRangeSet.ComplementRangesByLowerBound
 
descendingEntryIterator() - Method in class com.google.common.collect.TreeRangeSet.RangesByUpperBound
 
descendingEntryIterator() - Method in class com.google.common.collect.TreeRangeSet.SubRangeSetRangesByLowerBound
 
DescendingImmutableSortedMultiset<E> - Class in com.google.common.collect
A descending wrapper around an ImmutableSortedMultiset
DescendingImmutableSortedMultiset(ImmutableSortedMultiset<E>) - Constructor for class com.google.common.collect.DescendingImmutableSortedMultiset
 
DescendingImmutableSortedSet<E> - Class in com.google.common.collect
Skeletal implementation of ImmutableSortedSet.descendingSet().
DescendingImmutableSortedSet(ImmutableSortedSet<E>) - Constructor for class com.google.common.collect.DescendingImmutableSortedSet
 
descendingIterator() - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableKeySet
 
descendingIterator() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedNavigableSet
 
descendingIterator() - Method in class com.google.common.collect.AbstractSortedMultiset
 
descendingIterator() - Method in class com.google.common.collect.DescendingImmutableSortedSet
 
descendingIterator() - Method in class com.google.common.collect.EmptyContiguousSet
 
descendingIterator() - Method in class com.google.common.collect.EmptyImmutableSortedSet
 
descendingIterator() - Method in class com.google.common.collect.ForwardingDeque
 
descendingIterator() - Method in class com.google.common.collect.ForwardingNavigableSet
 
descendingIterator() - Method in class com.google.common.collect.ImmutableRangeSet.AsSet
 
descendingIterator() - Method in class com.google.common.collect.ImmutableSortedSet
 
descendingIterator() - Method in class com.google.common.collect.Maps.NavigableKeySet
 
descendingIterator() - Method in class com.google.common.collect.RegularContiguousSet
 
descendingIterator() - Method in class com.google.common.collect.RegularImmutableSortedSet
 
descendingIterator() - Method in class com.google.common.collect.Sets.DescendingSet
 
descendingIterator() - Method in class com.google.common.collect.Sets.FilteredNavigableSet
 
descendingIterator() - Method in class com.google.common.collect.Sets.UnmodifiableNavigableSet
 
descendingIterator() - Method in class com.google.common.collect.SortedMultisets.NavigableElementSet
 
descendingIterator() - Method in class com.google.common.collect.Synchronized.SynchronizedDeque
 
descendingIterator() - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableSet
 
descendingKeySet() - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableAsMap
 
descendingKeySet() - Method in class com.google.common.collect.AbstractNavigableMap
 
descendingKeySet() - Method in class com.google.common.collect.ForwardingNavigableMap
 
descendingKeySet() - Method in class com.google.common.collect.ImmutableSortedMap
 
descendingKeySet() - Method in class com.google.common.collect.Maps.DescendingMap
 
descendingKeySet() - Method in class com.google.common.collect.Maps.TransformedEntriesNavigableMap
 
descendingKeySet() - Method in class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
descendingKeySet - Variable in class com.google.common.collect.Synchronized.SynchronizedNavigableMap
 
descendingKeySet() - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableMap
 
descendingMap() - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableAsMap
 
descendingMap() - Method in class com.google.common.collect.AbstractNavigableMap
 
DescendingMap() - Constructor for class com.google.common.collect.AbstractNavigableMap.DescendingMap
 
descendingMap() - Method in class com.google.common.collect.ForwardingNavigableMap
 
descendingMap - Variable in class com.google.common.collect.ImmutableSortedMap
 
descendingMap() - Method in class com.google.common.collect.ImmutableSortedMap
 
DescendingMap() - Constructor for class com.google.common.collect.Maps.DescendingMap
 
descendingMap() - Method in class com.google.common.collect.Maps.DescendingMap
 
descendingMap() - Method in class com.google.common.collect.Maps.FilteredEntryNavigableMap
 
descendingMap() - Method in class com.google.common.collect.Maps.NavigableAsMapView
 
descendingMap() - Method in class com.google.common.collect.Maps.TransformedEntriesNavigableMap
 
descendingMap - Variable in class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
descendingMap() - Method in class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
descendingMap - Variable in class com.google.common.collect.Synchronized.SynchronizedNavigableMap
 
descendingMap() - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableMap
 
descendingMultiset - Variable in class com.google.common.collect.AbstractSortedMultiset
 
descendingMultiset() - Method in class com.google.common.collect.AbstractSortedMultiset
 
descendingMultiset() - Method in class com.google.common.collect.DescendingImmutableSortedMultiset
 
DescendingMultiset<E> - Class in com.google.common.collect
A skeleton implementation of a descending multiset.
DescendingMultiset() - Constructor for class com.google.common.collect.DescendingMultiset
 
descendingMultiset() - Method in class com.google.common.collect.DescendingMultiset
 
descendingMultiset() - Method in class com.google.common.collect.ForwardingSortedMultiset
 
descendingMultiset - Variable in class com.google.common.collect.ImmutableSortedMultiset
 
descendingMultiset() - Method in class com.google.common.collect.ImmutableSortedMultiset
 
descendingMultiset() - Method in interface com.google.common.collect.SortedMultiset
Returns a descending view of this multiset.
descendingMultiset - Variable in class com.google.common.collect.UnmodifiableSortedMultiset
 
descendingMultiset() - Method in class com.google.common.collect.UnmodifiableSortedMultiset
 
descendingSet() - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableKeySet
 
descendingSet() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedNavigableSet
 
descendingSet() - Method in class com.google.common.collect.DescendingImmutableSortedSet
 
descendingSet() - Method in class com.google.common.collect.ForwardingNavigableSet
 
descendingSet - Variable in class com.google.common.collect.ImmutableSortedSet
 
descendingSet() - Method in class com.google.common.collect.ImmutableSortedSet
 
descendingSet() - Method in class com.google.common.collect.Maps.NavigableKeySet
 
DescendingSet(NavigableSet<E>) - Constructor for class com.google.common.collect.Sets.DescendingSet
 
descendingSet() - Method in class com.google.common.collect.Sets.DescendingSet
 
descendingSet() - Method in class com.google.common.collect.Sets.FilteredNavigableSet
 
descendingSet - Variable in class com.google.common.collect.Sets.UnmodifiableNavigableSet
 
descendingSet() - Method in class com.google.common.collect.Sets.UnmodifiableNavigableSet
 
descendingSet() - Method in class com.google.common.collect.SortedMultisets.NavigableElementSet
 
descendingSet - Variable in class com.google.common.collect.Synchronized.SynchronizedNavigableSet
 
descendingSet() - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableSet
 
describeAsLowerBound(StringBuilder) - Method in class com.google.common.collect.Cut.AboveAll
 
describeAsLowerBound(StringBuilder) - Method in class com.google.common.collect.Cut.AboveValue
 
describeAsLowerBound(StringBuilder) - Method in class com.google.common.collect.Cut.BelowAll
 
describeAsLowerBound(StringBuilder) - Method in class com.google.common.collect.Cut.BelowValue
 
describeAsLowerBound(StringBuilder) - Method in class com.google.common.collect.Cut
 
describeAsUpperBound(StringBuilder) - Method in class com.google.common.collect.Cut.AboveAll
 
describeAsUpperBound(StringBuilder) - Method in class com.google.common.collect.Cut.AboveValue
 
describeAsUpperBound(StringBuilder) - Method in class com.google.common.collect.Cut.BelowAll
 
describeAsUpperBound(StringBuilder) - Method in class com.google.common.collect.Cut.BelowValue
 
describeAsUpperBound(StringBuilder) - Method in class com.google.common.collect.Cut
 
description - Variable in class com.google.common.base.CharMatcher
 
DESIRED_LOAD_FACTOR - Static variable in class com.google.common.base.SmallCharMatcher
 
DESIRED_LOAD_FACTOR - Static variable in class com.google.common.collect.ImmutableSet
 
DEST_PAD - Static variable in class com.google.common.escape.UnicodeEscaper
The amount of padding (chars) to use when growing the escape buffer.
DEST_PAD_MULTIPLIER - Static variable in class com.google.common.escape.CharEscaper
The multiplier for padding to use when growing the escape buffer.
DEST_TL - Static variable in class com.google.common.escape.Platform
A thread-local destination buffer to keep us from creating new buffers.
detectJvmBehavior() - Static method in enum com.google.common.reflect.Types.ClassOwnership
 
difference(Map<? extends K, ? extends V>, Map<? extends K, ? extends V>) - Static method in class com.google.common.collect.Maps
Computes the difference between two maps.
difference(Map<? extends K, ? extends V>, Map<? extends K, ? extends V>, Equivalence<? super V>) - Static method in class com.google.common.collect.Maps
Computes the difference between two maps.
difference(SortedMap<K, ? extends V>, Map<? extends K, ? extends V>) - Static method in class com.google.common.collect.Maps
Computes the difference between two sorted maps, using the comparator of the left map, or Ordering.natural() if the left map uses the natural ordering of its elements.
difference(Multiset<E>, Multiset<?>) - Static method in class com.google.common.collect.Multisets
Returns an unmodifiable view of the difference of two multisets.
difference(Set<E>, Set<?>) - Static method in class com.google.common.collect.Sets
Returns an unmodifiable view of the difference of two sets.
differences - Variable in class com.google.common.collect.Maps.MapDifferenceImpl
 
digest - Variable in class com.google.common.hash.MessageDigestHashFunction.MessageDigestHasher
 
DIGIT - Static variable in class com.google.common.base.CharMatcher
Determines whether a character is a digit according to Unicode.
digit(char) - Static method in class com.google.common.primitives.Ints
 
directExecutor() - Static method in class com.google.common.util.concurrent.MoreExecutors
Returns an Executor that runs each task in the thread that invokes execute, as in ThreadPoolExecutor.CallerRunsPolicy.
DirectExecutor() - Constructor for enum com.google.common.util.concurrent.MoreExecutors.DirectExecutor
 
DirectExecutorService() - Constructor for class com.google.common.util.concurrent.MoreExecutors.DirectExecutorService
 
DirectLoader() - Constructor for class com.google.common.base.FinalizableReferenceQueue.DirectLoader
 
disableCaching() - Static method in class com.google.common.cache.CacheBuilderSpec
Returns a CacheBuilderSpec that will prevent caching.
disabled - Static variable in class com.google.common.base.FinalizableReferenceQueue.SystemLoader
 
disallowedPriorLocks - Variable in class com.google.common.util.concurrent.CycleDetectingLockFactory.LockGraphNode
The map tracking lock nodes that can cause a lock acquisition cycle if acquired before this node.
disallowPrimitiveType(Type[], String) - Static method in class com.google.common.reflect.Types
 
DISCARDING_QUEUE - Static variable in class com.google.common.cache.LocalCache
 
DISCARDING_QUEUE - Static variable in class com.google.common.collect.MapMakerInternalMap
 
discardingQueue() - Static method in class com.google.common.cache.LocalCache
Queue that discards all elements.
discardingQueue() - Static method in class com.google.common.collect.MapMakerInternalMap
Queue that discards all elements.
DiscreteDomain<C extends java.lang.Comparable> - Class in com.google.common.collect
A descriptor for a discrete Comparable domain such as all Integer instances.
DiscreteDomain() - Constructor for class com.google.common.collect.DiscreteDomain
Constructor for use by subclasses.
DiscreteDomain.BigIntegerDomain - Class in com.google.common.collect
 
DiscreteDomain.IntegerDomain - Class in com.google.common.collect
 
DiscreteDomain.LongDomain - Class in com.google.common.collect
 
dispatch(Object, EventSubscriber) - Method in class com.google.common.eventbus.AsyncEventBus
Calls the AsyncEventBus.executor to dispatch event to subscriber.
dispatch(Object, EventSubscriber) - Method in class com.google.common.eventbus.EventBus
Dispatches event to the subscriber in wrapper.
dispatchQueuedEvents() - Method in class com.google.common.eventbus.AsyncEventBus
Dispatch events in the order they were posted, regardless of the posting thread.
dispatchQueuedEvents() - Method in class com.google.common.eventbus.EventBus
Drain the queue of events to be dispatched.
distance(BigInteger, BigInteger) - Method in class com.google.common.collect.DiscreteDomain.BigIntegerDomain
 
distance(C, C) - Method in class com.google.common.collect.DiscreteDomain
Returns a signed value indicating how many nested invocations of DiscreteDomain.next(C) (if positive) or DiscreteDomain.previous(C) (if negative) are needed to reach end starting from start.
distance(Integer, Integer) - Method in class com.google.common.collect.DiscreteDomain.IntegerDomain
 
distance(Long, Long) - Method in class com.google.common.collect.DiscreteDomain.LongDomain
 
DISTINCT_CHARS - Static variable in class com.google.common.base.CharMatcher
 
distinctElements() - Method in class com.google.common.collect.AbstractMapBasedMultiset
 
distinctElements() - Method in class com.google.common.collect.AbstractMultiset
 
distinctElements() - Method in class com.google.common.collect.ConcurrentHashMultiset
 
distinctElements() - Method in class com.google.common.collect.Multimaps.Keys
 
distinctElements() - Method in class com.google.common.collect.Multisets.FilteredMultiset
 
distinctElements - Variable in class com.google.common.collect.TreeMultiset.AvlNode
 
distinctElements() - Method in class com.google.common.collect.TreeMultiset
 
distinctElements(TreeMultiset.AvlNode<?>) - Static method in class com.google.common.collect.TreeMultiset
 
DistinctKeyIterator() - Constructor for class com.google.common.collect.LinkedListMultimap.DistinctKeyIterator
 
divide(BigInteger, BigInteger, RoundingMode) - Static method in class com.google.common.math.BigIntegerMath
Returns the result of dividing p by q, rounding using the specified RoundingMode.
divide(int, int, RoundingMode) - Static method in class com.google.common.math.IntMath
Returns the result of dividing p by q, rounding using the specified RoundingMode.
divide(long, long, RoundingMode) - Static method in class com.google.common.math.LongMath
Returns the result of dividing p by q, rounding using the specified RoundingMode.
divide(int, int) - Static method in class com.google.common.primitives.UnsignedInts
Returns dividend / divisor, where the dividend and divisor are treated as unsigned 32-bit quantities.
divide(long, long) - Static method in class com.google.common.primitives.UnsignedLongs
Returns dividend / divisor, where the dividend and divisor are treated as unsigned 64-bit quantities.
dividedBy(UnsignedInteger) - Method in class com.google.common.primitives.UnsignedInteger
Returns the result of dividing this by val.
dividedBy(UnsignedLong) - Method in class com.google.common.primitives.UnsignedLong
Returns the result of dividing this by val.
DLE - Static variable in class com.google.common.base.Ascii
Data Link Escape: A communication control character which will change the meaning of a limited number of contiguously following characters.
DNT - Static variable in class com.google.common.net.HttpHeaders
The HTTP DNT header field name.
doAndThen(Converter<B, C>) - Method in class com.google.common.base.Converter
Package-private non-final implementation of andThen() so only we can override it.
doAndThen(Converter<T, S>) - Method in class com.google.common.base.Converter.IdentityConverter
 
doBackward(String) - Method in class com.google.common.base.CaseFormat.StringConverter
 
doBackward(C) - Method in class com.google.common.base.Converter.ConverterComposition
 
doBackward(B) - Method in class com.google.common.base.Converter
Returns a representation of b as an instance of type A.
doBackward(B) - Method in class com.google.common.base.Converter.FunctionBasedConverter
 
doBackward(T) - Method in class com.google.common.base.Converter.IdentityConverter
 
doBackward(A) - Method in class com.google.common.base.Converter.ReverseConverter
 
doBackward(T) - Method in class com.google.common.base.Enums.StringConverter
 
doBackward(B) - Method in class com.google.common.collect.Maps.BiMapConverter
 
doBackward(Double) - Method in class com.google.common.primitives.Doubles.DoubleConverter
 
doBackward(Float) - Method in class com.google.common.primitives.Floats.FloatConverter
 
doBackward(Integer) - Method in class com.google.common.primitives.Ints.IntConverter
 
doBackward(Long) - Method in class com.google.common.primitives.Longs.LongConverter
 
doBackward(Short) - Method in class com.google.common.primitives.Shorts.ShortConverter
 
doDifference(Map<? extends K, ? extends V>, Map<? extends K, ? extends V>, Equivalence<? super V>, Map<K, V>, Map<K, V>, Map<K, V>, Map<K, MapDifference.ValueDifference<V>>) - Static method in class com.google.common.collect.Maps
 
doEquivalent(T, T) - Method in class com.google.common.base.Equivalence
Returns true if a and b are considered equivalent.
doEquivalent(Object, Object) - Method in class com.google.common.base.Equivalence.Equals
 
doEquivalent(Object, Object) - Method in class com.google.common.base.Equivalence.Identity
 
doEquivalent(F, F) - Method in class com.google.common.base.FunctionalEquivalence
 
doEquivalent(Iterable<T>, Iterable<T>) - Method in class com.google.common.base.PairwiseEquivalence
 
doForward(String) - Method in class com.google.common.base.CaseFormat.StringConverter
 
doForward(A) - Method in class com.google.common.base.Converter.ConverterComposition
 
doForward(A) - Method in class com.google.common.base.Converter
Returns a representation of a as an instance of type B.
doForward(A) - Method in class com.google.common.base.Converter.FunctionBasedConverter
 
doForward(T) - Method in class com.google.common.base.Converter.IdentityConverter
 
doForward(B) - Method in class com.google.common.base.Converter.ReverseConverter
 
doForward(String) - Method in class com.google.common.base.Enums.StringConverter
 
doForward(A) - Method in class com.google.common.collect.Maps.BiMapConverter
 
doForward(String) - Method in class com.google.common.primitives.Doubles.DoubleConverter
 
doForward(String) - Method in class com.google.common.primitives.Floats.FloatConverter
 
doForward(String) - Method in class com.google.common.primitives.Ints.IntConverter
 
doForward(String) - Method in class com.google.common.primitives.Longs.LongConverter
 
doForward(String) - Method in class com.google.common.primitives.Shorts.ShortConverter
 
doGetRate() - Method in class com.google.common.util.concurrent.RateLimiter
 
doGetRate() - Method in class com.google.common.util.concurrent.SmoothRateLimiter
 
doHash(T) - Method in class com.google.common.base.Equivalence
Returns a hash code for non-null object t.
doHash(Object) - Method in class com.google.common.base.Equivalence.Equals
 
doHash(Object) - Method in class com.google.common.base.Equivalence.Identity
 
doHash(F) - Method in class com.google.common.base.FunctionalEquivalence
 
doHash(Iterable<T>) - Method in class com.google.common.base.PairwiseEquivalence
 
domain - Variable in class com.google.common.collect.ContiguousSet
 
domain - Variable in class com.google.common.collect.EmptyContiguousSet.SerializedForm
 
domain - Variable in class com.google.common.collect.ImmutableRangeSet.AsSet
 
domain - Variable in class com.google.common.collect.ImmutableRangeSet.AsSetSerializedForm
 
domain - Variable in class com.google.common.collect.RegularContiguousSet.SerializedForm
 
done - Variable in class com.google.common.hash.MessageDigestHashFunction.MessageDigestHasher
 
done() - Method in class com.google.common.util.concurrent.Futures.CombinerFuture
 
done() - Method in class com.google.common.util.concurrent.ListenableFutureTask
Internal implementation detail used to invoke the listeners.
doNothing() - Static method in class com.google.common.util.concurrent.Runnables
Returns a Runnable instance that does nothing when run.
doParseTrieToBuilder(List<CharSequence>, CharSequence, ImmutableMap.Builder<String, PublicSuffixType>) - Static method in class com.google.thirdparty.publicsuffix.TrieParser
Parses a trie node and returns the number of characters consumed.
doSetRate(double, long) - Method in class com.google.common.util.concurrent.RateLimiter
 
doSetRate(double, long) - Method in class com.google.common.util.concurrent.SmoothRateLimiter
 
doSetRate(double, double) - Method in class com.google.common.util.concurrent.SmoothRateLimiter
 
doSetRate(double, double) - Method in class com.google.common.util.concurrent.SmoothRateLimiter.SmoothBursty
 
doSetRate(double, double) - Method in class com.google.common.util.concurrent.SmoothRateLimiter.SmoothWarmingUp
 
doStart() - Method in class com.google.common.util.concurrent.AbstractService
This method is called by AbstractService.startAsync() to initiate service startup.
doStart() - Method in class com.google.common.util.concurrent.ServiceManager.NoOpService
 
doStop() - Method in class com.google.common.util.concurrent.AbstractService
This method should be used to initiate service shutdown.
doStop() - Method in class com.google.common.util.concurrent.ServiceManager.NoOpService
 
DOT_JOINER - Static variable in class com.google.common.net.InternetDomainName
 
DOT_REGEX - Static variable in class com.google.common.net.InternetDomainName
 
DOT_SPLITTER - Static variable in class com.google.common.net.InternetDomainName
 
DOTS_MATCHER - Static variable in class com.google.common.net.InternetDomainName
 
DoubleArrayAsList(double[]) - Constructor for class com.google.common.primitives.Doubles.DoubleArrayAsList
 
DoubleArrayAsList(double[], int, int) - Constructor for class com.google.common.primitives.Doubles.DoubleArrayAsList
 
DoubleConverter() - Constructor for class com.google.common.primitives.Doubles.DoubleConverter
 
DoubleMath - Class in com.google.common.math
A class for arithmetic on doubles that is not covered by Math.
DoubleMath() - Constructor for class com.google.common.math.DoubleMath
 
DoubleMath.MeanAccumulator - Class in com.google.common.math
 
Doubles - Class in com.google.common.primitives
Static utility methods pertaining to double primitives, that are not already found in either Double or Arrays.
Doubles() - Constructor for class com.google.common.primitives.Doubles
 
Doubles.DoubleArrayAsList - Class in com.google.common.primitives
 
Doubles.DoubleConverter - Class in com.google.common.primitives
 
Doubles.LexicographicalComparator - Enum in com.google.common.primitives
 
DoubleUtils - Class in com.google.common.math
Utilities for double primitives.
DoubleUtils() - Constructor for class com.google.common.math.DoubleUtils
 
doubleValue() - Method in class com.google.common.cache.LongAdder
Returns the LongAdder.sum() as a double after a widening primitive conversion.
doubleValue() - Method in class com.google.common.primitives.UnsignedInteger
Returns the value of this UnsignedInteger as a float, analogous to a widening primitive conversion from int to double, and correctly rounded.
doubleValue() - Method in class com.google.common.primitives.UnsignedLong
Returns the value of this UnsignedLong as a double, analogous to a widening primitive conversion from long to double, and correctly rounded.
doubleValue() - Method in class com.google.common.util.concurrent.AtomicDouble
Returns the value of this AtomicDouble as a double.
downTo(Comparator<? super T>, T, BoundType) - Static method in class com.google.common.collect.GeneralRange
Returns everything above the endpoint relative to the specified comparator, with the specified endpoint behavior.
downTo(C, BoundType) - Static method in class com.google.common.collect.Range
Returns a range from the given endpoint, which may be either inclusive (closed) or exclusive (open), with no upper bound.
drain(BlockingQueue<E>, Collection<? super E>, int, long, TimeUnit) - Static method in class com.google.common.collect.Queues
Drains the queue as BlockingQueue.drainTo(Collection, int), but if the requested numElements elements are not available, it will wait for them up to the specified timeout.
DRAIN_MAX - Static variable in class com.google.common.cache.LocalCache
Maximum number of entries to be drained in a single cleanup run.
DRAIN_MAX - Static variable in class com.google.common.collect.MapMakerInternalMap
Maximum number of entries to be drained in a single cleanup run.
DRAIN_THRESHOLD - Static variable in class com.google.common.cache.LocalCache
Number of cache access operations that can be buffered per segment before the cache's recency ordering information is updated.
DRAIN_THRESHOLD - Static variable in class com.google.common.collect.MapMakerInternalMap
Number of cache access operations that can be buffered per segment before the cache's recency ordering information is updated.
drainKeyReferenceQueue() - Method in class com.google.common.cache.LocalCache.Segment
 
drainKeyReferenceQueue() - Method in class com.google.common.collect.MapMakerInternalMap.Segment
 
drainQueue() - Method in class com.google.common.util.concurrent.Striped.SmallLazyStriped
 
drainRecencyQueue() - Method in class com.google.common.cache.LocalCache.Segment
Drains the recency queue, updating eviction metadata that the entries therein were read in the specified relative order.
drainRecencyQueue() - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Drains the recency queue, updating eviction metadata that the entries therein were read in the specified relative order.
drainReferenceQueues() - Method in class com.google.common.cache.LocalCache.Segment
Drain the key and value reference queues, cleaning up internal entries containing garbage collected keys or values.
drainReferenceQueues() - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Drain the key and value reference queues, cleaning up internal entries containing garbage collected keys or values.
drainTo(Collection<? super E>) - Method in class com.google.common.collect.ForwardingBlockingDeque
 
drainTo(Collection<? super E>, int) - Method in class com.google.common.collect.ForwardingBlockingDeque
 
drainTo(Collection<? super E>, int) - Method in class com.google.common.util.concurrent.ForwardingBlockingQueue
 
drainTo(Collection<? super E>) - Method in class com.google.common.util.concurrent.ForwardingBlockingQueue
 
drainUninterruptibly(BlockingQueue<E>, Collection<? super E>, int, long, TimeUnit) - Static method in class com.google.common.collect.Queues
Drains the queue as Queues.drain(BlockingQueue, Collection, int, long, TimeUnit), but with a different behavior in case it is interrupted while waiting.
drainValueReferenceQueue() - Method in class com.google.common.cache.LocalCache.Segment
 
drainValueReferenceQueue() - Method in class com.google.common.collect.MapMakerInternalMap.Segment
 
Dummy() - Constructor for enum com.google.common.collect.Interners.WeakInterner.Dummy
 
durationInNanos(long, TimeUnit) - Static method in class com.google.common.cache.CacheBuilderSpec
Converts an expiration duration/unit pair into a single Long for hashing and equality.
durationNanos - Variable in class com.google.common.base.Suppliers.ExpiringMemoizingSupplier
 
DurationParser() - Constructor for class com.google.common.cache.CacheBuilderSpec.DurationParser
 

E

elapsed(TimeUnit) - Method in class com.google.common.base.Stopwatch
Returns the current elapsed time shown on this stopwatch, expressed in the desired time unit, with any fraction rounded down.
elapsedNanos - Variable in class com.google.common.base.Stopwatch
 
elapsedNanos() - Method in class com.google.common.base.Stopwatch
 
elapsedNanos() - Method in class com.google.common.cache.LocalCache.LoadingValueReference
 
elem - Variable in class com.google.common.collect.TreeMultiset.AvlNode
 
elemCount - Variable in class com.google.common.collect.TreeMultiset.AvlNode
 
element() - Method in class com.google.common.collect.ForwardingQueue
 
element - Variable in class com.google.common.collect.Multisets.ImmutableEntry
 
element - Variable in class com.google.common.collect.SingletonImmutableList
 
element - Variable in class com.google.common.collect.SingletonImmutableSet
 
element() - Method in class com.google.common.collect.Synchronized.SynchronizedQueue
 
Element - Class in com.google.common.reflect
Represents either a Field, a Method or a Constructor.
Element(M) - Constructor for class com.google.common.reflect.Element
 
elementData(int) - Method in class com.google.common.collect.MinMaxPriorityQueue
 
elementEquivalence - Variable in class com.google.common.base.PairwiseEquivalence
 
elementFunnel - Variable in class com.google.common.hash.Funnels.SequentialFunnel
 
elementOrder - Variable in class com.google.common.collect.LexicographicalOrdering
 
elements - Variable in class com.google.common.collect.ImmutableList.SerializedForm
 
elements - Variable in class com.google.common.collect.ImmutableMultiset.SerializedForm
 
elements - Variable in class com.google.common.collect.ImmutableSet.SerializedForm
 
elements - Variable in class com.google.common.collect.ImmutableSortedMultiset.SerializedForm
 
elements - Variable in class com.google.common.collect.ImmutableSortedSet.SerializedForm
 
elements - Variable in class com.google.common.collect.RegularImmutableSet
 
elements - Variable in class com.google.common.collect.RegularImmutableSortedSet
 
elementsEqual(Iterable<?>, Iterable<?>) - Static method in class com.google.common.collect.Iterables
Determines whether two iterables contain equal elements in the same order.
elementsEqual(Iterator<?>, Iterator<?>) - Static method in class com.google.common.collect.Iterators
Determines whether two iterators contain equal elements in the same order.
elementSet - Variable in class com.google.common.collect.AbstractMultiset
 
elementSet() - Method in class com.google.common.collect.AbstractMultiset
 
ElementSet() - Constructor for class com.google.common.collect.AbstractMultiset.ElementSet
 
elementSet() - Method in class com.google.common.collect.AbstractSortedMultiset
 
elementSet() - Method in class com.google.common.collect.DescendingImmutableSortedMultiset
 
elementSet - Variable in class com.google.common.collect.DescendingMultiset
 
elementSet() - Method in class com.google.common.collect.DescendingMultiset
 
elementSet - Variable in class com.google.common.collect.EmptyImmutableSortedMultiset
 
elementSet() - Method in class com.google.common.collect.EmptyImmutableSortedMultiset
 
elementSet() - Method in class com.google.common.collect.ForwardingMultiset
 
elementSet() - Method in class com.google.common.collect.ForwardingSortedMultiset
 
elementSet() - Method in class com.google.common.collect.ImmutableMultimap.Keys
 
elementSet() - Method in class com.google.common.collect.ImmutableSortedMultiset
 
elementSet() - Method in class com.google.common.collect.Multimaps.Keys
 
elementSet() - Method in interface com.google.common.collect.Multiset
Returns the set of distinct elements contained in this multiset.
ElementSet() - Constructor for class com.google.common.collect.Multisets.ElementSet
 
elementSet - Variable in class com.google.common.collect.Multisets.UnmodifiableMultiset
 
elementSet() - Method in class com.google.common.collect.Multisets.UnmodifiableMultiset
 
elementSet() - Method in class com.google.common.collect.RegularImmutableMultiset
 
elementSet - Variable in class com.google.common.collect.RegularImmutableSortedMultiset
 
elementSet() - Method in class com.google.common.collect.RegularImmutableSortedMultiset
 
elementSet() - Method in interface com.google.common.collect.SortedMultiset
Returns a NavigableSet view of the distinct elements in this multiset.
elementSet() - Method in interface com.google.common.collect.SortedMultisetBridge
 
ElementSet(SortedMultiset<E>) - Constructor for class com.google.common.collect.SortedMultisets.ElementSet
 
elementSet - Variable in class com.google.common.collect.Synchronized.SynchronizedMultiset
 
elementSet() - Method in class com.google.common.collect.Synchronized.SynchronizedMultiset
 
elementSet() - Method in class com.google.common.collect.UnmodifiableSortedMultiset
 
EM - Static variable in class com.google.common.base.Ascii
End of Medium: A control character associated with the sent data which may be used to identify the physical end of the medium, or the end of the used, or wanted, portion of information recorded on a medium.
EMPTY - Static variable in class com.google.common.collect.ImmutableList
 
EMPTY - Static variable in class com.google.common.collect.ImmutableMultiset
 
EMPTY - Static variable in class com.google.common.collect.ImmutableRangeMap
 
EMPTY - Static variable in class com.google.common.collect.ImmutableRangeSet
 
EMPTY - Static variable in class com.google.common.collect.ImmutableTable
 
empty() - Static method in class com.google.common.io.ByteSource
Returns an immutable ByteSource that contains no bytes.
empty() - Static method in class com.google.common.io.CharSource
Returns an immutable CharSource that contains no characters.
EMPTY_ARRAY - Static variable in class com.google.common.collect.ObjectArrays
 
EMPTY_ENTRY_ARRAY - Static variable in class com.google.common.collect.ImmutableBiMap
 
EMPTY_ENTRY_ARRAY - Static variable in class com.google.common.collect.ImmutableMap
 
EMPTY_LIST_ITERATOR - Static variable in class com.google.common.collect.Iterators
 
EMPTY_MODIFIABLE_ITERATOR - Static variable in class com.google.common.collect.Iterators
 
EMPTY_REPLACEMENT_ARRAY - Static variable in class com.google.common.escape.ArrayBasedEscaperMap
 
EMPTY_RUNNABLE - Static variable in class com.google.common.util.concurrent.Runnables
 
EMPTY_SET_FIELD_SETTER - Static variable in class com.google.common.collect.ImmutableMultimap.FieldSettersHolder
 
EMPTY_STACK_TRACE - Static variable in exception com.google.common.util.concurrent.CycleDetectingLockFactory.ExampleStackTrace
 
EMPTY_STATS - Static variable in class com.google.common.cache.CacheBuilder
 
EMPTY_SUB_RANGE_MAP - Static variable in class com.google.common.collect.TreeRangeMap
 
EmptyByteSource() - Constructor for class com.google.common.io.ByteSource.EmptyByteSource
 
EmptyCharSource() - Constructor for class com.google.common.io.CharSource.EmptyCharSource
 
EmptyContiguousSet<C extends java.lang.Comparable> - Class in com.google.common.collect
An empty contiguous set.
EmptyContiguousSet(DiscreteDomain<C>) - Constructor for class com.google.common.collect.EmptyContiguousSet
 
EmptyContiguousSet.SerializedForm<C extends java.lang.Comparable> - Class in com.google.common.collect
 
EmptyImmutableBiMap - Class in com.google.common.collect
Bimap with no mappings.
EmptyImmutableBiMap() - Constructor for class com.google.common.collect.EmptyImmutableBiMap
 
EmptyImmutableListMultimap - Class in com.google.common.collect
Implementation of ImmutableListMultimap with no entries.
EmptyImmutableListMultimap() - Constructor for class com.google.common.collect.EmptyImmutableListMultimap
 
EmptyImmutableSet - Class in com.google.common.collect
An empty immutable set.
EmptyImmutableSet() - Constructor for class com.google.common.collect.EmptyImmutableSet
 
EmptyImmutableSetMultimap - Class in com.google.common.collect
Implementation of ImmutableListMultimap with no entries.
EmptyImmutableSetMultimap() - Constructor for class com.google.common.collect.EmptyImmutableSetMultimap
 
EmptyImmutableSortedMap<K,V> - Class in com.google.common.collect
An empty immutable sorted map.
EmptyImmutableSortedMap(Comparator<? super K>) - Constructor for class com.google.common.collect.EmptyImmutableSortedMap
 
EmptyImmutableSortedMap(Comparator<? super K>, ImmutableSortedMap<K, V>) - Constructor for class com.google.common.collect.EmptyImmutableSortedMap
 
EmptyImmutableSortedMultiset<E> - Class in com.google.common.collect
An empty immutable sorted multiset.
EmptyImmutableSortedMultiset(Comparator<? super E>) - Constructor for class com.google.common.collect.EmptyImmutableSortedMultiset
 
EmptyImmutableSortedSet<E> - Class in com.google.common.collect
An empty immutable sorted set.
EmptyImmutableSortedSet(Comparator<? super E>) - Constructor for class com.google.common.collect.EmptyImmutableSortedSet
 
emptyIterator() - Static method in class com.google.common.collect.Iterators
Deprecated.
Use ImmutableSet.<T>of().iterator() instead; or for Java 7 or later, Collections.emptyIterator(). This method is scheduled for removal in May 2016.
emptyListIterator() - Static method in class com.google.common.collect.Iterators
Returns the empty iterator.
emptyMap(Comparator<? super K>) - Static method in class com.google.common.collect.ImmutableSortedMap
 
emptyModifiableIterator() - Static method in class com.google.common.collect.Iterators
Returns the empty Iterator that throws IllegalStateException instead of UnsupportedOperationException on a call to Iterator.remove().
emptyMultiset(Comparator<? super E>) - Static method in class com.google.common.collect.ImmutableSortedMultiset
 
EmptyServiceManagerWarning() - Constructor for class com.google.common.util.concurrent.ServiceManager.EmptyServiceManagerWarning
 
emptySet - Variable in class com.google.common.collect.ImmutableSetMultimap
Returned by get() when a missing key is provided.
emptySet(Comparator<? super V>) - Static method in class com.google.common.collect.ImmutableSetMultimap
 
emptySet() - Static method in class com.google.common.collect.ImmutableSortedSet
 
emptySet(Comparator<? super E>) - Static method in class com.google.common.collect.ImmutableSortedSet
 
emptySubRangeMap() - Method in class com.google.common.collect.TreeRangeMap
 
emptyToNull(String) - Static method in class com.google.common.base.Strings
Returns the given string if it is nonempty; null otherwise.
encloseAll(Iterable<C>) - Static method in class com.google.common.collect.Range
Returns the minimal range that contains all of the given values.
encloses(Range<C>) - Method in class com.google.common.collect.AbstractRangeSet
 
encloses(Range<C>) - Method in class com.google.common.collect.ImmutableRangeSet
 
encloses(Range<C>) - Method in class com.google.common.collect.Range
Returns true if the bounds of other do not extend outside the bounds of this range.
encloses(Range<C>) - Method in interface com.google.common.collect.RangeSet
Returns true if there exists a member range in this range set which encloses the specified range.
encloses(Range<C>) - Method in class com.google.common.collect.TreeRangeSet
 
encloses(Range<C>) - Method in class com.google.common.collect.TreeRangeSet.SubRangeSet
 
enclosesAll(RangeSet<C>) - Method in class com.google.common.collect.AbstractRangeSet
 
enclosesAll(RangeSet<C>) - Method in interface com.google.common.collect.RangeSet
Returns true if for each member range in other there exists a member range in this range set which encloses it.
encode(int) - Method in class com.google.common.io.BaseEncoding.Alphabet
 
encode(byte[]) - Method in class com.google.common.io.BaseEncoding
Encodes the specified byte array, and returns the encoded String.
encode(byte[], int, int) - Method in class com.google.common.io.BaseEncoding
Encodes the specified range of the specified byte array, and returns the encoded String.
encodedLength(CharSequence) - Static method in class com.google.common.base.Utf8
Returns the number of bytes in the UTF-8-encoded form of sequence.
encodedLengthGeneral(CharSequence, int) - Static method in class com.google.common.base.Utf8
 
encodingSink(CharSink) - Method in class com.google.common.io.BaseEncoding
Returns a ByteSink that writes base-encoded bytes to the specified CharSink.
encodingStream(Writer) - Method in class com.google.common.io.BaseEncoding
Returns an OutputStream that encodes bytes using this encoding into the specified Writer.
encodingStream(GwtWorkarounds.CharOutput) - Method in class com.google.common.io.BaseEncoding
 
encodingStream(GwtWorkarounds.CharOutput) - Method in class com.google.common.io.BaseEncoding.SeparatedBaseEncoding
 
encodingStream(GwtWorkarounds.CharOutput) - Method in class com.google.common.io.BaseEncoding.StandardBaseEncoding
 
end - Variable in class com.google.common.primitives.Booleans.BooleanArrayAsList
 
end - Variable in class com.google.common.primitives.Bytes.ByteArrayAsList
 
end - Variable in class com.google.common.primitives.Chars.CharArrayAsList
 
end - Variable in class com.google.common.primitives.Doubles.DoubleArrayAsList
 
end - Variable in class com.google.common.primitives.Floats.FloatArrayAsList
 
end - Variable in class com.google.common.primitives.Ints.IntArrayAsList
 
end - Variable in class com.google.common.primitives.Longs.LongArrayAsList
 
end - Variable in class com.google.common.primitives.Shorts.ShortArrayAsList
 
endOfData() - Method in class com.google.common.base.AbstractIterator
 
endOfData() - Method in class com.google.common.collect.AbstractIterator
Implementations of AbstractIterator.computeNext() must invoke this method when there are no elements left in the iteration.
endpoint() - Method in class com.google.common.collect.Cut.AboveAll
 
endpoint() - Method in class com.google.common.collect.Cut.BelowAll
 
endpoint - Variable in class com.google.common.collect.Cut
 
endpoint() - Method in class com.google.common.collect.Cut
 
endTask() - Method in class com.google.common.util.concurrent.MoreExecutors.DirectExecutorService
Decrements the running task count.
endWaitingFor(Monitor.Guard) - Method in class com.google.common.util.concurrent.Monitor
Records that the current thread is no longer waiting on the specified guard.
ENQ - Static variable in class com.google.common.base.Ascii
Enquiry: A communication control character used in data communication systems as a request for a response from a remote station.
enqueueEvent(Object, EventSubscriber) - Method in class com.google.common.eventbus.AsyncEventBus
 
enqueueEvent(Object, EventSubscriber) - Method in class com.google.common.eventbus.EventBus
Queue the event for dispatch during EventBus.dispatchQueuedEvents().
enqueueNotification(LocalCache.ReferenceEntry<K, V>, RemovalCause) - Method in class com.google.common.cache.LocalCache.Segment
 
enqueueNotification(K, int, LocalCache.ValueReference<K, V>, RemovalCause) - Method in class com.google.common.cache.LocalCache.Segment
 
enqueueNotification(MapMakerInternalMap.ReferenceEntry<K, V>, MapMaker.RemovalCause) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
 
enqueueNotification(K, int, V, MapMaker.RemovalCause) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
 
enqueueOn(Iterable<ListenerCallQueue<L>>) - Method in class com.google.common.util.concurrent.ListenerCallQueue.Callback
Helper method to add this callback to all the queues.
ensureCapacity(int) - Method in class com.google.common.collect.ImmutableCollection.ArrayBasedBuilder
Expand the absolute capacity of the builder so it can accept at least the specified number of elements without being resized.
ensureCapacity(int) - Method in class com.google.common.collect.ImmutableMap.Builder
 
ensureCapacity(boolean[], int, int) - Static method in class com.google.common.primitives.Booleans
Returns an array containing the same values as array, but guaranteed to be of a specified minimum length.
ensureCapacity(byte[], int, int) - Static method in class com.google.common.primitives.Bytes
Returns an array containing the same values as array, but guaranteed to be of a specified minimum length.
ensureCapacity(char[], int, int) - Static method in class com.google.common.primitives.Chars
Returns an array containing the same values as array, but guaranteed to be of a specified minimum length.
ensureCapacity(double[], int, int) - Static method in class com.google.common.primitives.Doubles
Returns an array containing the same values as array, but guaranteed to be of a specified minimum length.
ensureCapacity(float[], int, int) - Static method in class com.google.common.primitives.Floats
Returns an array containing the same values as array, but guaranteed to be of a specified minimum length.
ensureCapacity(int[], int, int) - Static method in class com.google.common.primitives.Ints
Returns an array containing the same values as array, but guaranteed to be of a specified minimum length.
ensureCapacity(long[], int, int) - Static method in class com.google.common.primitives.Longs
Returns an array containing the same values as array, but guaranteed to be of a specified minimum length.
ensureCapacity(short[], int, int) - Static method in class com.google.common.primitives.Shorts
Returns an array containing the same values as array, but guaranteed to be of a specified minimum length.
ensureNonNegative(double) - Static method in class com.google.common.math.DoubleUtils
Returns its argument if it is non-negative, zero if it is negative.
enter() - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor.
enter(long, TimeUnit) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor.
enterIf(Monitor.Guard) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor if the guard is satisfied.
enterIf(Monitor.Guard, long, TimeUnit) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor if the guard is satisfied.
enterIfInterruptibly(Monitor.Guard) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor if the guard is satisfied.
enterIfInterruptibly(Monitor.Guard, long, TimeUnit) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor if the guard is satisfied.
enterInterruptibly() - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor.
enterInterruptibly(long, TimeUnit) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor.
enterWhen(Monitor.Guard) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor when the guard is satisfied.
enterWhen(Monitor.Guard, long, TimeUnit) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor when the guard is satisfied.
enterWhenUninterruptibly(Monitor.Guard) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor when the guard is satisfied.
enterWhenUninterruptibly(Monitor.Guard, long, TimeUnit) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor when the guard is satisfied.
entries() - Method in class com.google.common.collect.AbstractMapBasedMultimap
Returns a view collection of all key-value pairs contained in this multimap, as Map.Entry instances.
entries - Variable in class com.google.common.collect.AbstractMultimap
 
entries() - Method in class com.google.common.collect.AbstractMultimap
 
Entries() - Constructor for class com.google.common.collect.AbstractMultimap.Entries
 
entries() - Method in class com.google.common.collect.AbstractSetMultimap
Returns a view collection of all key-value pairs contained in this multimap, as Map.Entry instances.
entries() - Method in class com.google.common.collect.FilteredEntrySetMultimap
 
Entries() - Constructor for class com.google.common.collect.FilteredKeyMultimap.Entries
 
entries() - Method in class com.google.common.collect.FilteredKeySetMultimap
 
entries() - Method in class com.google.common.collect.ForwardingMultimap
 
entries() - Method in class com.google.common.collect.ForwardingSetMultimap
 
entries - Variable in class com.google.common.collect.ImmutableMap.Builder
 
entries() - Method in class com.google.common.collect.ImmutableMultimap
Returns an immutable collection of all key-value pairs in the multimap.
entries - Variable in class com.google.common.collect.ImmutableSetMultimap
 
entries() - Method in class com.google.common.collect.ImmutableSetMultimap
Returns an immutable collection of all key-value pairs in the multimap.
entries() - Method in class com.google.common.collect.LinkedHashMultimap
Returns a set of all key-value pairs.
entries() - Method in class com.google.common.collect.LinkedListMultimap
Returns a view collection of all key-value pairs contained in this multimap, as Map.Entry instances.
entries - Variable in class com.google.common.collect.MapConstraints.ConstrainedAsMapEntries
 
entries - Variable in class com.google.common.collect.MapConstraints.ConstrainedEntries
 
entries - Variable in class com.google.common.collect.MapConstraints.ConstrainedMultimap
 
entries() - Method in class com.google.common.collect.MapConstraints.ConstrainedMultimap
 
entries() - Method in class com.google.common.collect.MapConstraints.ConstrainedSetMultimap
 
entries - Variable in class com.google.common.collect.Maps.UnmodifiableEntries
 
entries() - Method in interface com.google.common.collect.Multimap
Returns a view collection of all key-value pairs contained in this multimap, as Map.Entry instances.
Entries() - Constructor for class com.google.common.collect.Multimaps.Entries
 
entries() - Method in class com.google.common.collect.Multimaps.MapMultimap
 
entries - Variable in class com.google.common.collect.Multimaps.UnmodifiableMultimap
 
entries() - Method in class com.google.common.collect.Multimaps.UnmodifiableMultimap
 
entries() - Method in class com.google.common.collect.Multimaps.UnmodifiableSetMultimap
 
entries - Variable in class com.google.common.collect.RegularImmutableBiMap
 
entries - Variable in class com.google.common.collect.RegularImmutableMap
 
entries() - Method in interface com.google.common.collect.SetMultimap
Returns a view collection of all key-value pairs contained in this multimap, as Map.Entry instances.
entries - Variable in class com.google.common.collect.Synchronized.SynchronizedMultimap
 
entries() - Method in class com.google.common.collect.Synchronized.SynchronizedMultimap
 
entries() - Method in class com.google.common.collect.Synchronized.SynchronizedSetMultimap
 
entriesByLowerBound - Variable in class com.google.common.collect.TreeRangeMap
 
entriesDiffering() - Method in interface com.google.common.collect.MapDifference
Returns an unmodifiable map describing keys that appear in both maps, but with different values.
entriesDiffering() - Method in class com.google.common.collect.Maps.MapDifferenceImpl
 
entriesDiffering() - Method in class com.google.common.collect.Maps.SortedMapDifferenceImpl
 
entriesDiffering() - Method in interface com.google.common.collect.SortedMapDifference
 
entriesInCommon() - Method in interface com.google.common.collect.MapDifference
Returns an unmodifiable map containing the entries that appear in both maps; that is, the intersection of the two maps.
entriesInCommon() - Method in class com.google.common.collect.Maps.MapDifferenceImpl
 
entriesInCommon() - Method in class com.google.common.collect.Maps.SortedMapDifferenceImpl
 
entriesInCommon() - Method in interface com.google.common.collect.SortedMapDifference
 
entriesOnlyOnLeft() - Method in interface com.google.common.collect.MapDifference
Returns an unmodifiable map containing the entries from the left map whose keys are not present in the right map.
entriesOnlyOnLeft() - Method in class com.google.common.collect.Maps.MapDifferenceImpl
 
entriesOnlyOnLeft() - Method in class com.google.common.collect.Maps.SortedMapDifferenceImpl
 
entriesOnlyOnLeft() - Method in interface com.google.common.collect.SortedMapDifference
 
entriesOnlyOnRight() - Method in interface com.google.common.collect.MapDifference
Returns an unmodifiable map containing the entries from the right map whose keys are not present in the left map.
entriesOnlyOnRight() - Method in class com.google.common.collect.Maps.MapDifferenceImpl
 
entriesOnlyOnRight() - Method in class com.google.common.collect.Maps.SortedMapDifferenceImpl
 
entriesOnlyOnRight() - Method in interface com.google.common.collect.SortedMapDifference
 
entry - Variable in class com.google.common.cache.LocalCache.SoftValueReference
 
entry - Variable in class com.google.common.cache.LocalCache.WeakValueReference
 
entry - Variable in class com.google.common.collect.MapMakerInternalMap.SoftValueReference
 
entry - Variable in class com.google.common.collect.MapMakerInternalMap.WeakValueReference
 
EntryCollection(ImmutableMultimap<K, V>) - Constructor for class com.google.common.collect.ImmutableMultimap.EntryCollection
 
entryFactory - Variable in class com.google.common.cache.LocalCache
Factory used to create new entries.
EntryFactory() - Constructor for enum com.google.common.cache.LocalCache.EntryFactory
 
entryFactory - Variable in class com.google.common.collect.MapMakerInternalMap
Factory used to create new entries.
EntryFactory() - Constructor for enum com.google.common.collect.MapMakerInternalMap.EntryFactory
 
EntryFunction() - Constructor for enum com.google.common.collect.Maps.EntryFunction
 
EntryIterator() - Constructor for class com.google.common.cache.LocalCache.EntryIterator
 
entryIterator() - Method in class com.google.common.collect.AbstractMapBasedMultimap
Returns an iterator across all key-value map entries, used by entries().iterator() and values().iterator().
entryIterator() - Method in class com.google.common.collect.AbstractMapBasedMultiset
 
entryIterator - Variable in class com.google.common.collect.AbstractMapBasedMultiset.MapBasedMultisetIterator
 
entryIterator() - Method in class com.google.common.collect.AbstractMultimap
 
entryIterator() - Method in class com.google.common.collect.AbstractMultiset
 
entryIterator() - Method in class com.google.common.collect.AbstractNavigableMap.DescendingMap
 
entryIterator() - Method in class com.google.common.collect.AbstractNavigableMap
 
entryIterator() - Method in class com.google.common.collect.ConcurrentHashMultiset
 
entryIterator() - Method in class com.google.common.collect.DescendingMultiset
 
entryIterator() - Method in class com.google.common.collect.FilteredEntryMultimap
 
entryIterator() - Method in class com.google.common.collect.FilteredKeyMultimap
 
entryIterator() - Method in class com.google.common.collect.ForwardingNavigableMap.StandardDescendingMap
 
entryIterator() - Method in class com.google.common.collect.ImmutableMultimap
 
entryIterator() - Method in class com.google.common.collect.LinkedHashMultimap
 
entryIterator() - Method in class com.google.common.collect.LinkedListMultimap
 
EntryIterator() - Constructor for class com.google.common.collect.MapMakerInternalMap.EntryIterator
 
entryIterator() - Method in class com.google.common.collect.Maps.DescendingMap
 
entryIterator() - Method in class com.google.common.collect.Maps.FilteredEntryNavigableMap
 
entryIterator() - Method in class com.google.common.collect.Maps.NavigableAsMapView
 
entryIterator() - Method in class com.google.common.collect.Multimaps.Keys
 
entryIterator() - Method in class com.google.common.collect.Multimaps.MapMultimap
 
entryIterator() - Method in class com.google.common.collect.Multimaps.TransformedEntriesMultimap
 
entryIterator() - Method in class com.google.common.collect.Multisets.FilteredMultiset
 
entryIterator - Variable in class com.google.common.collect.Multisets.MultisetIteratorImpl
 
entryIterator - Variable in class com.google.common.collect.StandardTable.ColumnKeyIterator
 
entryIterator() - Method in class com.google.common.collect.TreeMultiset
 
entryIterator() - Method in class com.google.common.collect.TreeRangeSet.ComplementRangesByLowerBound
 
entryIterator() - Method in class com.google.common.collect.TreeRangeSet.RangesByUpperBound
 
entryIterator() - Method in class com.google.common.collect.TreeRangeSet.SubRangeSetRangesByLowerBound
 
entryOf(K, V) - Static method in class com.google.common.collect.ImmutableMap
Verifies that key and value are non-null, and returns a new immutable entry with those values.
entryPredicate() - Method in class com.google.common.collect.FilteredEntryMultimap
 
entryPredicate() - Method in class com.google.common.collect.FilteredKeyMultimap
 
entryPredicate() - Method in interface com.google.common.collect.FilteredMultimap
 
entryPredicate - Variable in class com.google.common.collect.Maps.FilteredEntryNavigableMap
 
entrySet - Variable in class com.google.common.cache.LocalCache
 
entrySet() - Method in class com.google.common.cache.LocalCache
 
EntrySet(ConcurrentMap<?, ?>) - Constructor for class com.google.common.cache.LocalCache.EntrySet
 
entrySet - Variable in class com.google.common.collect.AbstractBiMap
 
entrySet() - Method in class com.google.common.collect.AbstractBiMap
 
EntrySet() - Constructor for class com.google.common.collect.AbstractBiMap.EntrySet
 
entrySet() - Method in class com.google.common.collect.AbstractMapBasedMultiset
Returns a view of the contents of this multiset, grouped into Multiset.Entry instances, each providing an element of the multiset and the count of that element.
EntrySet() - Constructor for class com.google.common.collect.AbstractMultimap.EntrySet
 
entrySet - Variable in class com.google.common.collect.AbstractMultiset
 
entrySet() - Method in class com.google.common.collect.AbstractMultiset
 
EntrySet() - Constructor for class com.google.common.collect.AbstractMultiset.EntrySet
 
entrySet() - Method in class com.google.common.collect.AbstractNavigableMap
 
EntrySet() - Constructor for class com.google.common.collect.ConcurrentHashMultiset.EntrySet
 
entrySet - Variable in class com.google.common.collect.DescendingMultiset
 
entrySet() - Method in class com.google.common.collect.DescendingMultiset
 
entrySet() - Method in class com.google.common.collect.EmptyImmutableBiMap
 
entrySet() - Method in class com.google.common.collect.EmptyImmutableSortedMap
 
entrySet() - Method in class com.google.common.collect.FilteredEntryMultimap.Keys
 
EntrySet() - Constructor for class com.google.common.collect.FilteredKeySetMultimap.EntrySet
 
entrySet() - Method in class com.google.common.collect.ForwardingMap
 
entrySet() - Method in class com.google.common.collect.ForwardingMultiset
 
entrySet() - Method in class com.google.common.collect.HashBiMap
 
EntrySet() - Constructor for class com.google.common.collect.HashBiMap.EntrySet
 
entrySet() - Method in class com.google.common.collect.HashBiMap.Inverse
 
entrySet - Variable in class com.google.common.collect.ImmutableMap
 
entrySet() - Method in class com.google.common.collect.ImmutableMap
Returns an immutable set of the mappings in this map.
entrySet - Variable in class com.google.common.collect.ImmutableMultiset
 
entrySet() - Method in class com.google.common.collect.ImmutableMultiset
 
EntrySet() - Constructor for class com.google.common.collect.ImmutableMultiset.EntrySet
 
EntrySet(ImmutableSetMultimap<K, V>) - Constructor for class com.google.common.collect.ImmutableSetMultimap.EntrySet
 
entrySet() - Method in class com.google.common.collect.ImmutableSortedMap
Returns an immutable set of the mappings in this map, sorted by the key ordering.
entrySet - Variable in class com.google.common.collect.MapConstraints.ConstrainedAsMapValues
 
entrySet - Variable in class com.google.common.collect.MapConstraints.ConstrainedMap
 
entrySet() - Method in class com.google.common.collect.MapConstraints.ConstrainedMap
 
entrySet() - Method in class com.google.common.collect.MapMaker.NullConcurrentMap
 
entrySet - Variable in class com.google.common.collect.MapMakerInternalMap
 
entrySet() - Method in class com.google.common.collect.MapMakerInternalMap
 
EntrySet() - Constructor for class com.google.common.collect.MapMakerInternalMap.EntrySet
 
entrySet - Variable in class com.google.common.collect.Maps.DescendingMap
 
entrySet() - Method in class com.google.common.collect.Maps.DescendingMap
 
EntrySet() - Constructor for class com.google.common.collect.Maps.EntrySet
 
EntrySet() - Constructor for class com.google.common.collect.Maps.FilteredEntryMap.EntrySet
 
entrySet() - Method in class com.google.common.collect.Maps.FilteredEntryNavigableMap
 
entrySet - Variable in class com.google.common.collect.Maps.ImprovedAbstractMap
 
entrySet() - Method in class com.google.common.collect.Maps.ImprovedAbstractMap
 
EntrySet() - Constructor for class com.google.common.collect.Multimaps.AsMap.EntrySet
 
entrySet() - Method in interface com.google.common.collect.Multiset
Returns a view of the contents of this multiset, grouped into Multiset.Entry instances, each providing an element of the multiset and the count of that element.
EntrySet() - Constructor for class com.google.common.collect.Multisets.EntrySet
 
entrySet - Variable in class com.google.common.collect.Multisets.UnmodifiableMultiset
 
entrySet() - Method in class com.google.common.collect.Multisets.UnmodifiableMultiset
 
EntrySet() - Constructor for class com.google.common.collect.RegularImmutableMap.EntrySet
 
EntrySet() - Constructor for class com.google.common.collect.RegularImmutableSortedMap.EntrySet
 
entrySet() - Method in interface com.google.common.collect.SortedMultiset
Returns a view of the contents of this multiset, grouped into Multiset.Entry instances, each providing an element of the multiset and the count of that element.
EntrySet() - Constructor for class com.google.common.collect.StandardTable.Column.EntrySet
 
EntrySet() - Constructor for class com.google.common.collect.StandardTable.RowMap.EntrySet
 
entrySet() - Method in class com.google.common.collect.Synchronized.SynchronizedAsMap
 
entrySet - Variable in class com.google.common.collect.Synchronized.SynchronizedMap
 
entrySet() - Method in class com.google.common.collect.Synchronized.SynchronizedMap
 
entrySet - Variable in class com.google.common.collect.Synchronized.SynchronizedMultiset
 
entrySet() - Method in class com.google.common.collect.Synchronized.SynchronizedMultiset
 
entrySet - Variable in class com.google.common.collect.Synchronized.SynchronizedSetMultimap
 
entrySet() - Method in class com.google.common.collect.TreeRangeMap.AsMapOfRanges
 
entrySet() - Method in class com.google.common.collect.TreeRangeMap.SubRangeMap.SubRangeMapAsMap
 
entrySet - Variable in class com.google.common.collect.WellBehavedMap
 
entrySet() - Method in class com.google.common.collect.WellBehavedMap
 
EntrySet() - Constructor for class com.google.common.collect.WellBehavedMap.EntrySet
 
entrySet() - Method in class com.google.common.reflect.MutableTypeToInstanceMap
 
EntrySetIterator() - Constructor for class com.google.common.collect.StandardTable.Column.EntrySetIterator
 
EntrySetSerializedForm(ImmutableMap<K, V>) - Constructor for class com.google.common.collect.ImmutableMapEntrySet.EntrySetSerializedForm
 
EntrySetSerializedForm(ImmutableMultiset<E>) - Constructor for class com.google.common.collect.ImmutableMultiset.EntrySetSerializedForm
 
entrySplitter - Variable in class com.google.common.base.Splitter.MapSplitter
 
EnumBiMap<K extends java.lang.Enum<K>,V extends java.lang.Enum<V>> - Class in com.google.common.collect
A BiMap backed by two EnumMap instances.
EnumBiMap(Class<K>, Class<V>) - Constructor for class com.google.common.collect.EnumBiMap
 
enumClass - Variable in class com.google.common.base.Enums.StringConverter
 
enumConstantCache - Static variable in class com.google.common.base.Enums
 
EnumHashBiMap<K extends java.lang.Enum<K>,V> - Class in com.google.common.collect
A BiMap backed by an EnumMap instance for keys-to-values, and a HashMap instance for values-to-keys.
EnumHashBiMap(Class<K>) - Constructor for class com.google.common.collect.EnumHashBiMap
 
enumKeys(Class<K0>) - Static method in class com.google.common.collect.MultimapBuilder
Uses an EnumMap to map keys to value collections.
EnumMultiset<E extends java.lang.Enum<E>> - Class in com.google.common.collect
Multiset implementation backed by an EnumMap.
EnumMultiset(Class<E>) - Constructor for class com.google.common.collect.EnumMultiset
Creates an empty EnumMultiset.
Enums - Class in com.google.common.base
Utility methods for working with Enum instances.
Enums() - Constructor for class com.google.common.base.Enums
 
Enums.StringConverter<T extends java.lang.Enum<T>> - Class in com.google.common.base
 
EnumSerializedForm(EnumMap<K, V>) - Constructor for class com.google.common.collect.ImmutableEnumMap.EnumSerializedForm
 
EnumSerializedForm(EnumSet<E>) - Constructor for class com.google.common.collect.ImmutableEnumSet.EnumSerializedForm
 
EnumSetSupplier(Class<V>) - Constructor for class com.google.common.collect.MultimapBuilder.EnumSetSupplier
 
enumSetValues(Class<V0>) - Method in class com.google.common.collect.MultimapBuilder.MultimapBuilderWithKeys
Uses an EnumSet to store value collections.
EOT - Static variable in class com.google.common.base.Ascii
End of Transmission: A communication control character used to indicate the conclusion of a transmission, which may have contained one or more texts and any associated headings.
EOT - Static variable in class com.google.common.net.MediaType
Media type for Embedded OpenType fonts.
EPUB - Static variable in class com.google.common.net.MediaType
As described in the International Digital Publishing Forum EPUB is the distribution and interchange format standard for digital publications and documents.
equal(Object, Object) - Static method in class com.google.common.base.Objects
Determines whether two possibly-null objects are equal.
equal(File, File) - Static method in class com.google.common.io.Files
Returns true if the files contains the same bytes.
equals(Object) - Method in class com.google.common.base.Absent
 
equals(Object) - Method in class com.google.common.base.CaseFormat.StringConverter
 
equals(Object) - Method in class com.google.common.base.Converter.ConverterComposition
 
equals(Object) - Method in class com.google.common.base.Converter
Indicates whether another object is equal to this converter.
equals(Object) - Method in class com.google.common.base.Converter.FunctionBasedConverter
 
equals(Object) - Method in class com.google.common.base.Converter.ReverseConverter
 
equals(Object) - Method in class com.google.common.base.Enums.StringConverter
 
equals() - Static method in class com.google.common.base.Equivalence
Returns an equivalence that delegates to Object.equals(java.lang.Object) and Object.hashCode().
Equals() - Constructor for class com.google.common.base.Equivalence.Equals
 
equals(Object) - Method in class com.google.common.base.Equivalence.EquivalentToPredicate
 
equals(Object) - Method in class com.google.common.base.Equivalence.Wrapper
Returns true if Equivalence.equivalent(Object, Object) applied to the wrapped references is true and both wrappers use the same equivalence.
equals(Object) - Method in interface com.google.common.base.Function
Indicates whether another object is equal to this function.
equals(Object) - Method in class com.google.common.base.FunctionalEquivalence
 
equals(Object) - Method in class com.google.common.base.Functions.ConstantFunction
 
equals(Object) - Method in class com.google.common.base.Functions.ForMapWithDefault
 
equals(Object) - Method in class com.google.common.base.Functions.FunctionComposition
 
equals(Object) - Method in class com.google.common.base.Functions.FunctionForMapNoDefault
 
equals(Object) - Method in class com.google.common.base.Functions.PredicateFunction
 
equals(Object) - Method in class com.google.common.base.Functions.SupplierFunction
 
equals(Object) - Method in class com.google.common.base.Optional
Returns true if object is an Optional instance, and either the contained references are equal to each other or both are absent.
equals(Object) - Method in class com.google.common.base.PairwiseEquivalence
 
equals(Object) - Method in interface com.google.common.base.Predicate
Indicates whether another object is equal to this predicate.
equals(Object) - Method in class com.google.common.base.Predicates.AndPredicate
 
equals(Object) - Method in class com.google.common.base.Predicates.AssignableFromPredicate
 
equals(Object) - Method in class com.google.common.base.Predicates.CompositionPredicate
 
equals(Object) - Method in class com.google.common.base.Predicates.ContainsPatternPredicate
 
equals(Object) - Method in class com.google.common.base.Predicates.InPredicate
 
equals(Object) - Method in class com.google.common.base.Predicates.InstanceOfPredicate
 
equals(Object) - Method in class com.google.common.base.Predicates.IsEqualToPredicate
 
equals(Object) - Method in class com.google.common.base.Predicates.NotPredicate
 
equals(Object) - Method in class com.google.common.base.Predicates.OrPredicate
 
equals(Object) - Method in class com.google.common.base.Present
 
equals(Object) - Method in class com.google.common.base.Suppliers.SupplierComposition
 
equals(Object) - Method in class com.google.common.base.Suppliers.SupplierOfInstance
 
equals(Object) - Method in class com.google.common.cache.CacheBuilderSpec
 
equals(Object) - Method in class com.google.common.cache.CacheStats
 
equals(Object) - Method in class com.google.common.cache.LocalCache.WriteThroughEntry
 
equals(Object) - Method in class com.google.common.cache.RemovalNotification
 
equals(Object) - Method in class com.google.common.collect.AbstractListMultimap
Compares the specified object to this multimap for equality.
equals(Object) - Method in class com.google.common.collect.AbstractMapBasedMultimap.AsMap
 
equals(Object) - Method in class com.google.common.collect.AbstractMapBasedMultimap.KeySet
 
equals(Object) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection
 
equals(Object) - Method in class com.google.common.collect.AbstractMapEntry
 
equals(Object) - Method in class com.google.common.collect.AbstractMultimap.EntrySet
 
equals(Object) - Method in class com.google.common.collect.AbstractMultimap
 
equals(Object) - Method in class com.google.common.collect.AbstractMultiset
Compares the specified object with this multiset for equality.
equals(Object) - Method in class com.google.common.collect.AbstractRangeSet
 
equals(Object) - Method in class com.google.common.collect.AbstractSetMultimap
Compares the specified object to this multimap for equality.
equals(Object) - Method in class com.google.common.collect.AbstractTable
 
equals(Object) - Method in class com.google.common.collect.ByFunctionOrdering
 
equals(Object) - Method in class com.google.common.collect.ComparatorOrdering
 
equals(Object) - Method in class com.google.common.collect.CompoundOrdering
 
equals(Object) - Method in class com.google.common.collect.Count
 
equals(Object) - Method in class com.google.common.collect.Cut
 
equals(Object) - Method in class com.google.common.collect.EmptyContiguousSet
 
equals(Object) - Method in class com.google.common.collect.EmptyImmutableSet
 
equals(Object) - Method in class com.google.common.collect.EmptyImmutableSortedMultiset
 
equals(Object) - Method in class com.google.common.collect.EmptyImmutableSortedSet
 
equals(Object) - Method in class com.google.common.collect.ExplicitOrdering
 
equals(Object) - Method in class com.google.common.collect.FilteredKeySetMultimap.EntrySet
 
equals(Object) - Method in class com.google.common.collect.ForwardingList
 
equals(Object) - Method in class com.google.common.collect.ForwardingMap
 
equals(Object) - Method in class com.google.common.collect.ForwardingMapEntry
 
equals(Object) - Method in class com.google.common.collect.ForwardingMultimap
 
equals(Object) - Method in class com.google.common.collect.ForwardingMultiset
 
equals(Object) - Method in class com.google.common.collect.ForwardingSet
 
equals(Object) - Method in class com.google.common.collect.ForwardingTable
 
equals(Object) - Method in class com.google.common.collect.GeneralRange
 
equals(Object) - Method in class com.google.common.collect.HashBasedTable
 
equals(Object) - Method in class com.google.common.collect.ImmutableEnumSet
 
equals(Object) - Method in class com.google.common.collect.ImmutableList
 
equals(Object) - Method in class com.google.common.collect.ImmutableMap
 
equals(Object) - Method in class com.google.common.collect.ImmutableMultiset
 
equals(Object) - Method in class com.google.common.collect.ImmutableRangeMap
 
equals(Object) - Method in class com.google.common.collect.ImmutableSet
 
equals(Object) - Method in class com.google.common.collect.Interners.InternerFunction
 
equals(Object) - Method in class com.google.common.collect.LexicographicalOrdering
 
equals(Object) - Method in interface com.google.common.collect.ListMultimap
Compares the specified object to this multimap for equality.
equals(Object) - Method in class com.google.common.collect.MapConstraints.ConstrainedAsMapEntries
 
equals(Object) - Method in class com.google.common.collect.MapConstraints.ConstrainedEntrySet
 
equals(Object) - Method in interface com.google.common.collect.MapDifference
Compares the specified object with this instance for equality.
equals(Object) - Method in interface com.google.common.collect.MapDifference.ValueDifference
Two instances are considered equal if their MapDifference.ValueDifference.leftValue() values are equal and their MapDifference.ValueDifference.rightValue() values are also equal.
equals(Object) - Method in class com.google.common.collect.MapMakerInternalMap.WriteThroughEntry
 
equals(Object) - Method in class com.google.common.collect.Maps.BiMapConverter
 
equals(Object) - Method in class com.google.common.collect.Maps.MapDifferenceImpl
 
equals(Object) - Method in class com.google.common.collect.Maps.UnmodifiableEntrySet
 
equals(Object) - Method in class com.google.common.collect.Maps.ValueDifferenceImpl
 
equals(Object) - Method in interface com.google.common.collect.Multimap
Compares the specified object with this multimap for equality.
equals(Object) - Method in interface com.google.common.collect.Multiset.Entry
equals(Object) - Method in interface com.google.common.collect.Multiset
Compares the specified object with this multiset for equality.
equals(Object) - Method in class com.google.common.collect.Multisets.AbstractEntry
Indicates whether an object equals this entry, following the behavior specified in Multiset.Entry.equals(java.lang.Object).
equals(Object) - Method in class com.google.common.collect.NullsFirstOrdering
 
equals(Object) - Method in class com.google.common.collect.NullsLastOrdering
 
equals(Object) - Method in class com.google.common.collect.Range
Returns true if object is a range having the same endpoints and bound types as this range.
equals(Object) - Method in interface com.google.common.collect.RangeMap
Returns true if obj is another RangeMap that has an equivalent RangeMap.asMapOfRanges().
equals(Object) - Method in interface com.google.common.collect.RangeSet
Returns true if obj is another RangeSet that contains the same ranges according to Range.equals(Object).
equals(Object) - Method in class com.google.common.collect.RegularContiguousSet
 
equals(Object) - Method in class com.google.common.collect.RegularImmutableSortedSet
 
equals(Object) - Method in class com.google.common.collect.ReverseOrdering
 
equals(Object) - Method in interface com.google.common.collect.SetMultimap
Compares the specified object to this multimap for equality.
equals(Object) - Method in class com.google.common.collect.Sets.CartesianSet
 
equals(Object) - Method in class com.google.common.collect.Sets.FilteredSet
 
equals(Object) - Method in class com.google.common.collect.Sets.PowerSet
 
equals(Object) - Method in class com.google.common.collect.SingletonImmutableList
 
equals(Object) - Method in class com.google.common.collect.SingletonImmutableSet
 
equals(Object) - Method in class com.google.common.collect.Synchronized.SynchronizedAsMapEntries
 
equals(Object) - Method in class com.google.common.collect.Synchronized.SynchronizedEntry
 
equals(Object) - Method in class com.google.common.collect.Synchronized.SynchronizedList
 
equals(Object) - Method in class com.google.common.collect.Synchronized.SynchronizedMap
 
equals(Object) - Method in class com.google.common.collect.Synchronized.SynchronizedMultimap
 
equals(Object) - Method in class com.google.common.collect.Synchronized.SynchronizedMultiset
 
equals(Object) - Method in class com.google.common.collect.Synchronized.SynchronizedSet
 
equals(Object) - Method in interface com.google.common.collect.Table.Cell
Compares the specified object with this cell for equality.
equals(Object) - Method in interface com.google.common.collect.Table
Compares the specified object with this table for equality.
equals(Object) - Method in class com.google.common.collect.Tables.AbstractCell
 
equals(Object) - Method in class com.google.common.collect.TreeRangeMap
 
equals(Object) - Method in class com.google.common.collect.TreeRangeMap.SubRangeMap
 
equals(Object) - Method in class com.google.common.collect.TreeRangeSet.AsRanges
 
equals(Object) - Method in class com.google.common.eventbus.AnnotatedSubscriberFinder.MethodIdentifier
 
equals(Object) - Method in class com.google.common.eventbus.EventSubscriber
 
equals(Object) - Method in class com.google.common.hash.BloomFilter
 
equals(Object) - Method in class com.google.common.hash.BloomFilterStrategies.BitArray
 
equals(Object) - Method in class com.google.common.hash.Funnels.SequentialFunnel
 
equals(Object) - Method in class com.google.common.hash.Funnels.StringCharsetFunnel
 
equals(Object) - Method in class com.google.common.hash.HashCode
 
equals(Object) - Method in class com.google.common.hash.Hashing.ConcatenatedHashFunction
 
equals(Object) - Method in class com.google.common.hash.Murmur3_128HashFunction
 
equals(Object) - Method in class com.google.common.hash.Murmur3_32HashFunction
 
equals(Object) - Method in class com.google.common.hash.SipHashFunction
 
equals(Object) - Method in class com.google.common.net.HostAndPort
 
equals(Object) - Method in class com.google.common.net.HostSpecifier
 
equals(Object) - Method in class com.google.common.net.InternetDomainName
Equality testing is based on the text supplied by the caller, after normalization as described in the class documentation.
equals(Object) - Method in class com.google.common.net.MediaType
 
equals(Object) - Method in class com.google.common.primitives.Booleans.BooleanArrayAsList
 
equals(Object) - Method in class com.google.common.primitives.Bytes.ByteArrayAsList
 
equals(Object) - Method in class com.google.common.primitives.Chars.CharArrayAsList
 
equals(Object) - Method in class com.google.common.primitives.Doubles.DoubleArrayAsList
 
equals(Object) - Method in class com.google.common.primitives.Floats.FloatArrayAsList
 
equals(Object) - Method in class com.google.common.primitives.Ints.IntArrayAsList
 
equals(Object) - Method in class com.google.common.primitives.Longs.LongArrayAsList
 
equals(Object) - Method in class com.google.common.primitives.Shorts.ShortArrayAsList
 
equals(Object) - Method in class com.google.common.primitives.UnsignedInteger
 
equals(Object) - Method in class com.google.common.primitives.UnsignedLong
 
equals(Object) - Method in class com.google.common.reflect.AbstractInvocationHandler
By default delegates to Object.equals(java.lang.Object) so instances are only equal if they are identical.
equals(Object) - Method in class com.google.common.reflect.ClassPath.ResourceInfo
 
equals(Object) - Method in class com.google.common.reflect.Element
 
equals(Object) - Method in class com.google.common.reflect.Parameter
 
equals(Object) - Method in class com.google.common.reflect.TypeParameter
 
equals(Object) - Method in class com.google.common.reflect.TypeResolver.TypeVariableKey
 
equals(Object) - Method in class com.google.common.reflect.Types.GenericArrayTypeImpl
 
equals(Object) - Method in class com.google.common.reflect.Types.ParameterizedTypeImpl
 
equals(Object) - Method in class com.google.common.reflect.Types.TypeVariableImpl
 
equals(Object) - Method in class com.google.common.reflect.Types.WildcardTypeImpl
 
equals(Object) - Method in class com.google.common.reflect.TypeToken
Returns true if o is another TypeToken that represents the same Type.
equalsIgnoreCase(CharSequence, CharSequence) - Static method in class com.google.common.base.Ascii
Indicates whether the contents of the given character sequences s1 and s2 are equal, ignoring the case of any ASCII alphabetic characters between 'a' and 'z' or 'A' and 'Z' inclusive.
equalsImpl(List<?>, Object) - Static method in class com.google.common.collect.Lists
An implementation of List.equals(Object).
equalsImpl(Map<?, ?>, Object) - Static method in class com.google.common.collect.Maps
An implementation of Map.equals(java.lang.Object).
equalsImpl(Multimap<?, ?>, Object) - Static method in class com.google.common.collect.Multimaps
 
equalsImpl(Multiset<?>, Object) - Static method in class com.google.common.collect.Multisets
An implementation of Multiset.equals(java.lang.Object).
equalsImpl(Set<?>, Object) - Static method in class com.google.common.collect.Sets
An implementation for Set.equals(Object).
equalsImpl(Table<?, ?, ?>, Object) - Static method in class com.google.common.collect.Tables
 
equalsOrThrow(Comparable<?>, Comparable<?>) - Static method in class com.google.common.collect.RegularContiguousSet
 
equalsSameBits(HashCode) - Method in class com.google.common.hash.HashCode.BytesHashCode
 
equalsSameBits(HashCode) - Method in class com.google.common.hash.HashCode
Returns whether this HashCode and that HashCode have the same value, given that they have the same number of bits.
equalsSameBits(HashCode) - Method in class com.google.common.hash.HashCode.IntHashCode
 
equalsSameBits(HashCode) - Method in class com.google.common.hash.HashCode.LongHashCode
 
equalsType(Type) - Method in class com.google.common.reflect.TypeResolver.TypeVariableKey
Returns true if type is a TypeVariable with the same name and declared by the same GenericDeclaration.
equalsTypeVariable(TypeVariable<?>) - Method in class com.google.common.reflect.TypeResolver.TypeVariableKey
 
equalTo(T) - Static method in class com.google.common.base.Predicates
Returns a predicate that evaluates to true if the object being tested equals() the given target or both are null.
Equivalence<T> - Class in com.google.common.base
A strategy for determining whether two instances are considered equivalent.
Equivalence() - Constructor for class com.google.common.base.Equivalence
Constructor for use by subclasses.
equivalence - Variable in class com.google.common.base.Equivalence.EquivalentToPredicate
 
equivalence - Variable in class com.google.common.base.Equivalence.Wrapper
 
Equivalence.Equals - Class in com.google.common.base
 
Equivalence.EquivalentToPredicate<T> - Class in com.google.common.base
 
Equivalence.Identity - Class in com.google.common.base
 
Equivalence.Wrapper<T> - Class in com.google.common.base
equivalent(T, T) - Method in class com.google.common.base.Equivalence
Returns true if the given objects are considered equivalent.
equivalentTo(T) - Method in class com.google.common.base.Equivalence
Returns a predicate that evaluates to true if and only if the input is equivalent to target according to this equivalence relation.
EquivalentToPredicate(Equivalence<T>, T) - Constructor for class com.google.common.base.Equivalence.EquivalentToPredicate
 
erase(Object, Object) - Method in class com.google.common.collect.ArrayTable
Associates the value null with the specified keys, assuming both keys are valid.
eraseAll() - Method in class com.google.common.collect.ArrayTable
Associates the value null with every pair of allowed row and column keys.
ESC - Static variable in class com.google.common.base.Ascii
Escape: A control character intended to provide code extension (supplementary characters) in general information interchange.
escape(String) - Method in class com.google.common.escape.ArrayBasedCharEscaper
 
escape(char) - Method in class com.google.common.escape.ArrayBasedCharEscaper
Escapes a single character using the replacement array and safe range values.
escape(String) - Method in class com.google.common.escape.ArrayBasedUnicodeEscaper
 
escape(int) - Method in class com.google.common.escape.ArrayBasedUnicodeEscaper
Escapes a single Unicode code point using the replacement array and safe range values.
escape(String) - Method in class com.google.common.escape.CharEscaper
Returns the escaped form of a given literal string.
escape(char) - Method in class com.google.common.escape.CharEscaper
Returns the escaped form of the given character, or null if this character does not need to be escaped.
escape(String) - Method in class com.google.common.escape.CharEscaperBuilder.CharArrayDecorator
 
escape(char) - Method in class com.google.common.escape.CharEscaperBuilder.CharArrayDecorator
 
escape(String) - Method in class com.google.common.escape.Escaper
Returns the escaped form of a given literal string.
escape(int) - Method in class com.google.common.escape.UnicodeEscaper
Returns the escaped form of the given Unicode code point, or null if this code point does not need to be escaped.
escape(String) - Method in class com.google.common.escape.UnicodeEscaper
Returns the escaped form of a given literal string.
escape(String) - Method in class com.google.common.net.PercentEscaper
 
escape(int) - Method in class com.google.common.net.PercentEscaper
Escapes the given Unicode code point in UTF-8.
escapeAndQuote(String) - Static method in class com.google.common.net.MediaType
 
Escaper - Class in com.google.common.escape
An object that converts literal text into a format safe for inclusion in a particular context (such as an XML document).
Escaper() - Constructor for class com.google.common.escape.Escaper
Constructor for use by subclasses.
Escapers - Class in com.google.common.escape
Static utility methods pertaining to Escaper instances.
Escapers() - Constructor for class com.google.common.escape.Escapers
 
Escapers.Builder - Class in com.google.common.escape
A builder for simple, fast escapers.
escapeSlow(String, int) - Method in class com.google.common.escape.CharEscaper
Returns the escaped form of a given literal string, starting at the given index.
escapeSlow(String, int) - Method in class com.google.common.escape.UnicodeEscaper
Returns the escaped form of a given literal string, starting at the given index.
escapeUnsafe(char) - Method in class com.google.common.escape.ArrayBasedCharEscaper
Escapes a char value that has no direct explicit value in the replacement array and lies outside the stated safe range.
escapeUnsafe(int) - Method in class com.google.common.escape.ArrayBasedUnicodeEscaper
Escapes a code point that has no direct explicit value in the replacement array and lies outside the stated safe range.
esDelegate - Variable in class com.google.common.collect.AbstractBiMap.EntrySet
 
ETAG - Static variable in class com.google.common.net.HttpHeaders
The HTTP ETag header field name.
ETB - Static variable in class com.google.common.base.Ascii
End of Transmission Block: A communication control character used to indicate the end of a block of data for communication purposes.
ETX - Static variable in class com.google.common.base.Ascii
End of Text: A communication control character used to terminate a sequence of characters started with STX and transmitted as an entity.
EVEN_POWERS_OF_TWO - Static variable in class com.google.common.collect.MinMaxPriorityQueue
 
event - Variable in class com.google.common.eventbus.DeadEvent
 
event - Variable in class com.google.common.eventbus.EventBus.EventWithSubscriber
 
event - Variable in class com.google.common.eventbus.SubscriberExceptionContext
 
EventBus - Class in com.google.common.eventbus
Dispatches events to listeners, and provides ways for listeners to register themselves.
EventBus() - Constructor for class com.google.common.eventbus.EventBus
Creates a new EventBus named "default".
EventBus(String) - Constructor for class com.google.common.eventbus.EventBus
Creates a new EventBus with the given identifier.
EventBus(SubscriberExceptionHandler) - Constructor for class com.google.common.eventbus.EventBus
Creates a new EventBus with the given SubscriberExceptionHandler.
eventBus - Variable in class com.google.common.eventbus.SubscriberExceptionContext
 
EventBus.EventWithSubscriber - Class in com.google.common.eventbus
simple struct representing an event and it's subscriber
EventBus.LoggingSubscriberExceptionHandler - Class in com.google.common.eventbus
Simple logging handler for subscriber exceptions.
eventsToDispatch - Variable in class com.google.common.eventbus.AsyncEventBus
the queue of events is shared across all threads
eventsToDispatch - Variable in class com.google.common.eventbus.EventBus
queues of events for the current thread to dispatch
EventSubscriber - Class in com.google.common.eventbus
Wraps a single-argument subscriber method on a specific object.
EventSubscriber(Object, Method) - Constructor for class com.google.common.eventbus.EventSubscriber
Creates a new EventSubscriber to wrap method on @{code target}.
EventWithSubscriber(Object, EventSubscriber) - Constructor for class com.google.common.eventbus.EventBus.EventWithSubscriber
 
everySixteenthFactorial - Static variable in class com.google.common.math.DoubleMath
 
EVICTABLE_MASK - Static variable in enum com.google.common.collect.MapMakerInternalMap.EntryFactory
 
evictEntries() - Method in class com.google.common.cache.LocalCache.Segment
Performs eviction if the segment is full.
evictEntries() - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Performs eviction if the segment is full.
EvictingQueue<E> - Class in com.google.common.collect
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.
EvictingQueue(int) - Constructor for class com.google.common.collect.EvictingQueue
 
evictionCount - Variable in class com.google.common.cache.AbstractCache.SimpleStatsCounter
 
evictionCount - Variable in class com.google.common.cache.CacheStats
 
evictionCount() - Method in class com.google.common.cache.CacheStats
Returns the number of times an entry has been evicted.
EvictionQueue() - Constructor for class com.google.common.collect.MapMakerInternalMap.EvictionQueue
 
evictionQueue - Variable in class com.google.common.collect.MapMakerInternalMap.Segment
A queue of elements currently in the map, ordered by access time.
evictsBySize() - Method in class com.google.common.cache.LocalCache
 
evictsBySize() - Method in class com.google.common.collect.MapMakerInternalMap
 
EXACT - Static variable in class com.google.thirdparty.publicsuffix.PublicSuffixPatterns
If a hostname is contained as a key in this map, it is a public suffix.
ExampleStackTrace(CycleDetectingLockFactory.LockGraphNode, CycleDetectingLockFactory.LockGraphNode) - Constructor for exception com.google.common.util.concurrent.CycleDetectingLockFactory.ExampleStackTrace
 
exception - Variable in class com.google.common.util.concurrent.AbstractFuture.Sync
 
EXCLUDED - Static variable in class com.google.thirdparty.publicsuffix.PublicSuffixPatterns
The elements in this map would pass the UNDER test, but are known not to be public suffixes and are thus excluded from consideration.
EXCLUDED_CLASS_NAMES - Static variable in exception com.google.common.util.concurrent.CycleDetectingLockFactory.ExampleStackTrace
 
execute() - Method in class com.google.common.util.concurrent.ExecutionList
Runs this execution list, executing all existing pairs in the order they were added.
execute(Runnable) - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
execute() - Method in class com.google.common.util.concurrent.ListenerCallQueue
Executes all listeners added prior to this call, serially and in order.
execute(Runnable) - Method in enum com.google.common.util.concurrent.MoreExecutors.DirectExecutor
 
execute(Runnable) - Method in class com.google.common.util.concurrent.MoreExecutors.DirectExecutorService
 
execute(Runnable) - Method in class com.google.common.util.concurrent.MoreExecutors.ListeningDecorator
 
execute(Runnable) - Method in class com.google.common.util.concurrent.SerializingExecutor
Runs the given runnable strictly after all Runnables that were submitted before it, and using the executor passed to the constructor.
execute(Runnable) - Method in class com.google.common.util.concurrent.WrappingExecutorService
 
executed - Variable in class com.google.common.util.concurrent.ExecutionList
 
executeListener(Runnable, Executor) - Static method in class com.google.common.util.concurrent.ExecutionList
Submits the given runnable to the given Executor catching and logging all runtime exceptions thrown by the executor.
executeListeners() - Method in class com.google.common.util.concurrent.AbstractService
Attempts to execute all the listeners in AbstractService.listeners while not holding the AbstractService.monitor.
executeListeners() - Method in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState
Attempts to execute all the listeners in ServiceManager.ServiceManagerState.listeners.
ExecutionError - Error in com.google.common.util.concurrent
Error variant of ExecutionException.
ExecutionError() - Constructor for error com.google.common.util.concurrent.ExecutionError
Creates a new instance with null as its detail message.
ExecutionError(String) - Constructor for error com.google.common.util.concurrent.ExecutionError
Creates a new instance with the given detail message.
ExecutionError(String, Error) - Constructor for error com.google.common.util.concurrent.ExecutionError
Creates a new instance with the given detail message and cause.
ExecutionError(Error) - Constructor for error com.google.common.util.concurrent.ExecutionError
Creates a new instance with the given cause.
executionList - Variable in class com.google.common.util.concurrent.AbstractFuture
 
ExecutionList - Class in com.google.common.util.concurrent
A list of listeners, each with an associated Executor, that guarantees that every Runnable that is added will be executed after ExecutionList.execute() is called.
ExecutionList() - Constructor for class com.google.common.util.concurrent.ExecutionList
Creates a new, empty ExecutionList.
executionList - Variable in class com.google.common.util.concurrent.JdkFutureAdapters.ListenableFutureAdapter
 
executionList - Variable in class com.google.common.util.concurrent.ListenableFutureTask
 
ExecutionList.RunnableExecutorPair - Class in com.google.common.util.concurrent
 
executor - Variable in class com.google.common.eventbus.AsyncEventBus
 
executor() - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
Returns the Executor that will be used to run this service.
executor() - Method in class com.google.common.util.concurrent.AbstractIdleService
Returns the Executor that will be used to run this service.
executor - Variable in class com.google.common.util.concurrent.AbstractScheduledService.CustomScheduler.ReschedulableCallable
The executor on which this Callable will be scheduled.
executor() - Method in class com.google.common.util.concurrent.AbstractScheduledService
Returns the ScheduledExecutorService that will be used to execute the AbstractScheduledService.startUp(), AbstractScheduledService.runOneIteration() and AbstractScheduledService.shutDown() methods.
executor - Variable in class com.google.common.util.concurrent.ExecutionList.RunnableExecutorPair
 
executor - Variable in class com.google.common.util.concurrent.ListenerCallQueue
 
executor - Variable in class com.google.common.util.concurrent.SerializingExecutor
Underlying executor that all submitted Runnable objects are run on.
executor - Variable in class com.google.common.util.concurrent.SimpleTimeLimiter
 
Exiter(Runtime) - Constructor for class com.google.common.util.concurrent.UncaughtExceptionHandlers.Exiter
 
expand() - Method in class com.google.common.cache.LocalCache.Segment
Expands the table if possible.
expand() - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Expands the table if possible.
expand(T) - Method in class com.google.common.collect.TreeTraverser.PostOrderIterator
 
expandedCapacity(int, int) - Static method in class com.google.common.collect.ImmutableCollection.Builder
 
EXPECT - Static variable in class com.google.common.net.HttpHeaders
The HTTP Expect header field name.
expectArgument(Class<T>, Object) - Static method in class com.google.common.reflect.TypeResolver
 
expectedFpp() - Method in class com.google.common.hash.BloomFilter
Returns the probability that BloomFilter.mightContain(Object) will erroneously return true for an object that has not actually been put in the BloomFilter.
expectedModCount - Variable in class com.google.common.collect.HashBiMap.Itr
 
expectedModCount - Variable in class com.google.common.collect.LinkedListMultimap.DistinctKeyIterator
 
expectedModCount - Variable in class com.google.common.collect.LinkedListMultimap.NodeIterator
 
expectedModCount - Variable in class com.google.common.collect.MinMaxPriorityQueue.QueueIterator
 
expectedSize - Variable in class com.google.common.collect.HashBasedTable.Factory
 
expectedSize - Variable in class com.google.common.collect.MinMaxPriorityQueue.Builder
 
expectedSize(int) - Method in class com.google.common.collect.MinMaxPriorityQueue.Builder
Configures this builder to build min-max priority queues with an initial expected size of expectedSize.
expectedSize(int) - Static method in class com.google.common.collect.MinMaxPriorityQueue
Creates and returns a new builder, configured to build MinMaxPriorityQueue instances sized appropriately to hold expectedSize elements.
expectedValuesPerKey - Variable in class com.google.common.collect.ArrayListMultimap
 
expectedValuesPerKey - Variable in class com.google.common.collect.HashMultimap
 
expectedValuesPerKey - Variable in class com.google.common.collect.MultimapBuilder.ArrayListSupplier
 
expectedValuesPerKey - Variable in class com.google.common.collect.MultimapBuilder.HashSetSupplier
 
expectedValuesPerKey - Variable in class com.google.common.collect.MultimapBuilder.LinkedHashSetSupplier
 
EXPIRABLE_MASK - Static variable in enum com.google.common.collect.MapMakerInternalMap.EntryFactory
Masks used to compute indices in the following table.
expirationNanos - Variable in class com.google.common.base.Suppliers.ExpiringMemoizingSupplier
 
ExpirationQueue() - Constructor for class com.google.common.collect.MapMakerInternalMap.ExpirationQueue
 
expirationQueue - Variable in class com.google.common.collect.MapMakerInternalMap.Segment
A queue of elements currently in the map, ordered by expiration time (either access or write time).
expireAfterAccess(long, TimeUnit) - Method in class com.google.common.cache.CacheBuilder
Specifies that each entry should be automatically removed from the cache once a fixed duration has elapsed after the entry's creation, the most recent replacement of its value, or its last access.
expireAfterAccess(long, TimeUnit) - Method in class com.google.common.collect.GenericMapMaker
Deprecated.
expireAfterAccess(long, TimeUnit) - Method in class com.google.common.collect.MapMaker
Deprecated.
Caching functionality in MapMaker has been moved to CacheBuilder, with MapMaker.expireAfterAccess(long, java.util.concurrent.TimeUnit) being replaced by CacheBuilder.expireAfterAccess(long, java.util.concurrent.TimeUnit). Note that CacheBuilder is simply an enhanced API for an implementation which was branched from MapMaker.
expireAfterAccessNanos - Variable in class com.google.common.cache.CacheBuilder
 
expireAfterAccessNanos - Variable in class com.google.common.cache.LocalCache
How long after the last access to an entry the map will retain that entry.
expireAfterAccessNanos - Variable in class com.google.common.cache.LocalCache.ManualSerializationProxy
 
expireAfterAccessNanos - Variable in class com.google.common.collect.MapMaker
 
expireAfterAccessNanos - Variable in class com.google.common.collect.MapMakerInternalMap.AbstractSerializationProxy
 
expireAfterAccessNanos - Variable in class com.google.common.collect.MapMakerInternalMap
How long after the last access to an entry the map will retain that entry.
expireAfterWrite(long, TimeUnit) - Method in class com.google.common.cache.CacheBuilder
Specifies that each entry should be automatically removed from the cache once a fixed duration has elapsed after the entry's creation, or the most recent replacement of its value.
expireAfterWrite(long, TimeUnit) - Method in class com.google.common.collect.GenericMapMaker
Deprecated.
expireAfterWrite(long, TimeUnit) - Method in class com.google.common.collect.MapMaker
Deprecated.
Caching functionality in MapMaker has been moved to CacheBuilder, with MapMaker.expireAfterWrite(long, java.util.concurrent.TimeUnit) being replaced by CacheBuilder.expireAfterWrite(long, java.util.concurrent.TimeUnit). Note that CacheBuilder is simply an enhanced API for an implementation which was branched from MapMaker.
expireAfterWriteNanos - Variable in class com.google.common.cache.CacheBuilder
 
expireAfterWriteNanos - Variable in class com.google.common.cache.LocalCache
How long after the last write to an entry the map will retain that entry.
expireAfterWriteNanos - Variable in class com.google.common.cache.LocalCache.ManualSerializationProxy
 
expireAfterWriteNanos - Variable in class com.google.common.collect.MapMaker
 
expireAfterWriteNanos - Variable in class com.google.common.collect.MapMakerInternalMap.AbstractSerializationProxy
 
expireAfterWriteNanos - Variable in class com.google.common.collect.MapMakerInternalMap
How long after the last write to an entry the map will retain that entry.
expireEntries(long) - Method in class com.google.common.cache.LocalCache.Segment
 
expireEntries() - Method in class com.google.common.collect.MapMakerInternalMap.Segment
 
expires() - Method in class com.google.common.cache.LocalCache
 
expires() - Method in class com.google.common.collect.MapMakerInternalMap
 
EXPIRES - Static variable in class com.google.common.net.HttpHeaders
The HTTP Expires header field name.
expiresAfterAccess() - Method in class com.google.common.cache.LocalCache
 
expiresAfterAccess() - Method in class com.google.common.collect.MapMakerInternalMap
 
expiresAfterWrite() - Method in class com.google.common.cache.LocalCache
 
expiresAfterWrite() - Method in class com.google.common.collect.MapMakerInternalMap
 
ExpiringMemoizingSupplier(Supplier<T>, long, TimeUnit) - Constructor for class com.google.common.base.Suppliers.ExpiringMemoizingSupplier
 
explicit(List<T>) - Static method in class com.google.common.collect.Ordering
Returns an ordering that compares objects according to the order in which they appear in the given list.
explicit(T, T...) - Static method in class com.google.common.collect.Ordering
Returns an ordering that compares objects according to the order in which they are given to this method.
ExplicitOrdering<T> - Class in com.google.common.collect
An ordering that compares objects according to a given order.
ExplicitOrdering(List<T>) - Constructor for class com.google.common.collect.ExplicitOrdering
 
ExplicitOrdering(ImmutableMap<T, Integer>) - Constructor for class com.google.common.collect.ExplicitOrdering
 
EXPONENT_BIAS - Static variable in class com.google.common.math.DoubleUtils
 
EXPONENT_MASK - Static variable in class com.google.common.math.DoubleUtils
 
ExposedByteArrayOutputStream(int) - Constructor for class com.google.common.hash.AbstractNonStreamingHashFunction.ExposedByteArrayOutputStream
 
externalState() - Method in class com.google.common.util.concurrent.AbstractService.StateSnapshot
 
extract(byte[], int) - Static method in class com.google.common.io.BaseEncoding
 

F

f - Variable in class com.google.common.base.Functions.FunctionComposition
 
f - Variable in class com.google.common.base.Predicates.CompositionPredicate
 
factorial(int) - Static method in class com.google.common.math.BigIntegerMath
Returns n!, that is, the product of the first n positive integers, or 1 if n == 0.
factorial(int) - Static method in class com.google.common.math.DoubleMath
Returns n!, that is, the product of the first n positive integers, 1 if n == 0, or n!, or Double.POSITIVE_INFINITY if n! > Double.MAX_VALUE.
factorial(int) - Static method in class com.google.common.math.IntMath
Returns n!, that is, the product of the first n positive integers, 1 if n == 0, or Integer.MAX_VALUE if the result does not fit in a int.
factorial(int) - Static method in class com.google.common.math.LongMath
Returns n!, that is, the product of the first n positive integers, 1 if n == 0, or Long.MAX_VALUE if the result does not fit in a long.
factorials - Static variable in class com.google.common.math.IntMath
 
factorials - Static variable in class com.google.common.math.LongMath
 
factories - Static variable in enum com.google.common.cache.LocalCache.EntryFactory
Look-up table for factories.
factories - Static variable in enum com.google.common.collect.MapMakerInternalMap.EntryFactory
Look-up table for factories.
Factory(int) - Constructor for class com.google.common.collect.HashBasedTable.Factory
 
factory - Variable in class com.google.common.collect.Multimaps.CustomListMultimap
 
factory - Variable in class com.google.common.collect.Multimaps.CustomMultimap
 
factory - Variable in class com.google.common.collect.Multimaps.CustomSetMultimap
 
factory - Variable in class com.google.common.collect.Multimaps.CustomSortedSetMultimap
 
factory - Variable in class com.google.common.collect.StandardTable
 
Factory(Comparator<? super C>) - Constructor for class com.google.common.collect.TreeBasedTable.Factory
 
failed(Service.State, Throwable) - Method in class com.google.common.util.concurrent.AbstractService
 
failed(Service.State, Throwable) - Method in class com.google.common.util.concurrent.Service.Listener
Called when the service transitions to the FAILED state.
failed(Service.State, Throwable) - Method in class com.google.common.util.concurrent.ServiceManager.ServiceListener
 
failure - Variable in class com.google.common.util.concurrent.AbstractService.StateSnapshot
The exception that caused this service to fail.
failure(Service) - Method in class com.google.common.util.concurrent.ServiceManager.Listener
Called when a component service has failed.
failureCause() - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
 
failureCause() - Method in class com.google.common.util.concurrent.AbstractIdleService
 
failureCause() - Method in class com.google.common.util.concurrent.AbstractScheduledService
 
failureCause() - Method in class com.google.common.util.concurrent.AbstractService
 
failureCause() - Method in class com.google.common.util.concurrent.AbstractService.StateSnapshot
 
failureCause() - Method in interface com.google.common.util.concurrent.Service
Returns the Throwable that caused this service to fail.
fair - Variable in class com.google.common.util.concurrent.Monitor
Whether this monitor is fair.
FakeTimeLimiter - Class in com.google.common.util.concurrent
A TimeLimiter implementation which actually does not attempt to limit time at all.
FakeTimeLimiter() - Constructor for class com.google.common.util.concurrent.FakeTimeLimiter
 
FallbackFuture(ListenableFuture<? extends V>, FutureFallback<? extends V>, Executor) - Constructor for class com.google.common.util.concurrent.Futures.FallbackFuture
 
FastByteArrayOutputStream() - Constructor for class com.google.common.io.ByteStreams.FastByteArrayOutputStream
 
FastMatcher() - Constructor for class com.google.common.base.CharMatcher.FastMatcher
 
FastMatcher(String) - Constructor for class com.google.common.base.CharMatcher.FastMatcher
 
FF - Static variable in class com.google.common.base.Ascii
Form Feed ('\f'): A format effector which controls the movement of the printing position to the first pre-determined printing line on the next form or page.
field - Variable in class com.google.common.collect.Serialization.FieldSetter
 
FieldSetter(Field) - Constructor for class com.google.common.collect.Serialization.FieldSetter
 
FieldSettersHolder() - Constructor for class com.google.common.collect.ConcurrentHashMultiset.FieldSettersHolder
 
FieldSettersHolder() - Constructor for class com.google.common.collect.ImmutableMultimap.FieldSettersHolder
 
file - Variable in class com.google.common.io.FileBackedOutputStream
 
file - Variable in class com.google.common.io.Files.FileByteSink
 
file - Variable in class com.google.common.io.Files.FileByteSource
 
FILE_TREE_TRAVERSER - Static variable in class com.google.common.io.Files
 
FileBackedOutputStream - Class in com.google.common.io
An OutputStream that starts buffering to a byte array, but switches to file buffering once the data reaches a configurable size.
FileBackedOutputStream(int) - Constructor for class com.google.common.io.FileBackedOutputStream
Creates a new instance that uses the given file threshold, and does not reset the data when the ByteSource returned by FileBackedOutputStream.asByteSource() is finalized.
FileBackedOutputStream(int, boolean) - Constructor for class com.google.common.io.FileBackedOutputStream
Creates a new instance that uses the given file threshold, and optionally resets the data when the ByteSource returned by FileBackedOutputStream.asByteSource() is finalized.
FileBackedOutputStream.MemoryOutput - Class in com.google.common.io
ByteArrayOutputStream that exposes its internals.
FileByteSink(File, FileWriteMode...) - Constructor for class com.google.common.io.Files.FileByteSink
 
FileByteSource(File) - Constructor for class com.google.common.io.Files.FileByteSource
 
FilePredicate() - Constructor for enum com.google.common.io.Files.FilePredicate
 
Files - Class in com.google.common.io
Provides utility methods for working with files.
Files() - Constructor for class com.google.common.io.Files
 
Files.FileByteSink - Class in com.google.common.io
 
Files.FileByteSource - Class in com.google.common.io
 
Files.FilePredicate - Enum in com.google.common.io
 
fileThreshold - Variable in class com.google.common.io.FileBackedOutputStream
 
fileTreeTraverser() - Static method in class com.google.common.io.Files
Returns a TreeTraverser instance for File trees.
FileWriteMode - Enum in com.google.common.io
Modes for opening a file for writing.
FileWriteMode() - Constructor for enum com.google.common.io.FileWriteMode
 
fillArray(Iterable<?>, Object[]) - Static method in class com.google.common.collect.ObjectArrays
 
fillHole(int, E) - Method in class com.google.common.collect.MinMaxPriorityQueue
 
fillHoleAt(int) - Method in class com.google.common.collect.MinMaxPriorityQueue.Heap
Fills the hole at index by moving in the least of its grandchildren to this position, then recursively filling the new hole created.
filter - Variable in class com.google.common.base.SmallCharMatcher
 
filter(Collection<E>, Predicate<? super E>) - Static method in class com.google.common.collect.Collections2
Returns the elements of unfiltered that satisfy a predicate.
filter(Predicate<? super E>) - Method in class com.google.common.collect.FluentIterable
Returns the elements from this fluent iterable that satisfy a predicate.
filter(Class<T>) - Method in class com.google.common.collect.FluentIterable
Returns the elements from this fluent iterable that are instances of class type.
filter(Iterable<T>, Predicate<? super T>) - Static method in class com.google.common.collect.Iterables
Returns the elements of unfiltered that satisfy a predicate.
filter(Iterable<?>, Class<T>) - Static method in class com.google.common.collect.Iterables
Returns all instances of class type in unfiltered.
filter(Iterator<T>, Predicate<? super T>) - Static method in class com.google.common.collect.Iterators
Returns the elements of unfiltered that satisfy a predicate.
filter(Iterator<?>, Class<T>) - Static method in class com.google.common.collect.Iterators
Returns all instances of class type in unfiltered.
filter(Multiset<E>, Predicate<? super E>) - Static method in class com.google.common.collect.Multisets
Returns a view of the elements of unfiltered that satisfy a predicate.
filter(Set<E>, Predicate<? super E>) - Static method in class com.google.common.collect.Sets
Returns the elements of unfiltered that satisfy a predicate.
filter(SortedSet<E>, Predicate<? super E>) - Static method in class com.google.common.collect.Sets
Returns the elements of a SortedSet, unfiltered, that satisfy a predicate.
filter(NavigableSet<E>, Predicate<? super E>) - Static method in class com.google.common.collect.Sets
Returns the elements of a NavigableSet, unfiltered, that satisfy a predicate.
filterCollection(Collection<E>, Predicate<? super E>) - Static method in class com.google.common.collect.FilteredEntryMultimap
 
FilteredCollection(Collection<E>, Predicate<? super E>) - Constructor for class com.google.common.collect.Collections2.FilteredCollection
 
filteredDelegate - Variable in class com.google.common.collect.Maps.FilteredEntryNavigableMap
 
FilteredEntryBiMap(BiMap<K, V>, Predicate<? super Map.Entry<K, V>>) - Constructor for class com.google.common.collect.Maps.FilteredEntryBiMap
 
FilteredEntryBiMap(BiMap<K, V>, Predicate<? super Map.Entry<K, V>>, BiMap<V, K>) - Constructor for class com.google.common.collect.Maps.FilteredEntryBiMap
 
FilteredEntryMap(Map<K, V>, Predicate<? super Map.Entry<K, V>>) - Constructor for class com.google.common.collect.Maps.FilteredEntryMap
 
FilteredEntryMultimap<K,V> - Class in com.google.common.collect
FilteredEntryMultimap(Multimap<K, V>, Predicate<? super Map.Entry<K, V>>) - Constructor for class com.google.common.collect.FilteredEntryMultimap
 
FilteredEntryMultimap.AsMap - Class in com.google.common.collect
 
FilteredEntryMultimap.Keys - Class in com.google.common.collect
 
FilteredEntryMultimap.ValuePredicate - Class in com.google.common.collect
 
FilteredEntryNavigableMap(NavigableMap<K, V>, Predicate<? super Map.Entry<K, V>>) - Constructor for class com.google.common.collect.Maps.FilteredEntryNavigableMap
 
filteredEntrySet - Variable in class com.google.common.collect.Maps.FilteredEntryMap
Entries in this set satisfy the predicate, but they don't validate the input to Entry.setValue().
FilteredEntrySetMultimap<K,V> - Class in com.google.common.collect
FilteredEntrySetMultimap(SetMultimap<K, V>, Predicate<? super Map.Entry<K, V>>) - Constructor for class com.google.common.collect.FilteredEntrySetMultimap
 
FilteredEntrySortedMap(SortedMap<K, V>, Predicate<? super Map.Entry<K, V>>) - Constructor for class com.google.common.collect.Maps.FilteredEntrySortedMap
 
FilteredKeyListMultimap<K,V> - Class in com.google.common.collect
FilteredKeyListMultimap(ListMultimap<K, V>, Predicate<? super K>) - Constructor for class com.google.common.collect.FilteredKeyListMultimap
 
FilteredKeyMap(Map<K, V>, Predicate<? super K>, Predicate<? super Map.Entry<K, V>>) - Constructor for class com.google.common.collect.Maps.FilteredKeyMap
 
FilteredKeyMultimap<K,V> - Class in com.google.common.collect
FilteredKeyMultimap(Multimap<K, V>, Predicate<? super K>) - Constructor for class com.google.common.collect.FilteredKeyMultimap
 
FilteredKeyMultimap.AddRejectingList<K,V> - Class in com.google.common.collect
 
FilteredKeyMultimap.AddRejectingSet<K,V> - Class in com.google.common.collect
 
FilteredKeyMultimap.Entries - Class in com.google.common.collect
 
FilteredKeySetMultimap<K,V> - Class in com.google.common.collect
FilteredKeySetMultimap(SetMultimap<K, V>, Predicate<? super K>) - Constructor for class com.google.common.collect.FilteredKeySetMultimap
 
FilteredKeySetMultimap.EntrySet - Class in com.google.common.collect
 
FilteredMapValues(Map<K, V>, Map<K, V>, Predicate<? super Map.Entry<K, V>>) - Constructor for class com.google.common.collect.Maps.FilteredMapValues
 
FilteredMultimap<K,V> - Interface in com.google.common.collect
An interface for all filtered multimap types.
FilteredMultimapValues<K,V> - Class in com.google.common.collect
Implementation for Multimap.values().
FilteredMultimapValues(FilteredMultimap<K, V>) - Constructor for class com.google.common.collect.FilteredMultimapValues
 
FilteredMultiset(Multiset<E>, Predicate<? super E>) - Constructor for class com.google.common.collect.Multisets.FilteredMultiset
 
FilteredNavigableSet(NavigableSet<E>, Predicate<? super E>) - Constructor for class com.google.common.collect.Sets.FilteredNavigableSet
 
FilteredSet(Set<E>, Predicate<? super E>) - Constructor for class com.google.common.collect.Sets.FilteredSet
 
FilteredSetMultimap<K,V> - Interface in com.google.common.collect
A supertype for filtered SetMultimap implementations.
FilteredSortedSet(SortedSet<E>, Predicate<? super E>) - Constructor for class com.google.common.collect.Sets.FilteredSortedSet
 
filterEntries(Map<K, V>, Predicate<? super Map.Entry<K, V>>) - Static method in class com.google.common.collect.Maps
Returns a map containing the mappings in unfiltered that satisfy a predicate.
filterEntries(SortedMap<K, V>, Predicate<? super Map.Entry<K, V>>) - Static method in class com.google.common.collect.Maps
Returns a sorted map containing the mappings in unfiltered that satisfy a predicate.
filterEntries(NavigableMap<K, V>, Predicate<? super Map.Entry<K, V>>) - Static method in class com.google.common.collect.Maps
Returns a sorted map containing the mappings in unfiltered that satisfy a predicate.
filterEntries(BiMap<K, V>, Predicate<? super Map.Entry<K, V>>) - Static method in class com.google.common.collect.Maps
Returns a bimap containing the mappings in unfiltered that satisfy a predicate.
filterEntries(Multimap<K, V>, Predicate<? super Map.Entry<K, V>>) - Static method in class com.google.common.collect.Multimaps
Returns a multimap containing the mappings in unfiltered that satisfy a predicate.
filterEntries(SetMultimap<K, V>, Predicate<? super Map.Entry<K, V>>) - Static method in class com.google.common.collect.Multimaps
Returns a multimap containing the mappings in unfiltered that satisfy a predicate.
filterFiltered(Maps.AbstractFilteredMap<K, V>, Predicate<? super Map.Entry<K, V>>) - Static method in class com.google.common.collect.Maps
Support clear(), removeAll(), and retainAll() when filtering a filtered map.
filterFiltered(Maps.FilteredEntrySortedMap<K, V>, Predicate<? super Map.Entry<K, V>>) - Static method in class com.google.common.collect.Maps
Support clear(), removeAll(), and retainAll() when filtering a filtered sorted map.
filterFiltered(Maps.FilteredEntryNavigableMap<K, V>, Predicate<? super Map.Entry<K, V>>) - Static method in class com.google.common.collect.Maps
Support clear(), removeAll(), and retainAll() when filtering a filtered navigable map.
filterFiltered(Maps.FilteredEntryBiMap<K, V>, Predicate<? super Map.Entry<K, V>>) - Static method in class com.google.common.collect.Maps
Support clear(), removeAll(), and retainAll() when filtering a filtered map.
filterFiltered(FilteredMultimap<K, V>, Predicate<? super Map.Entry<K, V>>) - Static method in class com.google.common.collect.Multimaps
Support removal operations when filtering a filtered multimap.
filterFiltered(FilteredSetMultimap<K, V>, Predicate<? super Map.Entry<K, V>>) - Static method in class com.google.common.collect.Multimaps
Support removal operations when filtering a filtered multimap.
filterKeys(Map<K, V>, Predicate<? super K>) - Static method in class com.google.common.collect.Maps
Returns a map containing the mappings in unfiltered whose keys satisfy a predicate.
filterKeys(SortedMap<K, V>, Predicate<? super K>) - Static method in class com.google.common.collect.Maps
Returns a sorted map containing the mappings in unfiltered whose keys satisfy a predicate.
filterKeys(NavigableMap<K, V>, Predicate<? super K>) - Static method in class com.google.common.collect.Maps
Returns a navigable map containing the mappings in unfiltered whose keys satisfy a predicate.
filterKeys(BiMap<K, V>, Predicate<? super K>) - Static method in class com.google.common.collect.Maps
Returns a bimap containing the mappings in unfiltered whose keys satisfy a predicate.
filterKeys(Multimap<K, V>, Predicate<? super K>) - Static method in class com.google.common.collect.Multimaps
Returns a multimap containing the mappings in unfiltered whose keys satisfy a predicate.
filterKeys(SetMultimap<K, V>, Predicate<? super K>) - Static method in class com.google.common.collect.Multimaps
Returns a multimap containing the mappings in unfiltered whose keys satisfy a predicate.
filterKeys(ListMultimap<K, V>, Predicate<? super K>) - Static method in class com.google.common.collect.Multimaps
Returns a multimap containing the mappings in unfiltered whose keys satisfy a predicate.
filterSortedIgnoreNavigable(SortedMap<K, V>, Predicate<? super Map.Entry<K, V>>) - Static method in class com.google.common.collect.Maps
 
filterSortedIgnoreNavigable(SortedSet<E>, Predicate<? super E>) - Static method in class com.google.common.collect.Sets
 
filterUpperBounds(Iterable<Type>) - Static method in class com.google.common.reflect.Types
 
filterValues(Map<K, V>, Predicate<? super V>) - Static method in class com.google.common.collect.Maps
Returns a map containing the mappings in unfiltered whose values satisfy a predicate.
filterValues(SortedMap<K, V>, Predicate<? super V>) - Static method in class com.google.common.collect.Maps
Returns a sorted map containing the mappings in unfiltered whose values satisfy a predicate.
filterValues(NavigableMap<K, V>, Predicate<? super V>) - Static method in class com.google.common.collect.Maps
Returns a navigable map containing the mappings in unfiltered whose values satisfy a predicate.
filterValues(BiMap<K, V>, Predicate<? super V>) - Static method in class com.google.common.collect.Maps
Returns a bimap containing the mappings in unfiltered whose values satisfy a predicate.
filterValues(Multimap<K, V>, Predicate<? super V>) - Static method in class com.google.common.collect.Multimaps
Returns a multimap containing the mappings in unfiltered whose values satisfy a predicate.
filterValues(SetMultimap<K, V>, Predicate<? super V>) - Static method in class com.google.common.collect.Multimaps
Returns a multimap containing the mappings in unfiltered whose values satisfy a predicate.
FINALIZABLE_REFERENCE - Static variable in class com.google.common.base.internal.Finalizer
Name of FinalizableReference.class.
FinalizablePhantomReference<T> - Class in com.google.common.base
Phantom reference with a finalizeReferent() method which a background thread invokes after the garbage collector reclaims the referent.
FinalizablePhantomReference(T, FinalizableReferenceQueue) - Constructor for class com.google.common.base.FinalizablePhantomReference
Constructs a new finalizable phantom reference.
FinalizableReference - Interface in com.google.common.base
Implemented by references that have code to run after garbage collection of their referents.
finalizableReferenceClassReference - Variable in class com.google.common.base.internal.Finalizer
 
FinalizableReferenceQueue - Class in com.google.common.base
A reference queue with an associated background thread that dequeues references and invokes FinalizableReference.finalizeReferent() on them.
FinalizableReferenceQueue() - Constructor for class com.google.common.base.FinalizableReferenceQueue
Constructs a new queue.
FinalizableReferenceQueue.DecoupledLoader - Class in com.google.common.base
Try to load Finalizer in its own class loader.
FinalizableReferenceQueue.DirectLoader - Class in com.google.common.base
Loads Finalizer directly using the current class loader.
FinalizableReferenceQueue.FinalizerLoader - Interface in com.google.common.base
Loads Finalizer.class.
FinalizableReferenceQueue.SystemLoader - Class in com.google.common.base
Tries to load Finalizer from the system class loader.
FinalizableSoftReference<T> - Class in com.google.common.base
Soft reference with a finalizeReferent() method which a background thread invokes after the garbage collector reclaims the referent.
FinalizableSoftReference(T, FinalizableReferenceQueue) - Constructor for class com.google.common.base.FinalizableSoftReference
Constructs a new finalizable soft reference.
FinalizableWeakReference<T> - Class in com.google.common.base
Weak reference with a finalizeReferent() method which a background thread invokes after the garbage collector reclaims the referent.
FinalizableWeakReference(T, FinalizableReferenceQueue) - Constructor for class com.google.common.base.FinalizableWeakReference
Constructs a new finalizable weak reference.
Finalizer - Class in com.google.common.base.internal
Thread that finalizes referents.
Finalizer(Class<?>, ReferenceQueue<Object>, PhantomReference<Object>) - Constructor for class com.google.common.base.internal.Finalizer
Constructs a new finalizer thread.
FINALIZER_CLASS_NAME - Static variable in class com.google.common.base.FinalizableReferenceQueue
 
finalizeReferent() - Method in interface com.google.common.base.FinalizableReference
Invoked on a background thread after the referent has been garbage collected unless security restrictions prevented starting a background thread, in which case this method is invoked when new references are created.
finalM - Variable in class com.google.common.hash.SipHashFunction.SipHasher
 
find(Iterable<T>, Predicate<? super T>) - Static method in class com.google.common.collect.Iterables
Returns the first element in iterable that satisfies the given predicate; use this method only when such an element is known to exist.
find(Iterable<? extends T>, Predicate<? super T>, T) - Static method in class com.google.common.collect.Iterables
Returns the first element in iterable that satisfies the given predicate, or defaultValue if none found.
find(Iterator<T>, Predicate<? super T>) - Static method in class com.google.common.collect.Iterators
Returns the first element in iterator that satisfies the given predicate; use this method only when such an element is known to exist.
find(Iterator<? extends T>, Predicate<? super T>, T) - Static method in class com.google.common.collect.Iterators
Returns the first element in iterator that satisfies the given predicate.
findAllSubscribers(Object) - Method in class com.google.common.eventbus.AnnotatedSubscriberFinder
Finds all suitable event subscriber methods in source, organizes them by the type of event they handle, and wraps them in EventSubscriber instances.
findAllSubscribers(Object) - Method in interface com.google.common.eventbus.SubscriberFindingStrategy
Finds all suitable event subscriber methods in source, organizes them by the type of event they handle, and wraps them in EventSubscriber instances.
finder - Variable in class com.google.common.eventbus.EventBus
Strategy for finding subscriber methods in registered objects.
findInterruptibleMethods(Class<?>) - Static method in class com.google.common.util.concurrent.SimpleTimeLimiter
 
findMin(int, int) - Method in class com.google.common.collect.MinMaxPriorityQueue.Heap
Returns the index of minimum value between index and index + len, or -1 if index is greater than size.
findMinChild(int) - Method in class com.google.common.collect.MinMaxPriorityQueue.Heap
Returns the minimum child or -1 if no child exists.
findMinGrandChild(int) - Method in class com.google.common.collect.MinMaxPriorityQueue.Heap
Returns the minimum grand child or -1 if no grand child exists.
findNextJ() - Method in class com.google.common.collect.Collections2.OrderedPermutationIterator
 
findNextL(int) - Method in class com.google.common.collect.Collections2.OrderedPermutationIterator
 
findPathTo(CycleDetectingLockFactory.LockGraphNode, Set<CycleDetectingLockFactory.LockGraphNode>) - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory.LockGraphNode
Performs a depth-first traversal of the graph edges defined by each node's allowedPriorLocks to find a path between this and the specified lock.
findPublicSuffix() - Method in class com.google.common.net.InternetDomainName
Returns the index of the leftmost part of the public suffix, or -1 if not found.
finish() - Method in class com.google.common.io.LineBuffer
Subclasses must call this method after finishing character processing, in order to ensure that any unterminated line in the buffer is passed to LineBuffer.handleLine(java.lang.String, java.lang.String).
finishCollapseFrom(CharSequence, int, int, char, StringBuilder, boolean) - Method in class com.google.common.base.CharMatcher
 
finishLine(boolean) - Method in class com.google.common.io.LineBuffer
Called when a line is complete.
fireFailedListeners(Service) - Method in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState
 
fireHealthyListeners() - Method in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState
 
fireStoppedListeners() - Method in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState
 
first - Variable in class com.google.common.base.CharMatcher.And
 
first - Variable in class com.google.common.base.CharMatcher.Or
 
first - Variable in class com.google.common.base.Converter.ConverterComposition
 
first() - Method in class com.google.common.collect.AbstractMapBasedMultimap.SortedKeySet
 
first() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedSortedSet
 
first() - Method in class com.google.common.collect.EmptyContiguousSet
 
first() - Method in class com.google.common.collect.EmptyImmutableSortedSet
 
first() - Method in class com.google.common.collect.FluentIterable
Returns an Optional containing the first element in this fluent iterable.
first() - Method in class com.google.common.collect.ForwardingSortedSet
 
first() - Method in class com.google.common.collect.ImmutableSortedSet
 
first - Variable in class com.google.common.collect.Lists.OnePlusArrayList
 
first - Variable in class com.google.common.collect.Lists.TwoPlusArrayList
 
first() - Method in class com.google.common.collect.Maps.FilteredEntrySortedMap.SortedKeySet
 
first() - Method in class com.google.common.collect.Maps.SortedKeySet
 
first() - Method in class com.google.common.collect.RegularContiguousSet
 
first() - Method in class com.google.common.collect.RegularImmutableSortedSet
 
first() - Method in class com.google.common.collect.Sets.DescendingSet
 
first() - Method in class com.google.common.collect.Sets.FilteredSortedSet
 
first() - Method in class com.google.common.collect.SortedMultisets.ElementSet
 
first() - Method in class com.google.common.collect.Synchronized.SynchronizedSortedSet
 
firstCharOnlyToUpper(String) - Static method in enum com.google.common.base.CaseFormat
 
firstEntry() - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableAsMap
 
firstEntry() - Method in class com.google.common.collect.AbstractNavigableMap
 
firstEntry() - Method in class com.google.common.collect.AbstractSortedMultiset
 
firstEntry() - Method in class com.google.common.collect.DescendingImmutableSortedMultiset
 
firstEntry() - Method in class com.google.common.collect.DescendingMultiset
 
firstEntry() - Method in class com.google.common.collect.EmptyImmutableSortedMultiset
 
firstEntry() - Method in class com.google.common.collect.ForwardingNavigableMap
 
firstEntry() - Method in class com.google.common.collect.ForwardingSortedMultiset
 
firstEntry() - Method in class com.google.common.collect.ImmutableSortedMap
 
firstEntry - Variable in class com.google.common.collect.LinkedHashMultimap.ValueSet
 
firstEntry() - Method in class com.google.common.collect.Maps.DescendingMap
 
firstEntry() - Method in class com.google.common.collect.Maps.TransformedEntriesNavigableMap
 
firstEntry() - Method in class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
firstEntry() - Method in class com.google.common.collect.RegularImmutableSortedMultiset
 
firstEntry() - Method in interface com.google.common.collect.SortedMultiset
Returns the entry of the first element in this multiset, or null if this multiset is empty.
firstEntry() - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableMap
 
firstEntry() - Method in class com.google.common.collect.UnmodifiableSortedMultiset
 
firstKey() - Method in class com.google.common.collect.AbstractMapBasedMultimap.SortedAsMap
 
firstKey() - Method in class com.google.common.collect.AbstractNavigableMap
 
firstKey() - Method in class com.google.common.collect.ForwardingSortedMap
 
firstKey() - Method in class com.google.common.collect.ImmutableSortedMap
 
firstKey() - Method in class com.google.common.collect.Maps.DescendingMap
 
firstKey() - Method in class com.google.common.collect.Maps.FilteredEntrySortedMap
 
firstKey() - Method in class com.google.common.collect.Maps.SortedAsMapView
 
firstKey() - Method in class com.google.common.collect.Maps.TransformedEntriesSortedMap
 
firstKey() - Method in class com.google.common.collect.StandardRowSortedTable.RowSortedMap
 
firstKey() - Method in class com.google.common.collect.Synchronized.SynchronizedSortedMap
 
firstKey() - Method in class com.google.common.collect.TreeBasedTable.TreeRow
 
firstMatch(Predicate<? super E>) - Method in class com.google.common.collect.FluentIterable
Returns an Optional containing the first element in this fluent iterable that satisfies the given predicate, if such an element exists.
firstNode() - Method in class com.google.common.collect.TreeMultiset
Returns the first node in the tree that is in range.
firstNonNull(T, T) - Static method in class com.google.common.base.MoreObjects
Returns the first of two given parameters that is not null, if either is, or otherwise throws a NullPointerException.
firstNonNull(T, T) - Static method in class com.google.common.base.Objects
Deprecated.
Use MoreObjects.firstNonNull(T, T) instead. This method is scheduled for removal in June 2016.
fitsInInt(long) - Static method in class com.google.common.math.LongMath
 
fitsInLong(BigInteger) - Static method in class com.google.common.math.BigIntegerMath
 
fixedLength(int) - Static method in class com.google.common.base.Splitter
Returns a splitter that divides strings into pieces of the given length.
flags - Variable in class com.google.common.net.InetAddresses.TeredoInfo
 
flattenHierarchy(Class<?>) - Method in class com.google.common.eventbus.EventBus
Flattens a class's type hierarchy into a set of Class objects.
flattenHierarchyCache - Static variable in class com.google.common.eventbus.EventBus
A thread-safe cache for flattenHierarchy().
flip() - Method in enum com.google.common.collect.BoundType
 
flip(int) - Static method in class com.google.common.primitives.UnsignedInts
 
flip(long) - Static method in class com.google.common.primitives.UnsignedLongs
A (self-inverse) bijection which converts the ordering on unsigned longs to the ordering on longs, that is, a <= b as unsigned longs if and only if flip(a) <= flip(b) as signed longs.
FloatArrayAsList(float[]) - Constructor for class com.google.common.primitives.Floats.FloatArrayAsList
 
FloatArrayAsList(float[], int, int) - Constructor for class com.google.common.primitives.Floats.FloatArrayAsList
 
FloatConverter() - Constructor for class com.google.common.primitives.Floats.FloatConverter
 
FLOATING_POINT_PATTERN - Static variable in class com.google.common.primitives.Doubles
This is adapted from the regex suggested by Double.valueOf(String) for prevalidating inputs.
Floats - Class in com.google.common.primitives
Static utility methods pertaining to float primitives, that are not already found in either Float or Arrays.
Floats() - Constructor for class com.google.common.primitives.Floats
 
Floats.FloatArrayAsList - Class in com.google.common.primitives
 
Floats.FloatConverter - Class in com.google.common.primitives
 
Floats.LexicographicalComparator - Enum in com.google.common.primitives
 
floatValue() - Method in class com.google.common.cache.LongAdder
Returns the LongAdder.sum() as a float after a widening primitive conversion.
floatValue() - Method in class com.google.common.primitives.UnsignedInteger
Returns the value of this UnsignedInteger as a float, analogous to a widening primitive conversion from int to float, and correctly rounded.
floatValue() - Method in class com.google.common.primitives.UnsignedLong
Returns the value of this UnsignedLong as a float, analogous to a widening primitive conversion from long to float, and correctly rounded.
floatValue() - Method in class com.google.common.util.concurrent.AtomicDouble
Returns the value of this AtomicDouble as a float after a narrowing primitive conversion.
floor(K) - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableKeySet
 
floor(V) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedNavigableSet
 
floor(E) - Method in class com.google.common.collect.DescendingImmutableSortedSet
 
floor(E) - Method in class com.google.common.collect.ForwardingNavigableSet
 
floor(E) - Method in class com.google.common.collect.ImmutableSortedSet
 
floor(K) - Method in class com.google.common.collect.Maps.NavigableKeySet
 
floor(E) - Method in class com.google.common.collect.RegularImmutableSortedSet
 
floor(E) - Method in class com.google.common.collect.Sets.DescendingSet
 
floor(E) - Method in class com.google.common.collect.Sets.FilteredNavigableSet
 
floor(E) - Method in class com.google.common.collect.Sets.UnmodifiableNavigableSet
 
floor(E) - Method in class com.google.common.collect.SortedMultisets.NavigableElementSet
 
floor(E) - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableSet
 
floor(Comparator<? super E>, E) - Method in class com.google.common.collect.TreeMultiset.AvlNode
 
FLOOR_SQRT_MAX_INT - Static variable in class com.google.common.math.IntMath
 
FLOOR_SQRT_MAX_LONG - Static variable in class com.google.common.math.LongMath
 
floorEntry(K) - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableAsMap
 
floorEntry(K) - Method in class com.google.common.collect.AbstractNavigableMap
 
floorEntry(K) - Method in class com.google.common.collect.ForwardingNavigableMap
 
floorEntry(K) - Method in class com.google.common.collect.ImmutableSortedMap
 
floorEntry(K) - Method in class com.google.common.collect.Maps.DescendingMap
 
floorEntry(K) - Method in class com.google.common.collect.Maps.TransformedEntriesNavigableMap
 
floorEntry(K) - Method in class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
floorEntry(K) - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableMap
 
floorKey(K) - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableAsMap
 
floorKey(K) - Method in class com.google.common.collect.AbstractNavigableMap
 
floorKey(K) - Method in class com.google.common.collect.ForwardingNavigableMap
 
floorKey(K) - Method in class com.google.common.collect.ImmutableSortedMap
 
floorKey(K) - Method in class com.google.common.collect.Maps.DescendingMap
 
floorKey(K) - Method in class com.google.common.collect.Maps.TransformedEntriesNavigableMap
 
floorKey(K) - Method in class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
floorKey(K) - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableMap
 
FluentIterable<E> - Class in com.google.common.collect
FluentIterable provides a rich interface for manipulating Iterable instances in a chained fashion.
FluentIterable() - Constructor for class com.google.common.collect.FluentIterable
Constructor for use by subclasses.
FluentIterable(Iterable<E>) - Constructor for class com.google.common.collect.FluentIterable
 
FluentIterable.FromIterableFunction<E> - Class in com.google.common.collect
Function that transforms Iterable<E> into a fluent iterable.
flush() - Method in class com.google.common.io.AppendableWriter
 
flush() - Method in class com.google.common.io.CharStreams.NullWriter
 
flush() - Method in class com.google.common.io.FileBackedOutputStream
 
flush(Flushable, boolean) - Static method in class com.google.common.io.Flushables
Flush a Flushable, with control over whether an IOException may be thrown.
flush() - Method in interface com.google.common.io.GwtWorkarounds.ByteOutput
 
flush() - Method in interface com.google.common.io.GwtWorkarounds.CharOutput
 
Flushables - Class in com.google.common.io
Utility methods for working with Flushable objects.
Flushables() - Constructor for class com.google.common.io.Flushables
 
flushQuietly(Flushable) - Static method in class com.google.common.io.Flushables
Equivalent to calling flush(flushable, true), but with no IOException in the signature.
fmix(int, int) - Static method in class com.google.common.hash.Murmur3_32HashFunction
 
fmix64(long) - Static method in class com.google.common.hash.Murmur3_128HashFunction.Murmur3_128Hasher
 
fn(long, long) - Method in class com.google.common.cache.LongAdder
Version of plus for use in retryUpdate
fn(long, long) - Method in class com.google.common.cache.Striped64
Computes the function of current and new value.
FOLLOW_ONLY_WHEN_PRERENDER_SHOWN - Static variable in class com.google.common.net.HttpHeaders
The HTTP Follow-Only-When-Prerender-Shown header field name.
FOR_GENERIC_TYPE - Static variable in class com.google.common.reflect.TypeToken.TypeCollector
 
FOR_RAW_TYPE - Static variable in class com.google.common.reflect.TypeToken.TypeCollector
 
forArray(T...) - Static method in class com.google.common.collect.Iterators
Returns an iterator containing the elements of array in order.
forArray(T[], int, int, int) - Static method in class com.google.common.collect.Iterators
Returns a list iterator containing the elements in the specified range of array in order, starting at the specified index.
forBoolean(boolean) - Static method in enum com.google.common.collect.BoundType
Returns the bound type corresponding to a boolean value for inclusivity.
forCells(List<Table.Cell<R, C, V>>, Comparator<? super R>, Comparator<? super C>) - Static method in class com.google.common.collect.RegularImmutableTable
 
forCells(Iterable<Table.Cell<R, C, V>>) - Static method in class com.google.common.collect.RegularImmutableTable
 
forCellsInternal(Iterable<Table.Cell<R, C, V>>, Comparator<? super R>, Comparator<? super C>) - Static method in class com.google.common.collect.RegularImmutableTable
A factory that chooses the most space-efficient representation of the table.
forcePut(K, V) - Method in class com.google.common.collect.AbstractBiMap
 
forcePut(K, V) - Method in interface com.google.common.collect.BiMap
An alternate form of put that silently removes any existing entry with the value value before proceeding with the BiMap.put(K, V) operation.
forcePut(K, V) - Method in class com.google.common.collect.EnumHashBiMap
 
forcePut(K, V) - Method in class com.google.common.collect.HashBiMap
 
forcePut(V, K) - Method in class com.google.common.collect.HashBiMap.Inverse
 
forcePut(K, V) - Method in class com.google.common.collect.ImmutableBiMap
Deprecated.
Unsupported operation.
forcePut(K, V) - Method in class com.google.common.collect.MapConstraints.ConstrainedBiMap
 
forcePut(K, V) - Method in class com.google.common.collect.Maps.FilteredEntryBiMap
 
forcePut(K, V) - Method in class com.google.common.collect.Maps.UnmodifiableBiMap
 
forcePut(K, V) - Method in class com.google.common.collect.Synchronized.SynchronizedBiMap
 
forEnumeration(Enumeration<T>) - Static method in class com.google.common.collect.Iterators
Adapts an Enumeration to the Iterator interface.
forgetMeNot - Variable in class com.google.common.collect.MinMaxPriorityQueue.QueueIterator
 
forLookup(Type) - Static method in class com.google.common.reflect.TypeResolver.TypeVariableKey
Wraps t in a TypeVariableKey if it's a type variable.
FORM_DATA - Static variable in class com.google.common.net.MediaType
 
forMap(Map<K, V>) - Static method in class com.google.common.base.Functions
Returns a function which performs a map lookup.
forMap(Map<K, ? extends V>, V) - Static method in class com.google.common.base.Functions
Returns a function which performs a map lookup with a default value.
forMap(Map<K, V>) - Static method in class com.google.common.collect.Multimaps
Returns a multimap view of the specified map.
ForMapWithDefault(Map<K, ? extends V>, V) - Constructor for class com.google.common.base.Functions.ForMapWithDefault
 
format(String, Object...) - Static method in class com.google.common.base.Preconditions
Substitutes each %s in template with an argument.
forPredicate(Predicate<? super Character>) - Static method in class com.google.common.base.CharMatcher
Returns a matcher with identical behavior to the given Character-based predicate, but which operates on primitive char instances instead.
forPredicate(Predicate<T>) - Static method in class com.google.common.base.Functions
Creates a function that returns the same boolean output as the given predicate for all inputs.
forString(String) - Static method in class com.google.common.net.InetAddresses
Returns the InetAddress having the given string representation.
forSupplier(Supplier<T>) - Static method in class com.google.common.base.Functions
Returns a function that always returns the result of invoking Supplier.get() on supplier, regardless of its input.
forUriString(String) - Static method in class com.google.common.net.InetAddresses
Returns an InetAddress representing the literal IPv4 or IPv6 host portion of a URL, encoded in the format specified by RFC 3986 section 3.2.2.
forward() - Method in class com.google.common.collect.AbstractNavigableMap.DescendingMap
 
forward - Variable in class com.google.common.collect.DescendingImmutableSortedMultiset
 
forward - Variable in class com.google.common.collect.DescendingImmutableSortedSet
 
forward() - Method in class com.google.common.collect.ForwardingNavigableMap.StandardDescendingMap
 
forward() - Method in class com.google.common.collect.HashBiMap.Inverse
 
forward() - Method in class com.google.common.collect.Maps.DescendingMap
 
forward - Variable in class com.google.common.collect.RegularImmutableBiMap.InverseSerializedForm
 
forward - Variable in class com.google.common.collect.Sets.DescendingSet
 
forwardFunction - Variable in class com.google.common.base.Converter.FunctionBasedConverter
 
ForwardingBlockingDeque<E> - Class in com.google.common.collect
A BlockingDeque which forwards all its method calls to another BlockingDeque.
ForwardingBlockingDeque() - Constructor for class com.google.common.collect.ForwardingBlockingDeque
Constructor for use by subclasses.
ForwardingBlockingQueue<E> - Class in com.google.common.util.concurrent
A BlockingQueue which forwards all its method calls to another BlockingQueue.
ForwardingBlockingQueue() - Constructor for class com.google.common.util.concurrent.ForwardingBlockingQueue
Constructor for use by subclasses.
ForwardingCache<K,V> - Class in com.google.common.cache
A cache which forwards all its method calls to another cache.
ForwardingCache() - Constructor for class com.google.common.cache.ForwardingCache
Constructor for use by subclasses.
ForwardingCache.SimpleForwardingCache<K,V> - Class in com.google.common.cache
A simplified version of ForwardingCache where subclasses can pass in an already constructed Cache as the delegete.
ForwardingCheckedFuture<V,X extends java.lang.Exception> - Class in com.google.common.util.concurrent
A future which forwards all its method calls to another future.
ForwardingCheckedFuture() - Constructor for class com.google.common.util.concurrent.ForwardingCheckedFuture
 
ForwardingCheckedFuture.SimpleForwardingCheckedFuture<V,X extends java.lang.Exception> - Class in com.google.common.util.concurrent
A simplified version of ForwardingCheckedFuture where subclasses can pass in an already constructed CheckedFuture as the delegate.
ForwardingCollection<E> - Class in com.google.common.collect
A collection which forwards all its method calls to another collection.
ForwardingCollection() - Constructor for class com.google.common.collect.ForwardingCollection
Constructor for use by subclasses.
ForwardingConcurrentMap<K,V> - Class in com.google.common.collect
A concurrent map which forwards all its method calls to another concurrent map.
ForwardingConcurrentMap() - Constructor for class com.google.common.collect.ForwardingConcurrentMap
Constructor for use by subclasses.
ForwardingDeque<E> - Class in com.google.common.collect
A deque which forwards all its method calls to another deque.
ForwardingDeque() - Constructor for class com.google.common.collect.ForwardingDeque
Constructor for use by subclasses.
ForwardingExecutorService - Class in com.google.common.util.concurrent
An executor service which forwards all its method calls to another executor service.
ForwardingExecutorService() - Constructor for class com.google.common.util.concurrent.ForwardingExecutorService
Constructor for use by subclasses.
ForwardingFuture<V> - Class in com.google.common.util.concurrent
A Future which forwards all its method calls to another future.
ForwardingFuture() - Constructor for class com.google.common.util.concurrent.ForwardingFuture
Constructor for use by subclasses.
ForwardingFuture.SimpleForwardingFuture<V> - Class in com.google.common.util.concurrent
A simplified version of ForwardingFuture where subclasses can pass in an already constructed Future as the delegate.
ForwardingImmutableCollection - Class in com.google.common.collect
Dummy class that makes the GWT serialization policy happy.
ForwardingImmutableCollection() - Constructor for class com.google.common.collect.ForwardingImmutableCollection
 
ForwardingImmutableList<E> - Class in com.google.common.collect
Unused stub class, unreferenced under Java and manually emulated under GWT.
ForwardingImmutableList() - Constructor for class com.google.common.collect.ForwardingImmutableList
 
ForwardingImmutableMap<K,V> - Class in com.google.common.collect
Unused stub class, unreferenced under Java and manually emulated under GWT.
ForwardingImmutableMap() - Constructor for class com.google.common.collect.ForwardingImmutableMap
 
ForwardingImmutableSet<E> - Class in com.google.common.collect
Unused stub class, unreferenced under Java and manually emulated under GWT.
ForwardingImmutableSet() - Constructor for class com.google.common.collect.ForwardingImmutableSet
 
ForwardingIterator<T> - Class in com.google.common.collect
An iterator which forwards all its method calls to another iterator.
ForwardingIterator() - Constructor for class com.google.common.collect.ForwardingIterator
Constructor for use by subclasses.
ForwardingList<E> - Class in com.google.common.collect
A list which forwards all its method calls to another list.
ForwardingList() - Constructor for class com.google.common.collect.ForwardingList
Constructor for use by subclasses.
ForwardingListenableFuture<V> - Class in com.google.common.util.concurrent
A ListenableFuture which forwards all its method calls to another future.
ForwardingListenableFuture() - Constructor for class com.google.common.util.concurrent.ForwardingListenableFuture
Constructor for use by subclasses.
ForwardingListenableFuture.SimpleForwardingListenableFuture<V> - Class in com.google.common.util.concurrent
A simplified version of ForwardingListenableFuture where subclasses can pass in an already constructed ListenableFuture as the delegate.
ForwardingListeningExecutorService - Class in com.google.common.util.concurrent
A listening executor service which forwards all its method calls to another listening executor service.
ForwardingListeningExecutorService() - Constructor for class com.google.common.util.concurrent.ForwardingListeningExecutorService
Constructor for use by subclasses.
ForwardingListIterator<E> - Class in com.google.common.collect
A list iterator which forwards all its method calls to another list iterator.
ForwardingListIterator() - Constructor for class com.google.common.collect.ForwardingListIterator
Constructor for use by subclasses.
ForwardingListMultimap<K,V> - Class in com.google.common.collect
A list multimap which forwards all its method calls to another list multimap.
ForwardingListMultimap() - Constructor for class com.google.common.collect.ForwardingListMultimap
Constructor for use by subclasses.
ForwardingLoadingCache<K,V> - Class in com.google.common.cache
A cache which forwards all its method calls to another cache.
ForwardingLoadingCache() - Constructor for class com.google.common.cache.ForwardingLoadingCache
Constructor for use by subclasses.
ForwardingLoadingCache.SimpleForwardingLoadingCache<K,V> - Class in com.google.common.cache
A simplified version of ForwardingLoadingCache where subclasses can pass in an already constructed LoadingCache as the delegete.
ForwardingMap<K,V> - Class in com.google.common.collect
A map which forwards all its method calls to another map.
ForwardingMap() - Constructor for class com.google.common.collect.ForwardingMap
Constructor for use by subclasses.
ForwardingMap.StandardEntrySet - Class in com.google.common.collect
ForwardingMap.StandardKeySet - Class in com.google.common.collect
A sensible implementation of Map.keySet() in terms of the following methods: ForwardingMap.clear(), ForwardingMap.containsKey(java.lang.Object), ForwardingMap.isEmpty(), ForwardingMap.remove(java.lang.Object), ForwardingMap.size(), and the Set.iterator() method of ForwardingMap.entrySet().
ForwardingMap.StandardValues - Class in com.google.common.collect
A sensible implementation of Map.values() in terms of the following methods: ForwardingMap.clear(), ForwardingMap.containsValue(java.lang.Object), ForwardingMap.isEmpty(), ForwardingMap.size(), and the Set.iterator() method of ForwardingMap.entrySet().
ForwardingMapEntry<K,V> - Class in com.google.common.collect
A map entry which forwards all its method calls to another map entry.
ForwardingMapEntry() - Constructor for class com.google.common.collect.ForwardingMapEntry
Constructor for use by subclasses.
ForwardingMultimap<K,V> - Class in com.google.common.collect
A multimap which forwards all its method calls to another multimap.
ForwardingMultimap() - Constructor for class com.google.common.collect.ForwardingMultimap
Constructor for use by subclasses.
ForwardingMultiset<E> - Class in com.google.common.collect
A multiset which forwards all its method calls to another multiset.
ForwardingMultiset() - Constructor for class com.google.common.collect.ForwardingMultiset
Constructor for use by subclasses.
ForwardingMultiset.StandardElementSet - Class in com.google.common.collect
ForwardingNavigableMap<K,V> - Class in com.google.common.collect
A navigable map which forwards all its method calls to another navigable map.
ForwardingNavigableMap() - Constructor for class com.google.common.collect.ForwardingNavigableMap
Constructor for use by subclasses.
ForwardingNavigableMap.StandardDescendingMap - Class in com.google.common.collect
A sensible implementation of NavigableMap.descendingMap() in terms of the methods of this NavigableMap.
ForwardingNavigableMap.StandardNavigableKeySet - Class in com.google.common.collect
A sensible implementation of NavigableMap.navigableKeySet() in terms of the methods of this NavigableMap.
ForwardingNavigableSet<E> - Class in com.google.common.collect
A navigable set which forwards all its method calls to another navigable set.
ForwardingNavigableSet() - Constructor for class com.google.common.collect.ForwardingNavigableSet
Constructor for use by subclasses.
ForwardingNavigableSet.StandardDescendingSet - Class in com.google.common.collect
A sensible implementation of NavigableSet.descendingSet() in terms of the other methods of NavigableSet, notably including NavigableSet.descendingIterator().
ForwardingObject - Class in com.google.common.collect
An abstract base class for implementing the decorator pattern.
ForwardingObject() - Constructor for class com.google.common.collect.ForwardingObject
Constructor for use by subclasses.
ForwardingQueue<E> - Class in com.google.common.collect
A queue which forwards all its method calls to another queue.
ForwardingQueue() - Constructor for class com.google.common.collect.ForwardingQueue
Constructor for use by subclasses.
ForwardingSet<E> - Class in com.google.common.collect
A set which forwards all its method calls to another set.
ForwardingSet() - Constructor for class com.google.common.collect.ForwardingSet
Constructor for use by subclasses.
ForwardingSetMultimap<K,V> - Class in com.google.common.collect
A set multimap which forwards all its method calls to another set multimap.
ForwardingSetMultimap() - Constructor for class com.google.common.collect.ForwardingSetMultimap
 
ForwardingSortedMap<K,V> - Class in com.google.common.collect
A sorted map which forwards all its method calls to another sorted map.
ForwardingSortedMap() - Constructor for class com.google.common.collect.ForwardingSortedMap
Constructor for use by subclasses.
ForwardingSortedMap.StandardKeySet - Class in com.google.common.collect
A sensible implementation of SortedMap.keySet() in terms of the methods of ForwardingSortedMap.
ForwardingSortedMultiset<E> - Class in com.google.common.collect
A sorted multiset which forwards all its method calls to another sorted multiset.
ForwardingSortedMultiset() - Constructor for class com.google.common.collect.ForwardingSortedMultiset
Constructor for use by subclasses.
ForwardingSortedMultiset.StandardDescendingMultiset - Class in com.google.common.collect
A skeleton implementation of a descending multiset view.
ForwardingSortedMultiset.StandardElementSet - Class in com.google.common.collect
ForwardingSortedSet<E> - Class in com.google.common.collect
A sorted set which forwards all its method calls to another sorted set.
ForwardingSortedSet() - Constructor for class com.google.common.collect.ForwardingSortedSet
Constructor for use by subclasses.
ForwardingSortedSetMultimap<K,V> - Class in com.google.common.collect
A sorted set multimap which forwards all its method calls to another sorted set multimap.
ForwardingSortedSetMultimap() - Constructor for class com.google.common.collect.ForwardingSortedSetMultimap
Constructor for use by subclasses.
ForwardingTable<R,C,V> - Class in com.google.common.collect
A table which forwards all its method calls to another table.
ForwardingTable() - Constructor for class com.google.common.collect.ForwardingTable
Constructor for use by subclasses.
ForwardingTypeCollector(TypeToken.TypeCollector<K>) - Constructor for class com.google.common.reflect.TypeToken.TypeCollector.ForwardingTypeCollector
 
forwardList - Variable in class com.google.common.collect.ImmutableList.ReverseImmutableList
 
forwardList - Variable in class com.google.common.collect.Lists.ReverseList
 
forwardMultiset() - Method in class com.google.common.collect.DescendingMultiset
 
forwardMultiset() - Method in class com.google.common.collect.ForwardingSortedMultiset.StandardDescendingMultiset
 
forwardOrder - Variable in class com.google.common.collect.ReverseOrdering
 
fpPattern() - Static method in class com.google.common.primitives.Doubles
 
frequency(Iterable<?>, Object) - Static method in class com.google.common.collect.Iterables
Returns the number of elements in the specified iterable that equal the specified object.
frequency(Iterator<?>, Object) - Static method in class com.google.common.collect.Iterators
Returns the number of elements in the specified iterator that equal the specified object.
from(Function<? super A, ? extends B>, Function<? super B, ? extends A>) - Static method in class com.google.common.base.Converter
Returns a converter based on existing forward and backward functions.
from(BitSet, String) - Static method in class com.google.common.base.SmallCharMatcher
 
from(CacheBuilderSpec) - Static method in class com.google.common.cache.CacheBuilder
Constructs a new CacheBuilder instance with the settings specified in spec.
from(String) - Static method in class com.google.common.cache.CacheBuilder
Constructs a new CacheBuilder instance with the settings specified in spec.
from(Function<K, V>) - Static method in class com.google.common.cache.CacheLoader
Returns a cache loader based on an existing function instance.
from(Supplier<V>) - Static method in class com.google.common.cache.CacheLoader
Returns a cache loader based on an existing supplier instance.
from(Iterable<E>) - Static method in class com.google.common.collect.FluentIterable
Returns a fluent iterable that wraps iterable, or iterable itself if it is already a FluentIterable.
from(FluentIterable<E>) - Static method in class com.google.common.collect.FluentIterable
Deprecated.
instances of FluentIterable don't need to be converted to FluentIterable
from(Range<T>) - Static method in class com.google.common.collect.GeneralRange
Converts a Range to a GeneralRange.
from(ImmutableSortedSet<K>, ImmutableList<V>) - Static method in class com.google.common.collect.ImmutableSortedMap
 
from(Comparator<T>) - Static method in class com.google.common.collect.Ordering
Returns an ordering based on an existing comparator instance.
from(Ordering<T>) - Static method in class com.google.common.collect.Ordering
Deprecated.
no need to use this
from(String) - Static method in class com.google.common.net.HostSpecifier
Attempts to return a HostSpecifier for the given string, throwing an exception if parsing fails.
FROM - Static variable in class com.google.common.net.HttpHeaders
The HTTP From header field name.
from(String) - Static method in class com.google.common.net.InternetDomainName
Returns an instance of InternetDomainName after lenient validation.
from(ClassLoader) - Static method in class com.google.common.reflect.ClassPath
Returns a ClassPath representing all classes and resources loadable from classloader and its parent class loaders.
from(Method) - Static method in class com.google.common.reflect.Invokable
Returns Invokable of method.
from(Constructor<T>) - Static method in class com.google.common.reflect.Invokable
Returns Invokable of constructor.
fromByteArray(byte[]) - Static method in class com.google.common.primitives.Chars
Returns the char value whose big-endian representation is stored in the first 2 bytes of bytes; equivalent to ByteBuffer.wrap(bytes).getChar().
fromByteArray(byte[]) - Static method in class com.google.common.primitives.Ints
Returns the int value whose big-endian representation is stored in the first 4 bytes of bytes; equivalent to ByteBuffer.wrap(bytes).getInt().
fromByteArray(byte[]) - Static method in class com.google.common.primitives.Longs
Returns the long value whose big-endian representation is stored in the first 8 bytes of bytes; equivalent to ByteBuffer.wrap(bytes).getLong().
fromByteArray(byte[]) - Static method in class com.google.common.primitives.Shorts
Returns the short value whose big-endian representation is stored in the first 2 bytes of bytes; equivalent to ByteBuffer.wrap(bytes).getShort().
fromBytes(byte[]) - Static method in class com.google.common.hash.HashCode
Creates a HashCode from a byte array.
fromBytes(byte, byte) - Static method in class com.google.common.primitives.Chars
Returns the char value whose byte representation is the given 2 bytes, in big-endian order; equivalent to Chars.fromByteArray(new byte[] {b1, b2}).
fromBytes(byte, byte, byte, byte) - Static method in class com.google.common.primitives.Ints
Returns the int value whose byte representation is the given 4 bytes, in big-endian order; equivalent to Ints.fromByteArray(new byte[] {b1, b2, b3, b4}).
fromBytes(byte, byte, byte, byte, byte, byte, byte, byte) - Static method in class com.google.common.primitives.Longs
Returns the long value whose byte representation is the given 8 bytes, in big-endian order; equivalent to Longs.fromByteArray(new byte[] {b1, b2, b3, b4, b5, b6, b7, b8}).
fromBytes(byte, byte) - Static method in class com.google.common.primitives.Shorts
Returns the short value whose byte representation is the given 2 bytes, in big-endian order; equivalent to Shorts.fromByteArray(new byte[] {b1, b2}).
fromBytesNoCopy(byte[]) - Static method in class com.google.common.hash.HashCode
Creates a HashCode from a byte array.
fromCode(char) - Static method in enum com.google.thirdparty.publicsuffix.PublicSuffixType
Returns a PublicSuffixType of the right type according to the given code
fromCollection - Variable in class com.google.common.collect.Collections2.TransformedCollection
 
fromEntries(Comparator<? super K>, boolean, int, Map.Entry<K, V>...) - Static method in class com.google.common.collect.ImmutableSortedMap
 
fromHost(String) - Static method in class com.google.common.net.HostAndPort
Build a HostAndPort instance from a host only.
fromInt(int) - Static method in class com.google.common.hash.HashCode
Creates a 32-bit HashCode representation of the given int value.
fromIntBits(int) - Static method in class com.google.common.primitives.UnsignedInteger
Returns an UnsignedInteger corresponding to a given bit representation.
fromInteger(int) - Static method in class com.google.common.net.InetAddresses
Returns an Inet4Address having the integer value specified by the argument.
fromIsPrivate(boolean) - Static method in enum com.google.thirdparty.publicsuffix.PublicSuffixType
 
FromIterableFunction() - Constructor for class com.google.common.collect.FluentIterable.FromIterableFunction
 
fromList - Variable in class com.google.common.collect.Lists.TransformingRandomAccessList
 
fromList - Variable in class com.google.common.collect.Lists.TransformingSequentialList
 
fromLittleEndianByteArray(byte[]) - Static method in class com.google.common.net.InetAddresses
Returns an address from a little-endian ordered byte array (the opposite of what InetAddress.getByAddress(java.lang.String, byte[]) expects).
fromLong(long) - Static method in class com.google.common.hash.HashCode
Creates a 64-bit HashCode representation of the given long value.
fromLongBits(long) - Static method in class com.google.common.primitives.UnsignedLong
Returns an UnsignedLong corresponding to a given bit representation.
fromMap - Variable in class com.google.common.collect.Maps.TransformedEntriesMap
 
fromMap() - Method in class com.google.common.collect.Maps.TransformedEntriesNavigableMap
 
fromMap() - Method in class com.google.common.collect.Maps.TransformedEntriesSortedMap
 
fromMultimap - Variable in class com.google.common.collect.Multimaps.TransformedEntriesMultimap
 
fromNullable(T) - Static method in class com.google.common.base.Optional
If nullableReference is non-null, returns an Optional instance containing that reference; otherwise returns Optional.absent().
fromParts(String, int) - Static method in class com.google.common.net.HostAndPort
Build a HostAndPort instance from separate host and port values.
fromProperties(Properties) - Static method in class com.google.common.collect.Maps
Creates an ImmutableMap<String, String> from a Properties instance.
fromSortedEntries(Comparator<? super K>, int, Map.Entry<K, V>[]) - Static method in class com.google.common.collect.ImmutableSortedMap
 
fromString(String) - Static method in class com.google.common.hash.HashCode
Creates a HashCode from a hexadecimal (base 16) encoded string.
fromString(String) - Static method in class com.google.common.net.HostAndPort
Split a freeform string into a host and port, without strict validation.
fromString(String) - Static method in class com.google.common.primitives.ParseRequest
 
fromTable - Variable in class com.google.common.collect.Tables.TransformedTable
 
fromValid(String) - Static method in class com.google.common.net.HostSpecifier
Returns a HostSpecifier built from the provided specifier, which is already known to be valid.
frqRef - Variable in class com.google.common.base.FinalizableReferenceQueue
 
frqReference - Variable in class com.google.common.base.internal.Finalizer
 
FS - Static variable in class com.google.common.base.Ascii
File Separator: These four information separators may be used within data in optional fashion, except that their hierarchical relationship shall be: FS is the most inclusive, then GS, then RS, and US is least inclusive.
fullyFailedFuture(Throwable) - Method in class com.google.common.cache.LocalCache.LoadingValueReference
 
Function<F,T> - Interface in com.google.common.base
Determines an output value based on an input value.
function - Variable in class com.google.common.base.FunctionalEquivalence
 
function - Variable in class com.google.common.base.Suppliers.SupplierComposition
 
function - Variable in class com.google.common.collect.ByFunctionOrdering
 
function - Variable in class com.google.common.collect.Collections2.TransformedCollection
 
function - Variable in class com.google.common.collect.Lists.TransformingRandomAccessList
 
function - Variable in class com.google.common.collect.Lists.TransformingSequentialList
 
function - Variable in class com.google.common.collect.Maps.AsMapView
 
function - Variable in class com.google.common.collect.Maps.NavigableAsMapView
 
function - Variable in class com.google.common.collect.Tables.TransformedTable
 
function - Variable in class com.google.common.util.concurrent.Futures.ChainingListenableFuture
 
FunctionalEquivalence<F,T> - Class in com.google.common.base
Equivalence applied on functional result.
FunctionalEquivalence(Function<F, ? extends T>, Equivalence<T>) - Constructor for class com.google.common.base.FunctionalEquivalence
 
FunctionBasedConverter(Function<? super A, ? extends B>, Function<? super B, ? extends A>) - Constructor for class com.google.common.base.Converter.FunctionBasedConverter
 
FunctionComposition(Function<B, C>, Function<A, ? extends B>) - Constructor for class com.google.common.base.Functions.FunctionComposition
 
FunctionForMapNoDefault(Map<K, V>) - Constructor for class com.google.common.base.Functions.FunctionForMapNoDefault
 
Functions - Class in com.google.common.base
Static utility methods pertaining to Function instances.
Functions() - Constructor for class com.google.common.base.Functions
 
functions - Variable in class com.google.common.hash.AbstractCompositeHashFunction
 
Functions.ConstantFunction<E> - Class in com.google.common.base
 
Functions.ForMapWithDefault<K,V> - Class in com.google.common.base
 
Functions.FunctionComposition<A,B,C> - Class in com.google.common.base
 
Functions.FunctionForMapNoDefault<K,V> - Class in com.google.common.base
 
Functions.IdentityFunction - Enum in com.google.common.base
 
Functions.PredicateFunction<T> - Class in com.google.common.base
 
Functions.SupplierFunction<T> - Class in com.google.common.base
 
Functions.ToStringFunction - Enum in com.google.common.base
 
FunctionToCacheLoader(Function<K, V>) - Constructor for class com.google.common.cache.CacheLoader.FunctionToCacheLoader
 
funnel - Variable in class com.google.common.hash.BloomFilter
The funnel to translate Ts to bytes
funnel - Variable in class com.google.common.hash.BloomFilter.SerialForm
 
Funnel<T> - Interface in com.google.common.hash
An object which can send data from an object of type T into a PrimitiveSink.
funnel(T, PrimitiveSink) - Method in interface com.google.common.hash.Funnel
Sends a stream of data from the from object into the sink into.
funnel(byte[], PrimitiveSink) - Method in enum com.google.common.hash.Funnels.ByteArrayFunnel
 
funnel(Integer, PrimitiveSink) - Method in enum com.google.common.hash.Funnels.IntegerFunnel
 
funnel(Long, PrimitiveSink) - Method in enum com.google.common.hash.Funnels.LongFunnel
 
funnel(Iterable<? extends E>, PrimitiveSink) - Method in class com.google.common.hash.Funnels.SequentialFunnel
 
funnel(CharSequence, PrimitiveSink) - Method in class com.google.common.hash.Funnels.StringCharsetFunnel
 
funnel(CharSequence, PrimitiveSink) - Method in enum com.google.common.hash.Funnels.UnencodedCharsFunnel
 
Funnels - Class in com.google.common.hash
Funnels for common types.
Funnels() - Constructor for class com.google.common.hash.Funnels
 
Funnels.ByteArrayFunnel - Enum in com.google.common.hash
 
Funnels.IntegerFunnel - Enum in com.google.common.hash
 
Funnels.LongFunnel - Enum in com.google.common.hash
 
Funnels.SequentialFunnel<E> - Class in com.google.common.hash
 
Funnels.SinkAsStream - Class in com.google.common.hash
 
Funnels.StringCharsetFunnel - Class in com.google.common.hash
 
Funnels.StringCharsetFunnel.SerializedForm - Class in com.google.common.hash
 
Funnels.UnencodedCharsFunnel - Enum in com.google.common.hash
 
FutureCallback<V> - Interface in com.google.common.util.concurrent
A callback for accepting the results of a Future computation asynchronously.
FutureFallback<V> - Interface in com.google.common.util.concurrent
Provides a backup Future to replace an earlier failed Future.
Futures - Class in com.google.common.util.concurrent
Static utility methods pertaining to the Future interface.
Futures() - Constructor for class com.google.common.util.concurrent.Futures
 
futures - Variable in class com.google.common.util.concurrent.Futures.CombinedFuture
 
futures - Variable in class com.google.common.util.concurrent.Futures.CombinerFuture
 
Futures.ChainingListenableFuture<I,O> - Class in com.google.common.util.concurrent
An implementation of ListenableFuture that also implements Runnable so that it can be used to nest ListenableFutures.
Futures.CombinedFuture<V,C> - Class in com.google.common.util.concurrent
 
Futures.CombinerFuture<V> - Class in com.google.common.util.concurrent
 
Futures.FallbackFuture<V> - Class in com.google.common.util.concurrent
A future that falls back on a second, generated future, in case its original future fails.
Futures.FutureCombiner<V,C> - Interface in com.google.common.util.concurrent
 
Futures.ImmediateCancelledFuture<V> - Class in com.google.common.util.concurrent
 
Futures.ImmediateFailedCheckedFuture<V,X extends java.lang.Exception> - Class in com.google.common.util.concurrent
 
Futures.ImmediateFailedFuture<V> - Class in com.google.common.util.concurrent
 
Futures.ImmediateFuture<V> - Class in com.google.common.util.concurrent
 
Futures.ImmediateSuccessfulCheckedFuture<V,X extends java.lang.Exception> - Class in com.google.common.util.concurrent
 
Futures.ImmediateSuccessfulFuture<V> - Class in com.google.common.util.concurrent
 
Futures.MappingCheckedFuture<V,X extends java.lang.Exception> - Class in com.google.common.util.concurrent
A checked future that uses a function to map from exceptions to the appropriate checked type.
Futures.NonCancellationPropagatingFuture<V> - Class in com.google.common.util.concurrent
A wrapped future that does not propagate cancellation to its delegate.
Futures.WrappedCombiner<T> - Class in com.google.common.util.concurrent
 
futureValue - Variable in class com.google.common.cache.LocalCache.LoadingValueReference
 
fuzzyCompare(double, double, double) - Static method in class com.google.common.math.DoubleMath
Compares a and b "fuzzily," with a tolerance for nearly-equal values.
fuzzyEquals(double, double, double) - Static method in class com.google.common.math.DoubleMath
Returns true if a and b are within tolerance of each other.

G

g - Variable in class com.google.common.base.Functions.FunctionComposition
 
gcd(int, int) - Static method in class com.google.common.math.IntMath
Returns the greatest common divisor of a, b.
gcd(long, long) - Static method in class com.google.common.math.LongMath
Returns the greatest common divisor of a, b.
GeneralRange<T> - Class in com.google.common.collect
A generalized interval on any ordering, for internal use.
GeneralRange(Comparator<? super T>, boolean, T, BoundType, boolean, T, BoundType) - Constructor for class com.google.common.collect.GeneralRange
 
GenericArrayTypeImpl(Type) - Constructor for class com.google.common.reflect.Types.GenericArrayTypeImpl
 
genericDeclaration - Variable in class com.google.common.reflect.Types.TypeVariableImpl
 
GenericMapMaker<K0,V0> - Class in com.google.common.collect
Deprecated.
This class existed only to support the generic paramterization necessary for the caching functionality in MapMaker. That functionality has been moved to CacheBuilder, which is a properly generified class and thus needs no "Generic" equivalent; simple use CacheBuilder naturally. For general migration instructions, see the MapMaker Migration Guide.
GenericMapMaker() - Constructor for class com.google.common.collect.GenericMapMaker
Deprecated.
 
GenericMapMaker.NullListener - Enum in com.google.common.collect
Deprecated.
 
get() - Method in class com.google.common.base.Absent
 
get() - Method in class com.google.common.base.Equivalence.Wrapper
Returns the (possibly null) reference wrapped by this instance.
get() - Method in class com.google.common.base.Optional
Returns the contained instance, which must be present.
get() - Method in class com.google.common.base.Present
 
get() - Method in interface com.google.common.base.Supplier
Retrieves an instance of the appropriate type.
get() - Method in class com.google.common.base.Suppliers.ExpiringMemoizingSupplier
 
get() - Method in class com.google.common.base.Suppliers.MemoizingSupplier
 
get() - Method in class com.google.common.base.Suppliers.SupplierComposition
 
get() - Method in class com.google.common.base.Suppliers.SupplierOfInstance
 
get() - Method in class com.google.common.base.Suppliers.ThreadSafeSupplier
 
get(K, Callable<? extends V>) - Method in class com.google.common.cache.AbstractCache
 
get(K, Callable<? extends V>) - Method in interface com.google.common.cache.Cache
Returns the value associated with key in this cache, obtaining that value from valueLoader if necessary.
get(K, Callable<? extends V>) - Method in class com.google.common.cache.ForwardingCache
 
get(K) - Method in class com.google.common.cache.ForwardingLoadingCache
 
get(K) - Method in interface com.google.common.cache.LoadingCache
Returns the value associated with key in this cache, first loading that value if necessary.
get(Object) - Method in class com.google.common.cache.LocalCache
 
get(K, CacheLoader<? super K, V>) - Method in class com.google.common.cache.LocalCache
 
get(K) - Method in class com.google.common.cache.LocalCache.LoadingSerializationProxy
 
get() - Method in class com.google.common.cache.LocalCache.LoadingValueReference
 
get(K) - Method in class com.google.common.cache.LocalCache.LocalLoadingCache
 
get(K, Callable<? extends V>) - Method in class com.google.common.cache.LocalCache.LocalManualCache
 
get(K, int, CacheLoader<? super K, V>) - Method in class com.google.common.cache.LocalCache.Segment
 
get(Object, int) - Method in class com.google.common.cache.LocalCache.Segment
 
get() - Method in class com.google.common.cache.LocalCache.StrongValueReference
 
get() - Method in interface com.google.common.cache.LocalCache.ValueReference
Returns the value.
get(int) - Method in class com.google.common.collect.AbstractIndexedListIterator
Returns the element with the specified index.
get(K) - Method in class com.google.common.collect.AbstractListMultimap
Returns a view collection of the values associated with key in this multimap, if any.
get(Object) - Method in class com.google.common.collect.AbstractMapBasedMultimap.AsMap
 
get(K) - Method in class com.google.common.collect.AbstractMapBasedMultimap
Returns a view collection of the values associated with key in this multimap, if any.
get(int) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedList
 
get(Object) - Method in class com.google.common.collect.AbstractNavigableMap
 
get(K) - Method in class com.google.common.collect.AbstractSetMultimap
Returns a view collection of the values associated with key in this multimap, if any.
get(K) - Method in class com.google.common.collect.AbstractSortedSetMultimap
Returns a collection view of all values associated with a key.
get(Object, Object) - Method in class com.google.common.collect.AbstractTable
 
get(Object) - Method in class com.google.common.collect.ArrayTable.ArrayMap
 
get(Object, Object) - Method in class com.google.common.collect.ArrayTable
 
get(int) - Method in class com.google.common.collect.CartesianList
 
get() - Method in class com.google.common.collect.ComputingConcurrentHashMap.ComputationExceptionReference
 
get() - Method in class com.google.common.collect.ComputingConcurrentHashMap.ComputedReference
 
get() - Method in class com.google.common.collect.ComputingConcurrentHashMap.ComputingValueReference
 
get() - Method in class com.google.common.collect.Count
 
get(Object, Object) - Method in class com.google.common.collect.DenseImmutableTable
 
get(Object) - Method in class com.google.common.collect.DenseImmutableTable.ImmutableArrayMap
 
get(Object) - Method in class com.google.common.collect.EmptyImmutableBiMap
 
get(Object) - Method in class com.google.common.collect.EmptyImmutableSortedMap
 
get(Object) - Method in class com.google.common.collect.FilteredEntryMultimap.AsMap
 
get(K) - Method in class com.google.common.collect.FilteredEntryMultimap
 
get(K) - Method in class com.google.common.collect.FilteredEntrySetMultimap
 
get(K) - Method in class com.google.common.collect.FilteredKeyListMultimap
 
get(K) - Method in class com.google.common.collect.FilteredKeyMultimap
 
get(K) - Method in class com.google.common.collect.FilteredKeySetMultimap
 
get(int) - Method in class com.google.common.collect.FluentIterable
Returns the element at the specified position in this fluent iterable.
get(int) - Method in class com.google.common.collect.ForwardingList
 
get(K) - Method in class com.google.common.collect.ForwardingListMultimap
 
get(Object) - Method in class com.google.common.collect.ForwardingMap
 
get(K) - Method in class com.google.common.collect.ForwardingMultimap
 
get(K) - Method in class com.google.common.collect.ForwardingSetMultimap
 
get(K) - Method in class com.google.common.collect.ForwardingSortedSetMultimap
 
get(Object, Object) - Method in class com.google.common.collect.ForwardingTable
 
get() - Method in class com.google.common.collect.HashBasedTable.Factory
 
get(Object, Object) - Method in class com.google.common.collect.HashBasedTable
 
get(Object) - Method in class com.google.common.collect.HashBiMap
 
get(Object) - Method in class com.google.common.collect.HashBiMap.Inverse
 
get(Object) - Method in class com.google.common.collect.ImmutableEnumMap
 
get(int) - Method in class com.google.common.collect.ImmutableList.ReverseImmutableList
 
get(int) - Method in class com.google.common.collect.ImmutableList.SubList
 
get(K) - Method in class com.google.common.collect.ImmutableListMultimap
Returns an immutable list of the values for the given key.
get(Object) - Method in class com.google.common.collect.ImmutableMap
 
get(Object) - Method in class com.google.common.collect.ImmutableMap.MapViewOfValuesAsSingletonSets
 
get(K) - Method in class com.google.common.collect.ImmutableMultimap
Returns an immutable collection of the values for the given key.
get(K) - Method in class com.google.common.collect.ImmutableRangeMap
 
get(int) - Method in class com.google.common.collect.ImmutableRangeSet.ComplementRanges
 
get(K) - Method in class com.google.common.collect.ImmutableSetMultimap
Returns an immutable set of the values for the given key.
get(Iterable<T>, int) - Static method in class com.google.common.collect.Iterables
Returns the element at the specified position in an iterable.
get(Iterable<? extends T>, int, T) - Static method in class com.google.common.collect.Iterables
Returns the element at the specified position in an iterable or a default value otherwise.
get(Iterator<T>, int) - Static method in class com.google.common.collect.Iterators
Advances iterator position + 1 times, returning the element at the positionth position.
get(Iterator<? extends T>, int, T) - Static method in class com.google.common.collect.Iterators
Advances iterator position + 1 times, returning the element at the positionth position or defaultValue otherwise.
get(K) - Method in class com.google.common.collect.LinkedListMultimap
Returns a view collection of the values associated with key in this multimap, if any.
get(K) - Method in interface com.google.common.collect.ListMultimap
Returns a view collection of the values associated with key in this multimap, if any.
get(int) - Method in class com.google.common.collect.Lists.AbstractListWrapper
 
get(int) - Method in class com.google.common.collect.Lists.CharSequenceAsList
 
get(int) - Method in class com.google.common.collect.Lists.OnePlusArrayList
 
get(int) - Method in class com.google.common.collect.Lists.Partition
 
get(int) - Method in class com.google.common.collect.Lists.ReverseList
 
get(int) - Method in class com.google.common.collect.Lists.StringAsImmutableList
 
get(int) - Method in class com.google.common.collect.Lists.TransformingRandomAccessList
 
get(int) - Method in class com.google.common.collect.Lists.TwoPlusArrayList
 
get(K) - Method in class com.google.common.collect.MapConstraints.ConstrainedListMultimap
 
get(K) - Method in class com.google.common.collect.MapConstraints.ConstrainedMultimap
 
get(K) - Method in class com.google.common.collect.MapConstraints.ConstrainedSetMultimap
 
get(K) - Method in class com.google.common.collect.MapConstraints.ConstrainedSortedSetMultimap
 
get(Object) - Method in class com.google.common.collect.MapMaker.ComputingMapAdapter
 
get(Object) - Method in class com.google.common.collect.MapMaker.NullComputingConcurrentMap
 
get(Object) - Method in class com.google.common.collect.MapMaker.NullConcurrentMap
 
get(Object) - Method in class com.google.common.collect.MapMakerInternalMap
 
get(Object, int) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
 
get() - Method in class com.google.common.collect.MapMakerInternalMap.StrongValueReference
 
get() - Method in interface com.google.common.collect.MapMakerInternalMap.ValueReference
Gets the value.
get(Object) - Method in class com.google.common.collect.Maps.AbstractFilteredMap
 
get(Object) - Method in class com.google.common.collect.Maps.AsMapView
 
get(Object) - Method in class com.google.common.collect.Maps.FilteredEntryNavigableMap
 
get(Object) - Method in class com.google.common.collect.Maps.NavigableAsMapView
 
get(Object) - Method in class com.google.common.collect.Maps.TransformedEntriesMap
 
get(K) - Method in interface com.google.common.collect.Multimap
Returns a view collection of the values associated with key in this multimap, if any.
get() - Method in class com.google.common.collect.MultimapBuilder.ArrayListSupplier
 
get() - Method in class com.google.common.collect.MultimapBuilder.EnumSetSupplier
 
get() - Method in class com.google.common.collect.MultimapBuilder.HashSetSupplier
 
get() - Method in class com.google.common.collect.MultimapBuilder.LinkedHashSetSupplier
 
get() - Method in enum com.google.common.collect.MultimapBuilder.LinkedListSupplier
 
get() - Method in class com.google.common.collect.MultimapBuilder.TreeSetSupplier
 
get(Object) - Method in class com.google.common.collect.Multimaps.AsMap
 
get(K) - Method in class com.google.common.collect.Multimaps.MapMultimap
 
get(K) - Method in class com.google.common.collect.Multimaps.TransformedEntriesListMultimap
 
get(K) - Method in class com.google.common.collect.Multimaps.TransformedEntriesMultimap
 
get(K) - Method in class com.google.common.collect.Multimaps.UnmodifiableListMultimap
 
get(K) - Method in class com.google.common.collect.Multimaps.UnmodifiableMultimap
 
get(K) - Method in class com.google.common.collect.Multimaps.UnmodifiableSetMultimap
 
get(K) - Method in class com.google.common.collect.Multimaps.UnmodifiableSortedSetMultimap
 
get(K) - Method in interface com.google.common.collect.RangeMap
Returns the value associated with the specified key, or null if there is no such value.
get(int) - Method in class com.google.common.collect.RegularImmutableAsList
 
get(Object) - Method in class com.google.common.collect.RegularImmutableBiMap
 
get(Object) - Method in class com.google.common.collect.RegularImmutableBiMap.Inverse
 
get(int) - Method in class com.google.common.collect.RegularImmutableList
 
get(Object) - Method in class com.google.common.collect.RegularImmutableMap
 
get(Object) - Method in class com.google.common.collect.RegularImmutableSortedMap
 
get(int) - Method in class com.google.common.collect.RegularImmutableTable.Values
 
get(K) - Method in interface com.google.common.collect.SetMultimap
Returns a view collection of the values associated with key in this multimap, if any.
get(Object) - Method in class com.google.common.collect.SingletonImmutableBiMap
 
get(int) - Method in class com.google.common.collect.SingletonImmutableList
 
get(K) - Method in interface com.google.common.collect.SortedSetMultimap
Returns a collection view of all values associated with a key.
get(Object) - Method in class com.google.common.collect.StandardTable.Column
 
get(Object) - Method in class com.google.common.collect.StandardTable.ColumnMap
 
get(Object, Object) - Method in class com.google.common.collect.StandardTable
 
get(Object) - Method in class com.google.common.collect.StandardTable.Row
 
get(Object) - Method in class com.google.common.collect.StandardTable.RowMap
 
get(Object) - Method in class com.google.common.collect.Synchronized.SynchronizedAsMap
 
get(int) - Method in class com.google.common.collect.Synchronized.SynchronizedList
 
get(K) - Method in class com.google.common.collect.Synchronized.SynchronizedListMultimap
 
get(Object) - Method in class com.google.common.collect.Synchronized.SynchronizedMap
 
get(K) - Method in class com.google.common.collect.Synchronized.SynchronizedMultimap
 
get(K) - Method in class com.google.common.collect.Synchronized.SynchronizedSetMultimap
 
get(K) - Method in class com.google.common.collect.Synchronized.SynchronizedSortedSetMultimap
 
get(Object, Object) - Method in interface com.google.common.collect.Table
Returns the value corresponding to the given row and column keys, or null if no such mapping exists.
get(Object, Object) - Method in class com.google.common.collect.Tables.TransformedTable
 
get(Object, Object) - Method in class com.google.common.collect.Tables.TransposeTable
 
get() - Method in class com.google.common.collect.TreeBasedTable.Factory
 
get(K) - Method in class com.google.common.collect.TreeMultimap
 
get() - Method in class com.google.common.collect.TreeMultiset.Reference
 
get(Object) - Method in class com.google.common.collect.TreeRangeMap.AsMapOfRanges
 
get(K) - Method in class com.google.common.collect.TreeRangeMap
 
get(K) - Method in class com.google.common.collect.TreeRangeMap.SubRangeMap
 
get(Object) - Method in class com.google.common.collect.TreeRangeMap.SubRangeMap.SubRangeMapAsMap
 
get(Object) - Method in class com.google.common.collect.TreeRangeSet.ComplementRangesByLowerBound
 
get(Object) - Method in class com.google.common.collect.TreeRangeSet.RangesByUpperBound
 
get(Object) - Method in class com.google.common.collect.TreeRangeSet.SubRangeSetRangesByLowerBound
 
get(long) - Method in class com.google.common.hash.BloomFilterStrategies.BitArray
 
get() - Method in enum com.google.common.hash.Hashing.ChecksumType
 
get(int) - Method in class com.google.common.primitives.Booleans.BooleanArrayAsList
 
get(int) - Method in class com.google.common.primitives.Bytes.ByteArrayAsList
 
get(int) - Method in class com.google.common.primitives.Chars.CharArrayAsList
 
get(int) - Method in class com.google.common.primitives.Doubles.DoubleArrayAsList
 
get(int) - Method in class com.google.common.primitives.Floats.FloatArrayAsList
 
get(int) - Method in class com.google.common.primitives.Ints.IntArrayAsList
 
get(int) - Method in class com.google.common.primitives.Longs.LongArrayAsList
 
get(int) - Method in class com.google.common.primitives.Shorts.ShortArrayAsList
 
get(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractFuture
get() - Method in class com.google.common.util.concurrent.AbstractFuture
get(long) - Method in class com.google.common.util.concurrent.AbstractFuture.Sync
Blocks until the task is complete or the timeout expires.
get() - Method in class com.google.common.util.concurrent.AbstractFuture.Sync
Blocks until AbstractFuture.Sync.complete(Object, Throwable, int) has been successfully called.
get() - Method in class com.google.common.util.concurrent.AtomicDouble
Gets the current value.
get(int) - Method in class com.google.common.util.concurrent.AtomicDoubleArray
Gets the current value at position i.
get(K) - Method in class com.google.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.google.common.util.concurrent.ForwardingFuture
 
get(long, TimeUnit) - Method in class com.google.common.util.concurrent.ForwardingFuture
 
get(Future<V>, Class<X>) - Static method in class com.google.common.util.concurrent.Futures
Returns the result of Future.get(), converting most exceptions to a new instance of the given checked exception type.
get(Future<V>, long, TimeUnit, Class<X>) - Static method in class com.google.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.
get() - Method in class com.google.common.util.concurrent.Futures.ImmediateCancelledFuture
 
get() - Method in class com.google.common.util.concurrent.Futures.ImmediateFailedCheckedFuture
 
get() - Method in class com.google.common.util.concurrent.Futures.ImmediateFailedFuture
 
get() - Method in class com.google.common.util.concurrent.Futures.ImmediateFuture
 
get(long, TimeUnit) - Method in class com.google.common.util.concurrent.Futures.ImmediateFuture
 
get() - Method in class com.google.common.util.concurrent.Futures.ImmediateSuccessfulCheckedFuture
 
get() - Method in class com.google.common.util.concurrent.Futures.ImmediateSuccessfulFuture
 
get(Object) - Method in class com.google.common.util.concurrent.Striped
Returns the stripe that corresponds to the passed key.
get(Object) - Method in class com.google.common.util.concurrent.Striped.PowerOfTwoStriped
 
get6to4IPv4Address(Inet6Address) - Static method in class com.google.common.net.InetAddresses
Returns the IPv4 address embedded in a 6to4 address.
getAccessTime() - Method in class com.google.common.cache.LocalCache.AbstractReferenceEntry
 
getAccessTime() - Method in enum com.google.common.cache.LocalCache.NullEntry
 
getAccessTime() - Method in interface com.google.common.cache.LocalCache.ReferenceEntry
Returns the time that this entry was last accessed, in ns.
getAccessTime() - Method in class com.google.common.cache.LocalCache.StrongAccessEntry
 
getAccessTime() - Method in class com.google.common.cache.LocalCache.StrongAccessWriteEntry
 
getAccessTime() - Method in class com.google.common.cache.LocalCache.WeakAccessEntry
 
getAccessTime() - Method in class com.google.common.cache.LocalCache.WeakAccessWriteEntry
 
getAccessTime() - Method in class com.google.common.cache.LocalCache.WeakEntry
 
getActualTypeArguments() - Method in class com.google.common.reflect.Types.ParameterizedTypeImpl
 
getAddSuppressed() - Static method in class com.google.common.io.Closer.SuppressingSuppressor
 
getAll(Iterable<? extends K>) - Method in class com.google.common.cache.AbstractLoadingCache
 
getAll(Iterable<? extends K>) - Method in class com.google.common.cache.ForwardingLoadingCache
 
getAll(Iterable<? extends K>) - Method in interface com.google.common.cache.LoadingCache
Returns a map of the values associated with keys, creating or retrieving those values if necessary.
getAll(Iterable<? extends K>) - Method in class com.google.common.cache.LocalCache
 
getAll(Iterable<? extends K>) - Method in class com.google.common.cache.LocalCache.LoadingSerializationProxy
 
getAll(Iterable<? extends K>) - Method in class com.google.common.cache.LocalCache.LocalLoadingCache
 
getAllClasses() - Method in class com.google.common.reflect.ClassPath
Returns all classes loadable from the current class path.
getAllPresent(Iterable<?>) - Method in class com.google.common.cache.AbstractCache
This implementation of getAllPresent lacks any insight into the internal cache data structure, and is thus forced to return the query keys instead of the cached keys.
getAllPresent(Iterable<?>) - Method in interface com.google.common.cache.Cache
Returns a map of the values associated with keys in this cache.
getAllPresent(Iterable<?>) - Method in class com.google.common.cache.ForwardingCache
 
getAllPresent(Iterable<?>) - Method in class com.google.common.cache.LocalCache
 
getAllPresent(Iterable<?>) - Method in class com.google.common.cache.LocalCache.LocalManualCache
 
getAlphaIndex(char) - Static method in class com.google.common.base.Ascii
Returns the non-negative index value of the alpha character c, regardless of case.
getAncestor() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection
 
getAndAdd(int) - Method in class com.google.common.collect.Count
 
getAndAdd(double) - Method in class com.google.common.util.concurrent.AtomicDouble
Atomically adds the given value to the current value.
getAndAdd(int, double) - Method in class com.google.common.util.concurrent.AtomicDoubleArray
Atomically adds the given value to the element at index i.
getAndAdd(K, long) - Method in class com.google.common.util.concurrent.AtomicLongMap
Adds delta to the value currently associated with key, and returns the old value.
getAndDecrement(K) - Method in class com.google.common.util.concurrent.AtomicLongMap
Decrements by one the value currently associated with key, and returns the old value.
getAndIncrement(K) - Method in class com.google.common.util.concurrent.AtomicLongMap
Increments by one the value currently associated with key, and returns the old value.
getAndRecordStats(K, int, LocalCache.LoadingValueReference<K, V>, ListenableFuture<V>) - Method in class com.google.common.cache.LocalCache.Segment
Waits uninterruptibly for newValue to be loaded, and then records loading stats.
getAndSet(Count, int) - Static method in class com.google.common.collect.AbstractMapBasedMultiset
 
getAndSet(int) - Method in class com.google.common.collect.Count
 
getAndSet(double) - Method in class com.google.common.util.concurrent.AtomicDouble
Atomically sets to the given value and returns the old value.
getAndSet(int, double) - Method in class com.google.common.util.concurrent.AtomicDoubleArray
Atomically sets the element at position i to the given value and returns the old value.
getAnnotatedBounds() - Method in class com.google.common.reflect.Types.TypeVariableImpl
 
getAnnotatedMethods(Class<?>) - Static method in class com.google.common.eventbus.AnnotatedSubscriberFinder
 
getAnnotatedMethodsInternal(Class<?>) - Static method in class com.google.common.eventbus.AnnotatedSubscriberFinder
 
getAnnotation(Class<A>) - Method in class com.google.common.reflect.Element
 
getAnnotation(Class<A>) - Method in class com.google.common.reflect.Parameter
 
getAnnotation(Class<T>) - Method in class com.google.common.reflect.Types.TypeVariableImpl
 
getAnnotations() - Method in class com.google.common.reflect.Element
 
getAnnotations() - Method in class com.google.common.reflect.Parameter
 
getAnnotations() - Method in class com.google.common.reflect.Types.TypeVariableImpl
 
getAnnotationsByType(Class<A>) - Method in class com.google.common.reflect.Parameter
 
getArrayClass(Class<?>) - Static method in class com.google.common.reflect.Types
Returns the Class object of arrays with componentType.
getArraySubtype(Class<?>) - Method in class com.google.common.reflect.TypeToken
 
getArraySupertype(Class<? super T>) - Method in class com.google.common.reflect.TypeToken
 
getAt(int) - Method in class com.google.common.util.concurrent.Striped.CompactStriped
 
getAt(int) - Method in class com.google.common.util.concurrent.Striped
Returns the stripe at the specified index.
getAt(int) - Method in class com.google.common.util.concurrent.Striped.LargeLazyStriped
 
getAt(int) - Method in class com.google.common.util.concurrent.Striped.SmallLazyStriped
 
getAxisIndexForProductIndex(int, int) - Method in class com.google.common.collect.CartesianList
 
getBaseUrl() - Method in class com.google.common.base.FinalizableReferenceQueue.DecoupledLoader
Gets URL for base of path containing Finalizer.class.
getBestComparator() - Static method in class com.google.common.primitives.UnsignedBytes.LexicographicalComparatorHolder
Returns the Unsafe-using Comparator, or falls back to the pure-Java implementation if unable to do so.
getBounds() - Method in class com.google.common.reflect.Types.TypeVariableImpl
 
getBuffer() - Method in class com.google.common.io.FileBackedOutputStream.MemoryOutput
 
getBytesInternal() - Method in class com.google.common.hash.HashCode.BytesHashCode
 
getBytesInternal() - Method in class com.google.common.hash.HashCode
Returns a mutable view of the underlying bytes for the given HashCode if it is a byte-based hashcode.
getCausalChain(Throwable) - Static method in class com.google.common.base.Throwables
Gets a Throwable cause chain as a list.
getCause() - Method in class com.google.common.cache.RemovalNotification
Returns the cause for which the entry was removed.
getCause() - Method in class com.google.common.collect.MapMaker.RemovalNotification
Returns the cause for which the entry was removed.
getCell(int) - Method in class com.google.common.collect.DenseImmutableTable
 
getCell(int) - Method in class com.google.common.collect.RegularImmutableTable
 
getCell(int) - Method in class com.google.common.collect.SparseImmutableTable
 
getClassName(String) - Static method in class com.google.common.reflect.ClassPath
 
getClassPathEntries(ClassLoader) - Static method in class com.google.common.reflect.ClassPath
 
getClassPathEntry(File, String) - Static method in class com.google.common.reflect.ClassPath.Scanner
Returns the absolute uri of the Class-Path entry value as specified in JAR File Specification.
getClassPathFromManifest(File, Manifest) - Static method in class com.google.common.reflect.ClassPath.Scanner
Returns the class path URIs specified by the Class-Path manifest attribute, according to JAR File Specification.
getClient() - Method in class com.google.common.net.InetAddresses.TeredoInfo
 
getCoercedIPv4Address(InetAddress) - Static method in class com.google.common.net.InetAddresses
Coerces an IPv6 address into an IPv4 address.
getColumnKey() - Method in interface com.google.common.collect.Table.Cell
Returns the column key of this cell.
getColumnKey() - Method in class com.google.common.collect.Tables.ImmutableCell
 
getCompatIPv4Address(Inet6Address) - Static method in class com.google.common.net.InetAddresses
Returns the IPv4 address embedded in an IPv4 compatible address.
getComponentType(Type) - Static method in class com.google.common.reflect.Types
 
getComponentType() - Method in class com.google.common.reflect.TypeToken
Returns the array component type if this type represents an array (int[], T[], <? extends Map<String, Integer>[]> etc.), or else null is returned.
getConcurrencyLevel() - Method in class com.google.common.cache.CacheBuilder
 
getConcurrencyLevel() - Method in class com.google.common.collect.MapMaker
 
getConflictingStackTrace() - Method in exception com.google.common.util.concurrent.CycleDetectingLockFactory.PotentialDeadlockException
 
getCopy(Object) - Method in class com.google.common.collect.LinkedListMultimap
 
getCorrectLastElement(E) - Method in class com.google.common.collect.MinMaxPriorityQueue.Heap
Returns the conceptually correct last element of the heap.
getCount() - Method in interface com.google.common.collect.Multiset.Entry
Returns the count of the associated element in the underlying multiset.
getCount() - Method in class com.google.common.collect.Multisets.ImmutableEntry
 
getCount() - Method in class com.google.common.collect.TreeMultiset.AvlNode
 
getCount() - Method in class com.google.common.io.CountingInputStream
Returns the number of bytes read.
getCount() - Method in class com.google.common.io.CountingOutputStream
Returns the number of bytes written.
getCount() - Method in class com.google.common.io.FileBackedOutputStream.MemoryOutput
 
getDeclaredAnnotation(Class<A>) - Method in class com.google.common.reflect.Parameter
 
getDeclaredAnnotations() - Method in class com.google.common.reflect.Element
 
getDeclaredAnnotations() - Method in class com.google.common.reflect.Parameter
 
getDeclaredAnnotations() - Method in class com.google.common.reflect.Types.TypeVariableImpl
 
getDeclaredAnnotationsByType(Class<A>) - Method in class com.google.common.reflect.Parameter
 
getDeclaringClass() - Method in class com.google.common.reflect.Element
 
getDeclaringClass() - Method in class com.google.common.reflect.Invokable
 
getDeclaringInvokable() - Method in class com.google.common.reflect.Parameter
Returns the Invokable that declares this parameter.
getDelay(TimeUnit) - Method in class com.google.common.util.concurrent.MoreExecutors.ScheduledListeningDecorator.ListenableScheduledTask
 
getDelegate() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection
 
getDelegateIterator() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection.WrappedIterator
 
getDelegateListIterator() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedList.WrappedListIterator
 
getElement() - Method in interface com.google.common.collect.Multiset.Entry
Returns the multiset element corresponding to this entry.
getElement() - Method in class com.google.common.collect.Multisets.ImmutableEntry
 
getElement() - Method in class com.google.common.collect.TreeMultiset.AvlNode
 
getElementOrNull(Multiset.Entry<E>) - Static method in class com.google.common.collect.SortedMultisets
 
getElementOrThrow(Multiset.Entry<E>) - Static method in class com.google.common.collect.SortedMultisets
 
getEmbeddedIPv4ClientAddress(Inet6Address) - Static method in class com.google.common.net.InetAddresses
Examines the Inet6Address to extract the embedded IPv4 client address if the InetAddress is an IPv6 address of one of the specified address types that contain an embedded IPv4 address.
getEntry(Object) - Method in class com.google.common.cache.LocalCache
Returns the internal entry for the specified key.
getEntry() - Method in class com.google.common.cache.LocalCache.LoadingValueReference
 
getEntry(Object, int) - Method in class com.google.common.cache.LocalCache.Segment
 
getEntry() - Method in class com.google.common.cache.LocalCache.SoftValueReference
 
getEntry() - Method in class com.google.common.cache.LocalCache.StrongValueReference
 
getEntry() - Method in interface com.google.common.cache.LocalCache.ValueReference
Returns the entry associated with this value reference, or null if this value reference is independent of any entry.
getEntry() - Method in class com.google.common.cache.LocalCache.WeakValueReference
 
getEntry() - Method in class com.google.common.collect.ComputingConcurrentHashMap.ComputationExceptionReference
 
getEntry() - Method in class com.google.common.collect.ComputingConcurrentHashMap.ComputedReference
 
getEntry() - Method in class com.google.common.collect.ComputingConcurrentHashMap.ComputingValueReference
 
getEntry(int) - Method in class com.google.common.collect.DescendingImmutableSortedMultiset
 
getEntry(int) - Method in class com.google.common.collect.EmptyImmutableSortedMultiset
 
getEntry(int) - Method in class com.google.common.collect.ImmutableMultimap.Keys
 
getEntry(int) - Method in class com.google.common.collect.ImmutableMultiset
 
getEntry(K) - Method in class com.google.common.collect.ImmutableRangeMap
 
getEntry(Object) - Method in class com.google.common.collect.MapMakerInternalMap
Returns the internal entry for the specified key.
getEntry(Object, int) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
 
getEntry() - Method in class com.google.common.collect.MapMakerInternalMap.SoftValueReference
 
getEntry() - Method in class com.google.common.collect.MapMakerInternalMap.StrongValueReference
 
getEntry() - Method in interface com.google.common.collect.MapMakerInternalMap.ValueReference
Returns the entry associated with this value reference, or null if this value reference is independent of any entry.
getEntry() - Method in class com.google.common.collect.MapMakerInternalMap.WeakValueReference
 
getEntry(K) - Method in interface com.google.common.collect.RangeMap
Returns the range containing this key and its associated value, if such a range is present in the range map, or null otherwise.
getEntry(int) - Method in class com.google.common.collect.RegularImmutableMultiset
 
getEntry(int) - Method in class com.google.common.collect.RegularImmutableSortedMultiset
 
getEntry(K) - Method in class com.google.common.collect.TreeRangeMap
 
getEntry(K) - Method in class com.google.common.collect.TreeRangeMap.SubRangeMap
 
getEnumConstants(Class<T>) - Static method in class com.google.common.base.Enums
 
getEnumIfPresent(Class<T>, String) - Static method in class com.google.common.base.Platform
 
getEvent() - Method in class com.google.common.eventbus.DeadEvent
Returns the wrapped, 'dead' event, which the system was unable to deliver to any registered subscriber.
getEvent() - Method in class com.google.common.eventbus.SubscriberExceptionContext
 
getEventBus() - Method in class com.google.common.eventbus.SubscriberExceptionContext
 
getExceptionTypes() - Method in class com.google.common.reflect.Invokable
Returns all declared exception types of this Invokable.
getExitingExecutorService(ThreadPoolExecutor, long, TimeUnit) - Method in class com.google.common.util.concurrent.MoreExecutors.Application
 
getExitingExecutorService(ThreadPoolExecutor) - Method in class com.google.common.util.concurrent.MoreExecutors.Application
 
getExitingExecutorService(ThreadPoolExecutor, long, TimeUnit) - Static method in class com.google.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.google.common.util.concurrent.MoreExecutors
Converts the given ThreadPoolExecutor into an ExecutorService that exits when the application is complete.
getExitingScheduledExecutorService(ScheduledThreadPoolExecutor, long, TimeUnit) - Method in class com.google.common.util.concurrent.MoreExecutors.Application
 
getExitingScheduledExecutorService(ScheduledThreadPoolExecutor) - Method in class com.google.common.util.concurrent.MoreExecutors.Application
 
getExitingScheduledExecutorService(ScheduledThreadPoolExecutor, long, TimeUnit) - Static method in class com.google.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.google.common.util.concurrent.MoreExecutors
Converts the given ThreadPoolExecutor into a ScheduledExecutorService that exits when the application is complete.
getExpirationTime() - Method in class com.google.common.collect.MapMakerInternalMap.AbstractReferenceEntry
 
getExpirationTime() - Method in enum com.google.common.collect.MapMakerInternalMap.NullEntry
 
getExpirationTime() - Method in interface com.google.common.collect.MapMakerInternalMap.ReferenceEntry
Gets the entry expiration time in ns.
getExpirationTime() - Method in class com.google.common.collect.MapMakerInternalMap.SoftEntry
 
getExpirationTime() - Method in class com.google.common.collect.MapMakerInternalMap.SoftExpirableEntry
 
getExpirationTime() - Method in class com.google.common.collect.MapMakerInternalMap.SoftExpirableEvictableEntry
 
getExpirationTime() - Method in class com.google.common.collect.MapMakerInternalMap.StrongEntry
 
getExpirationTime() - Method in class com.google.common.collect.MapMakerInternalMap.StrongExpirableEntry
 
getExpirationTime() - Method in class com.google.common.collect.MapMakerInternalMap.StrongExpirableEvictableEntry
 
getExpirationTime() - Method in class com.google.common.collect.MapMakerInternalMap.WeakEntry
 
getExpirationTime() - Method in class com.google.common.collect.MapMakerInternalMap.WeakExpirableEntry
 
getExpirationTime() - Method in class com.google.common.collect.MapMakerInternalMap.WeakExpirableEvictableEntry
 
getExpireAfterAccessNanos() - Method in class com.google.common.cache.CacheBuilder
 
getExpireAfterAccessNanos() - Method in class com.google.common.collect.MapMaker
 
getExpireAfterWriteNanos() - Method in class com.google.common.cache.CacheBuilder
 
getExpireAfterWriteNanos() - Method in class com.google.common.collect.MapMaker
 
getFactory(LocalCache.Strength, boolean, boolean) - Static method in enum com.google.common.cache.LocalCache.EntryFactory
 
getFactory(MapMakerInternalMap.Strength, boolean, boolean) - Static method in enum com.google.common.collect.MapMakerInternalMap.EntryFactory
 
getField(Enum<?>) - Static method in class com.google.common.base.Enums
Returns the Field in which enumValue is defined.
getFieldSetter(Class<T>, String) - Static method in class com.google.common.collect.Serialization
 
getFile() - Method in class com.google.common.io.FileBackedOutputStream
Returns the file holding the data (possibly null).
getFileExtension(String) - Static method in class com.google.common.io.Files
Returns the file extension for the given file name, or the empty string if the file has no extension.
getFinalizeReferentMethod() - Method in class com.google.common.base.internal.Finalizer
Looks up FinalizableReference.finalizeReferent() method.
getFirst(int) - Method in class com.google.common.cache.LocalCache.Segment
Returns first entry of bin for given hash.
getFirst() - Method in class com.google.common.collect.ForwardingDeque
 
getFirst(Iterable<? extends T>, T) - Static method in class com.google.common.collect.Iterables
Returns the first element in iterable or defaultValue if the iterable is empty.
getFirst(int) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Returns first entry of bin for given hash.
getFirst() - Method in class com.google.common.collect.Synchronized.SynchronizedDeque
 
getFlags() - Method in class com.google.common.net.InetAddresses.TeredoInfo
 
getForwardList() - Method in class com.google.common.collect.Lists.ReverseList
 
getGenericComponentType() - Method in class com.google.common.reflect.Types.GenericArrayTypeImpl
 
getGenericDeclaration() - Method in class com.google.common.reflect.Types.TypeVariableImpl
 
getGenericExceptionTypes() - Method in class com.google.common.reflect.Invokable.ConstructorInvokable
 
getGenericExceptionTypes() - Method in class com.google.common.reflect.Invokable
This should never return a type that's not a subtype of Throwable.
getGenericExceptionTypes() - Method in class com.google.common.reflect.Invokable.MethodInvokable
 
getGenericInterfaces() - Method in class com.google.common.reflect.TypeToken
Returns the generic interfaces that this type directly implements.
getGenericParameterTypes() - Method in class com.google.common.reflect.Invokable.ConstructorInvokable
 
getGenericParameterTypes() - Method in class com.google.common.reflect.Invokable
 
getGenericParameterTypes() - Method in class com.google.common.reflect.Invokable.MethodInvokable
 
getGenericReturnType() - Method in class com.google.common.reflect.Invokable.ConstructorInvokable
If the class is parameterized, such as ArrayList, this returns ArrayList.
getGenericReturnType() - Method in class com.google.common.reflect.Invokable
 
getGenericReturnType() - Method in class com.google.common.reflect.Invokable.MethodInvokable
 
getGenericSuperclass() - Method in class com.google.common.reflect.TypeToken
Returns the generic superclass of this type or null if the type represents Object or an interface.
getGrandparentIndex(int) - Method in class com.google.common.collect.MinMaxPriorityQueue.Heap
 
getHash() - Method in class com.google.common.cache.LocalCache.AbstractReferenceEntry
 
getHash() - Method in enum com.google.common.cache.LocalCache.NullEntry
 
getHash() - Method in interface com.google.common.cache.LocalCache.ReferenceEntry
Returns the entry's hash.
getHash() - Method in class com.google.common.cache.LocalCache.StrongEntry
 
getHash() - Method in class com.google.common.cache.LocalCache.WeakEntry
 
getHash() - Method in class com.google.common.collect.MapMakerInternalMap.AbstractReferenceEntry
 
getHash() - Method in enum com.google.common.collect.MapMakerInternalMap.NullEntry
 
getHash() - Method in interface com.google.common.collect.MapMakerInternalMap.ReferenceEntry
Gets the entry's hash.
getHash() - Method in class com.google.common.collect.MapMakerInternalMap.SoftEntry
 
getHash() - Method in class com.google.common.collect.MapMakerInternalMap.StrongEntry
 
getHash() - Method in class com.google.common.collect.MapMakerInternalMap.WeakEntry
 
getHostAndPortFromBracketedHost(String) - Static method in class com.google.common.net.HostAndPort
Parses a bracketed host-port string, throwing IllegalArgumentException if parsing fails.
getHostText() - Method in class com.google.common.net.HostAndPort
Returns the portion of this HostAndPort instance that should represent the hostname or IPv4/IPv6 literal.
getIfPresent(Class<T>, String) - Static method in class com.google.common.base.Enums
Returns an optional enum constant for the given type, using Enum.valueOf(java.lang.Class<T>, java.lang.String).
getIfPresent(Object) - Method in interface com.google.common.cache.Cache
Returns the value associated with key in this cache, or null if there is no cached value for key.
getIfPresent(Object) - Method in class com.google.common.cache.ForwardingCache
 
getIfPresent(Object) - Method in class com.google.common.cache.LocalCache
 
getIfPresent(Object) - Method in class com.google.common.cache.LocalCache.LocalManualCache
 
getImmediateRawTypes() - Method in class com.google.common.reflect.TypeToken
Returns the raw type of the class or parameterized type; if T is type variable or wildcard type, the raw types of all its upper bounds are returned.
getInet4Address(byte[]) - Static method in class com.google.common.net.InetAddresses
Returns an Inet4Address, given a byte array representation of the IPv4 address.
getInheritableThreadLocalsField() - Static method in class com.google.common.base.internal.Finalizer
 
getInitialCapacity() - Method in class com.google.common.cache.CacheBuilder
 
getInitialCapacity() - Method in class com.google.common.collect.MapMaker
 
getInnerNodeCode() - Method in enum com.google.thirdparty.publicsuffix.PublicSuffixType
 
getInput() - Method in interface com.google.common.io.InputSupplier
Deprecated.
Returns an object that encapsulates a readable resource.
getInstance(Class<T>) - Method in interface com.google.common.collect.ClassToInstanceMap
Returns the value the specified class is mapped to, or null if no entry for this class is present.
getInstance(Class<T>) - Method in class com.google.common.collect.ImmutableClassToInstanceMap
 
getInstance(Class<T>) - Method in class com.google.common.collect.MutableClassToInstanceMap
 
getInstance(TypeToken<T>) - Method in class com.google.common.reflect.ImmutableTypeToInstanceMap
 
getInstance(Class<T>) - Method in class com.google.common.reflect.ImmutableTypeToInstanceMap
 
getInstance(Class<T>) - Method in class com.google.common.reflect.MutableTypeToInstanceMap
 
getInstance(TypeToken<T>) - Method in class com.google.common.reflect.MutableTypeToInstanceMap
 
getInstance(Class<T>) - Method in interface com.google.common.reflect.TypeToInstanceMap
Returns the value the specified class is mapped to, or null if no entry for this class is present.
getInstance(TypeToken<T>) - Method in interface com.google.common.reflect.TypeToInstanceMap
Returns the value the specified type is mapped to, or null if no entry for this type is present.
getInterfaces(K) - Method in class com.google.common.reflect.TypeToken.TypeCollector.ForwardingTypeCollector
 
getInterfaces(K) - Method in class com.google.common.reflect.TypeToken.TypeCollector
 
getIsatapIPv4Address(Inet6Address) - Static method in class com.google.common.net.InetAddresses
Returns the IPv4 address embedded in an ISATAP address.
getKey() - Method in class com.google.common.cache.LocalCache.AbstractReferenceEntry
 
getKey() - Method in enum com.google.common.cache.LocalCache.NullEntry
 
getKey() - Method in interface com.google.common.cache.LocalCache.ReferenceEntry
Returns the key for this entry.
getKey() - Method in class com.google.common.cache.LocalCache.StrongEntry
 
getKey() - Method in class com.google.common.cache.LocalCache.WeakEntry
 
getKey() - Method in class com.google.common.cache.LocalCache.WriteThroughEntry
 
getKey() - Method in class com.google.common.cache.RemovalNotification
 
getKey() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection
 
getKey() - Method in class com.google.common.collect.AbstractMapEntry
 
getKey(int) - Method in class com.google.common.collect.ArrayTable.ArrayMap
 
getKey(int) - Method in class com.google.common.collect.DenseImmutableTable.ImmutableArrayMap
 
getKey() - Method in class com.google.common.collect.ForwardingMapEntry
 
getKey() - Method in class com.google.common.collect.ImmutableEntry
 
getKey() - Method in class com.google.common.collect.LinkedListMultimap.Node
 
getKey() - Method in class com.google.common.collect.MapMakerInternalMap.AbstractReferenceEntry
 
getKey() - Method in enum com.google.common.collect.MapMakerInternalMap.NullEntry
 
getKey() - Method in interface com.google.common.collect.MapMakerInternalMap.ReferenceEntry
Gets the key for this entry.
getKey() - Method in class com.google.common.collect.MapMakerInternalMap.SoftEntry
 
getKey() - Method in class com.google.common.collect.MapMakerInternalMap.StrongEntry
 
getKey() - Method in class com.google.common.collect.MapMakerInternalMap.WeakEntry
 
getKey() - Method in class com.google.common.collect.MapMakerInternalMap.WriteThroughEntry
 
getKey() - Method in class com.google.common.collect.Synchronized.SynchronizedEntry
 
getKey() - Method in class com.google.common.collect.TreeRangeMap.RangeMapEntry
 
getKeyEquivalence() - Method in class com.google.common.cache.CacheBuilder
 
getKeyEquivalence() - Method in class com.google.common.collect.MapMaker
 
getKeyRole() - Method in class com.google.common.collect.ArrayTable.ArrayMap
 
getKeyRole() - Method in class com.google.common.collect.ArrayTable.Column
 
getKeyRole() - Method in class com.google.common.collect.ArrayTable.ColumnMap
 
getKeyRole() - Method in class com.google.common.collect.ArrayTable.Row
 
getKeyRole() - Method in class com.google.common.collect.ArrayTable.RowMap
 
getKeyStrength() - Method in class com.google.common.cache.CacheBuilder
 
getKeyStrength() - Method in class com.google.common.collect.MapMaker
 
getLast() - Method in class com.google.common.collect.ForwardingDeque
 
getLast(Iterable<T>) - Static method in class com.google.common.collect.Iterables
Returns the last element of iterable.
getLast(Iterable<? extends T>, T) - Static method in class com.google.common.collect.Iterables
Returns the last element of iterable or defaultValue if the iterable is empty.
getLast(Iterator<T>) - Static method in class com.google.common.collect.Iterators
Advances iterator to the end, returning the last element.
getLast(Iterator<? extends T>, T) - Static method in class com.google.common.collect.Iterators
Advances iterator to the end, returning the last element or defaultValue if the iterator is empty.
getLast() - Method in class com.google.common.collect.Synchronized.SynchronizedDeque
 
getLastInNonemptyList(List<T>) - Static method in class com.google.common.collect.Iterables
 
getLeafNodeCode() - Method in enum com.google.thirdparty.publicsuffix.PublicSuffixType
 
getLeftChildIndex(int) - Method in class com.google.common.collect.MinMaxPriorityQueue.Heap
 
getListDelegate() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedList
 
getLiveEntry(Object, int, long) - Method in class com.google.common.cache.LocalCache.Segment
 
getLiveEntry(Object, int) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
 
getLiveValue(LocalCache.ReferenceEntry<K, V>, long) - Method in class com.google.common.cache.LocalCache
Gets the value from an entry.
getLiveValue(LocalCache.ReferenceEntry<K, V>, long) - Method in class com.google.common.cache.LocalCache.Segment
Gets the value from an entry.
getLiveValue(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap
Gets the value from an entry.
getLiveValue(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Gets the value from an entry.
getLockGraphNode() - Method in interface com.google.common.util.concurrent.CycleDetectingLockFactory.CycleDetectingLock
 
getLockGraphNode() - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory.CycleDetectingReentrantLock
 
getLockGraphNode() - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory.CycleDetectingReentrantReadWriteLock
 
getLockName(Enum<?>) - Static method in class com.google.common.util.concurrent.CycleDetectingLockFactory
For the given Enum value rank, returns the value's "EnumClass.name", which is used in exception and warning output.
getLockName() - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory.LockGraphNode
 
getLowerBound() - Method in class com.google.common.collect.TreeRangeMap.RangeMapEntry
 
getLowerBounds() - Method in class com.google.common.reflect.Types.WildcardTypeImpl
 
getLowerBoundType() - Method in class com.google.common.collect.GeneralRange
 
getLowerEndpoint() - Method in class com.google.common.collect.GeneralRange
 
getMaxElementIndex() - Method in class com.google.common.collect.MinMaxPriorityQueue
Returns the index of the max element.
getMaximumWeight() - Method in class com.google.common.cache.CacheBuilder
 
getMessage() - Method in exception com.google.common.util.concurrent.CycleDetectingLockFactory.PotentialDeadlockException
Appends the chain of messages from the conflictingStackTrace to the original message.
getMessageDigest(String) - Static method in class com.google.common.hash.MessageDigestHashFunction
 
getMethod() - Method in class com.google.common.eventbus.EventSubscriber
 
getModifiers() - Method in class com.google.common.reflect.Element
 
getName() - Method in class com.google.common.reflect.ClassPath.ClassInfo
Returns the fully qualified name of the class.
getName() - Method in class com.google.common.reflect.Element
 
getName() - Method in class com.google.common.reflect.Types.TypeVariableImpl
 
getNameWithoutExtension(String) - Static method in class com.google.common.io.Files
Returns the file name without its file extension or path.
getNext() - Method in class com.google.common.cache.LocalCache.AbstractReferenceEntry
 
getNext() - Method in enum com.google.common.cache.LocalCache.NullEntry
 
getNext() - Method in interface com.google.common.cache.LocalCache.ReferenceEntry
Returns the next entry in the chain.
getNext() - Method in class com.google.common.cache.LocalCache.StrongEntry
 
getNext() - Method in class com.google.common.cache.LocalCache.WeakEntry
 
getNext(Iterator<? extends T>, T) - Static method in class com.google.common.collect.Iterators
Returns the next element in iterator or defaultValue if the iterator is empty.
getNext() - Method in class com.google.common.collect.MapMakerInternalMap.AbstractReferenceEntry
 
getNext() - Method in enum com.google.common.collect.MapMakerInternalMap.NullEntry
 
getNext() - Method in interface com.google.common.collect.MapMakerInternalMap.ReferenceEntry
Gets the next entry in the chain.
getNext() - Method in class com.google.common.collect.MapMakerInternalMap.SoftEntry
 
getNext() - Method in class com.google.common.collect.MapMakerInternalMap.StrongEntry
 
getNext() - Method in class com.google.common.collect.MapMakerInternalMap.WeakEntry
 
getNextEvictable() - Method in class com.google.common.cache.LocalCache.Segment
 
getNextEvictable() - Method in class com.google.common.collect.MapMakerInternalMap.AbstractReferenceEntry
 
getNextEvictable() - Method in enum com.google.common.collect.MapMakerInternalMap.NullEntry
 
getNextEvictable() - Method in interface com.google.common.collect.MapMakerInternalMap.ReferenceEntry
Gets the next entry in the recency list.
getNextEvictable() - Method in class com.google.common.collect.MapMakerInternalMap.SoftEntry
 
getNextEvictable() - Method in class com.google.common.collect.MapMakerInternalMap.SoftEvictableEntry
 
getNextEvictable() - Method in class com.google.common.collect.MapMakerInternalMap.SoftExpirableEvictableEntry
 
getNextEvictable() - Method in class com.google.common.collect.MapMakerInternalMap.StrongEntry
 
getNextEvictable() - Method in class com.google.common.collect.MapMakerInternalMap.StrongEvictableEntry
 
getNextEvictable() - Method in class com.google.common.collect.MapMakerInternalMap.StrongExpirableEvictableEntry
 
getNextEvictable() - Method in class com.google.common.collect.MapMakerInternalMap.WeakEntry
 
getNextEvictable() - Method in class com.google.common.collect.MapMakerInternalMap.WeakEvictableEntry
 
getNextEvictable() - Method in class com.google.common.collect.MapMakerInternalMap.WeakExpirableEvictableEntry
 
getNextExpirable() - Method in class com.google.common.collect.MapMakerInternalMap.AbstractReferenceEntry
 
getNextExpirable() - Method in enum com.google.common.collect.MapMakerInternalMap.NullEntry
 
getNextExpirable() - Method in interface com.google.common.collect.MapMakerInternalMap.ReferenceEntry
Gets the next entry in the recency list.
getNextExpirable() - Method in class com.google.common.collect.MapMakerInternalMap.SoftEntry
 
getNextExpirable() - Method in class com.google.common.collect.MapMakerInternalMap.SoftExpirableEntry
 
getNextExpirable() - Method in class com.google.common.collect.MapMakerInternalMap.SoftExpirableEvictableEntry
 
getNextExpirable() - Method in class com.google.common.collect.MapMakerInternalMap.StrongEntry
 
getNextExpirable() - Method in class com.google.common.collect.MapMakerInternalMap.StrongExpirableEntry
 
getNextExpirable() - Method in class com.google.common.collect.MapMakerInternalMap.StrongExpirableEvictableEntry
 
getNextExpirable() - Method in class com.google.common.collect.MapMakerInternalMap.WeakEntry
 
getNextExpirable() - Method in class com.google.common.collect.MapMakerInternalMap.WeakExpirableEntry
 
getNextExpirable() - Method in class com.google.common.collect.MapMakerInternalMap.WeakExpirableEvictableEntry
 
getNextInAccessQueue() - Method in class com.google.common.cache.LocalCache.AbstractReferenceEntry
 
getNextInAccessQueue() - Method in enum com.google.common.cache.LocalCache.NullEntry
 
getNextInAccessQueue() - Method in interface com.google.common.cache.LocalCache.ReferenceEntry
Returns the next entry in the access queue.
getNextInAccessQueue() - Method in class com.google.common.cache.LocalCache.StrongAccessEntry
 
getNextInAccessQueue() - Method in class com.google.common.cache.LocalCache.StrongAccessWriteEntry
 
getNextInAccessQueue() - Method in class com.google.common.cache.LocalCache.WeakAccessEntry
 
getNextInAccessQueue() - Method in class com.google.common.cache.LocalCache.WeakAccessWriteEntry
 
getNextInAccessQueue() - Method in class com.google.common.cache.LocalCache.WeakEntry
 
getNextInKeyBucket() - Method in class com.google.common.collect.ImmutableMapEntry
 
getNextInKeyBucket() - Method in class com.google.common.collect.ImmutableMapEntry.TerminalEntry
 
getNextInKeyBucket() - Method in class com.google.common.collect.RegularImmutableBiMap.NonTerminalBiMapEntry
 
getNextInKeyBucket() - Method in class com.google.common.collect.RegularImmutableMap.NonTerminalMapEntry
 
getNextInValueBucket() - Method in class com.google.common.collect.ImmutableMapEntry
 
getNextInValueBucket() - Method in class com.google.common.collect.ImmutableMapEntry.TerminalEntry
 
getNextInValueBucket() - Method in class com.google.common.collect.RegularImmutableBiMap.NonTerminalBiMapEntry
 
getNextInValueBucket() - Method in class com.google.common.collect.RegularImmutableMap.NonTerminalMapEntry
 
getNextInWriteQueue() - Method in class com.google.common.cache.LocalCache.AbstractReferenceEntry
 
getNextInWriteQueue() - Method in enum com.google.common.cache.LocalCache.NullEntry
 
getNextInWriteQueue() - Method in interface com.google.common.cache.LocalCache.ReferenceEntry
Returns the next entry in the write queue.
getNextInWriteQueue() - Method in class com.google.common.cache.LocalCache.StrongAccessWriteEntry
 
getNextInWriteQueue() - Method in class com.google.common.cache.LocalCache.StrongWriteEntry
 
getNextInWriteQueue() - Method in class com.google.common.cache.LocalCache.WeakAccessWriteEntry
 
getNextInWriteQueue() - Method in class com.google.common.cache.LocalCache.WeakEntry
 
getNextInWriteQueue() - Method in class com.google.common.cache.LocalCache.WeakWriteEntry
 
getNextSchedule() - Method in class com.google.common.util.concurrent.AbstractScheduledService.CustomScheduler
Calculates the time at which to next invoke the task.
getOccupiedDepth() - Method in class com.google.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.
getOldValue() - Method in class com.google.common.cache.LocalCache.LoadingValueReference
 
getOnlyElement(Iterable<T>) - Static method in class com.google.common.collect.Iterables
Returns the single element contained in iterable.
getOnlyElement(Iterable<? extends T>, T) - Static method in class com.google.common.collect.Iterables
Returns the single element contained in iterable, or defaultValue if the iterable is empty.
getOnlyElement(Iterator<T>) - Static method in class com.google.common.collect.Iterators
Returns the single element contained in iterator.
getOnlyElement(Iterator<? extends T>, T) - Static method in class com.google.common.collect.Iterators
Returns the single element contained in iterator, or defaultValue if the iterator is empty.
getOrCompute(K, int, Function<? super K, ? extends V>) - Method in class com.google.common.collect.ComputingConcurrentHashMap.ComputingSegment
 
getOrCompute(K) - Method in class com.google.common.collect.ComputingConcurrentHashMap
 
getOrCreate(R) - Method in class com.google.common.collect.StandardTable
 
getOrCreateCollection(K) - Method in class com.google.common.collect.AbstractMapBasedMultimap
 
getOrCreateNodes(Class<? extends Enum>) - Static method in class com.google.common.util.concurrent.CycleDetectingLockFactory
 
getOrLoad(K) - Method in class com.google.common.cache.LocalCache
 
getOutput() - Method in interface com.google.common.io.OutputSupplier
Deprecated.
Returns an object that encapsulates a writable resource.
getOwnerType() - Method in class com.google.common.reflect.Element
 
getOwnerType() - Method in class com.google.common.reflect.Invokable
Returns the type of T.
getOwnerType(Class<?>) - Method in enum com.google.common.reflect.Types.ClassOwnership
 
getOwnerType() - Method in class com.google.common.reflect.Types.ParameterizedTypeImpl
 
getPackageName() - Method in class com.google.common.reflect.ClassPath.ClassInfo
Returns the package name of the class, without attempting to load the class.
getPackageName(Class<?>) - Static method in class com.google.common.reflect.Reflection
Returns the package name of clazz according to the Java Language Specification (section 6.7).
getPackageName(String) - Static method in class com.google.common.reflect.Reflection
Returns the package name of classFullName according to the Java Language Specification (section 6.7).
getParameterAnnotations() - Method in class com.google.common.reflect.Invokable.ConstructorInvokable
 
getParameterAnnotations() - Method in class com.google.common.reflect.Invokable
 
getParameterAnnotations() - Method in class com.google.common.reflect.Invokable.MethodInvokable
 
getParameters() - Method in class com.google.common.reflect.Invokable
Returns all declared parameters of this Invokable.
getParentIndex(int) - Method in class com.google.common.collect.MinMaxPriorityQueue.Heap
 
getPort() - Method in class com.google.common.net.HostAndPort
Get the current port number, failing if no port is defined.
getPort() - Method in class com.google.common.net.InetAddresses.TeredoInfo
 
getPortOrDefault(int) - Method in class com.google.common.net.HostAndPort
Returns the current port number, with a default if no port is defined.
getPredecessorInMultimap() - Method in class com.google.common.collect.LinkedHashMultimap.ValueEntry
 
getPredecessorInValueSet() - Method in class com.google.common.collect.LinkedHashMultimap.ValueEntry
 
getPredecessorInValueSet() - Method in class com.google.common.collect.LinkedHashMultimap.ValueSet
 
getPredecessorInValueSet() - Method in interface com.google.common.collect.LinkedHashMultimap.ValueSetLink
 
getPreviousEvictable() - Method in class com.google.common.collect.MapMakerInternalMap.AbstractReferenceEntry
 
getPreviousEvictable() - Method in enum com.google.common.collect.MapMakerInternalMap.NullEntry
 
getPreviousEvictable() - Method in interface com.google.common.collect.MapMakerInternalMap.ReferenceEntry
Gets the previous entry in the recency list.
getPreviousEvictable() - Method in class com.google.common.collect.MapMakerInternalMap.SoftEntry
 
getPreviousEvictable() - Method in class com.google.common.collect.MapMakerInternalMap.SoftEvictableEntry
 
getPreviousEvictable() - Method in class com.google.common.collect.MapMakerInternalMap.SoftExpirableEvictableEntry
 
getPreviousEvictable() - Method in class com.google.common.collect.MapMakerInternalMap.StrongEntry
 
getPreviousEvictable() - Method in class com.google.common.collect.MapMakerInternalMap.StrongEvictableEntry
 
getPreviousEvictable() - Method in class com.google.common.collect.MapMakerInternalMap.StrongExpirableEvictableEntry
 
getPreviousEvictable() - Method in class com.google.common.collect.MapMakerInternalMap.WeakEntry
 
getPreviousEvictable() - Method in class com.google.common.collect.MapMakerInternalMap.WeakEvictableEntry
 
getPreviousEvictable() - Method in class com.google.common.collect.MapMakerInternalMap.WeakExpirableEvictableEntry
 
getPreviousExpirable() - Method in class com.google.common.collect.MapMakerInternalMap.AbstractReferenceEntry
 
getPreviousExpirable() - Method in enum com.google.common.collect.MapMakerInternalMap.NullEntry
 
getPreviousExpirable() - Method in interface com.google.common.collect.MapMakerInternalMap.ReferenceEntry
Gets the previous entry in the recency list.
getPreviousExpirable() - Method in class com.google.common.collect.MapMakerInternalMap.SoftEntry
 
getPreviousExpirable() - Method in class com.google.common.collect.MapMakerInternalMap.SoftExpirableEntry
 
getPreviousExpirable() - Method in class com.google.common.collect.MapMakerInternalMap.SoftExpirableEvictableEntry
 
getPreviousExpirable() - Method in class com.google.common.collect.MapMakerInternalMap.StrongEntry
 
getPreviousExpirable() - Method in class com.google.common.collect.MapMakerInternalMap.StrongExpirableEntry
 
getPreviousExpirable() - Method in class com.google.common.collect.MapMakerInternalMap.StrongExpirableEvictableEntry
 
getPreviousExpirable() - Method in class com.google.common.collect.MapMakerInternalMap.WeakEntry
 
getPreviousExpirable() - Method in class com.google.common.collect.MapMakerInternalMap.WeakExpirableEntry
 
getPreviousExpirable() - Method in class com.google.common.collect.MapMakerInternalMap.WeakExpirableEvictableEntry
 
getPreviousInAccessQueue() - Method in class com.google.common.cache.LocalCache.AbstractReferenceEntry
 
getPreviousInAccessQueue() - Method in enum com.google.common.cache.LocalCache.NullEntry
 
getPreviousInAccessQueue() - Method in interface com.google.common.cache.LocalCache.ReferenceEntry
Returns the previous entry in the access queue.
getPreviousInAccessQueue() - Method in class com.google.common.cache.LocalCache.StrongAccessEntry
 
getPreviousInAccessQueue() - Method in class com.google.common.cache.LocalCache.StrongAccessWriteEntry
 
getPreviousInAccessQueue() - Method in class com.google.common.cache.LocalCache.WeakAccessEntry
 
getPreviousInAccessQueue() - Method in class com.google.common.cache.LocalCache.WeakAccessWriteEntry
 
getPreviousInAccessQueue() - Method in class com.google.common.cache.LocalCache.WeakEntry
 
getPreviousInWriteQueue() - Method in class com.google.common.cache.LocalCache.AbstractReferenceEntry
 
getPreviousInWriteQueue() - Method in enum com.google.common.cache.LocalCache.NullEntry
 
getPreviousInWriteQueue() - Method in interface com.google.common.cache.LocalCache.ReferenceEntry
Returns the previous entry in the write queue.
getPreviousInWriteQueue() - Method in class com.google.common.cache.LocalCache.StrongAccessWriteEntry
 
getPreviousInWriteQueue() - Method in class com.google.common.cache.LocalCache.StrongWriteEntry
 
getPreviousInWriteQueue() - Method in class com.google.common.cache.LocalCache.WeakAccessWriteEntry
 
getPreviousInWriteQueue() - Method in class com.google.common.cache.LocalCache.WeakEntry
 
getPreviousInWriteQueue() - Method in class com.google.common.cache.LocalCache.WeakWriteEntry
 
getQueueLength() - Method in class com.google.common.util.concurrent.Monitor
Returns an estimate of the number of threads waiting to enter this monitor.
getRate() - Method in class com.google.common.util.concurrent.RateLimiter
Returns the stable rate (as permits per seconds) with which this RateLimiter is configured with.
getRawType() - Method in class com.google.common.reflect.Types.ParameterizedTypeImpl
 
getRawType() - Method in class com.google.common.reflect.TypeToken
Returns the raw type of T.
getRawType(Type) - Static method in class com.google.common.reflect.TypeToken
 
getRawType(K) - Method in class com.google.common.reflect.TypeToken.TypeCollector.ForwardingTypeCollector
 
getRawType(K) - Method in class com.google.common.reflect.TypeToken.TypeCollector
 
getRawTypes(Type) - Static method in class com.google.common.reflect.TypeToken
 
getRefreshNanos() - Method in class com.google.common.cache.CacheBuilder
 
getRemovalListener() - Method in class com.google.common.cache.CacheBuilder
 
getRemovalListener() - Method in class com.google.common.collect.GenericMapMaker
Deprecated.
 
getReplacementArray() - Method in class com.google.common.escape.ArrayBasedEscaperMap
 
getResource(String) - Static method in class com.google.common.io.Resources
Returns a URL pointing to resourceName if the resource is found using the context class loader.
getResource(Class<?>, String) - Static method in class com.google.common.io.Resources
Given a resourceName that is relative to contextClass, returns a URL pointing to the named resource.
getResourceName() - Method in class com.google.common.reflect.ClassPath.ResourceInfo
Returns the fully qualified name of the resource.
getResources() - Method in class com.google.common.reflect.ClassPath
Returns all resources loadable from the current class path, including the class files of all loadable classes but excluding the "META-INF/MANIFEST.MF" file.
getResources() - Method in class com.google.common.reflect.ClassPath.Scanner
 
getResult() - Method in interface com.google.common.io.ByteProcessor
Return the result of processing all the bytes.
getResult() - Method in interface com.google.common.io.LineProcessor
Return the result of processing all the lines.
getReturnType() - Method in class com.google.common.reflect.Invokable
Returns the return type of this Invokable.
getRightChildIndex(int) - Method in class com.google.common.collect.MinMaxPriorityQueue.Heap
 
getRootCause(Throwable) - Static method in class com.google.common.base.Throwables
Returns the innermost cause of throwable.
getRowKey() - Method in interface com.google.common.collect.Table.Cell
Returns the row key of this cell.
getRowKey() - Method in class com.google.common.collect.Tables.ImmutableCell
 
getServer() - Method in class com.google.common.net.InetAddresses.TeredoInfo
 
getSignificand(double) - Static method in class com.google.common.math.DoubleUtils
 
getSimpleName() - Method in class com.google.common.reflect.ClassPath.ClassInfo
Returns the simple name of the underlying class as given in the source code.
getSortedSetDelegate() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedNavigableSet
 
getSortedSetDelegate() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedSortedSet
 
getSource() - Method in class com.google.common.eventbus.DeadEvent
Returns the object that originated this event (not the object that originated the wrapped event).
getStackTraceAsString(Throwable) - Static method in class com.google.common.base.Throwables
Returns a string containing the result of toString(), followed by the full, recursive stack trace of throwable.
getStartFinalizer(Class<?>) - Static method in class com.google.common.base.FinalizableReferenceQueue
Looks up Finalizer.startFinalizer().
getStatsCounterSupplier() - Method in class com.google.common.cache.CacheBuilder
 
getSubMap(int, int) - Method in class com.google.common.collect.RegularImmutableSortedMap
 
getSubMultiset(int, int) - Method in class com.google.common.collect.RegularImmutableSortedMultiset
 
getSubscriber() - Method in class com.google.common.eventbus.EventSubscriber
 
getSubscriber() - Method in class com.google.common.eventbus.SubscriberExceptionContext
 
getSubscriberMethod() - Method in class com.google.common.eventbus.SubscriberExceptionContext
 
getSubSet(int, int) - Method in class com.google.common.collect.RegularImmutableSortedSet
 
getSubtype(Class<?>) - Method in class com.google.common.reflect.TypeToken
Returns subtype of this with subclass as the raw class.
getSubtypeFromLowerBounds(Class<?>, Type[]) - Method in class com.google.common.reflect.TypeToken
 
getSuccessorInMultimap() - Method in class com.google.common.collect.LinkedHashMultimap.ValueEntry
 
getSuccessorInValueSet() - Method in class com.google.common.collect.LinkedHashMultimap.ValueEntry
 
getSuccessorInValueSet() - Method in class com.google.common.collect.LinkedHashMultimap.ValueSet
 
getSuccessorInValueSet() - Method in interface com.google.common.collect.LinkedHashMultimap.ValueSetLink
 
getSuperclass(K) - Method in class com.google.common.reflect.TypeToken.TypeCollector.ForwardingTypeCollector
 
getSuperclass(K) - Method in class com.google.common.reflect.TypeToken.TypeCollector
 
getSupertype(Class<? super T>) - Method in class com.google.common.reflect.TypeToken
Returns the generic form of superclass.
getSupertypeFromUpperBounds(Class<? super T>, Type[]) - Method in class com.google.common.reflect.TypeToken
 
getTeredoInfo(Inet6Address) - Static method in class com.google.common.net.InetAddresses
Returns the Teredo information embedded in a Teredo address.
getTicker(boolean) - Method in class com.google.common.cache.CacheBuilder
 
getTicker() - Method in class com.google.common.collect.MapMaker
 
getTopLevelClasses() - Method in class com.google.common.reflect.ClassPath
Returns all top level classes loadable from the current class path.
getTopLevelClasses(String) - Method in class com.google.common.reflect.ClassPath
Returns all top level classes whose package name is packageName.
getTopLevelClassesRecursive(String) - Method in class com.google.common.reflect.ClassPath
Returns all top level classes whose package name is packageName or starts with packageName followed by a '.'.
getType() - Method in class com.google.common.reflect.Parameter
Returns the type of the parameter.
getType() - Method in class com.google.common.reflect.TypeToken
Returns the represented type.
getTypeMappings(Type) - Static method in class com.google.common.reflect.TypeResolver.TypeMappingIntrospector
Returns type mappings using type parameters and type arguments found in the generic superclass and the super interfaces of contextClass.
getTypeParameters() - Method in class com.google.common.reflect.Invokable.ConstructorInvokable
[<E>] will be returned for ArrayList's constructor.
getTypeParameters() - Method in class com.google.common.reflect.Invokable.MethodInvokable
 
getTypes() - Method in class com.google.common.reflect.TypeToken
Returns the set of interfaces and classes that this type is or is a subtype of.
getUnchecked(K) - Method in class com.google.common.cache.AbstractLoadingCache
 
getUnchecked(K) - Method in class com.google.common.cache.ForwardingLoadingCache
 
getUnchecked(K) - Method in interface com.google.common.cache.LoadingCache
Returns the value associated with key in this cache, first loading that value if necessary.
getUnchecked(K) - Method in class com.google.common.cache.LocalCache.LoadingSerializationProxy
 
getUnchecked(K) - Method in class com.google.common.cache.LocalCache.LocalLoadingCache
 
getUnchecked(Future<V>) - Static method in class com.google.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.google.common.util.concurrent.Uninterruptibles
Invokes future.get() uninterruptibly.
getUninterruptibly(Future<V>, long, TimeUnit) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes future.get(timeout, unit) uninterruptibly.
getUnsafe() - Static method in class com.google.common.cache.Striped64
Returns a sun.misc.Unsafe.
getUnsafe() - Static method in enum com.google.common.primitives.UnsignedBytes.LexicographicalComparatorHolder.UnsafeComparator
Returns a sun.misc.Unsafe.
getUpperBound() - Method in class com.google.common.collect.TreeRangeMap.RangeMapEntry
 
getUpperBounds() - Method in class com.google.common.reflect.Types.WildcardTypeImpl
 
getUpperBoundType() - Method in class com.google.common.collect.GeneralRange
 
getUpperEndpoint() - Method in class com.google.common.collect.GeneralRange
 
getValue() - Method in class com.google.common.cache.LocalCache.WriteThroughEntry
 
getValue() - Method in class com.google.common.cache.RemovalNotification
 
getValue() - Method in class com.google.common.collect.AbstractMapEntry
 
getValue(int) - Method in class com.google.common.collect.ArrayTable.ArrayMap
 
getValue(int) - Method in class com.google.common.collect.ArrayTable.Column
 
getValue(int) - Method in class com.google.common.collect.ArrayTable.ColumnMap
 
getValue(int) - Method in class com.google.common.collect.ArrayTable.Row
 
getValue(int) - Method in class com.google.common.collect.ArrayTable.RowMap
 
getValue(int) - Method in class com.google.common.collect.DenseImmutableTable.Column
 
getValue(int) - Method in class com.google.common.collect.DenseImmutableTable.ColumnMap
 
getValue(int) - Method in class com.google.common.collect.DenseImmutableTable
 
getValue(int) - Method in class com.google.common.collect.DenseImmutableTable.ImmutableArrayMap
 
getValue(int) - Method in class com.google.common.collect.DenseImmutableTable.Row
 
getValue(int) - Method in class com.google.common.collect.DenseImmutableTable.RowMap
 
getValue() - Method in class com.google.common.collect.ForwardingMapEntry
 
getValue() - Method in class com.google.common.collect.ImmutableEntry
 
getValue() - Method in class com.google.common.collect.LinkedListMultimap.Node
 
getValue() - Method in class com.google.common.collect.MapMakerInternalMap.WriteThroughEntry
 
getValue(int) - Method in class com.google.common.collect.RegularImmutableTable
 
getValue(int) - Method in class com.google.common.collect.SparseImmutableTable
 
getValue() - Method in class com.google.common.collect.Synchronized.SynchronizedEntry
 
getValue() - Method in interface com.google.common.collect.Table.Cell
Returns the value of this cell.
getValue() - Method in class com.google.common.collect.Tables.ImmutableCell
 
getValue() - Method in class com.google.common.collect.TreeRangeMap.RangeMapEntry
 
getValue() - Method in class com.google.common.util.concurrent.AbstractFuture.Sync
Implementation of the actual value retrieval.
getValueEquivalence() - Method in class com.google.common.cache.CacheBuilder
 
getValueReference() - Method in class com.google.common.cache.LocalCache.AbstractReferenceEntry
 
getValueReference() - Method in enum com.google.common.cache.LocalCache.NullEntry
 
getValueReference() - Method in interface com.google.common.cache.LocalCache.ReferenceEntry
Returns the value reference from this entry.
getValueReference() - Method in class com.google.common.cache.LocalCache.StrongEntry
 
getValueReference() - Method in class com.google.common.cache.LocalCache.WeakEntry
 
getValueReference() - Method in class com.google.common.collect.MapMakerInternalMap.AbstractReferenceEntry
 
getValueReference() - Method in enum com.google.common.collect.MapMakerInternalMap.NullEntry
 
getValueReference() - Method in interface com.google.common.collect.MapMakerInternalMap.ReferenceEntry
Gets the value reference from this entry.
getValueReference() - Method in class com.google.common.collect.MapMakerInternalMap.SoftEntry
 
getValueReference() - Method in class com.google.common.collect.MapMakerInternalMap.StrongEntry
 
getValueReference() - Method in class com.google.common.collect.MapMakerInternalMap.WeakEntry
 
getValueStrength() - Method in class com.google.common.cache.CacheBuilder
 
getValueStrength() - Method in class com.google.common.collect.MapMaker
 
getWaitQueueLength(Monitor.Guard) - Method in class com.google.common.util.concurrent.Monitor
Returns an estimate of the number of threads waiting for the given guard to become satisfied.
getWeigher() - Method in class com.google.common.cache.CacheBuilder
 
getWeight() - Method in class com.google.common.cache.LocalCache.LoadingValueReference
 
getWeight() - Method in class com.google.common.cache.LocalCache.SoftValueReference
 
getWeight() - Method in class com.google.common.cache.LocalCache.StrongValueReference
 
getWeight() - Method in interface com.google.common.cache.LocalCache.ValueReference
Returns the weight of this entry.
getWeight() - Method in class com.google.common.cache.LocalCache.WeakValueReference
 
getWeight() - Method in class com.google.common.cache.LocalCache.WeightedSoftValueReference
 
getWeight() - Method in class com.google.common.cache.LocalCache.WeightedStrongValueReference
 
getWeight() - Method in class com.google.common.cache.LocalCache.WeightedWeakValueReference
 
getWriteTime() - Method in class com.google.common.cache.LocalCache.AbstractReferenceEntry
 
getWriteTime() - Method in enum com.google.common.cache.LocalCache.NullEntry
 
getWriteTime() - Method in interface com.google.common.cache.LocalCache.ReferenceEntry
Returns the time that this entry was last written, in ns.
getWriteTime() - Method in class com.google.common.cache.LocalCache.StrongAccessWriteEntry
 
getWriteTime() - Method in class com.google.common.cache.LocalCache.StrongWriteEntry
 
getWriteTime() - Method in class com.google.common.cache.LocalCache.WeakAccessWriteEntry
 
getWriteTime() - Method in class com.google.common.cache.LocalCache.WeakEntry
 
getWriteTime() - Method in class com.google.common.cache.LocalCache.WeakWriteEntry
 
GIF - Static variable in class com.google.common.net.MediaType
 
globalStatsCounter - Variable in class com.google.common.cache.LocalCache
Accumulates global cache statistics.
GOOD_FAST_HASH_FUNCTION_128 - Static variable in class com.google.common.hash.Hashing.Murmur3_128Holder
Returned by Hashing.goodFastHash(int) when 32 < minimumBits <= 128.
GOOD_FAST_HASH_FUNCTION_32 - Static variable in class com.google.common.hash.Hashing.Murmur3_32Holder
Returned by Hashing.goodFastHash(int) when minimumBits <= 32.
GOOD_FAST_HASH_SEED - Static variable in class com.google.common.hash.Hashing
Used to randomize Hashing.goodFastHash(int) instances, so that programs which persist anything dependent on the hash codes they produce will fail sooner.
goodFastHash(int) - Static method in class com.google.common.hash.Hashing
Returns a general-purpose, temporary-use, non-cryptographic hash function.
GREATER - Static variable in class com.google.common.collect.ComparisonChain
 
greaterThan(C) - Static method in class com.google.common.collect.Range
Returns a range that contains all values strictly greater than endpoint.
greatestOf(Iterable<E>, int) - Method in class com.google.common.collect.Ordering
Returns the k greatest elements of the given iterable according to this ordering, in order from greatest to least.
greatestOf(Iterator<E>, int) - Method in class com.google.common.collect.Ordering
Returns the k greatest elements from the given iterator according to this ordering, in order from greatest to least.
greatestValueBelow(DiscreteDomain<Comparable<?>>) - Method in class com.google.common.collect.Cut.AboveAll
 
greatestValueBelow(DiscreteDomain<C>) - Method in class com.google.common.collect.Cut.AboveValue
 
greatestValueBelow(DiscreteDomain<Comparable<?>>) - Method in class com.google.common.collect.Cut.BelowAll
 
greatestValueBelow(DiscreteDomain<C>) - Method in class com.google.common.collect.Cut.BelowValue
 
greatestValueBelow(DiscreteDomain<C>) - Method in class com.google.common.collect.Cut
 
growBuffer(char[], int, int) - Static method in class com.google.common.escape.CharEscaper
Helper method to grow the character buffer as needed, this only happens once in a while so it's ok if it's in a method call.
growBuffer(char[], int, int) - Static method in class com.google.common.escape.UnicodeEscaper
Helper method to grow the character buffer as needed, this only happens once in a while so it's ok if it's in a method call.
growIfNeeded() - Method in class com.google.common.collect.MinMaxPriorityQueue
 
GS - Static variable in class com.google.common.base.Ascii
Group Separator: These four information separators may be used within data in optional fashion, except that their hierarchical relationship shall be: FS is the most inclusive, then GS, then RS, and US is least inclusive.
Guard(Monitor) - Constructor for class com.google.common.util.concurrent.Monitor.Guard
 
GwtCompatible - Annotation Type in com.google.common.annotations
The presence of this annotation on a type indicates that the type may be used with the Google Web Toolkit (GWT).
GwtIncompatible - Annotation Type in com.google.common.annotations
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.
GwtTransient - Annotation Type in com.google.common.collect
Private replacement for com.google.gwt.user.client.rpc.GwtTransient to work around build-system quirks.
GwtWorkarounds - Class in com.google.common.io
Provides simple GWT-compatible substitutes for InputStream, OutputStream, Reader, and Writer so that BaseEncoding can use streaming implementations while remaining GWT-compatible.
GwtWorkarounds() - Constructor for class com.google.common.io.GwtWorkarounds
 
GwtWorkarounds.ByteInput - Interface in com.google.common.io
A GWT-compatible substitute for an InputStream.
GwtWorkarounds.ByteOutput - Interface in com.google.common.io
A GWT-compatible substitute for an OutputStream.
GwtWorkarounds.CharInput - Interface in com.google.common.io
A GWT-compatible substitute for a Reader.
GwtWorkarounds.CharOutput - Interface in com.google.common.io
A GWT-compatible substitute for a Writer.
GZIP - Static variable in class com.google.common.net.MediaType
 

H

h1 - Variable in class com.google.common.hash.Murmur3_128HashFunction.Murmur3_128Hasher
 
h1 - Variable in class com.google.common.hash.Murmur3_32HashFunction.Murmur3_32Hasher
 
h2 - Variable in class com.google.common.hash.Murmur3_128HashFunction.Murmur3_128Hasher
 
halfPermits - Variable in class com.google.common.util.concurrent.SmoothRateLimiter.SmoothWarmingUp
 
halfPowersOf10 - Static variable in class com.google.common.math.IntMath
 
halfPowersOf10 - Static variable in class com.google.common.math.LongMath
 
handleEvent(Object) - Method in class com.google.common.eventbus.EventSubscriber
Invokes the wrapped subscriber method to handle event.
handleEvent(Object) - Method in class com.google.common.eventbus.SynchronizedEventSubscriber
 
handleException(Throwable, SubscriberExceptionContext) - Method in class com.google.common.eventbus.EventBus.LoggingSubscriberExceptionHandler
 
handleException(Throwable, SubscriberExceptionContext) - Method in interface com.google.common.eventbus.SubscriberExceptionHandler
Handles exceptions thrown by subscribers.
handleInvocation(Object, Method, Object[]) - Method in class com.google.common.reflect.AbstractInvocationHandler
AbstractInvocationHandler.invoke(java.lang.Object, java.lang.reflect.Method, java.lang.Object[]) delegates to this method upon any method invocation on the proxy instance, except Object.equals(java.lang.Object), Object.hashCode() and Object.toString().
handleLine(String, String) - Method in class com.google.common.io.LineBuffer
Called for each line found in the character data passed to LineBuffer.add(char[], int, int).
handleNullAutomatically - Variable in class com.google.common.base.Converter
 
handlePotentialDeadlock(CycleDetectingLockFactory.PotentialDeadlockException) - Method in interface com.google.common.util.concurrent.CycleDetectingLockFactory.Policy
Called when a potential deadlock is encountered.
hasBracketlessColons - Variable in class com.google.common.net.HostAndPort
True if the parsed host has colons, but no surrounding brackets.
hasEmbeddedIPv4ClientAddress(Inet6Address) - Static method in class com.google.common.net.InetAddresses
Examines the Inet6Address to determine if it is an IPv6 address of one of the specified address types that contain an embedded IPv4 address.
hasExpanded - Variable in class com.google.common.collect.BinaryTreeTraverser.PostOrderIterator
 
hasExpandedLeft - Variable in class com.google.common.collect.BinaryTreeTraverser.InOrderIterator
 
hash(T) - Method in class com.google.common.base.Equivalence
Returns a hash code for t.
hash(Object) - Method in class com.google.common.cache.LocalCache
 
hash - Variable in class com.google.common.cache.LocalCache.StrongEntry
 
hash - Variable in class com.google.common.cache.LocalCache.WeakEntry
 
hash(Object) - Static method in class com.google.common.collect.HashBiMap
 
hash(Object) - Method in class com.google.common.collect.MapMakerInternalMap
 
hash - Variable in class com.google.common.collect.MapMakerInternalMap.SoftEntry
 
hash - Variable in class com.google.common.collect.MapMakerInternalMap.StrongEntry
 
hash - Variable in class com.google.common.collect.MapMakerInternalMap.WeakEntry
 
hash() - Method in class com.google.common.hash.AbstractNonStreamingHashFunction.BufferingHasher
 
hash() - Method in class com.google.common.hash.AbstractStreamingHashFunction.AbstractStreamingHasher
 
hash() - Method in class com.google.common.hash.ChecksumHashFunction.ChecksumHasher
 
hash() - Method in class com.google.common.hash.Crc32cHashFunction.Crc32cHasher
 
hash - Variable in class com.google.common.hash.HashCode.IntHashCode
 
hash - Variable in class com.google.common.hash.HashCode.LongHashCode
 
hash() - Method in interface com.google.common.hash.Hasher
Computes a hash code based on the data that have been provided to this hasher.
hash() - Method in class com.google.common.hash.HashingInputStream
Returns the HashCode based on the data read from this stream.
hash() - Method in class com.google.common.hash.HashingOutputStream
Returns the HashCode based on the data written to this stream.
hash() - Method in class com.google.common.hash.MessageDigestHashFunction.MessageDigestHasher
 
hash(HashFunction) - Method in class com.google.common.io.ByteSource.ByteArrayByteSource
 
hash(HashFunction) - Method in class com.google.common.io.ByteSource
Hashes the contents of this byte source using the given hash function.
hash(File, HashFunction) - Static method in class com.google.common.io.Files
Computes the hash code of the file using hashFunction.
HashBasedTable<R,C,V> - Class in com.google.common.collect
Implementation of Table using hash tables.
HashBasedTable(Map<R, Map<C, V>>, HashBasedTable.Factory<C, V>) - Constructor for class com.google.common.collect.HashBasedTable
 
HashBasedTable.Factory<C,V> - Class in com.google.common.collect
 
HashBiMap<K,V> - Class in com.google.common.collect
A BiMap backed by two hash tables.
HashBiMap(int) - Constructor for class com.google.common.collect.HashBiMap
 
HashBiMap.BiEntry<K,V> - Class in com.google.common.collect
 
HashBiMap.EntrySet - Class in com.google.common.collect
 
HashBiMap.Inverse - Class in com.google.common.collect
 
HashBiMap.Inverse.InverseKeySet - Class in com.google.common.collect
 
HashBiMap.InverseSerializedForm<K,V> - Class in com.google.common.collect
 
HashBiMap.Itr<T> - Class in com.google.common.collect
 
HashBiMap.KeySet - Class in com.google.common.collect
 
hashBytes(byte[]) - Method in class com.google.common.hash.AbstractNonStreamingHashFunction
 
hashBytes(byte[]) - Method in class com.google.common.hash.AbstractStreamingHashFunction
 
hashBytes(byte[], int, int) - Method in class com.google.common.hash.AbstractStreamingHashFunction
 
hashBytes(byte[]) - Method in interface com.google.common.hash.HashFunction
Shortcut for newHasher().putBytes(input).hash().
hashBytes(byte[], int, int) - Method in interface com.google.common.hash.HashFunction
Shortcut for newHasher().putBytes(input, off, len).hash().
hashCode() - Method in class com.google.common.base.Absent
 
hashCode() - Method in class com.google.common.base.CaseFormat.StringConverter
 
hashCode() - Method in class com.google.common.base.Converter.ConverterComposition
 
hashCode() - Method in class com.google.common.base.Converter.FunctionBasedConverter
 
hashCode() - Method in class com.google.common.base.Converter.ReverseConverter
 
hashCode() - Method in class com.google.common.base.Enums.StringConverter
 
hashCode() - Method in class com.google.common.base.Equivalence.EquivalentToPredicate
 
hashCode() - Method in class com.google.common.base.Equivalence.Wrapper
Returns the result of Equivalence.hash(Object) applied to the wrapped reference.
hashCode() - Method in class com.google.common.base.FunctionalEquivalence
 
hashCode() - Method in class com.google.common.base.Functions.ConstantFunction
 
hashCode() - Method in class com.google.common.base.Functions.ForMapWithDefault
 
hashCode() - Method in class com.google.common.base.Functions.FunctionComposition
 
hashCode() - Method in class com.google.common.base.Functions.FunctionForMapNoDefault
 
hashCode() - Method in class com.google.common.base.Functions.PredicateFunction
 
hashCode() - Method in class com.google.common.base.Functions.SupplierFunction
 
hashCode(Object...) - Static method in class com.google.common.base.Objects
Generates a hash code for multiple values.
hashCode() - Method in class com.google.common.base.Optional
Returns a hash code for this instance.
hashCode() - Method in class com.google.common.base.PairwiseEquivalence
 
hashCode() - Method in class com.google.common.base.Predicates.AndPredicate
 
hashCode() - Method in class com.google.common.base.Predicates.AssignableFromPredicate
 
hashCode() - Method in class com.google.common.base.Predicates.CompositionPredicate
 
hashCode() - Method in class com.google.common.base.Predicates.ContainsPatternPredicate
 
hashCode() - Method in class com.google.common.base.Predicates.InPredicate
 
hashCode() - Method in class com.google.common.base.Predicates.InstanceOfPredicate
 
hashCode() - Method in class com.google.common.base.Predicates.IsEqualToPredicate
 
hashCode() - Method in class com.google.common.base.Predicates.NotPredicate
 
hashCode() - Method in class com.google.common.base.Predicates.OrPredicate
 
hashCode() - Method in class com.google.common.base.Present
 
hashCode() - Method in class com.google.common.base.Suppliers.SupplierComposition
 
hashCode() - Method in class com.google.common.base.Suppliers.SupplierOfInstance
 
hashCode() - Method in class com.google.common.cache.CacheBuilderSpec
 
hashCode() - Method in class com.google.common.cache.CacheStats
 
hashCode() - Method in class com.google.common.cache.LocalCache.WriteThroughEntry
 
hashCode() - Method in class com.google.common.cache.RemovalNotification
 
hashCode() - Method in class com.google.common.collect.AbstractMapBasedMultimap.AsMap
 
hashCode() - Method in class com.google.common.collect.AbstractMapBasedMultimap.KeySet
 
hashCode() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection
 
hashCode() - Method in class com.google.common.collect.AbstractMapEntry
 
hashCode() - Method in class com.google.common.collect.AbstractMultimap.EntrySet
 
hashCode() - Method in class com.google.common.collect.AbstractMultimap
Returns the hash code for this multimap.
hashCode() - Method in class com.google.common.collect.AbstractMultiset
Returns the hash code for this multiset.
hashCode() - Method in class com.google.common.collect.AbstractRangeSet
 
hashCode() - Method in class com.google.common.collect.AbstractTable
 
hashCode() - Method in class com.google.common.collect.ByFunctionOrdering
 
hashCode() - Method in class com.google.common.collect.ComparatorOrdering
 
hashCode() - Method in class com.google.common.collect.CompoundOrdering
 
hashCode() - Method in class com.google.common.collect.Count
 
hashCode() - Method in class com.google.common.collect.Cut.AboveValue
 
hashCode() - Method in class com.google.common.collect.Cut.BelowValue
 
hashCode() - Method in class com.google.common.collect.EmptyContiguousSet
 
hashCode() - Method in class com.google.common.collect.EmptyImmutableSet
 
hashCode() - Method in class com.google.common.collect.EmptyImmutableSortedSet
 
hashCode() - Method in class com.google.common.collect.ExplicitOrdering
 
hashCode() - Method in class com.google.common.collect.FilteredKeySetMultimap.EntrySet
 
hashCode() - Method in class com.google.common.collect.ForwardingList
 
hashCode() - Method in class com.google.common.collect.ForwardingMap
 
hashCode() - Method in class com.google.common.collect.ForwardingMapEntry
 
hashCode() - Method in class com.google.common.collect.ForwardingMultimap
 
hashCode() - Method in class com.google.common.collect.ForwardingMultiset
 
hashCode() - Method in class com.google.common.collect.ForwardingSet
 
hashCode() - Method in class com.google.common.collect.ForwardingTable
 
hashCode() - Method in class com.google.common.collect.GeneralRange
 
hashCode - Variable in class com.google.common.collect.ImmutableEnumSet
 
hashCode() - Method in class com.google.common.collect.ImmutableEnumSet
 
hashCode() - Method in class com.google.common.collect.ImmutableList
 
hashCode() - Method in class com.google.common.collect.ImmutableMap
 
hashCode() - Method in class com.google.common.collect.ImmutableMultiset.EntrySet
 
hashCode() - Method in class com.google.common.collect.ImmutableMultiset
 
hashCode() - Method in class com.google.common.collect.ImmutableRangeMap
 
hashCode() - Method in class com.google.common.collect.ImmutableSet
 
hashCode() - Method in class com.google.common.collect.Interners.InternerFunction
 
hashCode() - Method in class com.google.common.collect.LexicographicalOrdering
 
hashCode() - Method in class com.google.common.collect.MapConstraints.ConstrainedAsMapEntries
 
hashCode() - Method in class com.google.common.collect.MapConstraints.ConstrainedEntrySet
 
hashCode() - Method in interface com.google.common.collect.MapDifference
Returns the hash code for this instance.
hashCode() - Method in interface com.google.common.collect.MapDifference.ValueDifference
The hash code equals the value Arrays.asList(leftValue(), rightValue()).hashCode().
hashCode() - Method in class com.google.common.collect.MapMakerInternalMap.WriteThroughEntry
 
hashCode() - Method in class com.google.common.collect.Maps.BiMapConverter
 
hashCode() - Method in class com.google.common.collect.Maps.MapDifferenceImpl
 
hashCode() - Method in class com.google.common.collect.Maps.UnmodifiableEntrySet
 
hashCode() - Method in class com.google.common.collect.Maps.ValueDifferenceImpl
 
hashCode() - Method in interface com.google.common.collect.Multimap
Returns the hash code for this multimap.
hashCode() - Method in class com.google.common.collect.Multimaps.MapMultimap
 
hashCode() - Method in interface com.google.common.collect.Multiset.Entry
hashCode() - Method in interface com.google.common.collect.Multiset
Returns the hash code for this multiset.
hashCode() - Method in class com.google.common.collect.Multisets.AbstractEntry
Return this entry's hash code, following the behavior specified in Multiset.Entry.hashCode().
hashCode() - Method in class com.google.common.collect.NullsFirstOrdering
 
hashCode() - Method in class com.google.common.collect.NullsLastOrdering
 
hashCode() - Method in class com.google.common.collect.Range
Returns a hash code for this range.
hashCode() - Method in interface com.google.common.collect.RangeMap
Returns asMapOfRanges().hashCode().
hashCode() - Method in interface com.google.common.collect.RangeSet
Returns asRanges().hashCode().
hashCode() - Method in class com.google.common.collect.RegularContiguousSet
 
hashCode - Variable in class com.google.common.collect.RegularImmutableBiMap
 
hashCode() - Method in class com.google.common.collect.RegularImmutableBiMap.Inverse.InverseEntrySet
 
hashCode() - Method in class com.google.common.collect.RegularImmutableMultiset
 
hashCode - Variable in class com.google.common.collect.RegularImmutableSet
 
hashCode() - Method in class com.google.common.collect.RegularImmutableSet
 
hashCode() - Method in class com.google.common.collect.ReverseOrdering
 
hashCode() - Method in class com.google.common.collect.Sets.CartesianSet
 
hashCode() - Method in class com.google.common.collect.Sets.FilteredSet
 
hashCode() - Method in class com.google.common.collect.Sets.PowerSet
 
hashCode() - Method in class com.google.common.collect.SingletonImmutableList
 
hashCode() - Method in class com.google.common.collect.SingletonImmutableSet
 
hashCode() - Method in class com.google.common.collect.Synchronized.SynchronizedEntry
 
hashCode() - Method in class com.google.common.collect.Synchronized.SynchronizedList
 
hashCode() - Method in class com.google.common.collect.Synchronized.SynchronizedMap
 
hashCode() - Method in class com.google.common.collect.Synchronized.SynchronizedMultimap
 
hashCode() - Method in class com.google.common.collect.Synchronized.SynchronizedMultiset
 
hashCode() - Method in class com.google.common.collect.Synchronized.SynchronizedSet
 
hashCode() - Method in interface com.google.common.collect.Table.Cell
Returns the hash code of this cell.
hashCode() - Method in interface com.google.common.collect.Table
Returns the hash code for this table.
hashCode() - Method in class com.google.common.collect.Tables.AbstractCell
 
hashCode() - Method in class com.google.common.collect.TreeRangeMap
 
hashCode() - Method in class com.google.common.collect.TreeRangeMap.SubRangeMap
 
hashCode() - Method in class com.google.common.collect.TreeRangeSet.AsRanges
 
hashCode() - Method in class com.google.common.eventbus.AnnotatedSubscriberFinder.MethodIdentifier
 
hashCode() - Method in class com.google.common.eventbus.EventSubscriber
 
hashCode() - Method in class com.google.common.hash.BloomFilter
 
hashCode() - Method in class com.google.common.hash.BloomFilterStrategies.BitArray
 
hashCode() - Method in class com.google.common.hash.Funnels.SequentialFunnel
 
hashCode() - Method in class com.google.common.hash.Funnels.StringCharsetFunnel
 
HashCode - Class in com.google.common.hash
An immutable hash code of arbitrary bit length.
HashCode() - Constructor for class com.google.common.hash.HashCode
 
hashCode() - Method in class com.google.common.hash.HashCode
Returns a "Java hash code" for this HashCode instance; this is well-defined (so, for example, you can safely put HashCode instances into a HashSet) but is otherwise probably not what you want to use.
hashCode() - Method in class com.google.common.hash.Hashing.ConcatenatedHashFunction
 
hashCode() - Method in class com.google.common.hash.Murmur3_128HashFunction
 
hashCode() - Method in class com.google.common.hash.Murmur3_32HashFunction
 
hashCode() - Method in class com.google.common.hash.SipHashFunction
 
hashCode() - Method in class com.google.common.net.HostAndPort
 
hashCode() - Method in class com.google.common.net.HostSpecifier
 
hashCode() - Method in class com.google.common.net.InternetDomainName
 
hashCode() - Method in class com.google.common.net.MediaType
 
hashCode() - Method in class com.google.common.primitives.Booleans.BooleanArrayAsList
 
hashCode(boolean) - Static method in class com.google.common.primitives.Booleans
Returns a hash code for value; equal to the result of invoking ((Boolean) value).hashCode().
hashCode() - Method in class com.google.common.primitives.Bytes.ByteArrayAsList
 
hashCode(byte) - Static method in class com.google.common.primitives.Bytes
Returns a hash code for value; equal to the result of invoking ((Byte) value).hashCode().
hashCode() - Method in class com.google.common.primitives.Chars.CharArrayAsList
 
hashCode(char) - Static method in class com.google.common.primitives.Chars
Returns a hash code for value; equal to the result of invoking ((Character) value).hashCode().
hashCode() - Method in class com.google.common.primitives.Doubles.DoubleArrayAsList
 
hashCode(double) - Static method in class com.google.common.primitives.Doubles
Returns a hash code for value; equal to the result of invoking ((Double) value).hashCode().
hashCode() - Method in class com.google.common.primitives.Floats.FloatArrayAsList
 
hashCode(float) - Static method in class com.google.common.primitives.Floats
Returns a hash code for value; equal to the result of invoking ((Float) value).hashCode().
hashCode(int) - Static method in class com.google.common.primitives.Ints
Returns a hash code for value; equal to the result of invoking ((Integer) value).hashCode().
hashCode() - Method in class com.google.common.primitives.Ints.IntArrayAsList
 
hashCode(long) - Static method in class com.google.common.primitives.Longs
Returns a hash code for value; equal to the result of invoking ((Long) value).hashCode().
hashCode() - Method in class com.google.common.primitives.Longs.LongArrayAsList
 
hashCode(short) - Static method in class com.google.common.primitives.Shorts
Returns a hash code for value; equal to the result of invoking ((Short) value).hashCode().
hashCode() - Method in class com.google.common.primitives.Shorts.ShortArrayAsList
 
hashCode() - Method in class com.google.common.primitives.UnsignedInteger
 
hashCode() - Method in class com.google.common.primitives.UnsignedLong
 
hashCode() - Method in class com.google.common.reflect.AbstractInvocationHandler
By default delegates to Object.hashCode().
hashCode() - Method in class com.google.common.reflect.ClassPath.ResourceInfo
 
hashCode() - Method in class com.google.common.reflect.Element
 
hashCode() - Method in class com.google.common.reflect.Parameter
 
hashCode() - Method in class com.google.common.reflect.TypeParameter
 
hashCode() - Method in class com.google.common.reflect.TypeResolver.TypeVariableKey
 
hashCode() - Method in class com.google.common.reflect.Types.GenericArrayTypeImpl
 
hashCode() - Method in class com.google.common.reflect.Types.ParameterizedTypeImpl
 
hashCode() - Method in class com.google.common.reflect.Types.TypeVariableImpl
 
hashCode() - Method in class com.google.common.reflect.Types.WildcardTypeImpl
 
hashCode() - Method in class com.google.common.reflect.TypeToken
 
HashCode.BytesHashCode - Class in com.google.common.hash
 
HashCode.IntHashCode - Class in com.google.common.hash
 
HashCode.LongHashCode - Class in com.google.common.hash
 
hashCodeImpl(List<?>) - Static method in class com.google.common.collect.Lists
An implementation of List.hashCode().
hashCodeImpl(Set<?>) - Static method in class com.google.common.collect.Sets
An implementation for Set.hashCode().
Hasher - Interface in com.google.common.hash
A PrimitiveSink that can compute a hash code after reading the input.
hasher - Variable in class com.google.common.hash.HashingInputStream
 
hasher - Variable in class com.google.common.hash.HashingOutputStream
 
HashFunction - Interface in com.google.common.hash
A hash function is a collision-averse pure function that maps an arbitrary block of data to a number called a hash code.
Hashing - Class in com.google.common.collect
Static methods for implementing hash-based collections.
Hashing() - Constructor for class com.google.common.collect.Hashing
 
Hashing - Class in com.google.common.hash
Static methods to obtain HashFunction instances, and other static hashing-related utilities.
Hashing() - Constructor for class com.google.common.hash.Hashing
 
Hashing.Adler32Holder - Class in com.google.common.hash
 
Hashing.ChecksumType - Enum in com.google.common.hash
 
Hashing.ConcatenatedHashFunction - Class in com.google.common.hash
 
Hashing.Crc32cHolder - Class in com.google.common.hash
 
Hashing.Crc32Holder - Class in com.google.common.hash
 
Hashing.LinearCongruentialGenerator - Class in com.google.common.hash
Linear CongruentialGenerator to use for consistent hashing.
Hashing.Md5Holder - Class in com.google.common.hash
 
Hashing.Murmur3_128Holder - Class in com.google.common.hash
 
Hashing.Murmur3_32Holder - Class in com.google.common.hash
 
Hashing.Sha1Holder - Class in com.google.common.hash
 
Hashing.Sha256Holder - Class in com.google.common.hash
 
Hashing.Sha512Holder - Class in com.google.common.hash
 
Hashing.SipHash24Holder - Class in com.google.common.hash
 
HashingInputStream - Class in com.google.common.hash
An InputStream that maintains a hash of the data read from it.
HashingInputStream(HashFunction, InputStream) - Constructor for class com.google.common.hash.HashingInputStream
Creates an input stream that hashes using the given HashFunction and delegates all data read from it to the underlying InputStream.
HashingOutputStream - Class in com.google.common.hash
An OutputStream that maintains a hash of the data written to it.
HashingOutputStream(HashFunction, OutputStream) - Constructor for class com.google.common.hash.HashingOutputStream
Creates an output stream that hashes using the given HashFunction, and forwards all data written to it to the underlying OutputStream.
hashInt(int) - Method in class com.google.common.hash.AbstractNonStreamingHashFunction
 
hashInt(int) - Method in class com.google.common.hash.AbstractStreamingHashFunction
 
hashInt(int) - Method in interface com.google.common.hash.HashFunction
Shortcut for newHasher().putInt(input).hash(); returns the hash code for the given int value, interpreted in little-endian byte order.
hashInt(int) - Method in class com.google.common.hash.Murmur3_32HashFunction
 
HashIterator() - Constructor for class com.google.common.cache.LocalCache.HashIterator
 
HashIterator() - Constructor for class com.google.common.collect.MapMakerInternalMap.HashIterator
 
hashKeys() - Static method in class com.google.common.collect.MultimapBuilder
Uses a HashMap to map keys to value collections.
hashKeys(int) - Static method in class com.google.common.collect.MultimapBuilder
Uses a HashMap to map keys to value collections, initialized to expect the specified number of keys.
hashLong(long) - Method in class com.google.common.hash.AbstractNonStreamingHashFunction
 
hashLong(long) - Method in class com.google.common.hash.AbstractStreamingHashFunction
 
hashLong(long) - Method in interface com.google.common.hash.HashFunction
Shortcut for newHasher().putLong(input).hash(); returns the hash code for the given long value, interpreted in little-endian byte order.
hashLong(long) - Method in class com.google.common.hash.Murmur3_32HashFunction
 
HashMultimap<K,V> - Class in com.google.common.collect
Implementation of Multimap using hash tables.
HashMultimap() - Constructor for class com.google.common.collect.HashMultimap
 
HashMultimap(int, int) - Constructor for class com.google.common.collect.HashMultimap
 
HashMultimap(Multimap<? extends K, ? extends V>) - Constructor for class com.google.common.collect.HashMultimap
 
HashMultiset<E> - Class in com.google.common.collect
Multiset implementation backed by a HashMap.
HashMultiset() - Constructor for class com.google.common.collect.HashMultiset
 
HashMultiset(int) - Constructor for class com.google.common.collect.HashMultiset
 
hashObject(T, Funnel<? super T>) - Method in class com.google.common.hash.AbstractNonStreamingHashFunction
 
hashObject(T, Funnel<? super T>) - Method in class com.google.common.hash.AbstractStreamingHashFunction
 
hashObject(T, Funnel<? super T>) - Method in interface com.google.common.hash.HashFunction
Shortcut for newHasher().putObject(instance, funnel).hash().
HashSetSupplier(int) - Constructor for class com.google.common.collect.MultimapBuilder.HashSetSupplier
 
hashSetValues() - Method in class com.google.common.collect.MultimapBuilder.MultimapBuilderWithKeys
Uses a HashSet to store value collections.
hashSetValues(int) - Method in class com.google.common.collect.MultimapBuilder.MultimapBuilderWithKeys
Uses a HashSet to store value collections, initialized to expect the specified number of values per key.
hashString(CharSequence, Charset) - Method in class com.google.common.hash.AbstractNonStreamingHashFunction
 
hashString(CharSequence, Charset) - Method in class com.google.common.hash.AbstractStreamingHashFunction
 
hashString(CharSequence, Charset) - Method in interface com.google.common.hash.HashFunction
Shortcut for newHasher().putString(input, charset).hash().
hashTable - Variable in class com.google.common.collect.LinkedHashMultimap.ValueSet
 
hashTableKToV - Variable in class com.google.common.collect.HashBiMap
 
hashTableVToK - Variable in class com.google.common.collect.HashBiMap
 
hashUnencodedChars(CharSequence) - Method in class com.google.common.hash.AbstractNonStreamingHashFunction
 
hashUnencodedChars(CharSequence) - Method in class com.google.common.hash.AbstractStreamingHashFunction
 
hashUnencodedChars(CharSequence) - Method in interface com.google.common.hash.HashFunction
Shortcut for newHasher().putUnencodedChars(input).hash().
hashUnencodedChars(CharSequence) - Method in class com.google.common.hash.Murmur3_32HashFunction
 
hasListeners - Variable in class com.google.common.util.concurrent.JdkFutureAdapters.ListenableFutureAdapter
 
hasLowerBound - Variable in class com.google.common.collect.GeneralRange
 
hasLowerBound() - Method in class com.google.common.collect.GeneralRange
 
hasLowerBound() - Method in class com.google.common.collect.Range
Returns true if this range has a lower endpoint.
hasLowerCase() - Method in class com.google.common.io.BaseEncoding.Alphabet
 
hasMore() - Method in class com.google.common.net.MediaType.Tokenizer
 
hasNext() - Method in class com.google.common.base.AbstractIterator
 
hasNext() - Method in class com.google.common.cache.LocalCache.HashIterator
 
hasNext() - Method in class com.google.common.collect.AbstractIndexedListIterator
 
hasNext() - Method in class com.google.common.collect.AbstractIterator
 
hasNext() - Method in class com.google.common.collect.AbstractMapBasedMultimap.AsMap.AsMapIterator
 
hasNext() - Method in class com.google.common.collect.AbstractMapBasedMultimap.Itr
 
hasNext() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection.WrappedIterator
 
hasNext() - Method in class com.google.common.collect.AbstractMapBasedMultiset.MapBasedMultisetIterator
 
hasNext() - Method in class com.google.common.collect.AbstractSequentialIterator
 
hasNext() - Method in class com.google.common.collect.BinaryTreeTraverser.PostOrderIterator
 
hasNext() - Method in class com.google.common.collect.BinaryTreeTraverser.PreOrderIterator
 
hasNext() - Method in class com.google.common.collect.ForwardingIterator
 
hasNext() - Method in class com.google.common.collect.HashBiMap.Itr
 
hasNext() - Method in class com.google.common.collect.ImmutableMultimap.Itr
 
hasNext() - Method in class com.google.common.collect.Iterators.MergingIterator
 
hasNext() - Method in class com.google.common.collect.Iterators.PeekingImpl
 
hasNext() - Method in class com.google.common.collect.LinkedListMultimap.DistinctKeyIterator
 
hasNext() - Method in class com.google.common.collect.LinkedListMultimap.NodeIterator
 
hasNext() - Method in class com.google.common.collect.LinkedListMultimap.ValueForKeyIterator
 
hasNext() - Method in class com.google.common.collect.MapMakerInternalMap.HashIterator
 
hasNext() - Method in class com.google.common.collect.MinMaxPriorityQueue.QueueIterator
 
hasNext() - Method in class com.google.common.collect.Multisets.MultisetIteratorImpl
 
hasNext() - Method in class com.google.common.collect.StandardTable.CellIterator
 
hasNext() - Method in class com.google.common.collect.TransformedIterator
 
hasNext() - Method in class com.google.common.collect.TreeTraverser.BreadthFirstIterator
 
hasNext() - Method in class com.google.common.collect.TreeTraverser.PreOrderIterator
 
hasParent() - Method in class com.google.common.net.InternetDomainName
Indicates whether this domain is composed of two or more parts.
hasPeeked - Variable in class com.google.common.collect.Iterators.PeekingImpl
 
hasPort() - Method in class com.google.common.net.HostAndPort
Return true if this instance has a defined port.
hasPrevious() - Method in class com.google.common.collect.AbstractIndexedListIterator
 
hasPrevious() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedList.WrappedListIterator
 
hasPrevious() - Method in class com.google.common.collect.ForwardingListIterator
 
hasPrevious() - Method in class com.google.common.collect.LinkedListMultimap.NodeIterator
 
hasPrevious() - Method in class com.google.common.collect.LinkedListMultimap.ValueForKeyIterator
 
hasPrevious() - Method in class com.google.common.collect.TransformedListIterator
 
hasPublicSuffix() - Method in class com.google.common.net.InternetDomainName
Indicates whether this domain name ends in a public suffix, including if it is a public suffix itself.
hasQueuedThread(Thread) - Method in class com.google.common.util.concurrent.Monitor
Queries whether the given thread is waiting to enter this monitor.
hasQueuedThreads() - Method in class com.google.common.util.concurrent.Monitor
Returns whether any threads are waiting to enter this monitor.
hasReachedRunning - Variable in class com.google.common.util.concurrent.AbstractService
 
hasRemaining() - Method in class com.google.common.io.CharSequenceReader
 
hasSameComparator(Comparator<?>, Iterable<?>) - Static method in class com.google.common.collect.SortedIterables
Returns true if elements is a sorted collection using an ordering equivalent to comparator.
hasUpperBound - Variable in class com.google.common.collect.GeneralRange
 
hasUpperBound() - Method in class com.google.common.collect.GeneralRange
 
hasUpperBound() - Method in class com.google.common.collect.Range
Returns true if this range has an upper endpoint.
hasUpperCase() - Method in class com.google.common.io.BaseEncoding.Alphabet
 
hasWaiters(Monitor.Guard) - Method in class com.google.common.util.concurrent.Monitor
Queries whether any threads are waiting for the given guard to become satisfied.
hasWildcard() - Method in class com.google.common.net.MediaType
Returns true if either the type or subtype is the wildcard.
head - Variable in class com.google.common.cache.LocalCache.AccessQueue
 
head - Variable in class com.google.common.cache.LocalCache.WriteQueue
 
head - Variable in class com.google.common.collect.LinkedListMultimap
 
head - Variable in class com.google.common.collect.LinkedListMultimap.KeyList
 
head - Variable in class com.google.common.collect.MapMakerInternalMap.EvictionQueue
 
head - Variable in class com.google.common.collect.MapMakerInternalMap.ExpirationQueue
 
header - Variable in class com.google.common.collect.TreeMultiset
 
headIndex(E, boolean) - Method in class com.google.common.collect.RegularImmutableSortedSet
 
headMap(K) - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableAsMap
 
headMap(K, boolean) - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableAsMap
 
headMap(K) - Method in class com.google.common.collect.AbstractMapBasedMultimap.SortedAsMap
 
headMap(K) - Method in class com.google.common.collect.AbstractNavigableMap
 
headMap(K, boolean) - Method in class com.google.common.collect.EmptyImmutableSortedMap
 
headMap(K, boolean) - Method in class com.google.common.collect.ForwardingNavigableMap
 
headMap(K) - Method in class com.google.common.collect.ForwardingSortedMap
 
headMap(K) - Method in class com.google.common.collect.ImmutableSortedMap
This method returns a ImmutableSortedMap, consisting of the entries whose keys are less than toKey.
headMap(K, boolean) - Method in class com.google.common.collect.ImmutableSortedMap
This method returns a ImmutableSortedMap, consisting of the entries whose keys are less than (or equal to, if inclusive) toKey.
headMap(K, boolean) - Method in class com.google.common.collect.Maps.DescendingMap
 
headMap(K) - Method in class com.google.common.collect.Maps.DescendingMap
 
headMap(K, boolean) - Method in class com.google.common.collect.Maps.FilteredEntryNavigableMap
 
headMap(K) - Method in class com.google.common.collect.Maps.FilteredEntrySortedMap
 
headMap(K, boolean) - Method in class com.google.common.collect.Maps.NavigableAsMapView
 
headMap(K) - Method in class com.google.common.collect.Maps.SortedAsMapView
 
headMap(K) - Method in class com.google.common.collect.Maps.TransformedEntriesNavigableMap
 
headMap(K, boolean) - Method in class com.google.common.collect.Maps.TransformedEntriesNavigableMap
 
headMap(K) - Method in class com.google.common.collect.Maps.TransformedEntriesSortedMap
 
headMap(K) - Method in class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
headMap(K, boolean) - Method in class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
headMap(K, boolean) - Method in class com.google.common.collect.RegularImmutableSortedMap
 
headMap(R) - Method in class com.google.common.collect.StandardRowSortedTable.RowSortedMap
 
headMap(K, boolean) - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableMap
 
headMap(K) - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableMap
 
headMap(K) - Method in class com.google.common.collect.Synchronized.SynchronizedSortedMap
 
headMap(C) - Method in class com.google.common.collect.TreeBasedTable.TreeRow
 
headMap(Cut<C>, boolean) - Method in class com.google.common.collect.TreeRangeSet.ComplementRangesByLowerBound
 
headMap(Cut<C>, boolean) - Method in class com.google.common.collect.TreeRangeSet.RangesByUpperBound
 
headMap(Cut<C>, boolean) - Method in class com.google.common.collect.TreeRangeSet.SubRangeSetRangesByLowerBound
 
headMultiset(E, BoundType) - Method in class com.google.common.collect.DescendingImmutableSortedMultiset
 
headMultiset(E, BoundType) - Method in class com.google.common.collect.DescendingMultiset
 
headMultiset(E, BoundType) - Method in class com.google.common.collect.EmptyImmutableSortedMultiset
 
headMultiset(E, BoundType) - Method in class com.google.common.collect.ForwardingSortedMultiset
 
headMultiset(E, BoundType) - Method in class com.google.common.collect.ImmutableSortedMultiset
 
headMultiset(E, BoundType) - Method in class com.google.common.collect.RegularImmutableSortedMultiset
 
headMultiset(E, BoundType) - Method in interface com.google.common.collect.SortedMultiset
Returns a view of this multiset restricted to the elements less than upperBound, optionally including upperBound itself.
headMultiset(E, BoundType) - Method in class com.google.common.collect.TreeMultiset
 
headMultiset(E, BoundType) - Method in class com.google.common.collect.UnmodifiableSortedMultiset
 
headSet(K) - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableKeySet
 
headSet(K, boolean) - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableKeySet
 
headSet(K) - Method in class com.google.common.collect.AbstractMapBasedMultimap.SortedKeySet
 
headSet(V, boolean) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedNavigableSet
 
headSet(V) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedSortedSet
 
headSet(E) - Method in class com.google.common.collect.Constraints.ConstrainedSortedSet
 
headSet(C) - Method in class com.google.common.collect.ContiguousSet
 
headSet(C, boolean) - Method in class com.google.common.collect.ContiguousSet
 
headSet(E, boolean) - Method in class com.google.common.collect.ForwardingNavigableSet
 
headSet(E) - Method in class com.google.common.collect.ForwardingSortedSet
 
headSet(E) - Method in class com.google.common.collect.ImmutableSortedSet
headSet(E, boolean) - Method in class com.google.common.collect.ImmutableSortedSet
 
headSet(K) - Method in class com.google.common.collect.Maps.FilteredEntrySortedMap.SortedKeySet
 
headSet(K, boolean) - Method in class com.google.common.collect.Maps.NavigableKeySet
 
headSet(K) - Method in class com.google.common.collect.Maps.NavigableKeySet
 
headSet(K) - Method in class com.google.common.collect.Maps.SortedKeySet
 
headSet(E, boolean) - Method in class com.google.common.collect.Sets.DescendingSet
 
headSet(E) - Method in class com.google.common.collect.Sets.DescendingSet
 
headSet(E, boolean) - Method in class com.google.common.collect.Sets.FilteredNavigableSet
 
headSet(E) - Method in class com.google.common.collect.Sets.FilteredSortedSet
 
headSet(E, boolean) - Method in class com.google.common.collect.Sets.UnmodifiableNavigableSet
 
headSet(E) - Method in class com.google.common.collect.SortedMultisets.ElementSet
 
headSet(E, boolean) - Method in class com.google.common.collect.SortedMultisets.NavigableElementSet
 
headSet(E, boolean) - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableSet
 
headSet(E) - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableSet
 
headSet(E) - Method in class com.google.common.collect.Synchronized.SynchronizedSortedSet
 
headSetImpl(C, boolean) - Method in class com.google.common.collect.ContiguousSet
 
headSetImpl(E, boolean) - Method in class com.google.common.collect.DescendingImmutableSortedSet
 
headSetImpl(C, boolean) - Method in class com.google.common.collect.EmptyContiguousSet
 
headSetImpl(E, boolean) - Method in class com.google.common.collect.EmptyImmutableSortedSet
 
headSetImpl(C, boolean) - Method in class com.google.common.collect.ImmutableRangeSet.AsSet
 
headSetImpl(E, boolean) - Method in class com.google.common.collect.ImmutableSortedSet
 
headSetImpl(C, boolean) - Method in class com.google.common.collect.RegularContiguousSet
 
headSetImpl(E, boolean) - Method in class com.google.common.collect.RegularImmutableSortedSet
 
healthy() - Method in class com.google.common.util.concurrent.ServiceManager.Listener
Called when the service initially becomes healthy.
HEALTHY_CALLBACK - Static variable in class com.google.common.util.concurrent.ServiceManager
 
Heap(Ordering<E>) - Constructor for class com.google.common.collect.MinMaxPriorityQueue.Heap
 
heapForIndex(int) - Method in class com.google.common.collect.MinMaxPriorityQueue
 
height - Variable in class com.google.common.collect.TreeMultiset.AvlNode
 
height(TreeMultiset.AvlNode<?>) - Static method in class com.google.common.collect.TreeMultiset.AvlNode
 
hexDigits - Static variable in class com.google.common.hash.HashCode
 
hextetsToIPv6String(int[]) - Static method in class com.google.common.net.InetAddresses
Convert a list of hextets into a human-readable IPv6 address.
higher(K) - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableKeySet
 
higher(V) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedNavigableSet
 
higher(E) - Method in class com.google.common.collect.DescendingImmutableSortedSet
 
higher(E) - Method in class com.google.common.collect.ForwardingNavigableSet
 
higher(E) - Method in class com.google.common.collect.ImmutableSortedSet
 
higher(K) - Method in class com.google.common.collect.Maps.NavigableKeySet
 
higher(E) - Method in class com.google.common.collect.RegularImmutableSortedSet
 
higher(E) - Method in class com.google.common.collect.Sets.DescendingSet
 
higher(E) - Method in class com.google.common.collect.Sets.FilteredNavigableSet
 
higher(E) - Method in class com.google.common.collect.Sets.UnmodifiableNavigableSet
 
higher(E) - Method in class com.google.common.collect.SortedMultisets.NavigableElementSet
 
higher(E) - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableSet
 
higherEntry(K) - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableAsMap
 
higherEntry(K) - Method in class com.google.common.collect.AbstractNavigableMap
 
higherEntry(K) - Method in class com.google.common.collect.ForwardingNavigableMap
 
higherEntry(K) - Method in class com.google.common.collect.ImmutableSortedMap
 
higherEntry(K) - Method in class com.google.common.collect.Maps.DescendingMap
 
higherEntry(K) - Method in class com.google.common.collect.Maps.TransformedEntriesNavigableMap
 
higherEntry(K) - Method in class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
higherEntry(K) - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableMap
 
higherKey(K) - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableAsMap
 
higherKey(K) - Method in class com.google.common.collect.AbstractNavigableMap
 
higherKey(K) - Method in class com.google.common.collect.ForwardingNavigableMap
 
higherKey(K) - Method in class com.google.common.collect.ImmutableSortedMap
 
higherKey(K) - Method in class com.google.common.collect.Maps.DescendingMap
 
higherKey(K) - Method in class com.google.common.collect.Maps.TransformedEntriesNavigableMap
 
higherKey(K) - Method in class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
higherKey(K) - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableMap
 
hitCount - Variable in class com.google.common.cache.AbstractCache.SimpleStatsCounter
 
hitCount - Variable in class com.google.common.cache.CacheStats
 
hitCount() - Method in class com.google.common.cache.CacheStats
Returns the number of times Cache lookup methods have returned a cached value.
hitRate() - Method in class com.google.common.cache.CacheStats
Returns the ratio of cache requests which were hits.
holderHead - Variable in class com.google.common.base.MoreObjects.ToStringHelper
 
holderHead - Variable in class com.google.common.base.Objects.ToStringHelper
Deprecated.
 
holderTail - Variable in class com.google.common.base.MoreObjects.ToStringHelper
 
holderTail - Variable in class com.google.common.base.Objects.ToStringHelper
Deprecated.
 
host - Variable in class com.google.common.net.HostAndPort
Hostname, IPv4/IPv6 literal, or unvalidated nonsense.
HOST - Static variable in class com.google.common.net.HttpHeaders
The HTTP Host header field name.
HostAndPort - Class in com.google.common.net
An immutable representation of a host and port.
HostAndPort(String, int, boolean) - Constructor for class com.google.common.net.HostAndPort
 
HostSpecifier - Class in com.google.common.net
A syntactically valid host specifier, suitable for use in a URI.
HostSpecifier(String) - Constructor for class com.google.common.net.HostSpecifier
 
HT - Static variable in class com.google.common.base.Ascii
Horizontal Tabulation ('\t'): A format effector which controls the movement of the printing position to the next in a series of predetermined positions along the printing line.
HTML_ESCAPER - Static variable in class com.google.common.html.HtmlEscapers
 
HTML_UTF_8 - Static variable in class com.google.common.net.MediaType
 
htmlEscaper() - Static method in class com.google.common.html.HtmlEscapers
Returns an Escaper instance that escapes HTML metacharacters as specified by HTML 4.01.
HtmlEscapers - Class in com.google.common.html
Escaper instances suitable for strings to be included in HTML attribute values and most elements' text contents.
HtmlEscapers() - Constructor for class com.google.common.html.HtmlEscapers
 
HttpHeaders - Class in com.google.common.net
Contains constant definitions for the HTTP header field names.
HttpHeaders() - Constructor for class com.google.common.net.HttpHeaders
 

I

I_CALENDAR_UTF_8 - Static variable in class com.google.common.net.MediaType
 
ICO - Static variable in class com.google.common.net.MediaType
 
id - Variable in class com.google.common.reflect.TypeResolver.WildcardCapturer
 
identity() - Static method in class com.google.common.base.Converter
Returns a serializable converter that always converts or reverses an object to itself.
identity() - Static method in class com.google.common.base.Equivalence
Returns an equivalence that uses == to compare values and System.identityHashCode(Object) to compute the hash code.
Identity() - Constructor for class com.google.common.base.Equivalence.Identity
 
identity() - Static method in class com.google.common.base.Functions
Returns the identity function.
IdentityConverter() - Constructor for class com.google.common.base.Converter.IdentityConverter
 
IdentityFunction() - Constructor for enum com.google.common.base.Functions.IdentityFunction
 
identityHashCode(Object) - Method in class com.google.common.collect.Ordering.ArbitraryOrdering
 
IF_MATCH - Static variable in class com.google.common.net.HttpHeaders
The HTTP If-Match header field name.
IF_MODIFIED_SINCE - Static variable in class com.google.common.net.HttpHeaders
The HTTP If-Modified-Since header field name.
IF_NONE_MATCH - Static variable in class com.google.common.net.HttpHeaders
The HTTP If-None-Match header field name.
IF_RANGE - Static variable in class com.google.common.net.HttpHeaders
The HTTP If-Range header field name.
IF_UNMODIFIED_SINCE - Static variable in class com.google.common.net.HttpHeaders
The HTTP If-Unmodified-Since header field name.
ignoringInput(GwtWorkarounds.CharInput, CharMatcher) - Static method in class com.google.common.io.BaseEncoding
 
IMAGE_TYPE - Static variable in class com.google.common.net.MediaType
 
immediateCancelledFuture() - Static method in class com.google.common.util.concurrent.Futures
Creates a ListenableFuture which is cancelled immediately upon construction, so that isCancelled() always returns true.
ImmediateCancelledFuture() - Constructor for class com.google.common.util.concurrent.Futures.ImmediateCancelledFuture
 
immediateCheckedFuture(V) - Static method in class com.google.common.util.concurrent.Futures
Returns a CheckedFuture which has its value set immediately upon construction.
immediateFailedCheckedFuture(X) - Static method in class com.google.common.util.concurrent.Futures
Returns a CheckedFuture which has an exception set immediately upon construction.
ImmediateFailedCheckedFuture(X) - Constructor for class com.google.common.util.concurrent.Futures.ImmediateFailedCheckedFuture
 
immediateFailedFuture(Throwable) - Static method in class com.google.common.util.concurrent.Futures
Returns a ListenableFuture which has an exception set immediately upon construction.
ImmediateFailedFuture(Throwable) - Constructor for class com.google.common.util.concurrent.Futures.ImmediateFailedFuture
 
immediateFuture(V) - Static method in class com.google.common.util.concurrent.Futures
Creates a ListenableFuture which has its value set immediately upon construction.
ImmediateFuture() - Constructor for class com.google.common.util.concurrent.Futures.ImmediateFuture
 
ImmediateSuccessfulCheckedFuture(V) - Constructor for class com.google.common.util.concurrent.Futures.ImmediateSuccessfulCheckedFuture
 
ImmediateSuccessfulFuture(V) - Constructor for class com.google.common.util.concurrent.Futures.ImmediateSuccessfulFuture
 
ImmutableArrayMap(int) - Constructor for class com.google.common.collect.DenseImmutableTable.ImmutableArrayMap
 
ImmutableAsList<E> - Class in com.google.common.collect
List returned by ImmutableCollection.asList that delegates contains checks to the backing collection.
ImmutableAsList() - Constructor for class com.google.common.collect.ImmutableAsList
 
ImmutableAsList.SerializedForm - Class in com.google.common.collect
Serialized form that leads to the same performance as the original list.
ImmutableBiMap<K,V> - Class in com.google.common.collect
An immutable BiMap with reliable user-specified iteration order.
ImmutableBiMap() - Constructor for class com.google.common.collect.ImmutableBiMap
 
ImmutableBiMap.Builder<K,V> - Class in com.google.common.collect
A builder for creating immutable bimap instances, especially public static final bimaps ("constant bimaps").
ImmutableBiMap.SerializedForm - Class in com.google.common.collect
Serialized type for all ImmutableBiMap instances.
immutableCell(R, C, V) - Static method in class com.google.common.collect.Tables
Returns an immutable cell with the specified row key, column key, and value.
ImmutableCell(R, C, V) - Constructor for class com.google.common.collect.Tables.ImmutableCell
 
ImmutableClassToInstanceMap<B> - Class in com.google.common.collect
A class-to-instance map backed by an ImmutableMap.
ImmutableClassToInstanceMap(ImmutableMap<Class<? extends B>, B>) - Constructor for class com.google.common.collect.ImmutableClassToInstanceMap
 
ImmutableClassToInstanceMap.Builder<B> - Class in com.google.common.collect
A builder for creating immutable class-to-instance maps.
ImmutableCollection<E> - Class in com.google.common.collect
An immutable collection.
ImmutableCollection() - Constructor for class com.google.common.collect.ImmutableCollection
 
ImmutableCollection.ArrayBasedBuilder<E> - Class in com.google.common.collect
 
ImmutableCollection.Builder<E> - Class in com.google.common.collect
Abstract base class for builders of ImmutableCollection types.
immutableCopy() - Method in class com.google.common.collect.Sets.SetView
Returns an immutable copy of the current contents of this set view.
ImmutableEntry<K,V> - Class in com.google.common.collect
 
ImmutableEntry(K, V) - Constructor for class com.google.common.collect.ImmutableEntry
 
immutableEntry(K, V) - Static method in class com.google.common.collect.Maps
Returns an immutable map entry with the specified key and value.
immutableEntry(E, int) - Static method in class com.google.common.collect.Multisets
Returns an immutable multiset entry with the specified element and count.
ImmutableEntry(E, int) - Constructor for class com.google.common.collect.Multisets.ImmutableEntry
 
ImmutableEnumMap<K extends java.lang.Enum<K>,V> - Class in com.google.common.collect
Implementation of ImmutableMap backed by a non-empty EnumMap.
ImmutableEnumMap(EnumMap<K, V>) - Constructor for class com.google.common.collect.ImmutableEnumMap
 
immutableEnumMap(Map<K, ? extends V>) - Static method in class com.google.common.collect.Maps
Returns an immutable map instance containing the given entries.
ImmutableEnumMap.EnumSerializedForm<K extends java.lang.Enum<K>,V> - Class in com.google.common.collect
 
ImmutableEnumSet<E extends java.lang.Enum<E>> - Class in com.google.common.collect
Implementation of ImmutableSet backed by a non-empty EnumSet.
ImmutableEnumSet(EnumSet<E>) - Constructor for class com.google.common.collect.ImmutableEnumSet
 
immutableEnumSet(E, E...) - Static method in class com.google.common.collect.Sets
Returns an immutable set instance containing the given enum elements.
immutableEnumSet(Iterable<E>) - Static method in class com.google.common.collect.Sets
Returns an immutable set instance containing the given enum elements.
ImmutableEnumSet.EnumSerializedForm<E extends java.lang.Enum<E>> - Class in com.google.common.collect
 
ImmutableList<E> - Class in com.google.common.collect
A high-performance, immutable, random-access List implementation.
ImmutableList() - Constructor for class com.google.common.collect.ImmutableList
 
ImmutableList.Builder<E> - Class in com.google.common.collect
A builder for creating immutable list instances, especially public static final lists ("constant lists").
ImmutableList.ReverseImmutableList<E> - Class in com.google.common.collect
 
ImmutableList.SerializedForm - Class in com.google.common.collect
 
ImmutableList.SubList - Class in com.google.common.collect
 
ImmutableListMultimap<K,V> - Class in com.google.common.collect
An immutable ListMultimap with reliable user-specified key and value iteration order.
ImmutableListMultimap(ImmutableMap<K, ImmutableList<V>>, int) - Constructor for class com.google.common.collect.ImmutableListMultimap
 
ImmutableListMultimap.Builder<K,V> - Class in com.google.common.collect
A builder for creating immutable ListMultimap instances, especially public static final multimaps ("constant multimaps").
ImmutableMap<K,V> - Class in com.google.common.collect
An immutable, hash-based Map with reliable user-specified iteration order.
ImmutableMap() - Constructor for class com.google.common.collect.ImmutableMap
 
ImmutableMap.Builder<K,V> - Class in com.google.common.collect
A builder for creating immutable map instances, especially public static final maps ("constant maps").
ImmutableMap.MapViewOfValuesAsSingletonSets<K,V> - Class in com.google.common.collect
 
ImmutableMap.SerializedForm - Class in com.google.common.collect
Serialized type for all ImmutableMap instances.
ImmutableMapEntry<K,V> - Class in com.google.common.collect
Implementation of Map.Entry for ImmutableMap that adds extra methods to traverse hash buckets for the key and the value.
ImmutableMapEntry(K, V) - Constructor for class com.google.common.collect.ImmutableMapEntry
 
ImmutableMapEntry(ImmutableMapEntry<K, V>) - Constructor for class com.google.common.collect.ImmutableMapEntry
 
ImmutableMapEntry.TerminalEntry<K,V> - Class in com.google.common.collect
 
ImmutableMapEntrySet<K,V> - Class in com.google.common.collect
entrySet() implementation for ImmutableMap.
ImmutableMapEntrySet() - Constructor for class com.google.common.collect.ImmutableMapEntrySet
 
ImmutableMapEntrySet.EntrySetSerializedForm<K,V> - Class in com.google.common.collect
 
ImmutableMapKeySet<K,V> - Class in com.google.common.collect
keySet() implementation for ImmutableMap.
ImmutableMapKeySet(ImmutableMap<K, V>) - Constructor for class com.google.common.collect.ImmutableMapKeySet
 
ImmutableMapKeySet.KeySetSerializedForm<K> - Class in com.google.common.collect
 
ImmutableMapValues<K,V> - Class in com.google.common.collect
values() implementation for ImmutableMap.
ImmutableMapValues(ImmutableMap<K, V>) - Constructor for class com.google.common.collect.ImmutableMapValues
 
ImmutableMapValues.SerializedForm<V> - Class in com.google.common.collect
 
ImmutableMultimap<K,V> - Class in com.google.common.collect
An immutable Multimap.
ImmutableMultimap(ImmutableMap<K, ? extends ImmutableCollection<V>>, int) - Constructor for class com.google.common.collect.ImmutableMultimap
 
ImmutableMultimap.Builder<K,V> - Class in com.google.common.collect
A builder for creating immutable multimap instances, especially public static final multimaps ("constant multimaps").
ImmutableMultimap.BuilderMultimap<K,V> - Class in com.google.common.collect
Multimap for ImmutableMultimap.Builder that maintains key and value orderings, allows duplicate values, and performs better than LinkedListMultimap.
ImmutableMultimap.EntryCollection<K,V> - Class in com.google.common.collect
 
ImmutableMultimap.FieldSettersHolder - Class in com.google.common.collect
 
ImmutableMultimap.Itr<T> - Class in com.google.common.collect
 
ImmutableMultimap.Keys - Class in com.google.common.collect
 
ImmutableMultimap.Values<K,V> - Class in com.google.common.collect
 
ImmutableMultiset<E> - Class in com.google.common.collect
An immutable hash-based multiset.
ImmutableMultiset() - Constructor for class com.google.common.collect.ImmutableMultiset
 
ImmutableMultiset.Builder<E> - Class in com.google.common.collect
A builder for creating immutable multiset instances, especially public static final multisets ("constant multisets").
ImmutableMultiset.EntrySet - Class in com.google.common.collect
 
ImmutableMultiset.EntrySetSerializedForm<E> - Class in com.google.common.collect
 
ImmutableMultiset.SerializedForm - Class in com.google.common.collect
 
ImmutableRangeMap<K extends java.lang.Comparable<?>,V> - Class in com.google.common.collect
An immutable implementation of RangeMap, supporting all query operations efficiently.
ImmutableRangeMap(ImmutableList<Range<K>>, ImmutableList<V>) - Constructor for class com.google.common.collect.ImmutableRangeMap
 
ImmutableRangeMap.Builder<K extends java.lang.Comparable<?>,V> - Class in com.google.common.collect
A builder for immutable range maps.
ImmutableRangeSet<C extends java.lang.Comparable> - Class in com.google.common.collect
An efficient immutable implementation of a RangeSet.
ImmutableRangeSet(ImmutableList<Range<C>>) - Constructor for class com.google.common.collect.ImmutableRangeSet
 
ImmutableRangeSet(ImmutableList<Range<C>>, ImmutableRangeSet<C>) - Constructor for class com.google.common.collect.ImmutableRangeSet
 
ImmutableRangeSet.AsSet - Class in com.google.common.collect
 
ImmutableRangeSet.AsSetSerializedForm<C extends java.lang.Comparable> - Class in com.google.common.collect
 
ImmutableRangeSet.Builder<C extends java.lang.Comparable<?>> - Class in com.google.common.collect
A builder for immutable range sets.
ImmutableRangeSet.ComplementRanges - Class in com.google.common.collect
 
ImmutableRangeSet.SerializedForm<C extends java.lang.Comparable> - Class in com.google.common.collect
 
ImmutableSet<E> - Class in com.google.common.collect
A high-performance, immutable Set with reliable, user-specified iteration order.
ImmutableSet() - Constructor for class com.google.common.collect.ImmutableSet
 
ImmutableSet.Builder<E> - Class in com.google.common.collect
A builder for creating immutable set instances, especially public static final sets ("constant sets").
ImmutableSet.SerializedForm - Class in com.google.common.collect
 
ImmutableSetMultimap<K,V> - Class in com.google.common.collect
An immutable SetMultimap with reliable user-specified key and value iteration order.
ImmutableSetMultimap(ImmutableMap<K, ImmutableSet<V>>, int, Comparator<? super V>) - Constructor for class com.google.common.collect.ImmutableSetMultimap
 
ImmutableSetMultimap.Builder<K,V> - Class in com.google.common.collect
A builder for creating immutable SetMultimap instances, especially public static final multimaps ("constant multimaps").
ImmutableSetMultimap.BuilderMultimap<K,V> - Class in com.google.common.collect
Multimap for ImmutableSetMultimap.Builder that maintains key and value orderings and performs better than LinkedHashMultimap.
ImmutableSetMultimap.EntrySet<K,V> - Class in com.google.common.collect
 
ImmutableSortedAsList<E> - Class in com.google.common.collect
List returned by ImmutableSortedSet.asList() when the set isn't empty.
ImmutableSortedAsList(ImmutableSortedSet<E>, ImmutableList<E>) - Constructor for class com.google.common.collect.ImmutableSortedAsList
 
immutableSortedCopy(Iterable<E>) - Method in class com.google.common.collect.AllEqualOrdering
 
immutableSortedCopy(Iterable<E>) - Method in class com.google.common.collect.Ordering
Returns an immutable list containing elements sorted by this ordering.
ImmutableSortedMap<K,V> - Class in com.google.common.collect
An immutable SortedMap.
ImmutableSortedMap() - Constructor for class com.google.common.collect.ImmutableSortedMap
 
ImmutableSortedMap(ImmutableSortedMap<K, V>) - Constructor for class com.google.common.collect.ImmutableSortedMap
 
ImmutableSortedMap.Builder<K,V> - Class in com.google.common.collect
A builder for creating immutable sorted map instances, especially public static final maps ("constant maps").
ImmutableSortedMap.SerializedForm - Class in com.google.common.collect
Serialized type for all ImmutableSortedMap instances.
ImmutableSortedMapFauxverideShim<K,V> - Class in com.google.common.collect
"Overrides" the ImmutableMap static methods that lack ImmutableSortedMap equivalents with deprecated, exception-throwing versions.
ImmutableSortedMapFauxverideShim() - Constructor for class com.google.common.collect.ImmutableSortedMapFauxverideShim
 
ImmutableSortedMultiset<E> - Class in com.google.common.collect
An immutable SortedMultiset that stores its elements in a sorted array.
ImmutableSortedMultiset() - Constructor for class com.google.common.collect.ImmutableSortedMultiset
 
ImmutableSortedMultiset.Builder<E> - Class in com.google.common.collect
A builder for creating immutable multiset instances, especially public static final multisets ("constant multisets").
ImmutableSortedMultiset.SerializedForm<E> - Class in com.google.common.collect
 
ImmutableSortedMultisetFauxverideShim<E> - Class in com.google.common.collect
"Overrides" the ImmutableMultiset static methods that lack ImmutableSortedMultiset equivalents with deprecated, exception-throwing versions.
ImmutableSortedMultisetFauxverideShim() - Constructor for class com.google.common.collect.ImmutableSortedMultisetFauxverideShim
 
ImmutableSortedSet<E> - Class in com.google.common.collect
An immutable SortedSet that stores its elements in a sorted array.
ImmutableSortedSet(Comparator<? super E>) - Constructor for class com.google.common.collect.ImmutableSortedSet
 
ImmutableSortedSet.Builder<E> - Class in com.google.common.collect
A builder for creating immutable sorted set instances, especially public static final sets ("constant sets"), with a given comparator.
ImmutableSortedSet.SerializedForm<E> - Class in com.google.common.collect
 
ImmutableSortedSetFauxverideShim<E> - Class in com.google.common.collect
"Overrides" the ImmutableSet static methods that lack ImmutableSortedSet equivalents with deprecated, exception-throwing versions.
ImmutableSortedSetFauxverideShim() - Constructor for class com.google.common.collect.ImmutableSortedSetFauxverideShim
 
ImmutableTable<R,C,V> - Class in com.google.common.collect
An immutable Table with reliable user-specified iteration order.
ImmutableTable() - Constructor for class com.google.common.collect.ImmutableTable
 
ImmutableTable.Builder<R,C,V> - Class in com.google.common.collect
A builder for creating immutable table instances, especially public static final tables ("constant tables").
ImmutableTypeToInstanceMap<B> - Class in com.google.common.reflect
A type-to-instance map backed by an ImmutableMap.
ImmutableTypeToInstanceMap(ImmutableMap<TypeToken<? extends B>, B>) - Constructor for class com.google.common.reflect.ImmutableTypeToInstanceMap
 
ImmutableTypeToInstanceMap.Builder<B> - Class in com.google.common.reflect
A builder for creating immutable type-to-instance maps.
IMPLICIT_BIT - Static variable in class com.google.common.math.DoubleUtils
The implicit 1 bit that is omitted in significands of normal doubles.
ImprovedAbstractMap() - Constructor for class com.google.common.collect.Maps.ImprovedAbstractMap
 
ImprovedAbstractSet() - Constructor for class com.google.common.collect.Sets.ImprovedAbstractSet
 
in(Collection<? extends T>) - Static method in class com.google.common.base.Predicates
Returns a predicate that evaluates to true if the object reference being tested is a member of the given collection.
in - Variable in class com.google.common.io.MultiInputStream
 
InactiveComparisonChain(int) - Constructor for class com.google.common.collect.ComparisonChain.InactiveComparisonChain
 
IncomparableValueException(Object) - Constructor for exception com.google.common.collect.Ordering.IncomparableValueException
 
inCompletionOrder(Iterable<? extends ListenableFuture<? extends T>>) - Static method in class com.google.common.util.concurrent.Futures
Returns a list of delegate futures that correspond to the futures received in the order that they complete.
increment() - Method in interface com.google.common.cache.LongAddable
 
increment() - Method in class com.google.common.cache.LongAddables.PureJavaLongAddable
 
increment() - Method in class com.google.common.cache.LongAdder
Equivalent to add(1).
increment(InetAddress) - Static method in class com.google.common.net.InetAddresses
Returns a new InetAddress that is one more than the passed in address.
incrementAndGet(K) - Method in class com.google.common.util.concurrent.AtomicLongMap
Increments by one the value currently associated with key, and returns the new value.
incrementBy(AbstractCache.StatsCounter) - Method in class com.google.common.cache.AbstractCache.SimpleStatsCounter
Increments all counters by the values in other.
index(List<E>) - Static method in class com.google.common.collect.ArrayTable
 
index(Function<? super E, K>) - Method in class com.google.common.collect.FluentIterable
Creates an index ImmutableListMultimap that contains the results of applying a specified function to each item in this FluentIterable of values.
index(Iterable<V>, Function<? super V, K>) - Static method in class com.google.common.collect.Multimaps
Creates an index ImmutableListMultimap that contains the results of applying a specified function to each item in an Iterable of values.
index(Iterator<V>, Function<? super V, K>) - Static method in class com.google.common.collect.Multimaps
Creates an index ImmutableListMultimap that contains the results of applying a specified function to each item in an Iterator of values.
index - Variable in class com.google.common.util.concurrent.Striped.SmallLazyStriped.ArrayReference
 
indexFor(Object) - Method in class com.google.common.util.concurrent.Striped
Returns the index to which the given key is mapped, so that getAt(indexFor(key)) == get(key).
indexFor(Object) - Method in class com.google.common.util.concurrent.Striped.PowerOfTwoStriped
 
indexIn(CharSequence) - Method in class com.google.common.base.CharMatcher
Returns the index of the first matching character in a character sequence, or -1 if no matching character is present.
indexIn(CharSequence, int) - Method in class com.google.common.base.CharMatcher
Returns the index of the first matching character in a character sequence, starting from a given position, or -1 if no character matches after that position.
indexOf(Object) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedList
 
indexOf(Object) - Method in class com.google.common.collect.DescendingImmutableSortedSet
 
indexOf(Object) - Method in class com.google.common.collect.EmptyContiguousSet
 
indexOf(Object) - Method in class com.google.common.collect.EmptyImmutableSortedSet
 
indexOf(Object) - Method in class com.google.common.collect.ForwardingList
 
indexOf(Object) - Method in class com.google.common.collect.ImmutableList
 
indexOf(Object) - Method in class com.google.common.collect.ImmutableList.ReverseImmutableList
 
indexOf(Object) - Method in class com.google.common.collect.ImmutableRangeSet.AsSet
 
indexOf(Object) - Method in class com.google.common.collect.ImmutableSortedAsList
 
indexOf(Object) - Method in class com.google.common.collect.ImmutableSortedSet
Returns the position of an element within the set, or -1 if not present.
indexOf(Iterable<T>, Predicate<? super T>) - Static method in class com.google.common.collect.Iterables
Returns the index in iterable of the first element that satisfies the provided predicate, or -1 if the Iterable has no such elements.
indexOf(Iterator<T>, Predicate<? super T>) - Static method in class com.google.common.collect.Iterators
Returns the index in iterator of the first element that satisfies the provided predicate, or -1 if the Iterator has no such elements.
indexOf(Object) - Method in class com.google.common.collect.Lists.StringAsImmutableList
 
indexOf(Object) - Method in class com.google.common.collect.RegularContiguousSet
 
indexOf(Object) - Method in class com.google.common.collect.RegularImmutableList
 
indexOf(Object) - Method in class com.google.common.collect.RegularImmutableSortedSet
 
indexOf(Object) - Method in class com.google.common.collect.SingletonImmutableList
 
indexOf(Object) - Method in class com.google.common.collect.Synchronized.SynchronizedList
 
indexOf(Object) - Method in class com.google.common.primitives.Booleans.BooleanArrayAsList
 
indexOf(boolean[], boolean) - Static method in class com.google.common.primitives.Booleans
Returns the index of the first appearance of the value target in array.
indexOf(boolean[], boolean, int, int) - Static method in class com.google.common.primitives.Booleans
 
indexOf(boolean[], boolean[]) - Static method in class com.google.common.primitives.Booleans
Returns the start position of the first occurrence of the specified target within array, or -1 if there is no such occurrence.
indexOf(Object) - Method in class com.google.common.primitives.Bytes.ByteArrayAsList
 
indexOf(byte[], byte) - Static method in class com.google.common.primitives.Bytes
Returns the index of the first appearance of the value target in array.
indexOf(byte[], byte, int, int) - Static method in class com.google.common.primitives.Bytes
 
indexOf(byte[], byte[]) - Static method in class com.google.common.primitives.Bytes
Returns the start position of the first occurrence of the specified target within array, or -1 if there is no such occurrence.
indexOf(Object) - Method in class com.google.common.primitives.Chars.CharArrayAsList
 
indexOf(char[], char) - Static method in class com.google.common.primitives.Chars
Returns the index of the first appearance of the value target in array.
indexOf(char[], char, int, int) - Static method in class com.google.common.primitives.Chars
 
indexOf(char[], char[]) - Static method in class com.google.common.primitives.Chars
Returns the start position of the first occurrence of the specified target within array, or -1 if there is no such occurrence.
indexOf(Object) - Method in class com.google.common.primitives.Doubles.DoubleArrayAsList
 
indexOf(double[], double) - Static method in class com.google.common.primitives.Doubles
Returns the index of the first appearance of the value target in array.
indexOf(double[], double, int, int) - Static method in class com.google.common.primitives.Doubles
 
indexOf(double[], double[]) - Static method in class com.google.common.primitives.Doubles
Returns the start position of the first occurrence of the specified target within array, or -1 if there is no such occurrence.
indexOf(Object) - Method in class com.google.common.primitives.Floats.FloatArrayAsList
 
indexOf(float[], float) - Static method in class com.google.common.primitives.Floats
Returns the index of the first appearance of the value target in array.
indexOf(float[], float, int, int) - Static method in class com.google.common.primitives.Floats
 
indexOf(float[], float[]) - Static method in class com.google.common.primitives.Floats
Returns the start position of the first occurrence of the specified target within array, or -1 if there is no such occurrence.
indexOf(int[], int) - Static method in class com.google.common.primitives.Ints
Returns the index of the first appearance of the value target in array.
indexOf(int[], int, int, int) - Static method in class com.google.common.primitives.Ints
 
indexOf(int[], int[]) - Static method in class com.google.common.primitives.Ints
Returns the start position of the first occurrence of the specified target within array, or -1 if there is no such occurrence.
indexOf(Object) - Method in class com.google.common.primitives.Ints.IntArrayAsList
 
indexOf(long[], long) - Static method in class com.google.common.primitives.Longs
Returns the index of the first appearance of the value target in array.
indexOf(long[], long, int, int) - Static method in class com.google.common.primitives.Longs
 
indexOf(long[], long[]) - Static method in class com.google.common.primitives.Longs
Returns the start position of the first occurrence of the specified target within array, or -1 if there is no such occurrence.
indexOf(Object) - Method in class com.google.common.primitives.Longs.LongArrayAsList
 
indexOf(short[], short) - Static method in class com.google.common.primitives.Shorts
Returns the index of the first appearance of the value target in array.
indexOf(short[], short, int, int) - Static method in class com.google.common.primitives.Shorts
 
indexOf(short[], short[]) - Static method in class com.google.common.primitives.Shorts
Returns the start position of the first occurrence of the specified target within array, or -1 if there is no such occurrence.
indexOf(Object) - Method in class com.google.common.primitives.Shorts.ShortArrayAsList
 
indexOfImpl(List<?>, Object) - Static method in class com.google.common.collect.Lists
An implementation of List.indexOf(Object).
InetAddresses - Class in com.google.common.net
Static utility methods pertaining to InetAddress instances.
InetAddresses() - Constructor for class com.google.common.net.InetAddresses
 
InetAddresses.TeredoInfo - Class in com.google.common.net
A simple immutable data class to encapsulate the information to be found in a Teredo address.
inferDistinctElements(Iterable<?>) - Static method in class com.google.common.collect.Multisets
Returns the expected number of distinct elements given the specified elements.
inferKeyType(Map<K, ?>) - Static method in class com.google.common.collect.EnumBiMap
 
inferValueType(Map<?, V>) - Static method in class com.google.common.collect.EnumBiMap
 
inheritableThreadLocals - Static variable in class com.google.common.base.internal.Finalizer
 
init(int) - Method in class com.google.common.collect.HashBiMap
 
init(Executor) - Method in class com.google.common.util.concurrent.Futures.CombinedFuture
Must be called at the end of the constructor.
initialCapacity - Variable in class com.google.common.cache.CacheBuilder
 
initialCapacity(int) - Method in class com.google.common.cache.CacheBuilder
Sets the minimum total size for the internal hash tables.
initialCapacity - Variable in class com.google.common.cache.CacheBuilderSpec
 
initialCapacity(int) - Method in class com.google.common.collect.GenericMapMaker
Deprecated.
initialCapacity - Variable in class com.google.common.collect.MapMaker
 
initialCapacity(int) - Method in class com.google.common.collect.MapMaker
Sets the minimum total size for the internal hash tables.
InitialCapacityParser() - Constructor for class com.google.common.cache.CacheBuilderSpec.InitialCapacityParser
 
initialize(Class<?>...) - Static method in class com.google.common.reflect.Reflection
Ensures that the given classes are initialized, as described in JLS Section 12.4.2.
initialized - Variable in class com.google.common.base.Suppliers.MemoizingSupplier
 
initialQueueSize(int, int, Iterable<?>) - Static method in class com.google.common.collect.MinMaxPriorityQueue
 
initTable(AtomicReferenceArray<LocalCache.ReferenceEntry<K, V>>) - Method in class com.google.common.cache.LocalCache.Segment
 
initTable(AtomicReferenceArray<MapMakerInternalMap.ReferenceEntry<K, V>>) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
 
innerNodeCode - Variable in enum com.google.thirdparty.publicsuffix.PublicSuffixType
The character used for an inner node in the trie encoding
InOrderIterator(T) - Constructor for class com.google.common.collect.BinaryTreeTraverser.InOrderIterator
 
inOrderTraversal(T) - Method in class com.google.common.collect.BinaryTreeTraverser
 
InPredicate(Collection<?>) - Constructor for class com.google.common.base.Predicates.InPredicate
 
input - Variable in class com.google.common.io.ByteStreams.ByteArrayDataInputStream
 
input - Variable in class com.google.common.net.MediaType.Tokenizer
 
inputFuture - Variable in class com.google.common.util.concurrent.Futures.ChainingListenableFuture
 
inputList - Variable in class com.google.common.collect.Collections2.OrderedPermutationCollection
 
inputList - Variable in class com.google.common.collect.Collections2.PermutationCollection
 
inputSet - Variable in class com.google.common.collect.Sets.PowerSet
 
inputSet - Variable in class com.google.common.collect.Sets.SubSet
 
InputSupplier<T> - Interface in com.google.common.io
Deprecated.
For InputSupplier<? extends InputStream>, use ByteSource instead. For InputSupplier<? extends Reader>, use CharSource. Implementations of InputSupplier that don't fall into one of those categories do not benefit from any of the methods in common.io and should use a different interface. This interface is scheduled for removal in December 2015.
inRange(char, char) - Static method in class com.google.common.base.CharMatcher
Returns a char matcher that matches any character in a given range (both endpoints are inclusive).
inRange(char, char, String) - Static method in class com.google.common.base.CharMatcher
 
insert(HashBiMap.BiEntry<K, V>) - Method in class com.google.common.collect.HashBiMap
 
insertLoadingValueReference(K, int, boolean) - Method in class com.google.common.cache.LocalCache.Segment
Returns a newly inserted LoadingValueReference, or null if the live value reference is already loading.
INSTANCE - Static variable in class com.google.common.base.Absent
 
INSTANCE - Static variable in class com.google.common.base.Converter.IdentityConverter
 
INSTANCE - Static variable in class com.google.common.base.Equivalence.Equals
 
INSTANCE - Static variable in class com.google.common.base.Equivalence.Identity
 
instance - Variable in class com.google.common.base.Suppliers.SupplierOfInstance
 
INSTANCE - Static variable in class com.google.common.collect.AllEqualOrdering
 
INSTANCE - Static variable in class com.google.common.collect.Cut.AboveAll
 
INSTANCE - Static variable in class com.google.common.collect.Cut.BelowAll
 
INSTANCE - Static variable in class com.google.common.collect.DiscreteDomain.BigIntegerDomain
 
INSTANCE - Static variable in class com.google.common.collect.DiscreteDomain.IntegerDomain
 
INSTANCE - Static variable in class com.google.common.collect.DiscreteDomain.LongDomain
 
INSTANCE - Static variable in class com.google.common.collect.EmptyImmutableBiMap
 
INSTANCE - Static variable in class com.google.common.collect.EmptyImmutableListMultimap
 
INSTANCE - Static variable in class com.google.common.collect.EmptyImmutableSet
 
INSTANCE - Static variable in class com.google.common.collect.EmptyImmutableSetMultimap
 
instance() - Static method in enum com.google.common.collect.MultimapBuilder.LinkedListSupplier
 
INSTANCE - Static variable in class com.google.common.collect.NaturalOrdering
 
INSTANCE - Static variable in class com.google.common.collect.ReverseNaturalOrdering
 
INSTANCE - Static variable in class com.google.common.collect.UsingToStringOrdering
 
INSTANCE - Static variable in class com.google.common.io.ByteSource.EmptyByteSource
 
INSTANCE - Static variable in class com.google.common.io.CharSource.EmptyCharSource
 
INSTANCE - Static variable in class com.google.common.io.CharStreams.NullWriter
 
INSTANCE - Static variable in class com.google.common.io.Closer.LoggingSuppressor
 
INSTANCE - Static variable in class com.google.common.io.Closer.SuppressingSuppressor
 
INSTANCE - Static variable in class com.google.common.primitives.Doubles.DoubleConverter
 
INSTANCE - Static variable in class com.google.common.primitives.Floats.FloatConverter
 
INSTANCE - Static variable in class com.google.common.primitives.Ints.IntConverter
 
INSTANCE - Static variable in class com.google.common.primitives.Longs.LongConverter
 
INSTANCE - Static variable in class com.google.common.primitives.Shorts.ShortConverter
 
instanceOf(Class<?>) - Static method in class com.google.common.base.Predicates
Returns a predicate that evaluates to true if the object being tested is an instance of the given class.
InstanceOfPredicate(Class<?>) - Constructor for class com.google.common.base.Predicates.InstanceOfPredicate
 
INT_MASK - Static variable in class com.google.common.primitives.UnsignedInts
 
IntArrayAsList(int[]) - Constructor for class com.google.common.primitives.Ints.IntArrayAsList
 
IntArrayAsList(int[], int, int) - Constructor for class com.google.common.primitives.Ints.IntArrayAsList
 
IntConverter() - Constructor for class com.google.common.primitives.Ints.IntConverter
 
IntegerDomain() - Constructor for class com.google.common.collect.DiscreteDomain.IntegerDomain
 
integerFunnel() - Static method in class com.google.common.hash.Funnels
Returns a funnel for integers.
IntegerFunnel() - Constructor for enum com.google.common.hash.Funnels.IntegerFunnel
 
IntegerParser() - Constructor for class com.google.common.cache.CacheBuilderSpec.IntegerParser
 
integers() - Static method in class com.google.common.collect.DiscreteDomain
Returns the discrete domain for values of type Integer.
interfaces() - Method in class com.google.common.reflect.TypeToken.ClassSet
 
interfaces - Variable in class com.google.common.reflect.TypeToken.InterfaceSet
 
interfaces() - Method in class com.google.common.reflect.TypeToken.InterfaceSet
 
interfaces() - Method in class com.google.common.reflect.TypeToken.TypeSet
Returns the types that are interfaces implemented by this type.
InterfaceSet(TypeToken<T>.TypeSet) - Constructor for class com.google.common.reflect.TypeToken.InterfaceSet
 
intern(E) - Method in interface com.google.common.collect.Interner
Chooses and returns the representative instance for any of a collection of instances that are equal to each other.
intern(E) - Method in class com.google.common.collect.Interners.WeakInterner
 
internalLock - Variable in class com.google.common.util.concurrent.SerializingExecutor
 
internalReset(long) - Method in class com.google.common.cache.Striped64
Sets base and all cells to the given value.
Interner<E> - Interface in com.google.common.collect
Provides equivalent behavior to String.intern() for other immutable types.
interner - Variable in class com.google.common.collect.Interners.InternerFunction
 
InternerFunction(Interner<E>) - Constructor for class com.google.common.collect.Interners.InternerFunction
 
Interners - Class in com.google.common.collect
Contains static methods pertaining to instances of Interner.
Interners() - Constructor for class com.google.common.collect.Interners
 
Interners.InternerFunction<E> - Class in com.google.common.collect
 
Interners.WeakInterner<E> - Class in com.google.common.collect
 
Interners.WeakInterner.Dummy - Enum in com.google.common.collect
 
InternetDomainName - Class in com.google.common.net
An immutable well-formed internet domain name, such as com or foo.co.uk.
InternetDomainName(String) - Constructor for class com.google.common.net.InternetDomainName
Constructor used to implement InternetDomainName.from(String), and from subclasses.
INTERRUPTED - Static variable in class com.google.common.util.concurrent.AbstractFuture.Sync
 
interruptTask() - Method in class com.google.common.util.concurrent.AbstractFuture
Subclasses can override this method to implement interruption of the future's computation.
intersect(GeneralRange<T>) - Method in class com.google.common.collect.GeneralRange
Returns the intersection of the two ranges, or an empty range if their intersection is empty.
intersection(ContiguousSet<C>) - Method in class com.google.common.collect.ContiguousSet
Returns the set of values that are contained in both this set and the other.
intersection(ContiguousSet<C>) - Method in class com.google.common.collect.EmptyContiguousSet
 
intersection(Multiset<E>, Multiset<?>) - Static method in class com.google.common.collect.Multisets
Returns an unmodifiable view of the intersection of two multisets.
intersection(Range<C>) - Method in class com.google.common.collect.Range
Returns the maximal range enclosed by both this range and connectedRange, if such a range exists.
intersection(ContiguousSet<C>) - Method in class com.google.common.collect.RegularContiguousSet
 
intersection(Set<E>, Set<?>) - Static method in class com.google.common.collect.Sets
Returns an unmodifiable view of the intersection of two sets.
intersectionInCurrentDomain(Range<C>) - Method in class com.google.common.collect.RegularContiguousSet
 
intersectRanges(Range<C>) - Method in class com.google.common.collect.ImmutableRangeSet
Returns a list containing the nonempty intersections of range with the ranges in this range set.
IntHashCode(int) - Constructor for class com.google.common.hash.HashCode.IntHashCode
 
IntMath - Class in com.google.common.math
A class for arithmetic on values of type int.
IntMath() - Constructor for class com.google.common.math.IntMath
 
Ints - Class in com.google.common.primitives
Static utility methods pertaining to int primitives, that are not already found in either Integer or Arrays.
Ints() - Constructor for class com.google.common.primitives.Ints
 
Ints.IntArrayAsList - Class in com.google.common.primitives
 
Ints.IntConverter - Class in com.google.common.primitives
 
Ints.LexicographicalComparator - Enum in com.google.common.primitives
 
intValue() - Method in class com.google.common.cache.LongAdder
Returns the LongAdder.sum() as an int after a narrowing primitive conversion.
intValue() - Method in class com.google.common.primitives.UnsignedInteger
Returns the value of this UnsignedInteger as an int.
intValue() - Method in class com.google.common.primitives.UnsignedLong
Returns the value of this UnsignedLong as an int.
intValue() - Method in class com.google.common.util.concurrent.AtomicDouble
Returns the value of this AtomicDouble as an int after a narrowing primitive conversion.
INVALID_ENTRY_MESSAGE - Static variable in class com.google.common.base.Splitter.MapSplitter
 
invalidate(Object) - Method in class com.google.common.cache.AbstractCache
 
invalidate(Object) - Method in interface com.google.common.cache.Cache
Discards any cached value for key key.
invalidate(Object) - Method in class com.google.common.cache.ForwardingCache
 
invalidate(Object) - Method in class com.google.common.cache.LocalCache.LocalManualCache
 
invalidateAll(Iterable<?>) - Method in class com.google.common.cache.AbstractCache
 
invalidateAll() - Method in class com.google.common.cache.AbstractCache
 
invalidateAll(Iterable<?>) - Method in interface com.google.common.cache.Cache
Discards any cached values for keys keys.
invalidateAll() - Method in interface com.google.common.cache.Cache
Discards all entries in the cache.
invalidateAll(Iterable<?>) - Method in class com.google.common.cache.ForwardingCache
 
invalidateAll() - Method in class com.google.common.cache.ForwardingCache
 
invalidateAll(Iterable<?>) - Method in class com.google.common.cache.LocalCache
 
invalidateAll(Iterable<?>) - Method in class com.google.common.cache.LocalCache.LocalManualCache
 
invalidateAll() - Method in class com.google.common.cache.LocalCache.LocalManualCache
 
InvalidCacheLoadException(String) - Constructor for exception com.google.common.cache.CacheLoader.InvalidCacheLoadException
 
inverse - Variable in class com.google.common.collect.AbstractBiMap
 
inverse() - Method in class com.google.common.collect.AbstractBiMap
 
Inverse(Map<K, V>, AbstractBiMap<V, K>) - Constructor for class com.google.common.collect.AbstractBiMap.Inverse
 
inverse() - Method in interface com.google.common.collect.BiMap
Returns the inverse view of this bimap, which maps each of this bimap's values to its associated key.
inverse() - Method in class com.google.common.collect.EmptyImmutableBiMap
 
inverse - Variable in class com.google.common.collect.HashBiMap
 
inverse() - Method in class com.google.common.collect.HashBiMap
 
Inverse() - Constructor for class com.google.common.collect.HashBiMap.Inverse
 
inverse() - Method in class com.google.common.collect.HashBiMap.Inverse
 
inverse() - Method in class com.google.common.collect.ImmutableBiMap
Returns the inverse view of this bimap, which maps each of this bimap's values to its associated key.
inverse - Variable in class com.google.common.collect.ImmutableListMultimap
 
inverse() - Method in class com.google.common.collect.ImmutableListMultimap
Returns an immutable multimap which is the inverse of this one.
inverse() - Method in class com.google.common.collect.ImmutableMultimap
Returns an immutable multimap which is the inverse of this one.
inverse - Variable in class com.google.common.collect.ImmutableSetMultimap
 
inverse() - Method in class com.google.common.collect.ImmutableSetMultimap
Returns an immutable multimap which is the inverse of this one.
inverse - Variable in class com.google.common.collect.MapConstraints.ConstrainedBiMap
 
inverse() - Method in class com.google.common.collect.MapConstraints.ConstrainedBiMap
 
inverse - Variable in class com.google.common.collect.Maps.FilteredEntryBiMap
 
inverse() - Method in class com.google.common.collect.Maps.FilteredEntryBiMap
 
inverse - Variable in class com.google.common.collect.Maps.UnmodifiableBiMap
 
inverse() - Method in class com.google.common.collect.Maps.UnmodifiableBiMap
 
inverse - Variable in class com.google.common.collect.RegularImmutableBiMap
 
inverse() - Method in class com.google.common.collect.RegularImmutableBiMap
 
Inverse() - Constructor for class com.google.common.collect.RegularImmutableBiMap.Inverse
 
inverse() - Method in class com.google.common.collect.RegularImmutableBiMap.Inverse
 
inverse - Variable in class com.google.common.collect.SingletonImmutableBiMap
 
inverse() - Method in class com.google.common.collect.SingletonImmutableBiMap
 
inverse - Variable in class com.google.common.collect.Synchronized.SynchronizedBiMap
 
inverse() - Method in class com.google.common.collect.Synchronized.SynchronizedBiMap
 
InverseConstraint(MapConstraint<? super V, ? super K>) - Constructor for class com.google.common.collect.MapConstraints.InverseConstraint
 
InverseEntrySet() - Constructor for class com.google.common.collect.RegularImmutableBiMap.Inverse.InverseEntrySet
 
InverseKeySet() - Constructor for class com.google.common.collect.HashBiMap.Inverse.InverseKeySet
 
inversePredicate(Predicate<? super Map.Entry<K, V>>) - Static method in class com.google.common.collect.Maps.FilteredEntryBiMap
 
InverseSerializedForm(HashBiMap<K, V>) - Constructor for class com.google.common.collect.HashBiMap.InverseSerializedForm
 
InverseSerializedForm(ImmutableBiMap<K, V>) - Constructor for class com.google.common.collect.RegularImmutableBiMap.InverseSerializedForm
 
invert() - Method in class com.google.common.collect.ImmutableListMultimap
 
invert() - Method in class com.google.common.collect.ImmutableSetMultimap
 
invertFrom(Multimap<? extends V, ? extends K>, M) - Static method in class com.google.common.collect.Multimaps
Copies each key-value mapping in source into dest, with its key and value reversed.
INVISIBLE - Static variable in class com.google.common.base.CharMatcher
Determines whether a character is invisible; that is, if its Unicode category is any of SPACE_SEPARATOR, LINE_SEPARATOR, PARAGRAPH_SEPARATOR, CONTROL, FORMAT, SURROGATE, and PRIVATE_USE according to ICU4J.
Invokable<T,R> - Class in com.google.common.reflect
Wrapper around either a Method or a Constructor.
Invokable(M) - Constructor for class com.google.common.reflect.Invokable
 
Invokable.ConstructorInvokable<T> - Class in com.google.common.reflect
 
Invokable.MethodInvokable<T> - Class in com.google.common.reflect
 
invoke(Object, Method, Object[]) - Method in class com.google.common.reflect.AbstractInvocationHandler
invoke(T, Object...) - Method in class com.google.common.reflect.Invokable
Invokes with receiver as 'this' and args passed to the underlying method and returns the return value; or calls the underlying constructor with args and returns the constructed instance.
invokeAll(Collection<? extends Callable<T>>) - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
invokeAll(Collection<? extends Callable<T>>) - Method in interface com.google.common.util.concurrent.ListeningExecutorService
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in interface com.google.common.util.concurrent.ListeningExecutorService
invokeAll(Collection<? extends Callable<T>>) - Method in class com.google.common.util.concurrent.WrappingExecutorService
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.google.common.util.concurrent.WrappingExecutorService
 
invokeAny(Collection<? extends Callable<T>>) - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
invokeAny(Collection<? extends Callable<T>>) - Method in class com.google.common.util.concurrent.WrappingExecutorService
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.google.common.util.concurrent.WrappingExecutorService
 
invokeAnyImpl(ListeningExecutorService, Collection<? extends Callable<T>>, boolean, long) - Static method in class com.google.common.util.concurrent.MoreExecutors
An implementation of ExecutorService.invokeAny(java.util.Collection<? extends java.util.concurrent.Callable<T>>) for ListeningExecutorService implementations.
invokeInternal(Object, Object[]) - Method in class com.google.common.reflect.Invokable.ConstructorInvokable
 
invokeInternal(Object, Object[]) - Method in class com.google.common.reflect.Invokable
 
invokeInternal(Object, Object[]) - Method in class com.google.common.reflect.Invokable.MethodInvokable
 
ipStringToBytes(String) - Static method in class com.google.common.net.InetAddresses
 
IPV4_PART_COUNT - Static variable in class com.google.common.net.InetAddresses
 
IPV6_PART_COUNT - Static variable in class com.google.common.net.InetAddresses
 
is(char) - Static method in class com.google.common.base.CharMatcher
Returns a char matcher that matches only one specified character.
is(MediaType) - Method in class com.google.common.net.MediaType
Returns true if this instance falls within the range (as defined by the HTTP Accept header) given by the argument according to three criteria: The type of the argument is the wildcard or equal to the type of this instance.
is6to4Address(Inet6Address) - Static method in class com.google.common.net.InetAddresses
Evaluates whether the argument is a 6to4 address.
IS_TOP_LEVEL - Static variable in class com.google.common.reflect.ClassPath
 
isAbstract() - Method in class com.google.common.reflect.Element
Returns true if the method is abstract.
isAccessible() - Method in class com.google.common.reflect.Element
 
isAcquiredByCurrentThread() - Method in interface com.google.common.util.concurrent.CycleDetectingLockFactory.CycleDetectingLock
 
isAcquiredByCurrentThread() - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory.CycleDetectingReentrantLock
 
isAcquiredByCurrentThread() - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory.CycleDetectingReentrantReadWriteLock
 
isActive() - Method in class com.google.common.cache.LocalCache.LoadingValueReference
 
isActive() - Method in class com.google.common.cache.LocalCache.SoftValueReference
 
isActive() - Method in class com.google.common.cache.LocalCache.StrongValueReference
 
isActive() - Method in interface com.google.common.cache.LocalCache.ValueReference
Returns true if this reference contains an active value, meaning one that is still considered present in the cache.
isActive() - Method in class com.google.common.cache.LocalCache.WeakValueReference
 
isAnnotationPresent(Class<? extends Annotation>) - Method in class com.google.common.reflect.Element
 
isAnnotationPresent(Class<? extends Annotation>) - Method in class com.google.common.reflect.Parameter
 
isAppEngine() - Static method in class com.google.common.util.concurrent.MoreExecutors
 
isArray() - Method in class com.google.common.reflect.TypeToken
Returns true if this type is known to be an array type, such as int[], T[], <? extends Map<String, Integer>[]> etc.
isAssignable(Type, Type) - Static method in class com.google.common.reflect.TypeToken
 
isAssignableBySubtypeBound(Type, WildcardType) - Static method in class com.google.common.reflect.TypeToken
 
isAssignableFrom(TypeToken<?>) - Method in class com.google.common.reflect.TypeToken
Returns true if this type is assignable from the given type.
isAssignableFrom(Type) - Method in class com.google.common.reflect.TypeToken
Check if this type is assignable from the given type.
isAssignableFromAny(Type[], Type) - Static method in class com.google.common.reflect.TypeToken
 
isAssignableFromGenericArrayType(GenericArrayType, Type) - Static method in class com.google.common.reflect.TypeToken
 
isAssignableToClass(Type, Class<?>) - Static method in class com.google.common.reflect.TypeToken
 
isAssignableToGenericArrayType(Type, GenericArrayType) - Static method in class com.google.common.reflect.TypeToken
 
isAssignableToParameterizedType(Type, ParameterizedType) - Static method in class com.google.common.reflect.TypeToken
 
isAssignableToWildcardType(Type, WildcardType) - Static method in class com.google.common.reflect.TypeToken
 
isAvailable() - Static method in class com.google.common.io.Closer.SuppressingSuppressor
 
isCancelled() - Method in class com.google.common.util.concurrent.AbstractFuture
 
isCancelled() - Method in class com.google.common.util.concurrent.AbstractFuture.Sync
isCancelled() - Method in class com.google.common.util.concurrent.ForwardingFuture
 
isCancelled() - Method in class com.google.common.util.concurrent.Futures.ImmediateCancelledFuture
 
isCancelled() - Method in class com.google.common.util.concurrent.Futures.ImmediateFuture
 
isCollected(MapMakerInternalMap.ValueReference<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Returns true if the value has been partially collected, meaning that the value is null and it is not computing.
isCompatible(BloomFilter<T>) - Method in class com.google.common.hash.BloomFilter
Determines whether a given bloom filter is compatible with this bloom filter.
isCompatIPv4Address(Inet6Address) - Static method in class com.google.common.net.InetAddresses
Evaluates whether the argument is an IPv6 "compat" address.
isComputingReference() - Method in class com.google.common.collect.ComputingConcurrentHashMap.ComputationExceptionReference
 
isComputingReference() - Method in class com.google.common.collect.ComputingConcurrentHashMap.ComputedReference
 
isComputingReference() - Method in class com.google.common.collect.ComputingConcurrentHashMap.ComputingValueReference
 
isComputingReference() - Method in class com.google.common.collect.MapMakerInternalMap.SoftValueReference
 
isComputingReference() - Method in class com.google.common.collect.MapMakerInternalMap.StrongValueReference
 
isComputingReference() - Method in interface com.google.common.collect.MapMakerInternalMap.ValueReference
Returns true if the value type is a computing reference (regardless of whether or not computation has completed).
isComputingReference() - Method in class com.google.common.collect.MapMakerInternalMap.WeakValueReference
 
isConnected(Range<C>) - Method in class com.google.common.collect.Range
Returns true if there exists a (possibly empty) range which is enclosed by both this range and other.
isDirectory() - Static method in class com.google.common.io.Files
Returns a predicate that returns the result of File.isDirectory() on input files.
isDispatching - Variable in class com.google.common.eventbus.EventBus
true if the current thread is currently dispatching an event
isDone() - Method in class com.google.common.util.concurrent.AbstractFuture
 
isDone() - Method in class com.google.common.util.concurrent.AbstractFuture.Sync
Checks if the state is AbstractFuture.Sync.COMPLETED, AbstractFuture.Sync.CANCELLED, or INTERRUPTED.
isDone() - Method in class com.google.common.util.concurrent.ForwardingFuture
 
isDone() - Method in class com.google.common.util.concurrent.Futures.ImmediateFuture
 
isEither(char, char) - Static method in class com.google.common.base.CharMatcher
 
isEmpty() - Method in class com.google.common.cache.LocalCache.AbstractCacheSet
 
isEmpty() - Method in class com.google.common.cache.LocalCache.AccessQueue
 
isEmpty() - Method in class com.google.common.cache.LocalCache
 
isEmpty() - Method in class com.google.common.cache.LocalCache.Values
 
isEmpty() - Method in class com.google.common.cache.LocalCache.WriteQueue
 
isEmpty() - Method in class com.google.common.collect.AbstractMultimap
 
isEmpty() - Method in class com.google.common.collect.AbstractMultiset
 
isEmpty() - Method in class com.google.common.collect.AbstractRangeSet
 
isEmpty() - Method in class com.google.common.collect.AbstractTable
 
isEmpty() - Method in class com.google.common.collect.ArrayTable.ArrayMap
 
isEmpty() - Method in class com.google.common.collect.ArrayTable
Always returns false.
isEmpty() - Method in class com.google.common.collect.Collections2.FilteredCollection
 
isEmpty() - Method in class com.google.common.collect.Collections2.OrderedPermutationCollection
 
isEmpty() - Method in class com.google.common.collect.Collections2.PermutationCollection
 
isEmpty() - Method in class com.google.common.collect.Collections2.TransformedCollection
 
isEmpty() - Method in class com.google.common.collect.ConcurrentHashMultiset
 
isEmpty() - Method in class com.google.common.collect.EmptyContiguousSet
 
isEmpty() - Method in class com.google.common.collect.EmptyImmutableBiMap
 
isEmpty() - Method in class com.google.common.collect.EmptyImmutableSet
 
isEmpty() - Method in class com.google.common.collect.EmptyImmutableSortedMap
 
isEmpty() - Method in class com.google.common.collect.EmptyImmutableSortedSet
 
isEmpty() - Method in class com.google.common.collect.FluentIterable
Determines whether this fluent iterable is empty.
isEmpty() - Method in class com.google.common.collect.ForwardingCollection
 
isEmpty() - Method in class com.google.common.collect.ForwardingMap
 
isEmpty() - Method in class com.google.common.collect.ForwardingMultimap
 
isEmpty() - Method in class com.google.common.collect.ForwardingTable
 
isEmpty() - Method in class com.google.common.collect.GeneralRange
 
isEmpty() - Method in class com.google.common.collect.ImmutableAsList
 
isEmpty() - Method in class com.google.common.collect.ImmutableEnumSet
 
isEmpty() - Method in class com.google.common.collect.ImmutableMap
 
isEmpty() - Method in class com.google.common.collect.ImmutableRangeSet
 
isEmpty(Iterable<?>) - Static method in class com.google.common.collect.Iterables
Determines if the given iterable contains no elements.
isEmpty() - Method in class com.google.common.collect.LinkedListMultimap
 
isEmpty() - Method in class com.google.common.collect.Lists.Partition
 
isEmpty() - Method in class com.google.common.collect.Lists.TransformingRandomAccessList
 
isEmpty() - Method in class com.google.common.collect.MapMakerInternalMap.EntrySet
 
isEmpty() - Method in class com.google.common.collect.MapMakerInternalMap.EvictionQueue
 
isEmpty() - Method in class com.google.common.collect.MapMakerInternalMap.ExpirationQueue
 
isEmpty() - Method in class com.google.common.collect.MapMakerInternalMap
 
isEmpty() - Method in class com.google.common.collect.MapMakerInternalMap.KeySet
 
isEmpty() - Method in class com.google.common.collect.MapMakerInternalMap.Values
 
isEmpty() - Method in class com.google.common.collect.Maps.AbstractFilteredMap
 
isEmpty() - Method in class com.google.common.collect.Maps.EntrySet
 
isEmpty() - Method in class com.google.common.collect.Maps.FilteredEntryNavigableMap
 
isEmpty() - Method in class com.google.common.collect.Maps.KeySet
 
isEmpty() - Method in class com.google.common.collect.Maps.Values
 
isEmpty() - Method in interface com.google.common.collect.Multimap
Returns true if this multimap contains no key-value pairs.
isEmpty() - Method in class com.google.common.collect.Multimaps.AsMap
 
isEmpty() - Method in class com.google.common.collect.Multimaps.Keys.KeysEntrySet
 
isEmpty() - Method in class com.google.common.collect.Multimaps.TransformedEntriesMultimap
 
isEmpty() - Method in class com.google.common.collect.Multisets.ElementSet
 
isEmpty() - Method in class com.google.common.collect.Range
Returns true if this range is of the form [v..v) or (v..v].
isEmpty() - Method in interface com.google.common.collect.RangeSet
Returns true if this range set contains no ranges.
isEmpty() - Method in class com.google.common.collect.RegularContiguousSet
 
isEmpty() - Method in class com.google.common.collect.RegularImmutableSortedSet
 
isEmpty() - Method in class com.google.common.collect.Sets.PowerSet
 
isEmpty() - Method in class com.google.common.collect.SingletonImmutableList
 
isEmpty() - Method in class com.google.common.collect.SingletonImmutableSet
 
isEmpty() - Method in class com.google.common.collect.StandardTable.Column.EntrySet
 
isEmpty() - Method in class com.google.common.collect.StandardTable
 
isEmpty() - Method in class com.google.common.collect.StandardTable.TableSet
 
isEmpty() - Method in class com.google.common.collect.Synchronized.SynchronizedCollection
 
isEmpty() - Method in class com.google.common.collect.Synchronized.SynchronizedMap
 
isEmpty() - Method in class com.google.common.collect.Synchronized.SynchronizedMultimap
 
isEmpty() - Method in interface com.google.common.collect.Table
Returns true if the table contains no mappings.
isEmpty() - Method in class com.google.common.collect.TreeRangeSet.RangesByUpperBound
 
isEmpty() - Method in class com.google.common.io.ByteSource.ByteArrayByteSource
 
isEmpty() - Method in class com.google.common.io.ByteSource.ConcatenatedByteSource
 
isEmpty() - Method in class com.google.common.io.ByteSource
Returns whether the source has zero bytes.
isEmpty() - Method in class com.google.common.io.ByteSource.SlicedByteSource
 
isEmpty() - Method in class com.google.common.io.CharSource.CharSequenceCharSource
 
isEmpty() - Method in class com.google.common.io.CharSource.ConcatenatedCharSource
 
isEmpty() - Method in class com.google.common.io.CharSource
Returns whether the source has zero chars.
isEmpty() - Method in class com.google.common.primitives.Booleans.BooleanArrayAsList
 
isEmpty() - Method in class com.google.common.primitives.Bytes.ByteArrayAsList
 
isEmpty() - Method in class com.google.common.primitives.Chars.CharArrayAsList
 
isEmpty() - Method in class com.google.common.primitives.Doubles.DoubleArrayAsList
 
isEmpty() - Method in class com.google.common.primitives.Floats.FloatArrayAsList
 
isEmpty() - Method in class com.google.common.primitives.Ints.IntArrayAsList
 
isEmpty() - Method in class com.google.common.primitives.Longs.LongArrayAsList
 
isEmpty() - Method in class com.google.common.primitives.Shorts.ShortArrayAsList
 
isEmpty() - Method in class com.google.common.util.concurrent.AtomicLongMap
Returns true if this map contains no key-value mappings.
IsEqualToPredicate(T) - Constructor for class com.google.common.base.Predicates.IsEqualToPredicate
 
isEvenLevel(int) - Static method in class com.google.common.collect.MinMaxPriorityQueue
 
isExpired(LocalCache.ReferenceEntry<K, V>, long) - Method in class com.google.common.cache.LocalCache
Returns true if the entry has expired.
isExpired(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap
Returns true if the entry has expired.
isExpired(MapMakerInternalMap.ReferenceEntry<K, V>, long) - Method in class com.google.common.collect.MapMakerInternalMap
Returns true if the entry has expired.
isFair() - Method in class com.google.common.util.concurrent.Monitor
Returns whether this monitor is using a fair ordering policy.
isFile() - Static method in class com.google.common.io.Files
Returns a predicate that returns the result of File.isFile() on input files.
isFinal() - Method in class com.google.common.reflect.Element
Returns true if this method is final, per Modifier.isFinal(getModifiers()).
isFinite(double) - Static method in class com.google.common.math.DoubleUtils
 
isFinite(double) - Static method in class com.google.common.primitives.Doubles
Returns true if value represents a real number.
isFinite(float) - Static method in class com.google.common.primitives.Floats
Returns true if value represents a real number.
isFull() - Method in class com.google.common.collect.DenseImmutableTable.ImmutableArrayMap
 
isHashCodeFast() - Method in class com.google.common.collect.EmptyImmutableSet
 
isHashCodeFast() - Method in class com.google.common.collect.ImmutableSet
Returns true if the hashCode() method runs quickly.
isHashCodeFast() - Method in class com.google.common.collect.RegularImmutableBiMap.Inverse.InverseEntrySet
 
isHashCodeFast() - Method in class com.google.common.collect.RegularImmutableSet
 
isHashCodeFast() - Method in class com.google.common.collect.SingletonImmutableSet
 
isHealthy() - Method in class com.google.common.util.concurrent.ServiceManager
Returns true if all services are currently in the running state.
isInetAddress(String) - Static method in class com.google.common.net.InetAddresses
Returns true if the supplied string is a valid IP string literal, false otherwise.
isIntact() - Method in class com.google.common.collect.MinMaxPriorityQueue
Returns true if the MinMax heap structure holds.
isIsatapAddress(Inet6Address) - Static method in class com.google.common.net.InetAddresses
Evaluates whether the argument is an ISATAP address.
isLessThan(Comparable<?>) - Method in class com.google.common.collect.Cut.AboveAll
 
isLessThan(C) - Method in class com.google.common.collect.Cut.AboveValue
 
isLessThan(Comparable<?>) - Method in class com.google.common.collect.Cut.BelowAll
 
isLessThan(C) - Method in class com.google.common.collect.Cut.BelowValue
 
isLessThan(C) - Method in class com.google.common.collect.Cut
 
isLive(LocalCache.ReferenceEntry<K, V>, long) - Method in class com.google.common.cache.LocalCache
This method is a convenience for testing.
isLive(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap
This method is a convenience for testing.
isLoading() - Method in class com.google.common.cache.LocalCache.LoadingValueReference
 
isLoading() - Method in class com.google.common.cache.LocalCache.SoftValueReference
 
isLoading() - Method in class com.google.common.cache.LocalCache.StrongValueReference
 
isLoading() - Method in interface com.google.common.cache.LocalCache.ValueReference
Returns true if a new value is currently loading, regardless of whether or not there is an existing value.
isLoading() - Method in class com.google.common.cache.LocalCache.WeakValueReference
 
isLowerCase(char) - Static method in class com.google.common.base.Ascii
Indicates whether c is one of the twenty-six lowercase ASCII alphabetic characters between 'a' and 'z' inclusive.
isMappedIPv4Address(String) - Static method in class com.google.common.net.InetAddresses
Evaluates whether the argument is an "IPv4 mapped" IPv6 address.
isMathematicalInteger(double) - Static method in class com.google.common.math.DoubleMath
Returns true if x represents a mathematical integer.
isMaximum(InetAddress) - Static method in class com.google.common.net.InetAddresses
Returns true if the InetAddress is either 255.255.255.255 for IPv4 or ffff:ffff:ffff:ffff:ffff:ffff:ffff:ffff for IPv6.
isNative() - Method in class com.google.common.reflect.Element
Returns true if the element is native.
isNormal(double) - Static method in class com.google.common.math.DoubleUtils
 
isNot(char) - Static method in class com.google.common.base.CharMatcher
Returns a char matcher that matches any character except the one specified.
isNull() - Static method in class com.google.common.base.Predicates
Returns a predicate that evaluates to true if the object reference being tested is null.
isNullOrEmpty(String) - Static method in class com.google.common.base.Strings
Returns true if the given string is null or is the empty string.
ISO_8859_1 - Static variable in class com.google.common.base.Charsets
ISO-8859-1: ISO Latin Alphabet Number 1 (ISO-LATIN-1).
isOccupied() - Method in class com.google.common.util.concurrent.Monitor
Returns whether this monitor is occupied by any thread.
isOccupiedByCurrentThread() - Method in class com.google.common.util.concurrent.Monitor
Returns whether the current thread is occupying this monitor (has entered more times than it has left).
isOrdered(Iterable<? extends T>) - Method in class com.google.common.collect.Ordering
Returns true if each element in iterable after the first is greater than or equal to the element that preceded it, according to this ordering.
isOverridable() - Method in class com.google.common.reflect.Invokable.ConstructorInvokable
 
isOverridable() - Method in class com.google.common.reflect.Invokable
Returns true if this is an overridable method.
isOverridable() - Method in class com.google.common.reflect.Invokable.MethodInvokable
 
isPackagePrivate() - Method in class com.google.common.reflect.Element
Returns true if the element is package-private.
isPartialView() - Method in class com.google.common.collect.DenseImmutableTable.Column
 
isPartialView() - Method in class com.google.common.collect.DenseImmutableTable.ColumnMap
 
isPartialView() - Method in class com.google.common.collect.DenseImmutableTable.Row
 
isPartialView() - Method in class com.google.common.collect.DenseImmutableTable.RowMap
 
isPartialView() - Method in class com.google.common.collect.DescendingImmutableSortedMultiset
 
isPartialView() - Method in class com.google.common.collect.DescendingImmutableSortedSet
 
isPartialView() - Method in class com.google.common.collect.EmptyContiguousSet
 
isPartialView() - Method in class com.google.common.collect.EmptyImmutableBiMap
 
isPartialView() - Method in class com.google.common.collect.EmptyImmutableSet
 
isPartialView() - Method in class com.google.common.collect.EmptyImmutableSortedMap
 
isPartialView() - Method in class com.google.common.collect.EmptyImmutableSortedMultiset
 
isPartialView() - Method in class com.google.common.collect.EmptyImmutableSortedSet
 
isPartialView() - Method in class com.google.common.collect.ImmutableAsList
 
isPartialView() - Method in class com.google.common.collect.ImmutableCollection
Returns true if this immutable collection's implementation contains references to user-created objects that aren't accessible via this collection's methods.
isPartialView() - Method in class com.google.common.collect.ImmutableEnumMap
 
isPartialView() - Method in class com.google.common.collect.ImmutableEnumSet
 
isPartialView() - Method in class com.google.common.collect.ImmutableList.ReverseImmutableList
 
isPartialView() - Method in class com.google.common.collect.ImmutableList.SubList
 
isPartialView() - Method in class com.google.common.collect.ImmutableMap
 
isPartialView() - Method in class com.google.common.collect.ImmutableMap.MapViewOfValuesAsSingletonSets
 
isPartialView() - Method in class com.google.common.collect.ImmutableMapEntrySet
 
isPartialView() - Method in class com.google.common.collect.ImmutableMapKeySet
 
isPartialView() - Method in class com.google.common.collect.ImmutableMapValues
 
isPartialView() - Method in class com.google.common.collect.ImmutableMultimap.EntryCollection
 
isPartialView() - Method in class com.google.common.collect.ImmutableMultimap
Returns true if this immutable multimap's implementation contains references to user-created objects that aren't accessible via this multimap's methods.
isPartialView() - Method in class com.google.common.collect.ImmutableMultimap.Keys
 
isPartialView() - Method in class com.google.common.collect.ImmutableMultimap.Values
 
isPartialView() - Method in class com.google.common.collect.ImmutableMultiset.EntrySet
 
isPartialView() - Method in class com.google.common.collect.ImmutableRangeSet.AsSet
 
isPartialView() - Method in class com.google.common.collect.ImmutableRangeSet.ComplementRanges
 
isPartialView() - Method in class com.google.common.collect.ImmutableRangeSet
Returns true if this immutable range set's implementation contains references to user-created objects that aren't accessible via this range set's methods.
isPartialView() - Method in class com.google.common.collect.ImmutableSetMultimap.EntrySet
 
isPartialView() - Method in class com.google.common.collect.ImmutableSortedMap
 
isPartialView() - Method in class com.google.common.collect.Lists.StringAsImmutableList
 
isPartialView() - Method in class com.google.common.collect.RegularContiguousSet
 
isPartialView() - Method in class com.google.common.collect.RegularImmutableBiMap.Inverse
 
isPartialView() - Method in class com.google.common.collect.RegularImmutableBiMap
 
isPartialView() - Method in class com.google.common.collect.RegularImmutableList
 
isPartialView() - Method in class com.google.common.collect.RegularImmutableMap
 
isPartialView() - Method in class com.google.common.collect.RegularImmutableMultiset
 
isPartialView() - Method in class com.google.common.collect.RegularImmutableSet
 
isPartialView() - Method in class com.google.common.collect.RegularImmutableSortedMultiset
 
isPartialView() - Method in class com.google.common.collect.RegularImmutableSortedSet
 
isPartialView() - Method in class com.google.common.collect.RegularImmutableTable.CellSet
 
isPartialView() - Method in class com.google.common.collect.RegularImmutableTable.Values
 
isPartialView() - Method in class com.google.common.collect.SingletonImmutableBiMap
 
isPartialView() - Method in class com.google.common.collect.SingletonImmutableList
 
isPartialView() - Method in class com.google.common.collect.SingletonImmutableSet
 
isPermutation(List<?>, List<?>) - Static method in class com.google.common.collect.Collections2
Returns true if the second list is a permutation of the first.
isPositiveInt(long) - Static method in class com.google.common.collect.Collections2
 
isPowerOfTwo(BigInteger) - Static method in class com.google.common.math.BigIntegerMath
Returns true if x represents a power of two.
isPowerOfTwo(double) - Static method in class com.google.common.math.DoubleMath
Returns true if x is exactly equal to 2^k for some finite integer k.
isPowerOfTwo(int) - Static method in class com.google.common.math.IntMath
Returns true if x represents a power of two.
isPowerOfTwo(long) - Static method in class com.google.common.math.LongMath
Returns true if x represents a power of two.
isPresent() - Method in class com.google.common.base.Absent
 
isPresent() - Method in class com.google.common.base.Optional
Returns true if this holder contains a (non-null) instance.
isPresent() - Method in class com.google.common.base.Present
 
isPrimitive() - Method in class com.google.common.reflect.TypeToken
Returns true if this type is one of the nine primitive types (including void).
isPrivate() - Method in class com.google.common.reflect.Element
Returns true if the element is private.
isProtected() - Method in class com.google.common.reflect.Element
Returns true if the element is protected.
isProxyOfSameInterfaces(Object, Class<?>) - Static method in class com.google.common.reflect.AbstractInvocationHandler
 
isPublic() - Method in class com.google.common.reflect.Element
Returns true if the element is public.
isPublicSuffix() - Method in class com.google.common.net.InternetDomainName
Indicates whether this domain name represents a public suffix, as defined by the Mozilla Foundation's Public Suffix List (PSL).
isRecordingStats() - Method in class com.google.common.cache.CacheBuilder
 
isRunning - Variable in class com.google.common.base.Stopwatch
 
isRunning() - Method in class com.google.common.base.Stopwatch
Returns true if Stopwatch.start() has been called on this stopwatch, and Stopwatch.stop() has not been called since the last call to start().
isRunning() - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
 
isRunning() - Method in class com.google.common.util.concurrent.AbstractIdleService
 
isRunning() - Method in class com.google.common.util.concurrent.AbstractScheduledService
 
isRunning() - Method in class com.google.common.util.concurrent.AbstractService
 
isRunning() - Method in interface com.google.common.util.concurrent.Service
Returns true if this service is running.
isSatisfied() - Method in class com.google.common.util.concurrent.Monitor.Guard
Evaluates this guard's boolean condition.
isSatisfied(Monitor.Guard) - Method in class com.google.common.util.concurrent.Monitor
Exactly like guard.isSatisfied(), but in addition signals all waiting threads in the (hopefully unlikely) event that isSatisfied() throws.
isSet() - Method in class com.google.common.util.concurrent.AsyncSettableFuture
Returns true if this future has been (possibly asynchronously) set.
isShutdown() - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
isShutdown() - Method in class com.google.common.util.concurrent.MoreExecutors.DirectExecutorService
 
isShutdown() - Method in class com.google.common.util.concurrent.MoreExecutors.ListeningDecorator
 
isShutdown() - Method in class com.google.common.util.concurrent.WrappingExecutorService
 
isSmall(int, int) - Static method in class com.google.common.base.CharMatcher
 
isStartable - Variable in class com.google.common.util.concurrent.AbstractService
 
isStatic() - Method in class com.google.common.reflect.Element
Returns true if the element is static.
isStoppable - Variable in class com.google.common.util.concurrent.AbstractService
 
isStopped - Variable in class com.google.common.util.concurrent.AbstractService
 
isStrictlyOrdered(Iterable<? extends T>) - Method in class com.google.common.collect.Ordering
Returns true if each element in iterable after the first is strictly greater than the element that preceded it, according to this ordering.
isSynchronized() - Method in class com.google.common.reflect.Element
Returns true if the method is synchronized.
isSynthetic() - Method in class com.google.common.reflect.Element
 
isTeredoAddress(Inet6Address) - Static method in class com.google.common.net.InetAddresses
Evaluates whether the argument is a Teredo address.
isTerminal() - Method in enum com.google.common.util.concurrent.Service.State
Returns true if this state is terminal.
isTerminated() - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
isTerminated() - Method in class com.google.common.util.concurrent.MoreExecutors.DirectExecutorService
 
isTerminated() - Method in class com.google.common.util.concurrent.MoreExecutors.ListeningDecorator
 
isTerminated() - Method in class com.google.common.util.concurrent.WrappingExecutorService
 
isThreadScheduled - Variable in class com.google.common.util.concurrent.ListenerCallQueue
 
isThreadScheduled - Variable in class com.google.common.util.concurrent.SerializingExecutor
We explicitly keep track of if the TaskRunner is currently scheduled to run.
isTopPrivateDomain() - Method in class com.google.common.net.InternetDomainName
Indicates whether this domain name is composed of exactly one subdomain component followed by a public suffix.
isTransient() - Method in class com.google.common.reflect.Element
Returns true if the field is transient.
isUnderPublicSuffix() - Method in class com.google.common.net.InternetDomainName
Indicates whether this domain name ends in a public suffix, while not being a public suffix itself.
isUpperCase(char) - Static method in class com.google.common.base.Ascii
Indicates whether c is one of the twenty-six uppercase ASCII alphabetic characters between 'A' and 'Z' inclusive.
isUriInetAddress(String) - Static method in class com.google.common.net.InetAddresses
Returns true if the supplied string is a valid URI IP string literal, false otherwise.
isValid(String) - Static method in class com.google.common.net.HostSpecifier
Determines whether specifier represents a valid HostSpecifier as described in the documentation for HostSpecifier.fromValid(String).
isValid(String) - Static method in class com.google.common.net.InternetDomainName
Indicates whether the argument is a syntactically valid domain name using lenient validation.
isValidPaddingStartPosition(int) - Method in class com.google.common.io.BaseEncoding.Alphabet
 
isValidPort(int) - Static method in class com.google.common.net.HostAndPort
Return true for valid port numbers.
isVarArgs() - Method in class com.google.common.reflect.Invokable.ConstructorInvokable
 
isVarArgs() - Method in class com.google.common.reflect.Invokable
Returns true if this was declared to take a variable number of arguments.
isVarArgs() - Method in class com.google.common.reflect.Invokable.MethodInvokable
 
isVolatile() - Method in class com.google.common.reflect.Element
Returns true if the field is volatile.
isWellFormed(byte[]) - Static method in class com.google.common.base.Utf8
Returns true if bytes is a well-formed UTF-8 byte sequence according to Unicode 6.0.
isWellFormed(byte[], int, int) - Static method in class com.google.common.base.Utf8
Returns whether the given byte array slice is a well-formed UTF-8 byte sequence, as defined by Utf8.isWellFormed(byte[]).
isWellFormedSlowPath(byte[], int, int) - Static method in class com.google.common.base.Utf8
 
isWrapper() - Method in class com.google.common.reflect.TypeToken
 
isWrapperType(Class<?>) - Static method in class com.google.common.primitives.Primitives
Returns true if type is one of the nine primitive-wrapper types, such as Integer.
it - Variable in class com.google.common.io.MultiInputStream
 
it - Variable in class com.google.common.io.MultiReader
 
iterable(Object, Object, Object[]) - Static method in class com.google.common.base.Joiner
 
iterable - Variable in class com.google.common.collect.FluentIterable
 
iterable - Variable in class com.google.common.collect.Iterables.UnmodifiableIterable
 
Iterables - Class in com.google.common.collect
This class contains static utility methods that operate on or return objects of type Iterable.
Iterables() - Constructor for class com.google.common.collect.Iterables
 
Iterables.ConsumingQueueIterator<T> - Class in com.google.common.collect
 
Iterables.UnmodifiableIterable<T> - Class in com.google.common.collect
 
iterationOrderColumn - Variable in class com.google.common.collect.DenseImmutableTable
 
iterationOrderColumn - Variable in class com.google.common.collect.SparseImmutableTable
 
iterationOrderRow - Variable in class com.google.common.collect.DenseImmutableTable
 
iterationOrderRow - Variable in class com.google.common.collect.SparseImmutableTable
 
iterator(Splitter, CharSequence) - Method in interface com.google.common.base.Splitter.Strategy
 
iterator() - Method in class com.google.common.cache.LocalCache.AccessQueue
 
iterator() - Method in class com.google.common.cache.LocalCache.EntrySet
 
iterator() - Method in class com.google.common.cache.LocalCache.KeySet
 
iterator() - Method in class com.google.common.cache.LocalCache.Values
 
iterator() - Method in class com.google.common.cache.LocalCache.WriteQueue
 
iterator() - Method in class com.google.common.collect.AbstractBiMap.EntrySet
 
iterator() - Method in class com.google.common.collect.AbstractBiMap.KeySet
 
iterator() - Method in class com.google.common.collect.AbstractBiMap.ValueSet
 
iterator() - Method in class com.google.common.collect.AbstractMapBasedMultimap.AsMap.AsMapEntries
 
iterator() - Method in class com.google.common.collect.AbstractMapBasedMultimap.KeySet
 
iterator() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection
 
iterator() - Method in class com.google.common.collect.AbstractMapBasedMultiset
 
iterator() - Method in class com.google.common.collect.AbstractMultimap.Entries
 
iterator() - Method in class com.google.common.collect.AbstractMultimap.Values
 
iterator() - Method in class com.google.common.collect.AbstractMultiset.EntrySet
 
iterator() - Method in class com.google.common.collect.AbstractMultiset
 
iterator() - Method in class com.google.common.collect.AbstractTable.CellSet
 
iterator() - Method in class com.google.common.collect.AbstractTable.Values
 
iterator() - Method in class com.google.common.collect.Collections2.FilteredCollection
 
iterator() - Method in class com.google.common.collect.Collections2.OrderedPermutationCollection
 
iterator() - Method in class com.google.common.collect.Collections2.PermutationCollection
 
iterator() - Method in class com.google.common.collect.Collections2.TransformedCollection
 
iterator() - Method in class com.google.common.collect.DescendingImmutableSortedSet
 
iterator() - Method in class com.google.common.collect.DescendingMultiset
 
iterator() - Method in class com.google.common.collect.EmptyContiguousSet
 
iterator() - Method in class com.google.common.collect.EmptyImmutableSet
 
iterator() - Method in class com.google.common.collect.EmptyImmutableSortedMultiset
 
iterator() - Method in class com.google.common.collect.EmptyImmutableSortedSet
 
iterator() - Method in class com.google.common.collect.FilteredMultimapValues
 
iterator() - Method in class com.google.common.collect.ForwardingCollection
 
iterator() - Method in class com.google.common.collect.HashBiMap.EntrySet
 
iterator() - Method in class com.google.common.collect.HashBiMap.Inverse.InverseKeySet
 
iterator() - Method in class com.google.common.collect.HashBiMap.KeySet
 
iterator() - Method in class com.google.common.collect.ImmutableCollection
Returns an unmodifiable iterator across the elements in this collection.
iterator() - Method in class com.google.common.collect.ImmutableEnumSet
 
iterator() - Method in class com.google.common.collect.ImmutableList
 
iterator() - Method in class com.google.common.collect.ImmutableMapKeySet
 
iterator() - Method in class com.google.common.collect.ImmutableMapValues
 
iterator() - Method in class com.google.common.collect.ImmutableMultimap.EntryCollection
 
iterator() - Method in class com.google.common.collect.ImmutableMultimap.Values
 
iterator() - Method in class com.google.common.collect.ImmutableMultiset.EntrySet
 
iterator() - Method in class com.google.common.collect.ImmutableMultiset
 
iterator() - Method in class com.google.common.collect.ImmutableRangeSet.AsSet
 
iterator() - Method in class com.google.common.collect.ImmutableSet
 
iterator() - Method in class com.google.common.collect.ImmutableSetMultimap.EntrySet
 
iterator() - Method in class com.google.common.collect.ImmutableSortedSet
 
iterator() - Method in class com.google.common.collect.Iterables.UnmodifiableIterable
 
iterator - Variable in class com.google.common.collect.Iterators.PeekingImpl
 
iterator() - Method in class com.google.common.collect.LinkedHashMultimap.ValueSet
 
iterator() - Method in class com.google.common.collect.Lists.ReverseList
 
iterator() - Method in class com.google.common.collect.Lists.TransformingRandomAccessList
 
iterator() - Method in class com.google.common.collect.MapConstraints.ConstrainedAsMapEntries
 
iterator() - Method in class com.google.common.collect.MapConstraints.ConstrainedAsMapValues
 
iterator() - Method in class com.google.common.collect.MapConstraints.ConstrainedEntries
 
iterator() - Method in class com.google.common.collect.MapMakerInternalMap.EntrySet
 
iterator() - Method in class com.google.common.collect.MapMakerInternalMap.EvictionQueue
 
iterator() - Method in class com.google.common.collect.MapMakerInternalMap.ExpirationQueue
 
iterator() - Method in class com.google.common.collect.MapMakerInternalMap.KeySet
 
iterator() - Method in class com.google.common.collect.MapMakerInternalMap.Values
 
iterator() - Method in class com.google.common.collect.Maps.FilteredEntryMap.EntrySet
 
iterator() - Method in class com.google.common.collect.Maps.KeySet
 
iterator() - Method in class com.google.common.collect.Maps.UnmodifiableEntries
 
iterator() - Method in class com.google.common.collect.Maps.Values
 
iterator() - Method in class com.google.common.collect.MinMaxPriorityQueue
Returns an iterator over the elements contained in this collection, in no particular order.
iterator() - Method in class com.google.common.collect.Multimaps.AsMap.EntrySet
 
iterator() - Method in class com.google.common.collect.Multimaps.Keys
 
iterator() - Method in class com.google.common.collect.Multimaps.Keys.KeysEntrySet
 
iterator() - Method in interface com.google.common.collect.Multiset
iterator() - Method in class com.google.common.collect.Multisets.ElementSet
 
iterator() - Method in class com.google.common.collect.Multisets.FilteredMultiset
 
iterator() - Method in class com.google.common.collect.Multisets.UnmodifiableMultiset
 
iterator() - Method in class com.google.common.collect.RegularContiguousSet
 
iterator() - Method in class com.google.common.collect.RegularImmutableBiMap.Inverse.InverseEntrySet
 
iterator() - Method in class com.google.common.collect.RegularImmutableMap.EntrySet
 
iterator() - Method in class com.google.common.collect.RegularImmutableSet
 
iterator() - Method in class com.google.common.collect.RegularImmutableSortedMap.EntrySet
 
iterator() - Method in class com.google.common.collect.RegularImmutableSortedSet
 
iterator() - Method in class com.google.common.collect.RegularImmutableTable.CellSet
 
iterator() - Method in class com.google.common.collect.Sets.DescendingSet
 
iterator() - Method in class com.google.common.collect.Sets.PowerSet
 
iterator() - Method in class com.google.common.collect.Sets.SubSet
 
iterator() - Method in class com.google.common.collect.SingletonImmutableList
 
iterator() - Method in class com.google.common.collect.SingletonImmutableSet
 
iterator() - Method in interface com.google.common.collect.SortedIterable
Returns an iterator over elements of type T.
iterator() - Method in interface com.google.common.collect.SortedMultiset
iterator() - Method in class com.google.common.collect.StandardTable.Column.EntrySet
 
iterator - Variable in class com.google.common.collect.StandardTable.Column.EntrySetIterator
 
iterator() - Method in class com.google.common.collect.StandardTable.ColumnKeySet
 
iterator() - Method in class com.google.common.collect.StandardTable.ColumnMap.ColumnMapEntrySet
 
iterator() - Method in class com.google.common.collect.StandardTable.Row.RowEntrySet
 
iterator() - Method in class com.google.common.collect.StandardTable.RowMap.EntrySet
 
iterator() - Method in class com.google.common.collect.Synchronized.SynchronizedAsMapEntries
 
iterator() - Method in class com.google.common.collect.Synchronized.SynchronizedAsMapValues
 
iterator() - Method in class com.google.common.collect.Synchronized.SynchronizedCollection
 
iterator() - Method in class com.google.common.collect.WellBehavedMap.EntrySet
 
iteratorImpl(Multiset<E>) - Static method in class com.google.common.collect.Multisets
An implementation of Multiset.iterator().
iteratorOrListIterator(Collection<V>) - Method in class com.google.common.collect.AbstractMapBasedMultimap
 
iterators(Iterable<? extends Iterable<? extends T>>) - Static method in class com.google.common.collect.Iterables
Returns an iterator over the iterators of the given iterables.
Iterators - Class in com.google.common.collect
This class contains static utility methods that operate on or return objects of type Iterator.
Iterators() - Constructor for class com.google.common.collect.Iterators
 
Iterators.MergingIterator<T> - Class in com.google.common.collect
An iterator that performs a lazy N-way merge, calculating the next value each time the iterator is polled.
Iterators.PeekingImpl<E> - Class in com.google.common.collect
Implementation of PeekingIterator that avoids peeking unless necessary.
Itr() - Constructor for class com.google.common.collect.AbstractMapBasedMultimap.Itr
 
Itr() - Constructor for class com.google.common.collect.HashBiMap.Itr
 
Itr() - Constructor for class com.google.common.collect.ImmutableMultimap.Itr
 

J

j - Variable in class com.google.common.collect.Collections2.PermutationIterator
 
JAVA_DIGIT - Static variable in class com.google.common.base.CharMatcher
Determines whether a character is a digit according to Java's definition.
JAVA_ISO_CONTROL - Static variable in class com.google.common.base.CharMatcher
Determines whether a character is an ISO control character as specified by Character.isISOControl(char).
JAVA_LETTER - Static variable in class com.google.common.base.CharMatcher
Determines whether a character is a letter according to Java's definition.
JAVA_LETTER_OR_DIGIT - Static variable in class com.google.common.base.CharMatcher
Determines whether a character is a letter or digit according to Java's definition.
JAVA_LOWER_CASE - Static variable in class com.google.common.base.CharMatcher
Determines whether a character is lower case according to Java's definition.
JAVA_UPPER_CASE - Static variable in class com.google.common.base.CharMatcher
Determines whether a character is upper case according to Java's definition.
JAVASCRIPT_UTF_8 - Static variable in class com.google.common.net.MediaType
RFC 4329 declares this to be the correct media type for JavaScript, but text/javascript may be necessary in certain situations for compatibility.
JavaVersion() - Constructor for enum com.google.common.reflect.Types.JavaVersion
 
JdkFutureAdapters - Class in com.google.common.util.concurrent
Utilities necessary for working with libraries that supply plain Future instances.
JdkFutureAdapters() - Constructor for class com.google.common.util.concurrent.JdkFutureAdapters
 
JdkFutureAdapters.ListenableFutureAdapter<V> - Class in com.google.common.util.concurrent
An adapter to turn a Future into a ListenableFuture.
join(Iterable<?>) - Method in class com.google.common.base.Joiner
Returns a string containing the string representation of each of parts, using the previously configured separator between each.
join(Iterator<?>) - Method in class com.google.common.base.Joiner
Returns a string containing the string representation of each of parts, using the previously configured separator between each.
join(Object[]) - Method in class com.google.common.base.Joiner
Returns a string containing the string representation of each of parts, using the previously configured separator between each.
join(Object, Object, Object...) - Method in class com.google.common.base.Joiner
Returns a string containing the string representation of each argument, using the previously configured separator between each.
join(Map<?, ?>) - Method in class com.google.common.base.Joiner.MapJoiner
Returns a string containing the string representation of each entry of map, using the previously configured separator and key-value separator.
join(Iterable<? extends Map.Entry<?, ?>>) - Method in class com.google.common.base.Joiner.MapJoiner
Returns a string containing the string representation of each entry in entries, using the previously configured separator and key-value separator.
join(Iterator<? extends Map.Entry<?, ?>>) - Method in class com.google.common.base.Joiner.MapJoiner
Returns a string containing the string representation of each entry in entries, using the previously configured separator and key-value separator.
join(Joiner) - Method in class com.google.common.collect.FluentIterable
Returns a String containing all of the elements of this fluent iterable joined with joiner.
join(String, boolean...) - Static method in class com.google.common.primitives.Booleans
Returns a string containing the supplied boolean values separated by separator.
join(String, char...) - Static method in class com.google.common.primitives.Chars
Returns a string containing the supplied char values separated by separator.
join(String, double...) - Static method in class com.google.common.primitives.Doubles
Returns a string containing the supplied double values, converted to strings as specified by Double.toString(double), and separated by separator.
join(String, float...) - Static method in class com.google.common.primitives.Floats
Returns a string containing the supplied float values, converted to strings as specified by Float.toString(float), and separated by separator.
join(String, int...) - Static method in class com.google.common.primitives.Ints
Returns a string containing the supplied int values separated by separator.
join(String, long...) - Static method in class com.google.common.primitives.Longs
Returns a string containing the supplied long values separated by separator.
join(String, short...) - Static method in class com.google.common.primitives.Shorts
Returns a string containing the supplied short values separated by separator.
join(String, byte...) - Static method in class com.google.common.primitives.SignedBytes
Returns a string containing the supplied byte values separated by separator.
join(String, byte...) - Static method in class com.google.common.primitives.UnsignedBytes
Returns a string containing the supplied byte values separated by separator.
join(String, int...) - Static method in class com.google.common.primitives.UnsignedInts
Returns a string containing the supplied unsigned int values separated by separator.
join(String, long...) - Static method in class com.google.common.primitives.UnsignedLongs
Returns a string containing the supplied unsigned long values separated by separator.
Joiner - Class in com.google.common.base
An object which joins pieces of text (specified as an array, Iterable, varargs or even a Map) with a separator.
Joiner(String) - Constructor for class com.google.common.base.Joiner
 
Joiner(Joiner) - Constructor for class com.google.common.base.Joiner
 
joiner - Variable in class com.google.common.base.Joiner.MapJoiner
 
Joiner.MapJoiner - Class in com.google.common.base
An object that joins map entries in the same manner as Joiner joins iterables and arrays.
joinUninterruptibly(Thread) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes toJoin.join() uninterruptibly.
joinUninterruptibly(Thread, long, TimeUnit) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes unit.timedJoin(toJoin, timeout) uninterruptibly.
JPEG - Static variable in class com.google.common.net.MediaType
 
JSON_UTF_8 - Static variable in class com.google.common.net.MediaType
 
JVM_BEHAVIOR - Static variable in enum com.google.common.reflect.Types.ClassOwnership
 

K

k0 - Variable in class com.google.common.hash.SipHashFunction
 
k1 - Variable in class com.google.common.hash.SipHashFunction
 
key - Variable in enum com.google.common.base.StandardSystemProperty
 
key() - Method in enum com.google.common.base.StandardSystemProperty
Returns the key used to lookup this system property.
key - Variable in class com.google.common.cache.LocalCache.StrongEntry
 
key - Variable in class com.google.common.cache.LocalCache.WriteThroughEntry
 
key - Variable in class com.google.common.cache.RemovalNotification
 
key - Variable in class com.google.common.collect.AbstractMapBasedMultimap.Itr
 
key - Variable in class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection
 
key - Variable in class com.google.common.collect.FilteredEntryMultimap.ValuePredicate
 
key - Variable in class com.google.common.collect.FilteredKeyMultimap.AddRejectingList
 
key - Variable in class com.google.common.collect.FilteredKeyMultimap.AddRejectingSet
 
key - Variable in class com.google.common.collect.ImmutableEntry
 
key - Variable in class com.google.common.collect.ImmutableMultimap.Itr
 
key - Variable in class com.google.common.collect.LinkedHashMultimap.ValueSet
 
key - Variable in class com.google.common.collect.LinkedListMultimap.Node
 
key - Variable in class com.google.common.collect.LinkedListMultimap.ValueForKeyIterator
 
key - Variable in class com.google.common.collect.MapMakerInternalMap.StrongEntry
 
key - Variable in class com.google.common.collect.MapMakerInternalMap.WriteThroughEntry
 
KEY_ARCHIVE - Static variable in class com.google.common.net.MediaType
As described in PKCS #12: Personal Information Exchange Syntax Standard, PKCS #12 defines an archive file format for storing many cryptography objects as a single file.
KEY_VALUE_SPLITTER - Static variable in class com.google.common.cache.CacheBuilderSpec
Splits the key from the value.
KeyAbsentBehavior() - Constructor for enum com.google.common.collect.SortedLists.KeyAbsentBehavior
 
keyComparator - Variable in class com.google.common.collect.ImmutableMultimap.Builder
 
keyComparator - Variable in class com.google.common.collect.TreeMultimap
 
keyComparator() - Method in class com.google.common.collect.TreeMultimap
Returns the comparator that orders the multimap keys.
keyEquivalence - Variable in class com.google.common.cache.CacheBuilder
 
keyEquivalence(Equivalence<Object>) - Method in class com.google.common.cache.CacheBuilder
Sets a custom Equivalence strategy for comparing keys.
keyEquivalence - Variable in class com.google.common.cache.LocalCache
Strategy for comparing keys.
keyEquivalence - Variable in class com.google.common.cache.LocalCache.ManualSerializationProxy
 
keyEquivalence(Equivalence<Object>) - Method in class com.google.common.collect.GenericMapMaker
Deprecated.
keyEquivalence - Variable in class com.google.common.collect.MapMaker
 
keyEquivalence(Equivalence<Object>) - Method in class com.google.common.collect.MapMaker
Sets a custom Equivalence strategy for comparing keys.
keyEquivalence - Variable in class com.google.common.collect.MapMakerInternalMap.AbstractSerializationProxy
 
keyEquivalence - Variable in class com.google.common.collect.MapMakerInternalMap
Strategy for comparing keys.
keyFunction() - Static method in class com.google.common.collect.Maps
 
keyHash - Variable in class com.google.common.collect.HashBiMap.BiEntry
 
keyIndex - Variable in class com.google.common.collect.ArrayTable.ArrayMap
 
KeyIterator() - Constructor for class com.google.common.cache.LocalCache.KeyIterator
 
keyIterator - Variable in class com.google.common.collect.AbstractMapBasedMultimap.Itr
 
KeyIterator() - Constructor for class com.google.common.collect.MapMakerInternalMap.KeyIterator
 
keyIterator(Iterator<Map.Entry<K, V>>) - Static method in class com.google.common.collect.Maps
 
KeyList(LinkedListMultimap.Node<K, V>) - Constructor for class com.google.common.collect.LinkedListMultimap.KeyList
 
keyOrNull(Map.Entry<K, ?>) - Static method in class com.google.common.collect.Maps
 
keyPredicate - Variable in class com.google.common.collect.FilteredKeyMultimap
 
keyPredicate - Variable in class com.google.common.collect.Maps.FilteredKeyMap
 
keyPredicateOnEntries(Predicate<? super K>) - Static method in class com.google.common.collect.Maps
 
KeyPresentBehavior() - Constructor for enum com.google.common.collect.SortedLists.KeyPresentBehavior
 
keyRanges - Variable in class com.google.common.collect.ImmutableRangeMap.Builder
 
keyReferenceQueue - Variable in class com.google.common.cache.LocalCache.Segment
The key reference queue contains entries whose keys have been garbage collected, and which need to be cleaned up internally.
keyReferenceQueue - Variable in class com.google.common.collect.MapMakerInternalMap.Segment
The key reference queue contains entries whose keys have been garbage collected, and which need to be cleaned up internally.
keys - Variable in class com.google.common.collect.AbstractMultimap
 
keys() - Method in class com.google.common.collect.AbstractMultimap
 
Keys() - Constructor for class com.google.common.collect.FilteredEntryMultimap.Keys
 
keys() - Method in class com.google.common.collect.ForwardingMultimap
 
keys - Variable in class com.google.common.collect.ImmutableMap.SerializedForm
 
keys() - Method in class com.google.common.collect.ImmutableMultimap
Returns a collection, which may contain duplicates, of all keys.
Keys() - Constructor for class com.google.common.collect.ImmutableMultimap.Keys
 
keys() - Method in interface com.google.common.collect.Multimap
Returns a view collection containing the key from each key-value pair in this multimap, without collapsing duplicates.
Keys(Multimap<K, V>) - Constructor for class com.google.common.collect.Multimaps.Keys
 
keys() - Method in class com.google.common.collect.Multimaps.TransformedEntriesMultimap
 
keys - Variable in class com.google.common.collect.Multimaps.UnmodifiableMultimap
 
keys() - Method in class com.google.common.collect.Multimaps.UnmodifiableMultimap
 
keys - Variable in class com.google.common.collect.Synchronized.SynchronizedMultimap
 
keys() - Method in class com.google.common.collect.Synchronized.SynchronizedMultimap
 
KEYS_SPLITTER - Static variable in class com.google.common.cache.CacheBuilderSpec
Splits each key-value pair.
KeysEntrySet() - Constructor for class com.google.common.collect.Multimaps.Keys.KeysEntrySet
 
keySet - Variable in class com.google.common.cache.LocalCache
 
keySet() - Method in class com.google.common.cache.LocalCache
 
KeySet(ConcurrentMap<?, ?>) - Constructor for class com.google.common.cache.LocalCache.KeySet
 
keySet - Variable in class com.google.common.collect.AbstractBiMap
 
keySet() - Method in class com.google.common.collect.AbstractBiMap
 
KeySet() - Constructor for class com.google.common.collect.AbstractBiMap.KeySet
 
keySet() - Method in class com.google.common.collect.AbstractMapBasedMultimap.AsMap
 
KeySet(Map<K, Collection<V>>) - Constructor for class com.google.common.collect.AbstractMapBasedMultimap.KeySet
 
keySet() - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableAsMap
 
keySet() - Method in class com.google.common.collect.AbstractMapBasedMultimap.SortedAsMap
 
keySet - Variable in class com.google.common.collect.AbstractMultimap
 
keySet() - Method in class com.google.common.collect.AbstractMultimap
 
keySet() - Method in class com.google.common.collect.AbstractNavigableMap
 
keySet() - Method in class com.google.common.collect.AbstractSortedKeySortedSetMultimap
 
keySet() - Method in class com.google.common.collect.ArrayTable.ArrayMap
 
keySet() - Method in class com.google.common.collect.EmptyImmutableBiMap
 
keySet - Variable in class com.google.common.collect.EmptyImmutableSortedMap
 
keySet() - Method in class com.google.common.collect.EmptyImmutableSortedMap
 
keySet() - Method in class com.google.common.collect.FilteredEntryMultimap
 
keySet() - Method in class com.google.common.collect.ForwardingMap
 
keySet() - Method in class com.google.common.collect.ForwardingMultimap
 
keySet() - Method in class com.google.common.collect.HashBiMap.Inverse
 
keySet() - Method in class com.google.common.collect.HashBiMap
 
KeySet() - Constructor for class com.google.common.collect.HashBiMap.KeySet
 
keySet - Variable in class com.google.common.collect.ImmutableMap
 
keySet() - Method in class com.google.common.collect.ImmutableMap
Returns an immutable set of the keys in this map.
keySet() - Method in class com.google.common.collect.ImmutableMultimap
Returns an immutable set of the distinct keys in this multimap.
keySet() - Method in class com.google.common.collect.ImmutableSortedMap
Returns an immutable sorted set of the keys in this map.
keySet - Variable in class com.google.common.collect.MapMakerInternalMap
 
keySet() - Method in class com.google.common.collect.MapMakerInternalMap
 
KeySet() - Constructor for class com.google.common.collect.MapMakerInternalMap.KeySet
 
keySet() - Method in class com.google.common.collect.Maps.DescendingMap
 
KeySet() - Constructor for class com.google.common.collect.Maps.FilteredEntryMap.KeySet
 
keySet() - Method in class com.google.common.collect.Maps.FilteredEntrySortedMap
 
keySet - Variable in class com.google.common.collect.Maps.ImprovedAbstractMap
 
keySet() - Method in class com.google.common.collect.Maps.ImprovedAbstractMap
 
KeySet(Map<K, V>) - Constructor for class com.google.common.collect.Maps.KeySet
 
keySet() - Method in class com.google.common.collect.Maps.SortedAsMapView
 
keySet() - Method in class com.google.common.collect.Maps.TransformedEntriesMap
 
keySet() - Method in class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
keySet() - Method in interface com.google.common.collect.Multimap
Returns a view collection of all distinct keys contained in this multimap.
keySet() - Method in class com.google.common.collect.Multimaps.AsMap
 
keySet() - Method in class com.google.common.collect.Multimaps.MapMultimap
 
keySet() - Method in class com.google.common.collect.Multimaps.TransformedEntriesMultimap
 
keySet - Variable in class com.google.common.collect.Multimaps.UnmodifiableMultimap
 
keySet() - Method in class com.google.common.collect.Multimaps.UnmodifiableMultimap
 
keySet - Variable in class com.google.common.collect.RegularImmutableSortedMap
 
keySet() - Method in class com.google.common.collect.RegularImmutableSortedMap
 
keySet() - Method in class com.google.common.collect.StandardRowSortedTable.RowSortedMap
 
KeySet() - Constructor for class com.google.common.collect.StandardTable.Column.KeySet
 
keySet() - Method in class com.google.common.collect.StandardTable.ColumnMap
 
keySet - Variable in class com.google.common.collect.Synchronized.SynchronizedMap
 
keySet() - Method in class com.google.common.collect.Synchronized.SynchronizedMap
 
keySet - Variable in class com.google.common.collect.Synchronized.SynchronizedMultimap
 
keySet() - Method in class com.google.common.collect.Synchronized.SynchronizedMultimap
 
keySet() - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableMap
 
keySet() - Method in class com.google.common.collect.TreeBasedTable.TreeRow
 
keySet() - Method in class com.google.common.collect.TreeMultimap
Returns a view collection of all distinct keys contained in this multimap.
keySet() - Method in class com.google.common.collect.TreeRangeMap.SubRangeMap.SubRangeMapAsMap
 
KeySetSerializedForm(ImmutableMap<K, ?>) - Constructor for class com.google.common.collect.ImmutableMapKeySet.KeySetSerializedForm
 
keyStrength - Variable in class com.google.common.cache.CacheBuilder
 
keyStrength - Variable in class com.google.common.cache.CacheBuilderSpec
 
keyStrength - Variable in class com.google.common.cache.LocalCache
Strategy for referencing keys.
keyStrength - Variable in class com.google.common.cache.LocalCache.ManualSerializationProxy
 
keyStrength - Variable in class com.google.common.collect.MapMaker
 
keyStrength - Variable in class com.google.common.collect.MapMakerInternalMap.AbstractSerializationProxy
 
keyStrength - Variable in class com.google.common.collect.MapMakerInternalMap
Strategy for referencing keys.
KeyStrengthParser(LocalCache.Strength) - Constructor for class com.google.common.cache.CacheBuilderSpec.KeyStrengthParser
 
keyTable - Variable in class com.google.common.collect.RegularImmutableBiMap
 
keyToIndex() - Method in class com.google.common.collect.DenseImmutableTable.Column
 
keyToIndex() - Method in class com.google.common.collect.DenseImmutableTable.ColumnMap
 
keyToIndex() - Method in class com.google.common.collect.DenseImmutableTable.ImmutableArrayMap
 
keyToIndex() - Method in class com.google.common.collect.DenseImmutableTable.Row
 
keyToIndex() - Method in class com.google.common.collect.DenseImmutableTable.RowMap
 
keyToKeyList - Variable in class com.google.common.collect.LinkedListMultimap
 
keyType - Variable in class com.google.common.collect.EnumBiMap
 
keyType() - Method in class com.google.common.collect.EnumBiMap
Returns the associated key type.
keyType - Variable in class com.google.common.collect.EnumHashBiMap
 
keyType() - Method in class com.google.common.collect.EnumHashBiMap
Returns the associated key type.
keyValueSeparator - Variable in class com.google.common.base.Joiner.MapJoiner
 
KML - Static variable in class com.google.common.net.MediaType
 
KMZ - Static variable in class com.google.common.net.MediaType
 
KNOWN_TYPES - Static variable in class com.google.common.net.MediaType
 

L

LARGE_LAZY_CUTOFF - Static variable in class com.google.common.util.concurrent.Striped
If there are at least this many stripes, we assume the memory usage of a ConcurrentMap will be smaller than a large array.
LargeLazyStriped(int, Supplier<L>) - Constructor for class com.google.common.util.concurrent.Striped.LargeLazyStriped
 
last() - Method in class com.google.common.collect.AbstractMapBasedMultimap.SortedKeySet
 
last() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedSortedSet
 
last() - Method in class com.google.common.collect.EmptyContiguousSet
 
last() - Method in class com.google.common.collect.EmptyImmutableSortedSet
 
last() - Method in class com.google.common.collect.FluentIterable
Returns an Optional containing the last element in this fluent iterable.
last() - Method in class com.google.common.collect.ForwardingSortedSet
 
last() - Method in class com.google.common.collect.ImmutableSortedSet
 
last() - Method in class com.google.common.collect.Maps.FilteredEntrySortedMap.SortedKeySet
 
last() - Method in class com.google.common.collect.Maps.SortedKeySet
 
last() - Method in class com.google.common.collect.RegularContiguousSet
 
last() - Method in class com.google.common.collect.RegularImmutableSortedSet
 
last() - Method in class com.google.common.collect.Sets.DescendingSet
 
last() - Method in class com.google.common.collect.Sets.FilteredNavigableSet
 
last() - Method in class com.google.common.collect.Sets.FilteredSortedSet
 
last() - Method in class com.google.common.collect.SortedMultisets.ElementSet
 
last() - Method in class com.google.common.collect.Synchronized.SynchronizedSortedSet
 
LAST_EVENT_ID - Static variable in class com.google.common.net.HttpHeaders
The HTTP Last-Event-ID header field name.
LAST_MODIFIED - Static variable in class com.google.common.net.HttpHeaders
The HTTP Last-Modified header field name.
lastEntry() - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableAsMap
 
lastEntry() - Method in class com.google.common.collect.AbstractNavigableMap
 
lastEntry() - Method in class com.google.common.collect.AbstractSortedMultiset
 
lastEntry() - Method in class com.google.common.collect.DescendingImmutableSortedMultiset
 
lastEntry() - Method in class com.google.common.collect.DescendingMultiset
 
lastEntry() - Method in class com.google.common.collect.EmptyImmutableSortedMultiset
 
lastEntry() - Method in class com.google.common.collect.ForwardingNavigableMap
 
lastEntry() - Method in class com.google.common.collect.ForwardingSortedMultiset
 
lastEntry() - Method in class com.google.common.collect.ImmutableSortedMap
 
lastEntry - Variable in class com.google.common.collect.LinkedHashMultimap.ValueSet
 
lastEntry() - Method in class com.google.common.collect.Maps.DescendingMap
 
lastEntry() - Method in class com.google.common.collect.Maps.TransformedEntriesNavigableMap
 
lastEntry() - Method in class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
lastEntry() - Method in class com.google.common.collect.RegularImmutableSortedMultiset
 
lastEntry() - Method in interface com.google.common.collect.SortedMultiset
Returns the entry of the last element in this multiset, or null if this multiset is empty.
lastEntry() - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableMap
 
lastEntry() - Method in class com.google.common.collect.UnmodifiableSortedMultiset
 
lastFromForgetMeNot - Variable in class com.google.common.collect.MinMaxPriorityQueue.QueueIterator
 
lastIndexIn(CharSequence) - Method in class com.google.common.base.CharMatcher
Returns the index of the last matching character in a character sequence, or -1 if no matching character is present.
lastIndexOf(Object) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedList
 
lastIndexOf(Object) - Method in class com.google.common.collect.ForwardingList
 
lastIndexOf(Object) - Method in class com.google.common.collect.ImmutableList
 
lastIndexOf(Object) - Method in class com.google.common.collect.ImmutableList.ReverseImmutableList
 
lastIndexOf(Object) - Method in class com.google.common.collect.ImmutableSortedAsList
 
lastIndexOf(Object) - Method in class com.google.common.collect.Lists.StringAsImmutableList
 
lastIndexOf(Object) - Method in class com.google.common.collect.RegularImmutableList
 
lastIndexOf(Object) - Method in class com.google.common.collect.SingletonImmutableList
 
lastIndexOf(Object) - Method in class com.google.common.collect.Synchronized.SynchronizedList
 
lastIndexOf(Object) - Method in class com.google.common.primitives.Booleans.BooleanArrayAsList
 
lastIndexOf(boolean[], boolean) - Static method in class com.google.common.primitives.Booleans
Returns the index of the last appearance of the value target in array.
lastIndexOf(boolean[], boolean, int, int) - Static method in class com.google.common.primitives.Booleans
 
lastIndexOf(Object) - Method in class com.google.common.primitives.Bytes.ByteArrayAsList
 
lastIndexOf(byte[], byte) - Static method in class com.google.common.primitives.Bytes
Returns the index of the last appearance of the value target in array.
lastIndexOf(byte[], byte, int, int) - Static method in class com.google.common.primitives.Bytes
 
lastIndexOf(Object) - Method in class com.google.common.primitives.Chars.CharArrayAsList
 
lastIndexOf(char[], char) - Static method in class com.google.common.primitives.Chars
Returns the index of the last appearance of the value target in array.
lastIndexOf(char[], char, int, int) - Static method in class com.google.common.primitives.Chars
 
lastIndexOf(Object) - Method in class com.google.common.primitives.Doubles.DoubleArrayAsList
 
lastIndexOf(double[], double) - Static method in class com.google.common.primitives.Doubles
Returns the index of the last appearance of the value target in array.
lastIndexOf(double[], double, int, int) - Static method in class com.google.common.primitives.Doubles
 
lastIndexOf(Object) - Method in class com.google.common.primitives.Floats.FloatArrayAsList
 
lastIndexOf(float[], float) - Static method in class com.google.common.primitives.Floats
Returns the index of the last appearance of the value target in array.
lastIndexOf(float[], float, int, int) - Static method in class com.google.common.primitives.Floats
 
lastIndexOf(Object) - Method in class com.google.common.primitives.Ints.IntArrayAsList
 
lastIndexOf(int[], int) - Static method in class com.google.common.primitives.Ints
Returns the index of the last appearance of the value target in array.
lastIndexOf(int[], int, int, int) - Static method in class com.google.common.primitives.Ints
 
lastIndexOf(long[], long) - Static method in class com.google.common.primitives.Longs
Returns the index of the last appearance of the value target in array.
lastIndexOf(long[], long, int, int) - Static method in class com.google.common.primitives.Longs
 
lastIndexOf(Object) - Method in class com.google.common.primitives.Longs.LongArrayAsList
 
lastIndexOf(short[], short) - Static method in class com.google.common.primitives.Shorts
Returns the index of the last appearance of the value target in array.
lastIndexOf(short[], short, int, int) - Static method in class com.google.common.primitives.Shorts
 
lastIndexOf(Object) - Method in class com.google.common.primitives.Shorts.ShortArrayAsList
 
lastIndexOfImpl(List<?>, Object) - Static method in class com.google.common.collect.Lists
An implementation of List.lastIndexOf(Object).
lastKey() - Method in class com.google.common.collect.AbstractMapBasedMultimap.SortedAsMap
 
lastKey() - Method in class com.google.common.collect.AbstractNavigableMap
 
lastKey() - Method in class com.google.common.collect.ForwardingSortedMap
 
lastKey() - Method in class com.google.common.collect.ImmutableSortedMap
 
lastKey() - Method in class com.google.common.collect.Maps.DescendingMap
 
lastKey() - Method in class com.google.common.collect.Maps.FilteredEntrySortedMap
 
lastKey() - Method in class com.google.common.collect.Maps.SortedAsMapView
 
lastKey() - Method in class com.google.common.collect.Maps.TransformedEntriesSortedMap
 
lastKey() - Method in class com.google.common.collect.StandardRowSortedTable.RowSortedMap
 
lastKey() - Method in class com.google.common.collect.Synchronized.SynchronizedSortedMap
 
lastKey() - Method in class com.google.common.collect.TreeBasedTable.TreeRow
 
lastNode() - Method in class com.google.common.collect.TreeMultiset
 
lastReturned - Variable in class com.google.common.cache.LocalCache.HashIterator
 
lastReturned - Variable in class com.google.common.collect.MapMakerInternalMap.HashIterator
 
laterCount - Variable in class com.google.common.collect.Multisets.MultisetIteratorImpl
Count of subsequent elements equal to current element
lazy(int, Supplier<L>) - Static method in class com.google.common.util.concurrent.Striped
 
lazySet(double) - Method in class com.google.common.util.concurrent.AtomicDouble
Eventually sets to the given value.
lazySet(int, double) - Method in class com.google.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.google.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.google.common.util.concurrent.Striped
Creates a Striped<Lock> with lazily initialized, weakly referenced locks.
lazyWeakReadWriteLock(int) - Static method in class com.google.common.util.concurrent.Striped
Creates a Striped<ReadWriteLock> with lazily initialized, weakly referenced read-write locks.
lazyWeakSemaphore(int, int) - Static method in class com.google.common.util.concurrent.Striped
Creates a Striped<Semaphore> with lazily initialized, weakly referenced semaphores, with the specified number of permits.
leafNodeCode - Variable in enum com.google.thirdparty.publicsuffix.PublicSuffixType
The character used for a leaf node in the trie encoding
leastOf(Iterable<E>, int) - Method in class com.google.common.collect.Ordering
Returns the k least elements of the given iterable according to this ordering, in order from least to greatest.
leastOf(Iterator<E>, int) - Method in class com.google.common.collect.Ordering
Returns the k least elements from the given iterator according to this ordering, in order from least to greatest.
leastValueAbove(DiscreteDomain<Comparable<?>>) - Method in class com.google.common.collect.Cut.AboveAll
 
leastValueAbove(DiscreteDomain<C>) - Method in class com.google.common.collect.Cut.AboveValue
 
leastValueAbove(DiscreteDomain<Comparable<?>>) - Method in class com.google.common.collect.Cut.BelowAll
 
leastValueAbove(DiscreteDomain<C>) - Method in class com.google.common.collect.Cut.BelowValue
 
leastValueAbove(DiscreteDomain<C>) - Method in class com.google.common.collect.Cut
 
leave() - Method in class com.google.common.util.concurrent.Monitor
Leaves this monitor.
left - Variable in class com.google.common.collect.Maps.ValueDifferenceImpl
 
left - Variable in class com.google.common.collect.TreeMultiset.AvlNode
 
left - Variable in class com.google.common.io.ByteStreams.LimitedInputStream
 
LEFT_IS_GREATER - Static variable in class com.google.common.collect.Ordering
 
leftChild(T) - Method in class com.google.common.collect.BinaryTreeTraverser
Returns the left child of the specified node, or Optional.absent() if the specified node has no left child.
leftValue() - Method in interface com.google.common.collect.MapDifference.ValueDifference
Returns the value from the left map (possibly null).
leftValue() - Method in class com.google.common.collect.Maps.ValueDifferenceImpl
 
length - Variable in class com.google.common.collect.ImmutableList.SubList
 
length - Variable in class com.google.common.collect.RegularImmutableSortedMultiset
 
length() - Method in class com.google.common.hash.AbstractNonStreamingHashFunction.ExposedByteArrayOutputStream
 
length - Variable in class com.google.common.hash.Murmur3_128HashFunction.Murmur3_128Hasher
 
length - Variable in class com.google.common.hash.Murmur3_32HashFunction.Murmur3_32Hasher
 
length - Variable in class com.google.common.io.ByteSource.SlicedByteSource
 
length() - Method in class com.google.common.util.concurrent.AtomicDoubleArray
Returns the length of the array.
lenientParsing() - Method in class com.google.common.cache.CacheBuilder
Enables lenient parsing.
LESS - Static variable in class com.google.common.collect.ComparisonChain
 
lessThan(C) - Static method in class com.google.common.collect.Range
Returns a range that contains all values strictly less than endpoint.
lessThanBranchFree(int, int) - Static method in class com.google.common.math.IntMath
Returns 1 if x < y as unsigned integers, and 0 otherwise.
lessThanBranchFree(long, long) - Static method in class com.google.common.math.LongMath
Returns 1 if x < y as unsigned longs, and 0 otherwise.
lexicographical() - Method in class com.google.common.collect.Ordering
Returns a new ordering which sorts iterables by comparing corresponding elements pairwise until a nonzero result is found; imposes "dictionary order".
lexicographicalComparator() - Static method in class com.google.common.primitives.Booleans
Returns a comparator that compares two boolean arrays lexicographically.
LexicographicalComparator() - Constructor for enum com.google.common.primitives.Booleans.LexicographicalComparator
 
lexicographicalComparator() - Static method in class com.google.common.primitives.Chars
Returns a comparator that compares two char arrays lexicographically.
LexicographicalComparator() - Constructor for enum com.google.common.primitives.Chars.LexicographicalComparator
 
lexicographicalComparator() - Static method in class com.google.common.primitives.Doubles
Returns a comparator that compares two double arrays lexicographically.
LexicographicalComparator() - Constructor for enum com.google.common.primitives.Doubles.LexicographicalComparator
 
lexicographicalComparator() - Static method in class com.google.common.primitives.Floats
Returns a comparator that compares two float arrays lexicographically.
LexicographicalComparator() - Constructor for enum com.google.common.primitives.Floats.LexicographicalComparator
 
lexicographicalComparator() - Static method in class com.google.common.primitives.Ints
Returns a comparator that compares two int arrays lexicographically.
LexicographicalComparator() - Constructor for enum com.google.common.primitives.Ints.LexicographicalComparator
 
lexicographicalComparator() - Static method in class com.google.common.primitives.Longs
Returns a comparator that compares two long arrays lexicographically.
LexicographicalComparator() - Constructor for enum com.google.common.primitives.Longs.LexicographicalComparator
 
lexicographicalComparator() - Static method in class com.google.common.primitives.Shorts
Returns a comparator that compares two short arrays lexicographically.
LexicographicalComparator() - Constructor for enum com.google.common.primitives.Shorts.LexicographicalComparator
 
lexicographicalComparator() - Static method in class com.google.common.primitives.SignedBytes
Returns a comparator that compares two byte arrays lexicographically.
LexicographicalComparator() - Constructor for enum com.google.common.primitives.SignedBytes.LexicographicalComparator
 
lexicographicalComparator() - Static method in class com.google.common.primitives.UnsignedBytes
Returns a comparator that compares two byte arrays lexicographically.
lexicographicalComparator() - Static method in class com.google.common.primitives.UnsignedInts
Returns a comparator that compares two arrays of unsigned int values lexicographically.
LexicographicalComparator() - Constructor for enum com.google.common.primitives.UnsignedInts.LexicographicalComparator
 
lexicographicalComparator() - Static method in class com.google.common.primitives.UnsignedLongs
Returns a comparator that compares two arrays of unsigned long values lexicographically.
LexicographicalComparator() - Constructor for enum com.google.common.primitives.UnsignedLongs.LexicographicalComparator
 
LexicographicalComparatorHolder() - Constructor for class com.google.common.primitives.UnsignedBytes.LexicographicalComparatorHolder
 
lexicographicalComparatorJavaImpl() - Static method in class com.google.common.primitives.UnsignedBytes
 
LexicographicalOrdering<T> - Class in com.google.common.collect
An ordering which sorts iterables by comparing corresponding elements pairwise.
LexicographicalOrdering(Ordering<? super T>) - Constructor for class com.google.common.collect.LexicographicalOrdering
 
LF - Static variable in class com.google.common.base.Ascii
Line Feed ('\n'): A format effector which controls the movement of the printing position to the next printing line.
limit - Variable in class com.google.common.base.Splitter
 
limit(int) - Method in class com.google.common.base.Splitter
Returns a splitter that behaves equivalently to this splitter but stops splitting after it reaches the limit.
limit - Variable in class com.google.common.base.Splitter.SplittingIterator
 
limit(int) - Method in class com.google.common.collect.FluentIterable
Creates a fluent iterable with the first size elements of this fluent iterable.
limit(Iterable<T>, int) - Static method in class com.google.common.collect.Iterables
Creates an iterable with the first limitSize elements of the given iterable.
limit(Iterator<T>, int) - Static method in class com.google.common.collect.Iterators
Creates an iterator returning the first limitSize elements of the given iterator.
limit(InputStream, long) - Static method in class com.google.common.io.ByteStreams
Wraps a InputStream, limiting the number of bytes which can be read.
LimitedInputStream(InputStream, long) - Constructor for class com.google.common.io.ByteStreams.LimitedInputStream
 
line - Variable in class com.google.common.io.LineBuffer
Holds partial line contents.
LINE_SPLITTER - Static variable in class com.google.common.io.CharSource.CharSequenceCharSource
 
LINEAR_WHITE_SPACE - Static variable in class com.google.common.net.MediaType
 
LinearCongruentialGenerator(long) - Constructor for class com.google.common.hash.Hashing.LinearCongruentialGenerator
 
lineBuf - Variable in class com.google.common.io.LineReader
 
LineBuffer - Class in com.google.common.io
Package-protected abstract class that implements the line reading algorithm used by LineReader.
LineBuffer() - Constructor for class com.google.common.io.LineBuffer
 
LineProcessor<T> - Interface in com.google.common.io
A callback to be used with the streaming readLines methods.
LineReader - Class in com.google.common.io
A class for reading lines of text.
LineReader(Readable) - Constructor for class com.google.common.io.LineReader
Creates a new instance that will read lines from the given Readable object.
lines() - Method in class com.google.common.io.CharSource.CharSequenceCharSource
Returns an iterable over the lines in the string.
lines - Variable in class com.google.common.io.LineReader
 
LINK - Static variable in class com.google.common.net.HttpHeaders
The HTTP Link header field name.
linkedHashKeys() - Static method in class com.google.common.collect.MultimapBuilder
Uses a LinkedHashMap to map keys to value collections.
linkedHashKeys(int) - Static method in class com.google.common.collect.MultimapBuilder
Uses a LinkedHashMap to map keys to value collections, initialized to expect the specified number of keys.
LinkedHashMultimap<K,V> - Class in com.google.common.collect
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.
LinkedHashMultimap(int, int) - Constructor for class com.google.common.collect.LinkedHashMultimap
 
LinkedHashMultimap.ValueEntry<K,V> - Class in com.google.common.collect
LinkedHashMultimap entries are in no less than three coexisting linked lists: a bucket in the hash table for a Set associated with a key, the linked list of insertion-ordered entries in that Set, and the linked list of entries in the LinkedHashMultimap as a whole.
LinkedHashMultimap.ValueSet - Class in com.google.common.collect
 
LinkedHashMultimap.ValueSetLink<K,V> - Interface in com.google.common.collect
 
LinkedHashMultiset<E> - Class in com.google.common.collect
A Multiset implementation with predictable iteration order.
LinkedHashMultiset() - Constructor for class com.google.common.collect.LinkedHashMultiset
 
LinkedHashMultiset(int) - Constructor for class com.google.common.collect.LinkedHashMultiset
 
LinkedHashSetSupplier(int) - Constructor for class com.google.common.collect.MultimapBuilder.LinkedHashSetSupplier
 
linkedHashSetValues() - Method in class com.google.common.collect.MultimapBuilder.MultimapBuilderWithKeys
Uses a LinkedHashSet to store value collections.
linkedHashSetValues(int) - Method in class com.google.common.collect.MultimapBuilder.MultimapBuilderWithKeys
Uses a LinkedHashSet to store value collections, initialized to expect the specified number of values per key.
LinkedListMultimap<K,V> - Class in com.google.common.collect
An implementation of ListMultimap that supports deterministic iteration order for both keys and values.
LinkedListMultimap() - Constructor for class com.google.common.collect.LinkedListMultimap
 
LinkedListMultimap(int) - Constructor for class com.google.common.collect.LinkedListMultimap
 
LinkedListMultimap(Multimap<? extends K, ? extends V>) - Constructor for class com.google.common.collect.LinkedListMultimap
 
LinkedListMultimap.DistinctKeyIterator - Class in com.google.common.collect
An Iterator over distinct keys in key head order.
LinkedListMultimap.KeyList<K,V> - Class in com.google.common.collect
 
LinkedListMultimap.Node<K,V> - Class in com.google.common.collect
 
LinkedListMultimap.NodeIterator - Class in com.google.common.collect
An Iterator over all nodes.
LinkedListMultimap.ValueForKeyIterator - Class in com.google.common.collect
A ListIterator over values for a specified key.
LinkedListSupplier() - Constructor for enum com.google.common.collect.MultimapBuilder.LinkedListSupplier
 
linkedListValues() - Method in class com.google.common.collect.MultimapBuilder.MultimapBuilderWithKeys
Uses a LinkedList to store value collections.
list - Variable in class com.google.common.collect.Collections2.PermutationIterator
 
list - Variable in class com.google.common.collect.Lists.Partition
 
list(List<E>, Object) - Static method in class com.google.common.collect.Synchronized
 
ListenableFuture<V> - Interface in com.google.common.util.concurrent
A Future that accepts completion listeners.
ListenableFutureAdapter(Future<V>) - Constructor for class com.google.common.util.concurrent.JdkFutureAdapters.ListenableFutureAdapter
 
ListenableFutureAdapter(Future<V>, Executor) - Constructor for class com.google.common.util.concurrent.JdkFutureAdapters.ListenableFutureAdapter
 
ListenableFutureTask<V> - Class in com.google.common.util.concurrent
A FutureTask that also implements the ListenableFuture interface.
ListenableFutureTask(Callable<V>) - Constructor for class com.google.common.util.concurrent.ListenableFutureTask
 
ListenableFutureTask(Runnable, V) - Constructor for class com.google.common.util.concurrent.ListenableFutureTask
 
ListenableScheduledFuture<V> - Interface in com.google.common.util.concurrent
Helper interface to implement both ListenableFuture and ScheduledFuture.
ListenableScheduledTask(ListenableFuture<V>, ScheduledFuture<?>) - Constructor for class com.google.common.util.concurrent.MoreExecutors.ScheduledListeningDecorator.ListenableScheduledTask
 
listener - Variable in class com.google.common.util.concurrent.ListenerCallQueue
 
Listener() - Constructor for class com.google.common.util.concurrent.Service.Listener
 
Listener() - Constructor for class com.google.common.util.concurrent.ServiceManager.Listener
 
ListenerCallQueue<L> - Class in com.google.common.util.concurrent
A special purpose queue/executor that executes listener callbacks serially on a configured executor.
ListenerCallQueue(L, Executor) - Constructor for class com.google.common.util.concurrent.ListenerCallQueue
 
ListenerCallQueue.Callback<L> - Class in com.google.common.util.concurrent
 
listeners - Variable in class com.google.common.util.concurrent.AbstractService
The listeners to notify during a state transition.
listeners - Variable in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState
The listeners to notify during a state transition.
listeningDecorator(ExecutorService) - Static method in class com.google.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.google.common.util.concurrent.MoreExecutors
Creates a ScheduledExecutorService whose submit and invokeAll methods submit ListenableFutureTask instances to the given delegate executor.
ListeningDecorator(ExecutorService) - Constructor for class com.google.common.util.concurrent.MoreExecutors.ListeningDecorator
 
ListeningExecutorService - Interface in com.google.common.util.concurrent
An ExecutorService that returns ListenableFuture instances.
ListeningScheduledExecutorService - Interface in com.google.common.util.concurrent
A ScheduledExecutorService that returns ListenableFuture instances from its ExecutorService methods.
listenInPoolThread(Future<V>) - Static method in class com.google.common.util.concurrent.JdkFutureAdapters
Assigns a thread to the given Future to provide ListenableFuture functionality.
listenInPoolThread(Future<V>, Executor) - Static method in class com.google.common.util.concurrent.JdkFutureAdapters
Submits a blocking task for the given Future to provide ListenableFuture functionality.
listFuture(ImmutableList<ListenableFuture<? extends V>>, boolean, Executor) - Static method in class com.google.common.util.concurrent.Futures
listIterator() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedList
 
listIterator(int) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedList
 
listIterator() - Method in class com.google.common.collect.Constraints.ConstrainedList
 
listIterator(int) - Method in class com.google.common.collect.Constraints.ConstrainedList
 
listIterator() - Method in class com.google.common.collect.ForwardingList
 
listIterator(int) - Method in class com.google.common.collect.ForwardingList
 
listIterator() - Method in class com.google.common.collect.ImmutableList
 
listIterator(int) - Method in class com.google.common.collect.ImmutableList
 
listIterator(int) - Method in class com.google.common.collect.Lists.ReverseList
 
listIterator(int) - Method in class com.google.common.collect.Lists.TransformingRandomAccessList
 
listIterator(int) - Method in class com.google.common.collect.Lists.TransformingSequentialList
 
listIterator(int) - Method in class com.google.common.collect.RegularImmutableAsList
 
listIterator(int) - Method in class com.google.common.collect.RegularImmutableList
 
listIterator() - Method in class com.google.common.collect.Synchronized.SynchronizedList
 
listIterator(int) - Method in class com.google.common.collect.Synchronized.SynchronizedList
 
listIteratorImpl(List<E>, int) - Static method in class com.google.common.collect.Lists
Returns an implementation of List.listIterator(int).
ListMultimap<K,V> - Interface in com.google.common.collect
A Multimap that can hold duplicate key-value pairs and that maintains the insertion ordering of values for a given key.
listMultimap(ListMultimap<K, V>, Object) - Static method in class com.google.common.collect.Synchronized
 
ListMultimapBuilder() - Constructor for class com.google.common.collect.MultimapBuilder.ListMultimapBuilder
 
listProduct(List<BigInteger>) - Static method in class com.google.common.math.BigIntegerMath
 
listProduct(List<BigInteger>, int, int) - Static method in class com.google.common.math.BigIntegerMath
 
Lists - Class in com.google.common.collect
Static utility methods pertaining to List instances.
Lists() - Constructor for class com.google.common.collect.Lists
 
Lists.AbstractListWrapper<E> - Class in com.google.common.collect
 
Lists.CharSequenceAsList - Class in com.google.common.collect
 
Lists.OnePlusArrayList<E> - Class in com.google.common.collect
 
Lists.Partition<T> - Class in com.google.common.collect
 
Lists.RandomAccessListWrapper<E> - Class in com.google.common.collect
 
Lists.RandomAccessPartition<T> - Class in com.google.common.collect
 
Lists.RandomAccessReverseList<T> - Class in com.google.common.collect
 
Lists.ReverseList<T> - Class in com.google.common.collect
 
Lists.StringAsImmutableList - Class in com.google.common.collect
 
Lists.TransformingRandomAccessList<F,T> - Class in com.google.common.collect
Implementation of a transforming random access list.
Lists.TransformingSequentialList<F,T> - Class in com.google.common.collect
Implementation of a sequential transforming list.
Lists.TwoPlusArrayList<E> - Class in com.google.common.collect
 
LittleEndianDataInputStream - Class in com.google.common.io
An implementation of DataInput that uses little-endian byte ordering for reading short, int, float, double, and long values.
LittleEndianDataInputStream(InputStream) - Constructor for class com.google.common.io.LittleEndianDataInputStream
Creates a LittleEndianDataInputStream that wraps the given stream.
LittleEndianDataOutputStream - Class in com.google.common.io
An implementation of DataOutput that uses little-endian byte ordering for writing char, short, int, float, double, and long values.
LittleEndianDataOutputStream(OutputStream) - Constructor for class com.google.common.io.LittleEndianDataOutputStream
Creates a LittleEndianDataOutputStream that wraps the given stream.
LN_10 - Static variable in class com.google.common.math.BigIntegerMath
 
LN_2 - Static variable in class com.google.common.math.BigIntegerMath
 
LN_2 - Static variable in class com.google.common.math.DoubleMath
 
load(K) - Method in class com.google.common.cache.CacheLoader.FunctionToCacheLoader
 
load(K) - Method in class com.google.common.cache.CacheLoader
Computes or retrieves the value corresponding to key.
load(Object) - Method in class com.google.common.cache.CacheLoader.SupplierToCacheLoader
 
load() - Method in class com.google.common.reflect.ClassPath.ClassInfo
Loads (but doesn't link or initialize) the class.
LOAD_FACTOR - Static variable in class com.google.common.collect.HashBiMap
 
loadAll(Iterable<? extends K>) - Method in class com.google.common.cache.CacheLoader
Computes or retrieves the values corresponding to keys.
loadAll(Set<? extends K>, CacheLoader<? super K, V>) - Method in class com.google.common.cache.LocalCache
Returns the result of calling CacheLoader.loadAll(java.lang.Iterable<? extends K>), or null if loader doesn't implement loadAll.
loadAsync(K, int, LocalCache.LoadingValueReference<K, V>, CacheLoader<? super K, V>) - Method in class com.google.common.cache.LocalCache.Segment
 
loadCount() - Method in class com.google.common.cache.CacheStats
Returns the total number of times that Cache lookup methods attempted to load new values.
loader - Variable in class com.google.common.cache.LocalCache.ManualSerializationProxy
 
loader - Variable in class com.google.common.reflect.ClassPath.ResourceInfo
 
loadExceptionCount - Variable in class com.google.common.cache.AbstractCache.SimpleStatsCounter
 
loadExceptionCount - Variable in class com.google.common.cache.CacheStats
 
loadExceptionCount() - Method in class com.google.common.cache.CacheStats
Returns the number of times Cache lookup methods threw an exception while loading a new value.
loadExceptionRate() - Method in class com.google.common.cache.CacheStats
Returns the ratio of cache loading attempts which threw exceptions.
loadFinalizer() - Method in class com.google.common.base.FinalizableReferenceQueue.DecoupledLoader
 
loadFinalizer() - Method in class com.google.common.base.FinalizableReferenceQueue.DirectLoader
 
loadFinalizer() - Method in interface com.google.common.base.FinalizableReferenceQueue.FinalizerLoader
Returns Finalizer.class or null if this loader shouldn't or can't load it.
loadFinalizer(FinalizableReferenceQueue.FinalizerLoader...) - Static method in class com.google.common.base.FinalizableReferenceQueue
Iterates through the given loaders until it finds one that can load Finalizer.
loadFinalizer() - Method in class com.google.common.base.FinalizableReferenceQueue.SystemLoader
 
loadFuture(K, CacheLoader<? super K, V>) - Method in class com.google.common.cache.LocalCache.LoadingValueReference
 
LOADING_ERROR - Static variable in class com.google.common.base.FinalizableReferenceQueue.DecoupledLoader
 
LoadingCache<K,V> - Interface in com.google.common.cache
A semi-persistent mapping from keys to values.
LoadingSerializationProxy(LocalCache<K, V>) - Constructor for class com.google.common.cache.LocalCache.LoadingSerializationProxy
 
LoadingValueReference() - Constructor for class com.google.common.cache.LocalCache.LoadingValueReference
 
LoadingValueReference(LocalCache.ValueReference<K, V>) - Constructor for class com.google.common.cache.LocalCache.LoadingValueReference
 
loadSuccessCount - Variable in class com.google.common.cache.AbstractCache.SimpleStatsCounter
 
loadSuccessCount - Variable in class com.google.common.cache.CacheStats
 
loadSuccessCount() - Method in class com.google.common.cache.CacheStats
Returns the number of times Cache lookup methods have successfully loaded a new value.
loadSync(K, int, LocalCache.LoadingValueReference<K, V>, CacheLoader<? super K, V>) - Method in class com.google.common.cache.LocalCache.Segment
 
LocalCache<K,V> - Class in com.google.common.cache
The concurrent hash map implementation built by CacheBuilder.
LocalCache(CacheBuilder<? super K, ? super V>, CacheLoader<? super K, V>) - Constructor for class com.google.common.cache.LocalCache
Creates a new, empty map with the specified strategy, initial capacity and concurrency level.
localCache - Variable in class com.google.common.cache.LocalCache.LocalManualCache
 
LocalCache.AbstractCacheSet<T> - Class in com.google.common.cache
 
LocalCache.AbstractReferenceEntry<K,V> - Class in com.google.common.cache
 
LocalCache.AccessQueue<K,V> - Class in com.google.common.cache
A custom queue for managing access order.
LocalCache.EntryFactory - Enum in com.google.common.cache
Creates new entries.
LocalCache.EntryIterator - Class in com.google.common.cache
 
LocalCache.EntrySet - Class in com.google.common.cache
 
LocalCache.HashIterator<T> - Class in com.google.common.cache
 
LocalCache.KeyIterator - Class in com.google.common.cache
 
LocalCache.KeySet - Class in com.google.common.cache
 
LocalCache.LoadingSerializationProxy<K,V> - Class in com.google.common.cache
Serializes the configuration of a LocalCache, reconsitituting it as an LoadingCache using CacheBuilder upon deserialization.
LocalCache.LoadingValueReference<K,V> - Class in com.google.common.cache
 
LocalCache.LocalLoadingCache<K,V> - Class in com.google.common.cache
 
LocalCache.LocalManualCache<K,V> - Class in com.google.common.cache
 
LocalCache.ManualSerializationProxy<K,V> - Class in com.google.common.cache
Serializes the configuration of a LocalCache, reconsitituting it as a Cache using CacheBuilder upon deserialization.
LocalCache.NullEntry - Enum in com.google.common.cache
 
LocalCache.ReferenceEntry<K,V> - Interface in com.google.common.cache
An entry in a reference map.
LocalCache.Segment<K,V> - Class in com.google.common.cache
Segments are specialized versions of hash tables.
LocalCache.SoftValueReference<K,V> - Class in com.google.common.cache
References a soft value.
LocalCache.Strength - Enum in com.google.common.cache
 
LocalCache.StrongAccessEntry<K,V> - Class in com.google.common.cache
 
LocalCache.StrongAccessWriteEntry<K,V> - Class in com.google.common.cache
 
LocalCache.StrongEntry<K,V> - Class in com.google.common.cache
Used for strongly-referenced keys.
LocalCache.StrongValueReference<K,V> - Class in com.google.common.cache
References a strong value.
LocalCache.StrongWriteEntry<K,V> - Class in com.google.common.cache
 
LocalCache.ValueIterator - Class in com.google.common.cache
 
LocalCache.ValueReference<K,V> - Interface in com.google.common.cache
A reference to a value.
LocalCache.Values - Class in com.google.common.cache
 
LocalCache.WeakAccessEntry<K,V> - Class in com.google.common.cache
 
LocalCache.WeakAccessWriteEntry<K,V> - Class in com.google.common.cache
 
LocalCache.WeakEntry<K,V> - Class in com.google.common.cache
Used for weakly-referenced keys.
LocalCache.WeakValueReference<K,V> - Class in com.google.common.cache
References a weak value.
LocalCache.WeakWriteEntry<K,V> - Class in com.google.common.cache
 
LocalCache.WeightedSoftValueReference<K,V> - Class in com.google.common.cache
References a soft value.
LocalCache.WeightedStrongValueReference<K,V> - Class in com.google.common.cache
References a strong value.
LocalCache.WeightedWeakValueReference<K,V> - Class in com.google.common.cache
References a weak value.
LocalCache.WriteQueue<K,V> - Class in com.google.common.cache
A custom queue for managing eviction order.
LocalCache.WriteThroughEntry - Class in com.google.common.cache
Custom Entry class used by EntryIterator.next(), that relays setValue changes to the underlying map.
LocalLoadingCache(CacheBuilder<? super K, ? super V>, CacheLoader<? super K, V>) - Constructor for class com.google.common.cache.LocalCache.LocalLoadingCache
 
LocalManualCache(CacheBuilder<? super K, ? super V>) - Constructor for class com.google.common.cache.LocalCache.LocalManualCache
 
LocalManualCache(LocalCache<K, V>) - Constructor for class com.google.common.cache.LocalCache.LocalManualCache
 
LOCATION - Static variable in class com.google.common.net.HttpHeaders
The HTTP Location header field name.
lock - Variable in class com.google.common.util.concurrent.AbstractScheduledService.CustomScheduler.ReschedulableCallable
This lock is used to ensure safe and correct cancellation, it ensures that a new task is not scheduled while a cancel is ongoing.
lock() - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory.CycleDetectingReentrantLock
 
lock() - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory.CycleDetectingReentrantReadLock
 
lock() - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory.CycleDetectingReentrantWriteLock
 
lock - Variable in class com.google.common.util.concurrent.Monitor
The lock underlying this monitor.
lock - Variable in class com.google.common.util.concurrent.MoreExecutors.DirectExecutorService
Lock used whenever accessing the state variables (runningTasks, shutdown, terminationCondition) of the executor
lock(int) - Static method in class com.google.common.util.concurrent.Striped
Creates a Striped<Lock> with eagerly initialized, strongly referenced locks.
lockedGetOrLoad(K, int, CacheLoader<? super K, V>) - Method in class com.google.common.cache.LocalCache.Segment
 
lockGraphNode - Variable in class com.google.common.util.concurrent.CycleDetectingLockFactory.CycleDetectingReentrantLock
 
lockGraphNode - Variable in class com.google.common.util.concurrent.CycleDetectingLockFactory.CycleDetectingReentrantReadWriteLock
 
LockGraphNode(String) - Constructor for class com.google.common.util.concurrent.CycleDetectingLockFactory.LockGraphNode
 
lockGraphNodes - Variable in class com.google.common.util.concurrent.CycleDetectingLockFactory.WithExplicitOrdering
 
lockGraphNodesPerType - Static variable in class com.google.common.util.concurrent.CycleDetectingLockFactory
 
lockInterruptibly() - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory.CycleDetectingReentrantLock
 
lockInterruptibly() - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory.CycleDetectingReentrantReadLock
 
lockInterruptibly() - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory.CycleDetectingReentrantWriteLock
 
lockName - Variable in class com.google.common.util.concurrent.CycleDetectingLockFactory.LockGraphNode
 
locks - Variable in class com.google.common.util.concurrent.Striped.LargeLazyStriped
 
locks - Variable in class com.google.common.util.concurrent.Striped.SmallLazyStriped
 
lockStateChanged(CycleDetectingLockFactory.CycleDetectingLock) - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory
CycleDetectingLock implementations must call this method in a finally clause after any attempt to change the lock state, including both lock and unlock attempts.
log - Static variable in class com.google.common.util.concurrent.ExecutionList
 
log - Static variable in class com.google.common.util.concurrent.Futures.ImmediateFuture
 
log - Static variable in class com.google.common.util.concurrent.SerializingExecutor
 
log10(BigInteger, RoundingMode) - Static method in class com.google.common.math.BigIntegerMath
Returns the base-10 logarithm of x, rounded according to the specified rounding mode.
log10(int, RoundingMode) - Static method in class com.google.common.math.IntMath
Returns the base-10 logarithm of x, rounded according to the specified rounding mode.
log10(long, RoundingMode) - Static method in class com.google.common.math.LongMath
Returns the base-10 logarithm of x, rounded according to the specified rounding mode.
log10Floor(int) - Static method in class com.google.common.math.IntMath
 
log10Floor(long) - Static method in class com.google.common.math.LongMath
 
log2(BigInteger, RoundingMode) - Static method in class com.google.common.math.BigIntegerMath
Returns the base-2 logarithm of x, rounded according to the specified rounding mode.
log2(double) - Static method in class com.google.common.math.DoubleMath
Returns the base 2 logarithm of a double value.
log2(double, RoundingMode) - Static method in class com.google.common.math.DoubleMath
Returns the base 2 logarithm of a double value, rounded with the specified rounding mode to an int.
log2(int, RoundingMode) - Static method in class com.google.common.math.IntMath
Returns the base-2 logarithm of x, rounded according to the specified rounding mode.
log2(long, RoundingMode) - Static method in class com.google.common.math.LongMath
Returns the base-2 logarithm of x, rounded according to the specified rounding mode.
logger - Static variable in class com.google.common.base.FinalizableReferenceQueue
 
logger - Static variable in class com.google.common.base.internal.Finalizer
 
logger - Static variable in class com.google.common.cache.CacheBuilder
 
logger - Static variable in class com.google.common.cache.LocalCache
 
logger - Static variable in class com.google.common.collect.MapMakerInternalMap
 
logger - Variable in class com.google.common.eventbus.EventBus.LoggingSubscriberExceptionHandler
Logger for event dispatch failures.
logger - Static variable in class com.google.common.io.Closeables
 
logger - Static variable in class com.google.common.io.Flushables
 
logger - Static variable in class com.google.common.reflect.ClassPath
 
logger - Static variable in class com.google.common.util.concurrent.AbstractExecutionThreadService
 
logger - Static variable in class com.google.common.util.concurrent.AbstractScheduledService
 
logger - Static variable in class com.google.common.util.concurrent.CycleDetectingLockFactory
 
logger - Static variable in class com.google.common.util.concurrent.Futures.CombinedFuture
 
logger - Static variable in class com.google.common.util.concurrent.ListenerCallQueue
 
logger - Static variable in class com.google.common.util.concurrent.ServiceManager
 
logger - Static variable in class com.google.common.util.concurrent.UncaughtExceptionHandlers.Exiter
 
LoggingSubscriberExceptionHandler(String) - Constructor for class com.google.common.eventbus.EventBus.LoggingSubscriberExceptionHandler
 
LoggingSuppressor() - Constructor for class com.google.common.io.Closer.LoggingSuppressor
 
LongAddable - Interface in com.google.common.cache
Abstract interface for objects that can concurrently add longs.
LongAddables - Class in com.google.common.cache
Source of LongAddable objects that deals with GWT, Unsafe, and all that.
LongAddables() - Constructor for class com.google.common.cache.LongAddables
 
LongAddables.PureJavaLongAddable - Class in com.google.common.cache
 
LongAdder - Class in com.google.common.cache
One or more variables that together maintain an initially zero long sum.
LongAdder() - Constructor for class com.google.common.cache.LongAdder
Creates a new adder with initial sum of zero.
LongArrayAsList(long[]) - Constructor for class com.google.common.primitives.Longs.LongArrayAsList
 
LongArrayAsList(long[], int, int) - Constructor for class com.google.common.primitives.Longs.LongArrayAsList
 
LongConverter() - Constructor for class com.google.common.primitives.Longs.LongConverter
 
LongDomain() - Constructor for class com.google.common.collect.DiscreteDomain.LongDomain
 
longFunnel() - Static method in class com.google.common.hash.Funnels
Returns a funnel for longs.
LongFunnel() - Constructor for enum com.google.common.hash.Funnels.LongFunnel
 
LongHashCode(long) - Constructor for class com.google.common.hash.HashCode.LongHashCode
 
LongMath - Class in com.google.common.math
A class for arithmetic on values of type long.
LongMath() - Constructor for class com.google.common.math.LongMath
 
LongParser() - Constructor for class com.google.common.cache.CacheBuilderSpec.LongParser
 
longs() - Static method in class com.google.common.collect.DiscreteDomain
Returns the discrete domain for values of type Long.
Longs - Class in com.google.common.primitives
Static utility methods pertaining to long primitives, that are not already found in either Long or Arrays.
Longs() - Constructor for class com.google.common.primitives.Longs
 
longs - Variable in class com.google.common.util.concurrent.AtomicDoubleArray
 
Longs.LexicographicalComparator - Enum in com.google.common.primitives
 
Longs.LongArrayAsList - Class in com.google.common.primitives
 
Longs.LongConverter - Class in com.google.common.primitives
 
longSize() - Method in class com.google.common.cache.LocalCache
 
longValue() - Method in class com.google.common.cache.LongAdder
Equivalent to LongAdder.sum().
longValue() - Method in class com.google.common.primitives.UnsignedInteger
Returns the value of this UnsignedInteger as a long.
longValue() - Method in class com.google.common.primitives.UnsignedLong
Returns the value of this UnsignedLong as a long.
longValue() - Method in class com.google.common.util.concurrent.AtomicDouble
Returns the value of this AtomicDouble as a long after a narrowing primitive conversion.
LOOPBACK4 - Static variable in class com.google.common.net.InetAddresses
 
lower(K) - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableKeySet
 
lower(V) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedNavigableSet
 
lower(E) - Method in class com.google.common.collect.DescendingImmutableSortedSet
 
lower(E) - Method in class com.google.common.collect.ForwardingNavigableSet
 
lower(E) - Method in class com.google.common.collect.ImmutableSortedSet
 
lower(K) - Method in class com.google.common.collect.Maps.NavigableKeySet
 
lower(E) - Method in class com.google.common.collect.RegularImmutableSortedSet
 
lower(E) - Method in class com.google.common.collect.Sets.DescendingSet
 
lower(E) - Method in class com.google.common.collect.Sets.FilteredNavigableSet
 
lower(E) - Method in class com.google.common.collect.Sets.UnmodifiableNavigableSet
 
lower(E) - Method in class com.google.common.collect.SortedMultisets.NavigableElementSet
 
lower(E) - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableSet
 
LOWER_BOUND_FN - Static variable in class com.google.common.collect.Range
 
lowerBound - Variable in class com.google.common.collect.Range
 
lowerBound - Variable in class com.google.common.collect.TreeBasedTable.TreeRow
 
lowerBoundFn() - Static method in class com.google.common.collect.Range
 
lowerBounds - Variable in class com.google.common.reflect.Types.WildcardTypeImpl
 
lowerBoundType - Variable in class com.google.common.collect.GeneralRange
 
lowerBoundType() - Method in class com.google.common.collect.Range
Returns the type of this range's lower bound: BoundType.CLOSED if the range includes its lower endpoint, BoundType.OPEN if it does not.
lowerBoundWindow - Variable in class com.google.common.collect.TreeRangeSet.SubRangeSetRangesByLowerBound
lowerBoundWindow is the headMap/subMap/tailMap view; it only restricts the keys, and does not affect the values.
lowerCase() - Method in class com.google.common.io.BaseEncoding.Alphabet
 
lowerCase() - Method in class com.google.common.io.BaseEncoding
Returns an encoding that behaves equivalently to this encoding, but encodes and decodes with lowercase letters.
lowerCase() - Method in class com.google.common.io.BaseEncoding.SeparatedBaseEncoding
 
lowerCase - Variable in class com.google.common.io.BaseEncoding.StandardBaseEncoding
 
lowerCase() - Method in class com.google.common.io.BaseEncoding.StandardBaseEncoding
 
lowerEndpoint - Variable in class com.google.common.collect.GeneralRange
 
lowerEndpoint() - Method in class com.google.common.collect.Range
Returns the lower endpoint of this range.
lowerEntry(K) - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableAsMap
 
lowerEntry(K) - Method in class com.google.common.collect.AbstractNavigableMap
 
lowerEntry(K) - Method in class com.google.common.collect.ForwardingNavigableMap
 
lowerEntry(K) - Method in class com.google.common.collect.ImmutableSortedMap
 
lowerEntry(K) - Method in class com.google.common.collect.Maps.DescendingMap
 
lowerEntry(K) - Method in class com.google.common.collect.Maps.TransformedEntriesNavigableMap
 
lowerEntry(K) - Method in class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
lowerEntry(K) - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableMap
 
lowerKey(K) - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableAsMap
 
lowerKey(K) - Method in class com.google.common.collect.AbstractNavigableMap
 
lowerKey(K) - Method in class com.google.common.collect.ForwardingNavigableMap
 
lowerKey(K) - Method in class com.google.common.collect.ImmutableSortedMap
 
lowerKey(K) - Method in class com.google.common.collect.Maps.DescendingMap
 
lowerKey(K) - Method in class com.google.common.collect.Maps.TransformedEntriesNavigableMap
 
lowerKey(K) - Method in class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
lowerKey(K) - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableMap
 

M

maintainEmptyInvariant() - Method in class com.google.common.collect.StandardTable.Row
 
maintainEmptyInvariant() - Method in class com.google.common.collect.TreeBasedTable.TreeRow
 
makeChecked(ListenableFuture<V>, Function<? super Exception, X>) - Static method in class com.google.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.
makeComplementByHand(Collection<E>, Class<E>) - Static method in class com.google.common.collect.Sets
 
makeComputingMap(Function<? super K, ? extends V>) - Method in class com.google.common.collect.GenericMapMaker
Deprecated.
makeComputingMap(Function<? super K, ? extends V>) - Method in class com.google.common.collect.MapMaker
makeCustomMap() - Method in class com.google.common.collect.GenericMapMaker
Deprecated.
makeCustomMap() - Method in class com.google.common.collect.MapMaker
Returns a MapMakerInternalMap for the benefit of internal callers that use features of that class not exposed through ConcurrentMap.
makeHash(Hasher[]) - Method in class com.google.common.hash.AbstractCompositeHashFunction
Constructs a HashCode from the Hasher objects of the functions.
makeHash() - Method in class com.google.common.hash.AbstractStreamingHashFunction.AbstractStreamingHasher
 
makeHash(Hasher[]) - Method in class com.google.common.hash.Hashing.ConcatenatedHashFunction
 
makeHash() - Method in class com.google.common.hash.Murmur3_128HashFunction.Murmur3_128Hasher
 
makeHash() - Method in class com.google.common.hash.Murmur3_32HashFunction.Murmur3_32Hasher
 
makeHash() - Method in class com.google.common.hash.SipHashFunction.SipHasher
 
makeIndex(ImmutableSet<E>) - Static method in class com.google.common.collect.DenseImmutableTable
 
makeMap() - Method in class com.google.common.collect.GenericMapMaker
Deprecated.
makeMap() - Method in class com.google.common.collect.MapMaker
Builds a thread-safe map, without on-demand computation of values.
makeSubscriber(Object, Method) - Static method in class com.google.common.eventbus.AnnotatedSubscriberFinder
Creates an EventSubscriber for subsequently calling method on listener.
ManualSerializationProxy(LocalCache<K, V>) - Constructor for class com.google.common.cache.LocalCache.ManualSerializationProxy
 
ManualSerializationProxy(LocalCache.Strength, LocalCache.Strength, Equivalence<Object>, Equivalence<Object>, long, long, long, Weigher<K, V>, int, RemovalListener<? super K, ? super V>, Ticker, CacheLoader<? super K, V>) - Constructor for class com.google.common.cache.LocalCache.ManualSerializationProxy
 
map - Variable in class com.google.common.base.Functions.ForMapWithDefault
 
map - Variable in class com.google.common.base.Functions.FunctionForMapNoDefault
 
map - Variable in class com.google.common.cache.LocalCache.AbstractCacheSet
 
map - Variable in class com.google.common.cache.LocalCache.Segment
 
map - Variable in class com.google.common.cache.LocalCache.Values
 
map() - Method in class com.google.common.collect.AbstractMapBasedMultimap.AsMap.AsMapEntries
 
map - Variable in class com.google.common.collect.AbstractMapBasedMultimap
 
map() - Method in class com.google.common.collect.ForwardingMap.StandardEntrySet
 
map() - Method in class com.google.common.collect.HashBiMap.EntrySet
 
map - Variable in class com.google.common.collect.ImmutableMapEntrySet.EntrySetSerializedForm
 
map() - Method in class com.google.common.collect.ImmutableMapEntrySet
 
map - Variable in class com.google.common.collect.ImmutableMapKeySet.KeySetSerializedForm
 
map - Variable in class com.google.common.collect.ImmutableMapKeySet
 
map - Variable in class com.google.common.collect.ImmutableMapValues
 
map - Variable in class com.google.common.collect.ImmutableMapValues.SerializedForm
 
map - Variable in class com.google.common.collect.ImmutableMultimap
 
map - Variable in class com.google.common.collect.Interners.WeakInterner
 
map - Variable in class com.google.common.collect.MapMakerInternalMap.Segment
 
map() - Method in class com.google.common.collect.Maps.EntrySet
 
map - Variable in class com.google.common.collect.Maps.KeySet
 
map() - Method in class com.google.common.collect.Maps.KeySet
 
map() - Method in class com.google.common.collect.Maps.NavigableKeySet
 
map() - Method in class com.google.common.collect.Maps.SortedKeySet
 
map - Variable in class com.google.common.collect.Maps.Values
 
map() - Method in class com.google.common.collect.Maps.Values
 
map() - Method in class com.google.common.collect.Multimaps.AsMap.EntrySet
 
map - Variable in class com.google.common.collect.Multimaps.MapMultimap
 
map - Variable in class com.google.common.collect.Multimaps.UnmodifiableMultimap
 
map() - Method in class com.google.common.collect.RegularImmutableBiMap.Inverse.InverseEntrySet
 
map() - Method in class com.google.common.collect.RegularImmutableMap.EntrySet
 
map - Variable in class com.google.common.collect.RegularImmutableMultiset
 
map() - Method in class com.google.common.collect.RegularImmutableSortedMap.EntrySet
 
map() - Method in class com.google.common.collect.StandardTable.Row.RowEntrySet
 
map(Map<K, V>, Object) - Static method in class com.google.common.collect.Synchronized
 
map() - Method in class com.google.common.collect.WellBehavedMap.EntrySet
 
map - Variable in class com.google.common.escape.CharEscaperBuilder
 
map(File) - Static method in class com.google.common.io.Files
Fully maps a file read-only in to memory as per FileChannel.map(java.nio.channels.FileChannel.MapMode, long, long).
map(File, FileChannel.MapMode) - Static method in class com.google.common.io.Files
Fully maps a file in to memory as per FileChannel.map(java.nio.channels.FileChannel.MapMode, long, long) using the requested FileChannel.MapMode.
map(File, FileChannel.MapMode, long) - Static method in class com.google.common.io.Files
Maps a file in to memory as per FileChannel.map(java.nio.channels.FileChannel.MapMode, long, long) using the requested FileChannel.MapMode.
map(RandomAccessFile, FileChannel.MapMode, long) - Static method in class com.google.common.io.Files
 
map(TypeResolver.TypeVariableKey, Type) - Method in class com.google.common.reflect.TypeResolver.TypeMappingIntrospector
 
map - Variable in class com.google.common.reflect.TypeResolver.TypeTable
 
map - Variable in class com.google.common.util.concurrent.AtomicLongMap
 
MAP_FIELD_SETTER - Static variable in class com.google.common.collect.ImmutableMultimap.FieldSettersHolder
 
MapBasedMultisetIterator() - Constructor for class com.google.common.collect.AbstractMapBasedMultiset.MapBasedMultisetIterator
 
mapBuilder - Variable in class com.google.common.collect.ImmutableClassToInstanceMap.Builder
 
mapBuilder - Variable in class com.google.common.reflect.ImmutableTypeToInstanceMap.Builder
 
MapConstraint<K,V> - Interface in com.google.common.collect
A constraint on the keys and values that may be added to a Map or Multimap.
MapConstraints - Class in com.google.common.collect
Factory and utilities pertaining to the MapConstraint interface.
MapConstraints() - Constructor for class com.google.common.collect.MapConstraints
 
MapConstraints.ConstrainedAsMapEntries<K,V> - Class in com.google.common.collect
 
MapConstraints.ConstrainedAsMapValues<K,V> - Class in com.google.common.collect
 
MapConstraints.ConstrainedBiMap<K,V> - Class in com.google.common.collect
 
MapConstraints.ConstrainedEntries<K,V> - Class in com.google.common.collect
 
MapConstraints.ConstrainedEntrySet<K,V> - Class in com.google.common.collect
 
MapConstraints.ConstrainedListMultimap<K,V> - Class in com.google.common.collect
 
MapConstraints.ConstrainedMap<K,V> - Class in com.google.common.collect
 
MapConstraints.ConstrainedMultimap<K,V> - Class in com.google.common.collect
 
MapConstraints.ConstrainedSetMultimap<K,V> - Class in com.google.common.collect
 
MapConstraints.ConstrainedSortedSetMultimap<K,V> - Class in com.google.common.collect
 
MapConstraints.InverseConstraint<K,V> - Class in com.google.common.collect
 
MapConstraints.NotNullMapConstraint - Enum in com.google.common.collect
 
MapDifference<K,V> - Interface in com.google.common.collect
An object representing the differences between two maps.
MapDifference.ValueDifference<V> - Interface in com.google.common.collect
A difference between the mappings from two maps with the same key.
MapDifferenceImpl(Map<K, V>, Map<K, V>, Map<K, V>, Map<K, MapDifference.ValueDifference<V>>) - Constructor for class com.google.common.collect.Maps.MapDifferenceImpl
 
mapException(Exception) - Method in class com.google.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.
mapException(Exception) - Method in class com.google.common.util.concurrent.Futures.MappingCheckedFuture
 
mapIterator - Variable in class com.google.common.collect.ImmutableMultimap.Itr
 
mapIterator - Variable in class com.google.common.collect.StandardTable.ColumnKeyIterator
 
MapJoiner(Joiner, String) - Constructor for class com.google.common.base.Joiner.MapJoiner
 
MapMaker - Class in com.google.common.collect
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 on-demand computation of values for keys not already present
MapMaker() - Constructor for class com.google.common.collect.MapMaker
Constructs a new MapMaker instance with default settings, including strong keys, strong values, and no automatic eviction of any kind.
MapMaker.ComputingMapAdapter<K,V> - Class in com.google.common.collect
Overrides get() to compute on demand.
MapMaker.NullComputingConcurrentMap<K,V> - Class in com.google.common.collect
Computes on retrieval and evicts the result.
MapMaker.NullConcurrentMap<K,V> - Class in com.google.common.collect
A map that is always empty and evicts on insertion.
MapMaker.RemovalCause - Enum in com.google.common.collect
The reason why an entry was removed.
MapMaker.RemovalListener<K,V> - Interface in com.google.common.collect
An object that can receive a notification when an entry is removed from a map.
MapMaker.RemovalNotification<K,V> - Class in com.google.common.collect
A notification of the removal of a single entry.
MapMakerInternalMap<K,V> - Class in com.google.common.collect
The concurrent hash map implementation built by MapMaker.
MapMakerInternalMap(MapMaker) - Constructor for class com.google.common.collect.MapMakerInternalMap
Creates a new, empty map with the specified strategy, initial capacity and concurrency level.
MapMakerInternalMap.AbstractReferenceEntry<K,V> - Class in com.google.common.collect
 
MapMakerInternalMap.AbstractSerializationProxy<K,V> - Class in com.google.common.collect
The actual object that gets serialized.
MapMakerInternalMap.CleanupMapTask - Class in com.google.common.collect
 
MapMakerInternalMap.EntryFactory - Enum in com.google.common.collect
Creates new entries.
MapMakerInternalMap.EntryIterator - Class in com.google.common.collect
 
MapMakerInternalMap.EntrySet - Class in com.google.common.collect
 
MapMakerInternalMap.EvictionQueue<K,V> - Class in com.google.common.collect
A custom queue for managing eviction order.
MapMakerInternalMap.ExpirationQueue<K,V> - Class in com.google.common.collect
A custom queue for managing expiration order.
MapMakerInternalMap.HashIterator<E> - Class in com.google.common.collect
 
MapMakerInternalMap.KeyIterator - Class in com.google.common.collect
 
MapMakerInternalMap.KeySet - Class in com.google.common.collect
 
MapMakerInternalMap.NullEntry - Enum in com.google.common.collect
 
MapMakerInternalMap.ReferenceEntry<K,V> - Interface in com.google.common.collect
An entry in a reference map.
MapMakerInternalMap.Segment<K,V> - Class in com.google.common.collect
Segments are specialized versions of hash tables.
MapMakerInternalMap.SerializationProxy<K,V> - Class in com.google.common.collect
The actual object that gets serialized.
MapMakerInternalMap.SoftEntry<K,V> - Class in com.google.common.collect
Used for softly-referenced keys.
MapMakerInternalMap.SoftEvictableEntry<K,V> - Class in com.google.common.collect
 
MapMakerInternalMap.SoftExpirableEntry<K,V> - Class in com.google.common.collect
 
MapMakerInternalMap.SoftExpirableEvictableEntry<K,V> - Class in com.google.common.collect
 
MapMakerInternalMap.SoftValueReference<K,V> - Class in com.google.common.collect
References a soft value.
MapMakerInternalMap.Strength - Enum in com.google.common.collect
 
MapMakerInternalMap.StrongEntry<K,V> - Class in com.google.common.collect
Used for strongly-referenced keys.
MapMakerInternalMap.StrongEvictableEntry<K,V> - Class in com.google.common.collect
 
MapMakerInternalMap.StrongExpirableEntry<K,V> - Class in com.google.common.collect
 
MapMakerInternalMap.StrongExpirableEvictableEntry<K,V> - Class in com.google.common.collect
 
MapMakerInternalMap.StrongValueReference<K,V> - Class in com.google.common.collect
References a strong value.
MapMakerInternalMap.ValueIterator - Class in com.google.common.collect
 
MapMakerInternalMap.ValueReference<K,V> - Interface in com.google.common.collect
A reference to a value.
MapMakerInternalMap.Values - Class in com.google.common.collect
 
MapMakerInternalMap.WeakEntry<K,V> - Class in com.google.common.collect
Used for weakly-referenced keys.
MapMakerInternalMap.WeakEvictableEntry<K,V> - Class in com.google.common.collect
 
MapMakerInternalMap.WeakExpirableEntry<K,V> - Class in com.google.common.collect
 
MapMakerInternalMap.WeakExpirableEvictableEntry<K,V> - Class in com.google.common.collect
 
MapMakerInternalMap.WeakValueReference<K,V> - Class in com.google.common.collect
References a weak value.
MapMakerInternalMap.WriteThroughEntry - Class in com.google.common.collect
Custom Entry class used by EntryIterator.next(), that relays setValue changes to the underlying map.
MapMultimap(Map<K, V>) - Constructor for class com.google.common.collect.Multimaps.MapMultimap
 
mapper - Variable in class com.google.common.util.concurrent.Futures.MappingCheckedFuture
 
MappingCheckedFuture(ListenableFuture<V>, Function<? super Exception, X>) - Constructor for class com.google.common.util.concurrent.Futures.MappingCheckedFuture
 
mappings - Variable in class com.google.common.reflect.TypeResolver.TypeMappingIntrospector
 
mapReference - Variable in class com.google.common.collect.MapMakerInternalMap.CleanupMapTask
 
Maps - Class in com.google.common.collect
Static utility methods pertaining to Map instances (including instances of SortedMap, BiMap, etc.).
Maps() - Constructor for class com.google.common.collect.Maps
 
Maps.AbstractFilteredMap<K,V> - Class in com.google.common.collect
 
Maps.AsMapView<K,V> - Class in com.google.common.collect
 
Maps.BiMapConverter<A,B> - Class in com.google.common.collect
 
Maps.DescendingMap<K,V> - Class in com.google.common.collect
 
Maps.EntryFunction - Enum in com.google.common.collect
 
Maps.EntrySet<K,V> - Class in com.google.common.collect
 
Maps.EntryTransformer<K,V1,V2> - Interface in com.google.common.collect
A transformation of the value of a key-value pair, using both key and value as inputs.
Maps.FilteredEntryBiMap<K,V> - Class in com.google.common.collect
 
Maps.FilteredEntryMap<K,V> - Class in com.google.common.collect
 
Maps.FilteredEntryMap.EntrySet - Class in com.google.common.collect
 
Maps.FilteredEntryMap.KeySet - Class in com.google.common.collect
 
Maps.FilteredEntryNavigableMap<K,V> - Class in com.google.common.collect
 
Maps.FilteredEntrySortedMap<K,V> - Class in com.google.common.collect
 
Maps.FilteredEntrySortedMap.SortedKeySet - Class in com.google.common.collect
 
Maps.FilteredKeyMap<K,V> - Class in com.google.common.collect
 
Maps.FilteredMapValues<K,V> - Class in com.google.common.collect
 
Maps.ImprovedAbstractMap<K,V> - Class in com.google.common.collect
AbstractMap extension that implements AbstractMap.isEmpty() as entrySet().isEmpty() instead of size() == 0 to speed up implementations where size() is O(n), and it delegates the isEmpty() methods of its key set and value collection to this implementation.
Maps.KeySet<K,V> - Class in com.google.common.collect
 
Maps.MapDifferenceImpl<K,V> - Class in com.google.common.collect
 
Maps.NavigableAsMapView<K,V> - Class in com.google.common.collect
 
Maps.NavigableKeySet<K,V> - Class in com.google.common.collect
 
Maps.SortedAsMapView<K,V> - Class in com.google.common.collect
 
Maps.SortedKeySet<K,V> - Class in com.google.common.collect
 
Maps.SortedMapDifferenceImpl<K,V> - Class in com.google.common.collect
 
Maps.TransformedEntriesMap<K,V1,V2> - Class in com.google.common.collect
 
Maps.TransformedEntriesNavigableMap<K,V1,V2> - Class in com.google.common.collect
 
Maps.TransformedEntriesSortedMap<K,V1,V2> - Class in com.google.common.collect
 
Maps.UnmodifiableBiMap<K,V> - Class in com.google.common.collect
 
Maps.UnmodifiableEntries<K,V> - Class in com.google.common.collect
 
Maps.UnmodifiableEntrySet<K,V> - Class in com.google.common.collect
 
Maps.UnmodifiableNavigableMap<K,V> - Class in com.google.common.collect
 
Maps.ValueDifferenceImpl<V> - Class in com.google.common.collect
 
Maps.Values<K,V> - Class in com.google.common.collect
 
mapsAsMapSortedSet(SortedSet<K>, Function<? super K, V>) - Static method in class com.google.common.collect.Platform
 
mapsFilterSortedMap(SortedMap<K, V>, Predicate<? super Map.Entry<K, V>>) - Static method in class com.google.common.collect.Platform
 
MapSplitter(Splitter, Splitter) - Constructor for class com.google.common.base.Splitter.MapSplitter
 
mapsTransformEntriesSortedMap(SortedMap<K, V1>, Maps.EntryTransformer<? super K, ? super V1, V2>) - Static method in class com.google.common.collect.Platform
 
MapViewOfValuesAsSingletonSets(ImmutableMap<K, V>) - Constructor for class com.google.common.collect.ImmutableMap.MapViewOfValuesAsSingletonSets
 
mark(int) - Method in class com.google.common.hash.HashingInputStream
mark() is not supported for HashingInputStream
mark - Variable in class com.google.common.io.ByteStreams.LimitedInputStream
 
mark(int) - Method in class com.google.common.io.ByteStreams.LimitedInputStream
 
mark - Variable in class com.google.common.io.CharSequenceReader
 
mark(int) - Method in class com.google.common.io.CharSequenceReader
 
mark - Variable in class com.google.common.io.CountingInputStream
 
mark(int) - Method in class com.google.common.io.CountingInputStream
 
markReady() - Method in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState
Marks the Service.State as ready to receive transitions.
markSupported() - Method in class com.google.common.hash.HashingInputStream
mark() is not supported for HashingInputStream
markSupported() - Method in class com.google.common.io.CharSequenceReader
 
markSupported() - Method in class com.google.common.io.MultiInputStream
 
mask - Variable in class com.google.common.collect.HashBiMap
 
mask() - Method in class com.google.common.collect.LinkedHashMultimap.ValueSet
 
mask - Variable in class com.google.common.collect.RegularImmutableBiMap
 
mask - Variable in class com.google.common.collect.RegularImmutableMap
 
mask - Variable in class com.google.common.collect.RegularImmutableSet
 
mask - Variable in class com.google.common.collect.Sets.SubSet
 
mask - Variable in class com.google.common.io.BaseEncoding.Alphabet
 
mask - Variable in class com.google.common.util.concurrent.Striped.PowerOfTwoStriped
Capacity (power of two) minus one, for fast mod evaluation
matches(char) - Method in class com.google.common.base.CharMatcher.And
 
matches(char) - Method in class com.google.common.base.CharMatcher.BitSetMatcher
 
matches(char) - Method in class com.google.common.base.CharMatcher
Determines a true or false value for the given character.
matches(char) - Method in class com.google.common.base.CharMatcher.NegatedMatcher
 
matches(char) - Method in class com.google.common.base.CharMatcher.Or
 
matches(char) - Method in class com.google.common.base.CharMatcher.RangesMatcher
 
matches(char) - Method in class com.google.common.base.SmallCharMatcher
 
matches(char) - Method in class com.google.common.io.BaseEncoding.Alphabet
 
matchesAllOf(CharSequence) - Method in class com.google.common.base.CharMatcher
Returns true if a character sequence contains only matching characters.
matchesAllOf(CharSequence) - Method in class com.google.common.base.CharMatcher.NegatedMatcher
 
matchesAnyOf(CharSequence) - Method in class com.google.common.base.CharMatcher
Returns true if a character sequence contains at least one matching character.
matchesNoneOf(CharSequence) - Method in class com.google.common.base.CharMatcher
Returns true if a character sequence contains no matching characters.
matchesNoneOf(CharSequence) - Method in class com.google.common.base.CharMatcher.NegatedMatcher
 
matchesValue(Object, int) - Method in class com.google.common.collect.LinkedHashMultimap.ValueEntry
 
matchesWildcardPublicSuffix(String) - Static method in class com.google.common.net.InternetDomainName
Does the domain name match one of the "wildcard" patterns (e.g.
matchTypeArgument(Type, Type) - Static method in class com.google.common.reflect.TypeToken
 
MathPreconditions - Class in com.google.common.math
A collection of preconditions for math functions.
MathPreconditions() - Constructor for class com.google.common.math.MathPreconditions
 
MAX - Static variable in class com.google.common.base.Ascii
The maximum value of an ASCII character.
max(Iterator<E>) - Method in class com.google.common.collect.Ordering
Returns the greatest of the specified values according to this ordering.
max(Iterable<E>) - Method in class com.google.common.collect.Ordering
Returns the greatest of the specified values according to this ordering.
max(E, E) - Method in class com.google.common.collect.Ordering
Returns the greater of the two values according to this ordering.
max(E, E, E, E...) - Method in class com.google.common.collect.Ordering
Returns the greatest of the specified values according to this ordering.
max(E, E) - Method in class com.google.common.collect.ReverseNaturalOrdering
 
max(E, E, E, E...) - Method in class com.google.common.collect.ReverseNaturalOrdering
 
max(Iterator<E>) - Method in class com.google.common.collect.ReverseNaturalOrdering
 
max(Iterable<E>) - Method in class com.google.common.collect.ReverseNaturalOrdering
 
max(E, E) - Method in class com.google.common.collect.ReverseOrdering
 
max(E, E, E, E...) - Method in class com.google.common.collect.ReverseOrdering
 
max(Iterator<E>) - Method in class com.google.common.collect.ReverseOrdering
 
max(Iterable<E>) - Method in class com.google.common.collect.ReverseOrdering
 
max - Variable in class com.google.common.escape.CharEscaperBuilder
 
max(char...) - Static method in class com.google.common.primitives.Chars
Returns the greatest value present in array.
max(double...) - Static method in class com.google.common.primitives.Doubles
Returns the greatest value present in array, using the same rules of comparison as Math.max(double, double).
max(float...) - Static method in class com.google.common.primitives.Floats
Returns the greatest value present in array, using the same rules of comparison as Math.min(float, float).
max(int...) - Static method in class com.google.common.primitives.Ints
Returns the greatest value present in array.
max(long...) - Static method in class com.google.common.primitives.Longs
Returns the greatest value present in array.
max(short...) - Static method in class com.google.common.primitives.Shorts
Returns the greatest value present in array.
max(byte...) - Static method in class com.google.common.primitives.SignedBytes
Returns the greatest value present in array.
max(byte...) - Static method in class com.google.common.primitives.UnsignedBytes
Returns the greatest value present in array.
max(int...) - Static method in class com.google.common.primitives.UnsignedInts
Returns the greatest value present in array, treating values as unsigned.
max(long...) - Static method in class com.google.common.primitives.UnsignedLongs
Returns the greatest value present in array, treating values as unsigned.
MAX_ASCII_CONTROL_CHAR - Static variable in class com.google.common.xml.XmlEscapers
 
MAX_DOMAIN_PART_LENGTH - Static variable in class com.google.common.net.InternetDomainName
Maximum size of a single part of a domain name.
MAX_FACTORIAL - Static variable in class com.google.common.math.DoubleMath
 
MAX_FORWARDS - Static variable in class com.google.common.net.HttpHeaders
The HTTP Max-Forwards header field name.
MAX_INT_AS_DOUBLE - Static variable in class com.google.common.math.DoubleMath
 
MAX_LENGTH - Static variable in class com.google.common.net.InternetDomainName
Maximum length of a full domain name, including separators, and leaving room for the root label.
MAX_LOAD_FACTOR - Static variable in class com.google.common.collect.RegularImmutableBiMap
 
MAX_LOAD_FACTOR - Static variable in class com.google.common.collect.RegularImmutableMap
Closed addressing tends to perform well even with high load factors.
MAX_LONG - Static variable in class com.google.common.collect.DiscreteDomain.BigIntegerDomain
 
MAX_LONG_AS_DOUBLE_PLUS_ONE - Static variable in class com.google.common.math.DoubleMath
 
MAX_PARTS - Static variable in class com.google.common.net.InternetDomainName
Maximum parts (labels) in a domain name.
MAX_POWER_OF_SQRT2_UNSIGNED - Static variable in class com.google.common.math.IntMath
The biggest half power of two that can fit in an unsigned int.
MAX_POWER_OF_SQRT2_UNSIGNED - Static variable in class com.google.common.math.LongMath
The biggest half power of two that fits into an unsigned long
MAX_POWER_OF_TWO - Static variable in class com.google.common.primitives.Ints
The largest power of two that can be represented as an int.
MAX_POWER_OF_TWO - Static variable in class com.google.common.primitives.Longs
The largest power of two that can be represented as a long.
MAX_POWER_OF_TWO - Static variable in class com.google.common.primitives.Shorts
The largest power of two that can be represented as a short.
MAX_POWER_OF_TWO - Static variable in class com.google.common.primitives.SignedBytes
The largest power of two that can be represented as a signed byte.
MAX_POWER_OF_TWO - Static variable in class com.google.common.primitives.UnsignedBytes
The largest power of two that can be represented as an unsigned byte.
MAX_SEGMENTS - Static variable in class com.google.common.cache.LocalCache
The maximum number of segments to allow; used to bound constructor arguments.
MAX_SEGMENTS - Static variable in class com.google.common.collect.MapMakerInternalMap
The maximum number of segments to allow; used to bound constructor arguments.
MAX_SIZE - Static variable in class com.google.common.base.SmallCharMatcher
 
MAX_TABLE_SIZE - Static variable in class com.google.common.collect.Hashing
 
MAX_TABLE_SIZE - Static variable in class com.google.common.collect.ImmutableSet
 
MAX_VALUE - Static variable in class com.google.common.primitives.UnsignedBytes
The largest value that fits into an unsigned byte.
MAX_VALUE - Static variable in class com.google.common.primitives.UnsignedInteger
 
MAX_VALUE - Static variable in class com.google.common.primitives.UnsignedLong
 
MAX_VALUE - Static variable in class com.google.common.primitives.UnsignedLongs
 
maxBurstSeconds - Variable in class com.google.common.util.concurrent.SmoothRateLimiter.SmoothBursty
The work (permits) of how many seconds can be saved up if this RateLimiter is unused?
maxDecodedSize(int) - Method in class com.google.common.io.BaseEncoding
 
maxDecodedSize(int) - Method in class com.google.common.io.BaseEncoding.SeparatedBaseEncoding
 
maxDecodedSize(int) - Method in class com.google.common.io.BaseEncoding.StandardBaseEncoding
 
maxEncodedSize(int) - Method in class com.google.common.io.BaseEncoding
 
maxEncodedSize(int) - Method in class com.google.common.io.BaseEncoding.SeparatedBaseEncoding
 
maxEncodedSize(int) - Method in class com.google.common.io.BaseEncoding.StandardBaseEncoding
 
maxHeap - Variable in class com.google.common.collect.MinMaxPriorityQueue
 
MAXIMUM_CAPACITY - Static variable in class com.google.common.cache.LocalCache
The maximum capacity, used if a higher value is implicitly specified by either of the constructors with arguments.
MAXIMUM_CAPACITY - Static variable in class com.google.common.collect.MapMakerInternalMap
The maximum capacity, used if a higher value is implicitly specified by either of the constructors with arguments.
maximumSize - Variable in class com.google.common.cache.CacheBuilder
 
maximumSize(long) - Method in class com.google.common.cache.CacheBuilder
Specifies the maximum number of entries the cache may contain.
maximumSize - Variable in class com.google.common.cache.CacheBuilderSpec
 
maximumSize(int) - Method in class com.google.common.collect.GenericMapMaker
Deprecated.
maximumSize - Variable in class com.google.common.collect.MapMaker
 
maximumSize(int) - Method in class com.google.common.collect.MapMaker
Deprecated.
Caching functionality in MapMaker has been moved to CacheBuilder, with MapMaker.maximumSize being replaced by CacheBuilder.maximumSize. Note that CacheBuilder is simply an enhanced API for an implementation which was branched from MapMaker.
maximumSize - Variable in class com.google.common.collect.MapMakerInternalMap.AbstractSerializationProxy
 
maximumSize - Variable in class com.google.common.collect.MapMakerInternalMap
The maximum size of this map.
maximumSize - Variable in class com.google.common.collect.MinMaxPriorityQueue.Builder
 
maximumSize(int) - Method in class com.google.common.collect.MinMaxPriorityQueue.Builder
Configures this builder to build MinMaxPriorityQueue instances that are limited to maximumSize elements.
maximumSize - Variable in class com.google.common.collect.MinMaxPriorityQueue
 
maximumSize(int) - Static method in class com.google.common.collect.MinMaxPriorityQueue
Creates and returns a new builder, configured to build MinMaxPriorityQueue instances that are limited to maximumSize elements.
MaximumSizeParser() - Constructor for class com.google.common.cache.CacheBuilderSpec.MaximumSizeParser
 
maximumWeight - Variable in class com.google.common.cache.CacheBuilder
 
maximumWeight(long) - Method in class com.google.common.cache.CacheBuilder
Specifies the maximum weight of entries the cache may contain.
maximumWeight - Variable in class com.google.common.cache.CacheBuilderSpec
 
MaximumWeightParser() - Constructor for class com.google.common.cache.CacheBuilderSpec.MaximumWeightParser
 
maxLog10ForLeadingZeros - Static variable in class com.google.common.math.IntMath
 
maxLog10ForLeadingZeros - Static variable in class com.google.common.math.LongMath
 
maxPermits - Variable in class com.google.common.util.concurrent.SmoothRateLimiter
The maximum number of stored permits.
maxSafeDigits - Static variable in class com.google.common.primitives.UnsignedLongs
 
maxSegmentSize - Variable in class com.google.common.collect.MapMakerInternalMap.Segment
The maximum size of this map.
maxSegmentWeight - Variable in class com.google.common.cache.LocalCache.Segment
The maximum weight of this segment.
maxSize - Variable in class com.google.common.collect.EvictingQueue
 
maxValue() - Method in class com.google.common.collect.DiscreteDomain.IntegerDomain
 
maxValue() - Method in class com.google.common.collect.DiscreteDomain.LongDomain
 
maxValue() - Method in class com.google.common.collect.DiscreteDomain
Returns the maximum value of type C, if it has one.
maxValueDivs - Static variable in class com.google.common.primitives.UnsignedLongs
 
maxValueMods - Static variable in class com.google.common.primitives.UnsignedLongs
 
maxWeight - Variable in class com.google.common.cache.LocalCache.ManualSerializationProxy
 
maxWeight - Variable in class com.google.common.cache.LocalCache
The maximum weight of this map.
mayNeedHiddenThis() - Method in class com.google.common.reflect.Invokable.ConstructorInvokable
 
MBOX - Static variable in class com.google.common.net.MediaType
 
md5() - Static method in class com.google.common.hash.Hashing
Returns a hash function implementing the MD5 hash algorithm (128 hash bits) by delegating to the MD5 MessageDigest.
MD5 - Static variable in class com.google.common.hash.Hashing.Md5Holder
 
Md5Holder() - Constructor for class com.google.common.hash.Hashing.Md5Holder
 
mean(double...) - Static method in class com.google.common.math.DoubleMath
Returns the arithmetic mean of the values.
mean(int...) - Static method in class com.google.common.math.DoubleMath
Returns the arithmetic mean of the values.
mean(long...) - Static method in class com.google.common.math.DoubleMath
Returns the arithmetic mean of the values.
mean(Iterable<? extends Number>) - Static method in class com.google.common.math.DoubleMath
Returns the arithmetic mean of the values.
mean(Iterator<? extends Number>) - Static method in class com.google.common.math.DoubleMath
Returns the arithmetic mean of the values.
mean - Variable in class com.google.common.math.DoubleMath.MeanAccumulator
 
mean() - Method in class com.google.common.math.DoubleMath.MeanAccumulator
 
mean(int, int) - Static method in class com.google.common.math.IntMath
Returns the arithmetic mean of x and y, rounded towards negative infinity.
mean(long, long) - Static method in class com.google.common.math.LongMath
Returns the arithmetic mean of x and y, rounded toward negative infinity.
MeanAccumulator() - Constructor for class com.google.common.math.DoubleMath.MeanAccumulator
 
MediaType - Class in com.google.common.net
Represents an Internet Media Type (also known as a MIME Type or Content Type).
MediaType(String, String, ImmutableListMultimap<String, String>) - Constructor for class com.google.common.net.MediaType
 
MediaType.Tokenizer - Class in com.google.common.net
 
member - Variable in class com.google.common.reflect.Element
 
memoize(Supplier<T>) - Static method in class com.google.common.base.Suppliers
Returns a supplier which caches the instance retrieved during the first call to get() and returns that value on subsequent calls to get().
memoizeWithExpiration(Supplier<T>, long, TimeUnit) - Static method in class com.google.common.base.Suppliers
Returns a supplier that caches the instance supplied by the delegate and removes the cached value after the specified time has passed.
MemoizingSupplier(Supplier<T>) - Constructor for class com.google.common.base.Suppliers.MemoizingSupplier
 
memory - Variable in class com.google.common.io.FileBackedOutputStream
 
MemoryOutput() - Constructor for class com.google.common.io.FileBackedOutputStream.MemoryOutput
 
mergeSorted(Iterable<? extends Iterable<? extends T>>, Comparator<? super T>) - Static method in class com.google.common.collect.Iterables
Returns an iterable over the merged contents of all given iterables.
mergeSorted(Iterable<? extends Iterator<? extends T>>, Comparator<? super T>) - Static method in class com.google.common.collect.Iterators
Returns an iterator over the merged contents of all given iterators, traversing every element of the input iterators.
MergingIterator(Iterable<? extends Iterator<? extends T>>, Comparator<? super T>) - Constructor for class com.google.common.collect.Iterators.MergingIterator
 
MessageDigestHasher(MessageDigest, int) - Constructor for class com.google.common.hash.MessageDigestHashFunction.MessageDigestHasher
 
MessageDigestHashFunction - Class in com.google.common.hash
HashFunction adapter for MessageDigest instances.
MessageDigestHashFunction(String, String) - Constructor for class com.google.common.hash.MessageDigestHashFunction
 
MessageDigestHashFunction(String, int, String) - Constructor for class com.google.common.hash.MessageDigestHashFunction
 
MessageDigestHashFunction.MessageDigestHasher - Class in com.google.common.hash
Hasher that updates a message digest.
MessageDigestHashFunction.SerializedForm - Class in com.google.common.hash
 
method - Variable in class com.google.common.eventbus.EventSubscriber
Subscriber method.
method - Variable in class com.google.common.reflect.Invokable.MethodInvokable
 
method(Method) - Method in class com.google.common.reflect.TypeToken
Returns the Invokable for method, which must be a member of T.
methodCall - Variable in class com.google.common.util.concurrent.ListenerCallQueue.Callback
 
MethodIdentifier(Method) - Constructor for class com.google.common.eventbus.AnnotatedSubscriberFinder.MethodIdentifier
 
MethodInvokable(Method) - Constructor for class com.google.common.reflect.Invokable.MethodInvokable
 
methodIsDeclaredThreadSafe(Method) - Static method in class com.google.common.eventbus.AnnotatedSubscriberFinder
Checks whether method is thread-safe, as indicated by the AllowConcurrentEvents annotation.
MICROSOFT_EXCEL - Static variable in class com.google.common.net.MediaType
 
MICROSOFT_POWERPOINT - Static variable in class com.google.common.net.MediaType
 
MICROSOFT_WORD - Static variable in class com.google.common.net.MediaType
 
mightContain(T) - Method in class com.google.common.hash.BloomFilter
Returns true if the element might have been put in this Bloom filter, false if this is definitely not the case.
mightContain(T, Funnel<? super T>, int, BloomFilterStrategies.BitArray) - Method in interface com.google.common.hash.BloomFilter.Strategy
Queries numHashFunctions bits of the given bit array, by hashing a user element; returns true if and only if all selected bits are set.
MIN - Static variable in class com.google.common.base.Ascii
The minimum value of an ASCII character.
min(Iterator<E>) - Method in class com.google.common.collect.Ordering
Returns the least of the specified values according to this ordering.
min(Iterable<E>) - Method in class com.google.common.collect.Ordering
Returns the least of the specified values according to this ordering.
min(E, E) - Method in class com.google.common.collect.Ordering
Returns the lesser of the two values according to this ordering.
min(E, E, E, E...) - Method in class com.google.common.collect.Ordering
Returns the least of the specified values according to this ordering.
min(E, E) - Method in class com.google.common.collect.ReverseNaturalOrdering
 
min(E, E, E, E...) - Method in class com.google.common.collect.ReverseNaturalOrdering
 
min(Iterator<E>) - Method in class com.google.common.collect.ReverseNaturalOrdering
 
min(Iterable<E>) - Method in class com.google.common.collect.ReverseNaturalOrdering
 
min(E, E) - Method in class com.google.common.collect.ReverseOrdering
 
min(E, E, E, E...) - Method in class com.google.common.collect.ReverseOrdering
 
min(Iterator<E>) - Method in class com.google.common.collect.ReverseOrdering
 
min(Iterable<E>) - Method in class com.google.common.collect.ReverseOrdering
 
min(char...) - Static method in class com.google.common.primitives.Chars
Returns the least value present in array.
min(double...) - Static method in class com.google.common.primitives.Doubles
Returns the least value present in array, using the same rules of comparison as Math.min(double, double).
min(float...) - Static method in class com.google.common.primitives.Floats
Returns the least value present in array, using the same rules of comparison as Math.min(float, float).
min(int...) - Static method in class com.google.common.primitives.Ints
Returns the least value present in array.
min(long...) - Static method in class com.google.common.primitives.Longs
Returns the least value present in array.
min(short...) - Static method in class com.google.common.primitives.Shorts
Returns the least value present in array.
min(byte...) - Static method in class com.google.common.primitives.SignedBytes
Returns the least value present in array.
min(byte...) - Static method in class com.google.common.primitives.UnsignedBytes
Returns the least value present in array.
min(int...) - Static method in class com.google.common.primitives.UnsignedInts
Returns the least value present in array, treating values as unsigned.
min(long...) - Static method in class com.google.common.primitives.UnsignedLongs
Returns the least value present in array, treating values as unsigned.
MIN_ASCII_CONTROL_CHAR - Static variable in class com.google.common.xml.XmlEscapers
 
MIN_INT_AS_DOUBLE - Static variable in class com.google.common.math.DoubleMath
 
MIN_LONG - Static variable in class com.google.common.collect.DiscreteDomain.BigIntegerDomain
 
MIN_LONG_AS_DOUBLE - Static variable in class com.google.common.math.DoubleMath
 
minHeap - Variable in class com.google.common.collect.MinMaxPriorityQueue
 
MinMaxPriorityQueue<E> - Class in com.google.common.collect
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(MinMaxPriorityQueue.Builder<? super E>, int) - Constructor for class com.google.common.collect.MinMaxPriorityQueue
 
MinMaxPriorityQueue.Builder<B> - Class in com.google.common.collect
The builder class used in creation of min-max priority queues.
MinMaxPriorityQueue.Heap - Class in com.google.common.collect
Each instance of MinMaxPriortyQueue encapsulates two instances of Heap: a min-heap and a max-heap.
MinMaxPriorityQueue.MoveDesc<E> - Class in com.google.common.collect
 
MinMaxPriorityQueue.QueueIterator - Class in com.google.common.collect
Iterates the elements of the queue in no particular order.
minus(CacheStats) - Method in class com.google.common.cache.CacheStats
Returns a new CacheStats representing the difference between this CacheStats and other.
minus(UnsignedInteger) - Method in class com.google.common.primitives.UnsignedInteger
Returns the result of subtracting this and val.
minus(UnsignedLong) - Method in class com.google.common.primitives.UnsignedLong
Returns the result of subtracting this and val.
minValue() - Method in class com.google.common.collect.DiscreteDomain.IntegerDomain
 
minValue() - Method in class com.google.common.collect.DiscreteDomain.LongDomain
 
minValue() - Method in class com.google.common.collect.DiscreteDomain
Returns the minimum value of type C, if it has one.
missCount - Variable in class com.google.common.cache.AbstractCache.SimpleStatsCounter
 
missCount - Variable in class com.google.common.cache.CacheStats
 
missCount() - Method in class com.google.common.cache.CacheStats
Returns the number of times Cache lookup methods have returned an uncached (newly loaded) value, or null.
missRate() - Method in class com.google.common.cache.CacheStats
Returns the ratio of cache requests which were misses.
mixH1(int, int) - Static method in class com.google.common.hash.Murmur3_32HashFunction
 
mixK1(long) - Static method in class com.google.common.hash.Murmur3_128HashFunction.Murmur3_128Hasher
 
mixK1(int) - Static method in class com.google.common.hash.Murmur3_32HashFunction
 
mixK2(long) - Static method in class com.google.common.hash.Murmur3_128HashFunction.Murmur3_128Hasher
 
mod(int, int) - Static method in class com.google.common.math.IntMath
Returns x mod m, a non-negative value less than m.
mod(long, int) - Static method in class com.google.common.math.LongMath
Returns x mod m, a non-negative value less than m.
mod(long, long) - Static method in class com.google.common.math.LongMath
Returns x mod m, a non-negative value less than m.
mod(UnsignedInteger) - Method in class com.google.common.primitives.UnsignedInteger
Returns this mod val.
mod(UnsignedLong) - Method in class com.google.common.primitives.UnsignedLong
Returns this modulo val.
modCount - Variable in class com.google.common.cache.LocalCache.Segment
Number of updates that alter the size of the table.
modCount - Variable in class com.google.common.collect.HashBiMap
 
modCount - Variable in class com.google.common.collect.LinkedHashMultimap.ValueSet
 
modCount - Variable in class com.google.common.collect.LinkedListMultimap
 
modCount - Variable in class com.google.common.collect.MapMakerInternalMap.Segment
Number of updates that alter the size of the table.
modCount - Variable in class com.google.common.collect.MinMaxPriorityQueue
 
modes - Variable in class com.google.common.io.Files.FileByteSink
 
modes(boolean) - Static method in class com.google.common.io.Files
 
monitor - Variable in class com.google.common.util.concurrent.AbstractService
 
Monitor - Class in com.google.common.util.concurrent
A synchronization abstraction supporting waiting on arbitrary boolean conditions.
Monitor() - Constructor for class com.google.common.util.concurrent.Monitor
Creates a monitor with a non-fair (but fast) ordering policy.
Monitor(boolean) - Constructor for class com.google.common.util.concurrent.Monitor
Creates a monitor with the given ordering policy.
monitor - Variable in class com.google.common.util.concurrent.Monitor.Guard
 
monitor - Variable in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState
 
Monitor.Guard - Class in com.google.common.util.concurrent
A boolean condition for which a thread may wait.
MoreExecutors - Class in com.google.common.util.concurrent
Factory and utility methods for Executor, ExecutorService, and ThreadFactory.
MoreExecutors() - Constructor for class com.google.common.util.concurrent.MoreExecutors
 
MoreExecutors.Application - Class in com.google.common.util.concurrent
Represents the current application to register shutdown hooks.
MoreExecutors.DirectExecutor - Enum in com.google.common.util.concurrent
See MoreExecutors.directExecutor() for behavioral notes.
MoreExecutors.DirectExecutorService - Class in com.google.common.util.concurrent
 
MoreExecutors.ListeningDecorator - Class in com.google.common.util.concurrent
 
MoreExecutors.ScheduledListeningDecorator - Class in com.google.common.util.concurrent
 
MoreExecutors.ScheduledListeningDecorator.ListenableScheduledTask<V> - Class in com.google.common.util.concurrent
 
MoreExecutors.ScheduledListeningDecorator.NeverSuccessfulListenableFutureTask - Class in com.google.common.util.concurrent
 
MoreObjects - Class in com.google.common.base
Helper functions that operate on any Object, and are not already provided in Objects.
MoreObjects() - Constructor for class com.google.common.base.MoreObjects
 
MoreObjects.ToStringHelper - Class in com.google.common.base
MoreObjects.ToStringHelper.ValueHolder - Class in com.google.common.base
 
move(File, File) - Static method in class com.google.common.io.Files
Moves a file from one path to another.
MoveDesc(E, E) - Constructor for class com.google.common.collect.MinMaxPriorityQueue.MoveDesc
 
MP4_AUDIO - Static variable in class com.google.common.net.MediaType
 
MP4_VIDEO - Static variable in class com.google.common.net.MediaType
 
MPEG_AUDIO - Static variable in class com.google.common.net.MediaType
 
MPEG_VIDEO - Static variable in class com.google.common.net.MediaType
 
MultiInputStream - Class in com.google.common.io
An InputStream that concatenates multiple substreams.
MultiInputStream(Iterator<? extends ByteSource>) - Constructor for class com.google.common.io.MultiInputStream
Creates a new instance.
multimap() - Method in class com.google.common.collect.AbstractMultimap.Entries
 
multimap - Variable in class com.google.common.collect.FilteredMultimapValues
 
multimap - Variable in class com.google.common.collect.ImmutableMultimap.EntryCollection
 
multimap - Variable in class com.google.common.collect.ImmutableMultimap.Values
 
multimap - Variable in class com.google.common.collect.ImmutableSetMultimap.EntrySet
 
Multimap<K,V> - Interface in com.google.common.collect
A collection that maps keys to values, similar to Map, but in which each key may be associated with multiple values.
multimap - Variable in class com.google.common.collect.Multimaps.AsMap
 
multimap() - Method in class com.google.common.collect.Multimaps.Entries
 
multimap - Variable in class com.google.common.collect.Multimaps.Keys
 
multimap(Multimap<K, V>, Object) - Static method in class com.google.common.collect.Synchronized
 
MultimapBuilder<K0,V0> - Class in com.google.common.collect
A builder for a multimap implementation that allows customization of the backing map and value collection implementations used in a particular multimap.
MultimapBuilder() - Constructor for class com.google.common.collect.MultimapBuilder
 
MultimapBuilder.ArrayListSupplier<V> - Class in com.google.common.collect
 
MultimapBuilder.EnumSetSupplier<V extends java.lang.Enum<V>> - Class in com.google.common.collect
 
MultimapBuilder.HashSetSupplier<V> - Class in com.google.common.collect
 
MultimapBuilder.LinkedHashSetSupplier<V> - Class in com.google.common.collect
 
MultimapBuilder.LinkedListSupplier - Enum in com.google.common.collect
 
MultimapBuilder.ListMultimapBuilder<K0,V0> - Class in com.google.common.collect
A specialization of MultimapBuilder that generates ListMultimap instances.
MultimapBuilder.MultimapBuilderWithKeys<K0> - Class in com.google.common.collect
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> - Class in com.google.common.collect
A specialization of MultimapBuilder that generates SetMultimap instances.
MultimapBuilder.SortedSetMultimapBuilder<K0,V0> - Class in com.google.common.collect
A specialization of MultimapBuilder that generates SortedSetMultimap instances.
MultimapBuilder.TreeSetSupplier<V> - Class in com.google.common.collect
 
MultimapBuilderWithKeys() - Constructor for class com.google.common.collect.MultimapBuilder.MultimapBuilderWithKeys
 
multimapHeaderEntry - Variable in class com.google.common.collect.LinkedHashMultimap
 
Multimaps - Class in com.google.common.collect
Provides static methods acting on or generating a Multimap.
Multimaps() - Constructor for class com.google.common.collect.Multimaps
 
Multimaps.AsMap<K,V> - Class in com.google.common.collect
A skeleton implementation of Multimap.asMap().
Multimaps.AsMap.EntrySet - Class in com.google.common.collect
 
Multimaps.CustomListMultimap<K,V> - Class in com.google.common.collect
 
Multimaps.CustomMultimap<K,V> - Class in com.google.common.collect
 
Multimaps.CustomSetMultimap<K,V> - Class in com.google.common.collect
 
Multimaps.CustomSortedSetMultimap<K,V> - Class in com.google.common.collect
 
Multimaps.Entries<K,V> - Class in com.google.common.collect
A skeleton implementation of Multimap.entries().
Multimaps.Keys<K,V> - Class in com.google.common.collect
 
Multimaps.Keys.KeysEntrySet - Class in com.google.common.collect
 
Multimaps.MapMultimap<K,V> - Class in com.google.common.collect
 
Multimaps.TransformedEntriesListMultimap<K,V1,V2> - Class in com.google.common.collect
 
Multimaps.TransformedEntriesMultimap<K,V1,V2> - Class in com.google.common.collect
 
Multimaps.UnmodifiableListMultimap<K,V> - Class in com.google.common.collect
 
Multimaps.UnmodifiableMultimap<K,V> - Class in com.google.common.collect
 
Multimaps.UnmodifiableSetMultimap<K,V> - Class in com.google.common.collect
 
Multimaps.UnmodifiableSortedSetMultimap<K,V> - Class in com.google.common.collect
 
multimapView - Variable in class com.google.common.collect.ImmutableMap
 
multiplyFraction(long, long, long) - Static method in class com.google.common.math.LongMath
Returns (x * numerator / denominator), which is assumed to come out to an integral value.
MultiReader - Class in com.google.common.io
A Reader that concatenates multiple readers.
MultiReader(Iterator<? extends CharSource>) - Constructor for class com.google.common.io.MultiReader
 
multiset() - Method in class com.google.common.collect.AbstractMultiset.ElementSet
 
multiset() - Method in class com.google.common.collect.AbstractMultiset.EntrySet
 
multiset() - Method in class com.google.common.collect.ConcurrentHashMultiset.EntrySet
 
multiset() - Method in class com.google.common.collect.ForwardingMultiset.StandardElementSet
 
multiset - Variable in class com.google.common.collect.ImmutableMultiset.EntrySetSerializedForm
 
multiset() - Method in class com.google.common.collect.Multimaps.Keys.KeysEntrySet
 
Multiset<E> - Interface in com.google.common.collect
A collection that supports order-independent equality, like Set, but may have duplicate elements.
multiset() - Method in class com.google.common.collect.Multisets.ElementSet
 
multiset() - Method in class com.google.common.collect.Multisets.EntrySet
 
multiset - Variable in class com.google.common.collect.Multisets.MultisetIteratorImpl
 
multiset - Variable in class com.google.common.collect.SortedMultisets.ElementSet
 
multiset() - Method in class com.google.common.collect.SortedMultisets.ElementSet
 
multiset(Multiset<E>, Object) - Static method in class com.google.common.collect.Synchronized
 
Multiset.Entry<E> - Interface in com.google.common.collect
An unmodifiable element-count pair for a multiset.
MultisetIteratorImpl(Multiset<E>, Iterator<Multiset.Entry<E>>) - Constructor for class com.google.common.collect.Multisets.MultisetIteratorImpl
 
Multisets - Class in com.google.common.collect
Provides static utility methods for creating and working with Multiset instances.
Multisets() - Constructor for class com.google.common.collect.Multisets
 
Multisets.AbstractEntry<E> - Class in com.google.common.collect
Implementation of the equals, hashCode, and toString methods of Multiset.Entry.
Multisets.ElementSet<E> - Class in com.google.common.collect
 
Multisets.EntrySet<E> - Class in com.google.common.collect
 
Multisets.FilteredMultiset<E> - Class in com.google.common.collect
 
Multisets.ImmutableEntry<E> - Class in com.google.common.collect
 
Multisets.MultisetIteratorImpl<E> - Class in com.google.common.collect
 
Multisets.UnmodifiableMultiset<E> - Class in com.google.common.collect
 
munch() - Method in class com.google.common.hash.AbstractStreamingHashFunction.AbstractStreamingHasher
 
munchIfFull() - Method in class com.google.common.hash.AbstractStreamingHashFunction.AbstractStreamingHasher
 
murmur3_128(int) - Static method in class com.google.common.hash.Hashing
Returns a hash function implementing the 128-bit murmur3 algorithm, x64 variant (little-endian variant), using the given seed value.
murmur3_128() - Static method in class com.google.common.hash.Hashing
Returns a hash function implementing the 128-bit murmur3 algorithm, x64 variant (little-endian variant), using a seed value of zero.
MURMUR3_128 - Static variable in class com.google.common.hash.Hashing.Murmur3_128Holder
 
Murmur3_128Hasher(int) - Constructor for class com.google.common.hash.Murmur3_128HashFunction.Murmur3_128Hasher
 
Murmur3_128HashFunction - Class in com.google.common.hash
See http://smhasher.googlecode.com/svn/trunk/MurmurHash3.cpp MurmurHash3_x64_128
Murmur3_128HashFunction(int) - Constructor for class com.google.common.hash.Murmur3_128HashFunction
 
Murmur3_128HashFunction.Murmur3_128Hasher - Class in com.google.common.hash
 
Murmur3_128Holder() - Constructor for class com.google.common.hash.Hashing.Murmur3_128Holder
 
murmur3_32(int) - Static method in class com.google.common.hash.Hashing
Returns a hash function implementing the 32-bit murmur3 algorithm, x86 variant (little-endian variant), using the given seed value.
murmur3_32() - Static method in class com.google.common.hash.Hashing
Returns a hash function implementing the 32-bit murmur3 algorithm, x86 variant (little-endian variant), using a seed value of zero.
MURMUR3_32 - Static variable in class com.google.common.hash.Hashing.Murmur3_32Holder
 
Murmur3_32Hasher(int) - Constructor for class com.google.common.hash.Murmur3_32HashFunction.Murmur3_32Hasher
 
Murmur3_32HashFunction - Class in com.google.common.hash
See http://smhasher.googlecode.com/svn/trunk/MurmurHash3.cpp MurmurHash3_x86_32
Murmur3_32HashFunction(int) - Constructor for class com.google.common.hash.Murmur3_32HashFunction
 
Murmur3_32HashFunction.Murmur3_32Hasher - Class in com.google.common.hash
 
Murmur3_32Holder() - Constructor for class com.google.common.hash.Hashing.Murmur3_32Holder
 
MutableClassToInstanceMap<B> - Class in com.google.common.collect
A mutable class-to-instance map backed by an arbitrary user-provided map.
MutableClassToInstanceMap(Map<Class<? extends B>, B>) - Constructor for class com.google.common.collect.MutableClassToInstanceMap
 
MutableTypeToInstanceMap<B> - Class in com.google.common.reflect
A mutable type-to-instance map.
MutableTypeToInstanceMap() - Constructor for class com.google.common.reflect.MutableTypeToInstanceMap
 
MutableTypeToInstanceMap.UnmodifiableEntry<K,V> - Class in com.google.common.reflect
 
mutex - Variable in class com.google.common.collect.Synchronized.SynchronizedObject
 
mutex() - Method in class com.google.common.util.concurrent.RateLimiter
 
mutexDoNotUseDirectly - Variable in class com.google.common.util.concurrent.RateLimiter
 

N

NAK - Static variable in class com.google.common.base.Ascii
Negative Acknowledge: A communication control character transmitted by a receiver as a negative response to the sender.
name - Variable in class com.google.common.base.MoreObjects.ToStringHelper.ValueHolder
 
name - Variable in class com.google.common.base.Objects.ToStringHelper.ValueHolder
Deprecated.
 
name - Variable in class com.google.common.eventbus.AnnotatedSubscriberFinder.MethodIdentifier
 
name - Variable in class com.google.common.io.BaseEncoding.Alphabet
 
name - Variable in class com.google.common.net.InternetDomainName
The full domain name, converted to lower case.
name - Variable in class com.google.common.reflect.Types.TypeVariableImpl
 
nameFormat - Variable in class com.google.common.util.concurrent.ThreadFactoryBuilder
 
NATIVE_TYPE_VARIABLE_ONLY - Static variable in class com.google.common.reflect.Types.NativeTypeVariableEquals
 
NativeTypeVariableEquals() - Constructor for class com.google.common.reflect.Types.NativeTypeVariableEquals
 
natural() - Static method in class com.google.common.collect.Ordering
Returns a serializable ordering that uses the natural order of the values.
NATURAL_EMPTY_MAP - Static variable in class com.google.common.collect.ImmutableSortedMap
 
NATURAL_EMPTY_MULTISET - Static variable in class com.google.common.collect.ImmutableSortedMultiset
 
NATURAL_EMPTY_SET - Static variable in class com.google.common.collect.ImmutableSortedSet
 
NATURAL_ORDER - Static variable in class com.google.common.collect.ImmutableSortedMap
 
NATURAL_ORDER - Static variable in class com.google.common.collect.ImmutableSortedMultiset
 
NATURAL_ORDER - Static variable in class com.google.common.collect.ImmutableSortedSet
 
naturalOrder() - Static method in class com.google.common.collect.ImmutableSortedMap
Returns a builder that creates immutable sorted maps whose keys are ordered by their natural ordering.
naturalOrder() - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns a builder that creates immutable sorted multisets whose elements are ordered by their natural ordering.
naturalOrder() - Static method in class com.google.common.collect.ImmutableSortedSet
Returns a builder that creates immutable sorted sets whose elements are ordered by their natural ordering.
NaturalOrdering - Class in com.google.common.collect
An ordering that uses the natural order of the values.
NaturalOrdering() - Constructor for class com.google.common.collect.NaturalOrdering
 
NavigableAsMap(NavigableMap<K, Collection<V>>) - Constructor for class com.google.common.collect.AbstractMapBasedMultimap.NavigableAsMap
 
NavigableAsMapView(NavigableSet<K>, Function<? super K, V>) - Constructor for class com.google.common.collect.Maps.NavigableAsMapView
 
NavigableElementSet(SortedMultiset<E>) - Constructor for class com.google.common.collect.SortedMultisets.NavigableElementSet
 
navigableKeySet() - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableAsMap
 
NavigableKeySet(NavigableMap<K, Collection<V>>) - Constructor for class com.google.common.collect.AbstractMapBasedMultimap.NavigableKeySet
 
navigableKeySet() - Method in class com.google.common.collect.AbstractNavigableMap
 
navigableKeySet() - Method in class com.google.common.collect.ForwardingNavigableMap
 
navigableKeySet() - Method in class com.google.common.collect.ImmutableSortedMap
 
navigableKeySet - Variable in class com.google.common.collect.Maps.DescendingMap
 
navigableKeySet() - Method in class com.google.common.collect.Maps.DescendingMap
 
navigableKeySet() - Method in class com.google.common.collect.Maps.FilteredEntryNavigableMap
 
navigableKeySet() - Method in class com.google.common.collect.Maps.NavigableAsMapView
 
NavigableKeySet(NavigableMap<K, V>) - Constructor for class com.google.common.collect.Maps.NavigableKeySet
 
navigableKeySet() - Method in class com.google.common.collect.Maps.TransformedEntriesNavigableMap
 
navigableKeySet() - Method in class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
navigableKeySet - Variable in class com.google.common.collect.Synchronized.SynchronizedNavigableMap
 
navigableKeySet() - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableMap
 
navigableMap(NavigableMap<K, V>) - Static method in class com.google.common.collect.Synchronized
 
navigableMap(NavigableMap<K, V>, Object) - Static method in class com.google.common.collect.Synchronized
 
navigableSet(NavigableSet<E>, Object) - Static method in class com.google.common.collect.Synchronized
 
navigableSet(NavigableSet<E>) - Static method in class com.google.common.collect.Synchronized
 
NCPU - Static variable in class com.google.common.cache.Striped64
Number of CPUS, to place bound on table size
needsResizing(int, int, double) - Static method in class com.google.common.collect.Hashing
 
negate() - Method in class com.google.common.base.CharMatcher.FastMatcher
 
negate() - Method in class com.google.common.base.CharMatcher
Returns a matcher that matches any character not matched by this matcher.
negate() - Method in class com.google.common.base.CharMatcher.NegatedMatcher
 
NegatedFastMatcher(CharMatcher) - Constructor for class com.google.common.base.CharMatcher.NegatedFastMatcher
 
NegatedFastMatcher(String, CharMatcher) - Constructor for class com.google.common.base.CharMatcher.NegatedFastMatcher
 
NegatedMatcher(String, CharMatcher) - Constructor for class com.google.common.base.CharMatcher.NegatedMatcher
 
NegatedMatcher(CharMatcher) - Constructor for class com.google.common.base.CharMatcher.NegatedMatcher
 
nested - Variable in class com.google.common.util.concurrent.AsyncSettableFuture
 
NestedFuture() - Constructor for class com.google.common.util.concurrent.AsyncSettableFuture.NestedFuture
 
NeverSuccessfulListenableFutureTask(Runnable) - Constructor for class com.google.common.util.concurrent.MoreExecutors.ScheduledListeningDecorator.NeverSuccessfulListenableFutureTask
 
newArray(Class<T>, int) - Static method in class com.google.common.collect.ObjectArrays
Returns a new array of the given length with the specified component type.
newArray(T[], int) - Static method in class com.google.common.collect.ObjectArrays
Returns a new array of the given length with the same type as a reference array.
newArray(T[], int) - Static method in class com.google.common.collect.Platform
Returns a new array of the given length with the same type as a reference array.
newArrayBlockingQueue(int) - Static method in class com.google.common.collect.Queues
Creates an empty ArrayBlockingQueue with the given (fixed) capacity and nonfair access policy.
newArrayClassOrGenericArrayType(Type) - Static method in class com.google.common.reflect.TypeToken
Creates an array class if componentType is a class, or else, a GenericArrayType.
newArrayDeque() - Static method in class com.google.common.collect.Queues
Creates an empty ArrayDeque.
newArrayDeque(Iterable<? extends E>) - Static method in class com.google.common.collect.Queues
Creates an ArrayDeque containing the elements of the specified iterable, in the order they are returned by the iterable's iterator.
newArrayList() - Static method in class com.google.common.collect.Lists
Creates a mutable, empty ArrayList instance (for Java 6 and earlier).
newArrayList(E...) - Static method in class com.google.common.collect.Lists
Creates a mutable ArrayList instance containing the given elements.
newArrayList(Iterable<? extends E>) - Static method in class com.google.common.collect.Lists
Creates a mutable ArrayList instance containing the given elements; a very thin shortcut for creating an empty list then calling Iterables.addAll(java.util.Collection<T>, java.lang.Iterable<? extends T>).
newArrayList(Iterator<? extends E>) - Static method in class com.google.common.collect.Lists
Creates a mutable ArrayList instance containing the given elements; a very thin shortcut for creating an empty list and then calling Iterators.addAll(java.util.Collection<T>, java.util.Iterator<? extends T>).
newArrayListWithCapacity(int) - Static method in class com.google.common.collect.Lists
Creates an ArrayList instance backed by an array with the specified initial size; simply delegates to ArrayList.ArrayList(int).
newArrayListWithExpectedSize(int) - Static method in class com.google.common.collect.Lists
Creates an ArrayList instance to hold estimatedSize elements, plus an unspecified amount of padding; you almost certainly mean to call Lists.newArrayListWithCapacity(int) (see that method for further advice on usage).
newArrayType(Type) - Method in enum com.google.common.reflect.Types.JavaVersion
 
newArrayType(Type) - Static method in class com.google.common.reflect.Types
Returns the array type of componentType.
newArtificialTypeVariable(D, String, Type...) - Static method in class com.google.common.reflect.Types
Returns a new TypeVariable that belongs to declaration with name and bounds.
newBuilder() - Static method in class com.google.common.cache.CacheBuilder
Constructs a new CacheBuilder instance with default settings, including strong keys, strong values, and no automatic eviction of any kind.
newConcurrentHashSet() - Static method in class com.google.common.collect.Sets
Creates a thread-safe set backed by a hash map.
newConcurrentHashSet(Iterable<? extends E>) - Static method in class com.google.common.collect.Sets
Creates a thread-safe set backed by a hash map and containing the given elements.
newConcurrentLinkedQueue() - Static method in class com.google.common.collect.Queues
Creates an empty ConcurrentLinkedQueue.
newConcurrentLinkedQueue(Iterable<? extends E>) - Static method in class com.google.common.collect.Queues
Creates a ConcurrentLinkedQueue containing the elements of the specified iterable, in the order they are returned by the iterable's iterator.
newConcurrentMap() - Static method in class com.google.common.collect.Maps
Returns a general-purpose instance of ConcurrentMap, which supports all optional operations of the ConcurrentMap interface.
newCopyOnWriteArrayList() - Static method in class com.google.common.collect.Lists
Creates an empty CopyOnWriteArrayList instance.
newCopyOnWriteArrayList(Iterable<? extends E>) - Static method in class com.google.common.collect.Lists
Creates a CopyOnWriteArrayList instance containing the given elements.
newCopyOnWriteArraySet() - Static method in class com.google.common.collect.Sets
Creates an empty CopyOnWriteArraySet instance.
newCopyOnWriteArraySet(Iterable<? extends E>) - Static method in class com.google.common.collect.Sets
Creates a CopyOnWriteArraySet instance containing the given elements.
newCustomTable(Map<R, Map<C, V>>, Supplier<? extends Map<C, V>>) - Static method in class com.google.common.collect.Tables
Creates a table that uses the specified backing map and factory.
newDataInput(byte[]) - Static method in class com.google.common.io.ByteStreams
Returns a new ByteArrayDataInput instance to read from the bytes array from the beginning.
newDataInput(byte[], int) - Static method in class com.google.common.io.ByteStreams
Returns a new ByteArrayDataInput instance to read from the bytes array, starting at the given position.
newDataInput(ByteArrayInputStream) - Static method in class com.google.common.io.ByteStreams
Returns a new ByteArrayDataInput instance to read from the given ByteArrayInputStream.
newDataOutput() - Static method in class com.google.common.io.ByteStreams
Returns a new ByteArrayDataOutput instance with a default size.
newDataOutput(int) - Static method in class com.google.common.io.ByteStreams
Returns a new ByteArrayDataOutput instance sized to hold size bytes before resizing.
newDataOutput(ByteArrayOutputStream) - Static method in class com.google.common.io.ByteStreams
Returns a new ByteArrayDataOutput instance which writes to the given ByteArrayOutputStream.
newDirectExecutorService() - Static method in class com.google.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.
newEntry(LocalCache.Segment<K, V>, K, int, LocalCache.ReferenceEntry<K, V>) - Method in enum com.google.common.cache.LocalCache.EntryFactory
Creates a new entry.
newEntry(K, int, LocalCache.ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache
This method is a convenience for testing.
newEntry(K, int, LocalCache.ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.Segment
 
newEntry(MapMakerInternalMap.Segment<K, V>, K, int, MapMakerInternalMap.ReferenceEntry<K, V>) - Method in enum com.google.common.collect.MapMakerInternalMap.EntryFactory
Creates a new entry.
newEntry(K, int, MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap
This method is a convenience for testing.
newEntry(K, int, MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
 
newEntryArray(int) - Method in class com.google.common.cache.LocalCache.Segment
 
newEntryArray(int) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
 
newEnumMap(Class<K>) - Static method in class com.google.common.collect.Maps
Creates an EnumMap instance.
newEnumMap(Map<K, ? extends V>) - Static method in class com.google.common.collect.Maps
Creates an EnumMap with the same mappings as the specified map.
newEnumSet(Iterable<E>, Class<E>) - Static method in class com.google.common.collect.Sets
Returns a new EnumSet instance containing the given elements.
newFixedDelaySchedule(long, long, TimeUnit) - Static method in class com.google.common.util.concurrent.AbstractScheduledService.Scheduler
Returns a AbstractScheduledService.Scheduler that schedules the task using the ScheduledExecutorService.scheduleWithFixedDelay(java.lang.Runnable, long, long, java.util.concurrent.TimeUnit) method.
newFixedRateSchedule(long, long, TimeUnit) - Static method in class com.google.common.util.concurrent.AbstractScheduledService.Scheduler
Returns a AbstractScheduledService.Scheduler that schedules the task using the ScheduledExecutorService.scheduleAtFixedRate(java.lang.Runnable, long, long, java.util.concurrent.TimeUnit) method.
newFromConstructor(Constructor<X>, Throwable) - Static method in class com.google.common.util.concurrent.Futures
 
newHasher() - Method in class com.google.common.hash.AbstractCompositeHashFunction
 
newHasher() - Method in class com.google.common.hash.AbstractNonStreamingHashFunction
 
newHasher(int) - Method in class com.google.common.hash.AbstractNonStreamingHashFunction
 
newHasher(int) - Method in class com.google.common.hash.AbstractStreamingHashFunction
 
newHasher() - Method in class com.google.common.hash.ChecksumHashFunction
 
newHasher() - Method in class com.google.common.hash.Crc32cHashFunction
 
newHasher() - Method in interface com.google.common.hash.HashFunction
Begins a new hash code computation by returning an initialized, stateful Hasher instance that is ready to receive data.
newHasher(int) - Method in interface com.google.common.hash.HashFunction
Begins a new hash code computation as HashFunction.newHasher(), but provides a hint of the expected size of the input (in bytes).
newHasher() - Method in class com.google.common.hash.MessageDigestHashFunction
 
newHasher() - Method in class com.google.common.hash.Murmur3_128HashFunction
 
newHasher() - Method in class com.google.common.hash.Murmur3_32HashFunction
 
newHasher() - Method in class com.google.common.hash.SipHashFunction
 
newHashMap() - Static method in class com.google.common.collect.Maps
Creates a mutable, empty HashMap instance.
newHashMap(Map<? extends K, ? extends V>) - Static method in class com.google.common.collect.Maps
Creates a mutable HashMap instance with the same mappings as the specified map.
newHashMapWithExpectedSize(int) - Static method in class com.google.common.collect.Maps
Creates a HashMap instance, with a high enough "initial capacity" that it should hold expectedSize elements without growth.
newHashSet() - Static method in class com.google.common.collect.Sets
Creates a mutable, empty HashSet instance.
newHashSet(E...) - Static method in class com.google.common.collect.Sets
Creates a mutable HashSet instance containing the given elements in unspecified order.
newHashSet(Iterable<? extends E>) - Static method in class com.google.common.collect.Sets
Creates a mutable HashSet instance containing the given elements in unspecified order.
newHashSet(Iterator<? extends E>) - Static method in class com.google.common.collect.Sets
Creates a mutable HashSet instance containing the given elements in unspecified order.
newHashSetWithExpectedSize(int) - Static method in class com.google.common.collect.Sets
Creates a HashSet instance, with a high enough "initial capacity" that it should hold expectedSize elements without growth.
newIdentityHashMap() - Static method in class com.google.common.collect.Maps
Creates an IdentityHashMap instance.
newIdentityHashSet() - Static method in class com.google.common.collect.Sets
Creates an empty Set that uses identity to determine equality.
newInstance(CycleDetectingLockFactory.Policy) - Static method in class com.google.common.util.concurrent.CycleDetectingLockFactory
Creates a new factory with the specified policy.
newInstanceWithExplicitOrdering(Class<E>, CycleDetectingLockFactory.Policy) - Static method in class com.google.common.util.concurrent.CycleDetectingLockFactory
Creates a CycleDetectingLockFactory.WithExplicitOrdering<E>.
newLinkedBlockingDeque() - Static method in class com.google.common.collect.Queues
Creates an empty LinkedBlockingDeque with a capacity of Integer.MAX_VALUE.
newLinkedBlockingDeque(int) - Static method in class com.google.common.collect.Queues
Creates an empty LinkedBlockingDeque with the given (fixed) capacity.
newLinkedBlockingDeque(Iterable<? extends E>) - Static method in class com.google.common.collect.Queues
Creates a LinkedBlockingDeque with a capacity of Integer.MAX_VALUE, containing the elements of the specified iterable, in the order they are returned by the iterable's iterator.
newLinkedBlockingQueue() - Static method in class com.google.common.collect.Queues
Creates an empty LinkedBlockingQueue with a capacity of Integer.MAX_VALUE.
newLinkedBlockingQueue(int) - Static method in class com.google.common.collect.Queues
Creates an empty LinkedBlockingQueue with the given (fixed) capacity.
newLinkedBlockingQueue(Iterable<? extends E>) - Static method in class com.google.common.collect.Queues
Creates a LinkedBlockingQueue with a capacity of Integer.MAX_VALUE, containing the elements of the specified iterable, in the order they are returned by the iterable's iterator.
newLinkedHashMap() - Static method in class com.google.common.collect.Maps
Creates a mutable, empty, insertion-ordered LinkedHashMap instance.
newLinkedHashMap(Map<? extends K, ? extends V>) - Static method in class com.google.common.collect.Maps
Creates a mutable, insertion-ordered LinkedHashMap instance with the same mappings as the specified map.
newLinkedHashSet() - Static method in class com.google.common.collect.Sets
Creates a mutable, empty LinkedHashSet instance.
newLinkedHashSet(Iterable<? extends E>) - Static method in class com.google.common.collect.Sets
Creates a mutable LinkedHashSet instance containing the given elements in order.
newLinkedHashSetWithExpectedSize(int) - Static method in class com.google.common.collect.Sets
Creates a LinkedHashSet instance, with a high enough "initial capacity" that it should hold expectedSize elements without growth.
newLinkedList() - Static method in class com.google.common.collect.Lists
Creates a mutable, empty LinkedList instance (for Java 6 and earlier).
newLinkedList(Iterable<? extends E>) - Static method in class com.google.common.collect.Lists
Creates a mutable LinkedList instance containing the given elements; a very thin shortcut for creating an empty list then calling Iterables.addAll(java.util.Collection<T>, java.lang.Iterable<? extends T>).
newListMultimap(Map<K, Collection<V>>, Supplier<? extends List<V>>) - Static method in class com.google.common.collect.Multimaps
Creates a new ListMultimap that uses the provided map and factory.
newLoader(URL) - Method in class com.google.common.base.FinalizableReferenceQueue.DecoupledLoader
Creates a class loader with the given base URL as its classpath.
newMultimap(Map<K, Collection<V>>, Supplier<? extends Collection<V>>) - Static method in class com.google.common.collect.Multimaps
Creates a new Multimap backed by map, whose internal value collections are generated by factory.
newParameterizedType(Class<?>, Type...) - Static method in class com.google.common.reflect.Types
Returns a type where rawType is parameterized by arguments.
newParameterizedTypeWithOwner(Type, Class<?>, Type...) - Static method in class com.google.common.reflect.Types
Returns a type where rawType is parameterized by arguments and is owned by ownerType.
newPriorityBlockingQueue() - Static method in class com.google.common.collect.Queues
Creates an empty PriorityBlockingQueue with the ordering given by its elements' natural ordering.
newPriorityBlockingQueue(Iterable<? extends E>) - Static method in class com.google.common.collect.Queues
Creates a PriorityBlockingQueue containing the given elements.
newPriorityQueue() - Static method in class com.google.common.collect.Queues
Creates an empty PriorityQueue with the ordering given by its elements' natural ordering.
newPriorityQueue(Iterable<? extends E>) - Static method in class com.google.common.collect.Queues
Creates a PriorityQueue containing the given elements.
newProxy(Class<T>, InvocationHandler) - Static method in class com.google.common.reflect.Reflection
Returns a proxy instance that implements interfaceType by dispatching method invocations to handler.
newProxy(T, Class<T>, long, TimeUnit) - Method in class com.google.common.util.concurrent.FakeTimeLimiter
 
newProxy(T, Class<T>, long, TimeUnit) - Method in class com.google.common.util.concurrent.SimpleTimeLimiter
 
newProxy(Class<T>, InvocationHandler) - Static method in class com.google.common.util.concurrent.SimpleTimeLimiter
 
newProxy(T, Class<T>, long, TimeUnit) - Method in interface com.google.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.
newReader(File, Charset) - Static method in class com.google.common.io.Files
Returns a buffered reader that reads from a file using the given character set.
newReentrantLock(String) - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory
Equivalent to newReentrantLock(lockName, false).
newReentrantLock(String, boolean) - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory
Creates a ReentrantLock with the given fairness policy.
newReentrantLock(E) - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory.WithExplicitOrdering
Equivalent to newReentrantLock(rank, false).
newReentrantLock(E, boolean) - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory.WithExplicitOrdering
Creates a ReentrantLock with the given fairness policy and rank.
newReentrantReadWriteLock(String) - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory
Equivalent to newReentrantReadWriteLock(lockName, false).
newReentrantReadWriteLock(String, boolean) - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory
Creates a ReentrantReadWriteLock with the given fairness policy.
newReentrantReadWriteLock(E) - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory.WithExplicitOrdering
Equivalent to newReentrantReadWriteLock(rank, false).
newReentrantReadWriteLock(E, boolean) - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory.WithExplicitOrdering
Creates a ReentrantReadWriteLock with the given fairness policy and rank.
newReference() - Static method in class com.google.common.util.concurrent.Atomics
Creates an AtomicReference instance with no initial value.
newReference(V) - Static method in class com.google.common.util.concurrent.Atomics
Creates an AtomicReference instance with the given initial value.
newReferenceArray(int) - Static method in class com.google.common.util.concurrent.Atomics
Creates an AtomicReferenceArray instance of given length.
newReferenceArray(E[]) - Static method in class com.google.common.util.concurrent.Atomics
Creates an AtomicReferenceArray instance with the same length as, and all elements copied from, the given array.
newSegmentArray(int) - Method in class com.google.common.cache.LocalCache
 
newSegmentArray(int) - Method in class com.google.common.collect.MapMakerInternalMap
 
newSetFromMap(Map<E, Boolean>) - Static method in class com.google.common.collect.Platform
 
newSetFromMap(Map<E, Boolean>) - Static method in class com.google.common.collect.Sets
Returns a set backed by the specified map.
newSetMultimap(Map<K, Collection<V>>, Supplier<? extends Set<V>>) - Static method in class com.google.common.collect.Multimaps
Creates a new SetMultimap that uses the provided map and factory.
newSortedSetMultimap(Map<K, Collection<V>>, Supplier<? extends SortedSet<V>>) - Static method in class com.google.common.collect.Multimaps
Creates a new SortedSetMultimap that uses the provided map and factory.
newStringBuilderForCollection(int) - Static method in class com.google.common.collect.Collections2
Returns best-effort-sized StringBuilder based on the given collection size.
newStrongInterner() - Static method in class com.google.common.collect.Interners
Returns a new thread-safe interner which retains a strong reference to each instance it has interned, thus preventing these instances from being garbage-collected.
newSynchronousQueue() - Static method in class com.google.common.collect.Queues
Creates an empty SynchronousQueue with nonfair access policy.
newTaskFor(Runnable, T) - Method in class com.google.common.util.concurrent.AbstractListeningExecutorService
 
newTaskFor(Callable<T>) - Method in class com.google.common.util.concurrent.AbstractListeningExecutorService
 
newThread(String, Runnable) - Static method in class com.google.common.util.concurrent.MoreExecutors
Creates a thread using MoreExecutors.platformThreadFactory(), and sets its name to name unless changing the name is forbidden by the security manager.
newTreeMap() - Static method in class com.google.common.collect.Maps
Creates a mutable, empty TreeMap instance using the natural ordering of its elements.
newTreeMap(SortedMap<K, ? extends V>) - Static method in class com.google.common.collect.Maps
Creates a mutable TreeMap instance with the same mappings as the specified map and using the same ordering as the specified map.
newTreeMap(Comparator<C>) - Static method in class com.google.common.collect.Maps
Creates a mutable, empty TreeMap instance using the given comparator.
newTreeSet() - Static method in class com.google.common.collect.Sets
Creates a mutable, empty TreeSet instance sorted by the natural sort ordering of its elements.
newTreeSet(Iterable<? extends E>) - Static method in class com.google.common.collect.Sets
Creates a mutable TreeSet instance containing the given elements sorted by their natural ordering.
newTreeSet(Comparator<? super E>) - Static method in class com.google.common.collect.Sets
Creates a mutable, empty TreeSet instance with the given comparator.
newValueReference(LocalCache.ReferenceEntry<K, V>, V, int) - Method in class com.google.common.cache.LocalCache
This method is a convenience for testing.
newValueReference(MapMakerInternalMap.ReferenceEntry<K, V>, V) - Method in class com.google.common.collect.MapMakerInternalMap
This method is a convenience for testing.
newWeakInterner() - Static method in class com.google.common.collect.Interners
Returns a new thread-safe interner which retains a weak reference to each instance it has interned, and so does not prevent these instances from being garbage-collected.
newWithCause(Class<X>, Throwable) - Static method in class com.google.common.util.concurrent.Futures
 
newWriter(File, Charset) - Static method in class com.google.common.io.Files
Returns a buffered writer that writes to a file using the given character set.
next - Variable in class com.google.common.base.AbstractIterator
 
next() - Method in class com.google.common.base.AbstractIterator
 
next - Variable in class com.google.common.base.MoreObjects.ToStringHelper.ValueHolder
 
next - Variable in class com.google.common.base.Objects.ToStringHelper.ValueHolder
Deprecated.
 
next() - Method in class com.google.common.cache.LocalCache.EntryIterator
 
next() - Method in class com.google.common.cache.LocalCache.HashIterator
 
next() - Method in class com.google.common.cache.LocalCache.KeyIterator
 
next - Variable in class com.google.common.cache.LocalCache.StrongEntry
 
next() - Method in class com.google.common.cache.LocalCache.ValueIterator
 
next - Variable in class com.google.common.cache.LocalCache.WeakEntry
 
next() - Method in class com.google.common.collect.AbstractIndexedListIterator
 
next - Variable in class com.google.common.collect.AbstractIterator
 
next() - Method in class com.google.common.collect.AbstractIterator
 
next() - Method in class com.google.common.collect.AbstractMapBasedMultimap.AsMap.AsMapIterator
 
next() - Method in class com.google.common.collect.AbstractMapBasedMultimap.Itr
 
next() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection.WrappedIterator
 
next() - Method in class com.google.common.collect.AbstractMapBasedMultiset.MapBasedMultisetIterator
 
next() - Method in class com.google.common.collect.AbstractSequentialIterator
 
next() - Method in class com.google.common.collect.BinaryTreeTraverser.PostOrderIterator
 
next() - Method in class com.google.common.collect.BinaryTreeTraverser.PreOrderIterator
 
next(BigInteger) - Method in class com.google.common.collect.DiscreteDomain.BigIntegerDomain
 
next(Integer) - Method in class com.google.common.collect.DiscreteDomain.IntegerDomain
 
next(Long) - Method in class com.google.common.collect.DiscreteDomain.LongDomain
 
next(C) - Method in class com.google.common.collect.DiscreteDomain
Returns the unique least value of type C that is greater than value, or null if none exists.
next() - Method in class com.google.common.collect.ForwardingIterator
 
next - Variable in class com.google.common.collect.HashBiMap.Itr
 
next() - Method in class com.google.common.collect.HashBiMap.Itr
 
next() - Method in class com.google.common.collect.ImmutableMultimap.Itr
 
next() - Method in class com.google.common.collect.Iterators.MergingIterator
 
next() - Method in class com.google.common.collect.Iterators.PeekingImpl
 
next - Variable in class com.google.common.collect.LinkedListMultimap.DistinctKeyIterator
 
next() - Method in class com.google.common.collect.LinkedListMultimap.DistinctKeyIterator
 
next - Variable in class com.google.common.collect.LinkedListMultimap.Node
 
next - Variable in class com.google.common.collect.LinkedListMultimap.NodeIterator
 
next() - Method in class com.google.common.collect.LinkedListMultimap.NodeIterator
 
next - Variable in class com.google.common.collect.LinkedListMultimap.ValueForKeyIterator
 
next() - Method in class com.google.common.collect.LinkedListMultimap.ValueForKeyIterator
 
next() - Method in class com.google.common.collect.MapMakerInternalMap.EntryIterator
 
next() - Method in class com.google.common.collect.MapMakerInternalMap.HashIterator
 
next() - Method in class com.google.common.collect.MapMakerInternalMap.KeyIterator
 
next - Variable in class com.google.common.collect.MapMakerInternalMap.SoftEntry
 
next - Variable in class com.google.common.collect.MapMakerInternalMap.StrongEntry
 
next() - Method in class com.google.common.collect.MapMakerInternalMap.ValueIterator
 
next - Variable in class com.google.common.collect.MapMakerInternalMap.WeakEntry
 
next() - Method in class com.google.common.collect.MinMaxPriorityQueue.QueueIterator
 
next() - Method in class com.google.common.collect.Multisets.MultisetIteratorImpl
 
next() - Method in interface com.google.common.collect.PeekingIterator
next() - Method in class com.google.common.collect.StandardTable.CellIterator
 
next() - Method in class com.google.common.collect.TransformedIterator
 
next() - Method in class com.google.common.collect.TreeTraverser.BreadthFirstIterator
 
next() - Method in class com.google.common.collect.TreeTraverser.PreOrderIterator
 
next - Variable in class com.google.common.util.concurrent.ExecutionList.RunnableExecutorPair
 
next - Variable in class com.google.common.util.concurrent.Monitor.Guard
The next active guard
nextAccess - Variable in class com.google.common.cache.LocalCache.StrongAccessEntry
 
nextAccess - Variable in class com.google.common.cache.LocalCache.StrongAccessWriteEntry
 
nextAccess - Variable in class com.google.common.cache.LocalCache.WeakAccessEntry
 
nextAccess - Variable in class com.google.common.cache.LocalCache.WeakAccessWriteEntry
 
nextBucket - Variable in class com.google.common.collect.HashBiMap.Itr
 
nextDouble() - Method in class com.google.common.hash.Hashing.LinearCongruentialGenerator
 
nextDown(double) - Static method in class com.google.common.math.DoubleUtils
 
nextEntry - Variable in class com.google.common.cache.LocalCache.HashIterator
 
nextEntry() - Method in class com.google.common.cache.LocalCache.HashIterator
 
nextEntry - Variable in class com.google.common.collect.MapMakerInternalMap.HashIterator
 
nextEntry() - Method in class com.google.common.collect.MapMakerInternalMap.HashIterator
 
nextEscapeIndex(CharSequence, int, int) - Method in class com.google.common.escape.ArrayBasedUnicodeEscaper
 
nextEscapeIndex(CharSequence, int, int) - Method in class com.google.common.escape.UnicodeEscaper
Scans a sub-sequence of characters from a given CharSequence, returning the index of the next character that requires escaping.
nextEscapeIndex(CharSequence, int, int) - Method in class com.google.common.net.PercentEscaper
 
nextEvictable - Variable in class com.google.common.collect.MapMakerInternalMap.SoftEvictableEntry
 
nextEvictable - Variable in class com.google.common.collect.MapMakerInternalMap.SoftExpirableEvictableEntry
 
nextEvictable - Variable in class com.google.common.collect.MapMakerInternalMap.StrongEvictableEntry
 
nextEvictable - Variable in class com.google.common.collect.MapMakerInternalMap.StrongExpirableEvictableEntry
 
nextEvictable - Variable in class com.google.common.collect.MapMakerInternalMap.WeakEvictableEntry
 
nextEvictable - Variable in class com.google.common.collect.MapMakerInternalMap.WeakExpirableEvictableEntry
 
nextExpirable - Variable in class com.google.common.collect.MapMakerInternalMap.SoftExpirableEntry
 
nextExpirable - Variable in class com.google.common.collect.MapMakerInternalMap.SoftExpirableEvictableEntry
 
nextExpirable - Variable in class com.google.common.collect.MapMakerInternalMap.StrongExpirableEntry
 
nextExpirable - Variable in class com.google.common.collect.MapMakerInternalMap.StrongExpirableEvictableEntry
 
nextExpirable - Variable in class com.google.common.collect.MapMakerInternalMap.WeakExpirableEntry
 
nextExpirable - Variable in class com.google.common.collect.MapMakerInternalMap.WeakExpirableEvictableEntry
 
nextExternal - Variable in class com.google.common.cache.LocalCache.HashIterator
 
nextExternal - Variable in class com.google.common.collect.MapMakerInternalMap.HashIterator
 
nextFreeTicketMicros - Variable in class com.google.common.util.concurrent.SmoothRateLimiter
The time when the next request (no matter its size) will be granted.
nextInChain() - Method in class com.google.common.cache.LocalCache.HashIterator
Finds the next entry in the current chain.
nextInChain() - Method in class com.google.common.collect.MapMakerInternalMap.HashIterator
Finds the next entry in the current chain.
nextIndex() - Method in class com.google.common.collect.AbstractIndexedListIterator
 
nextIndex() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedList.WrappedListIterator
 
nextIndex() - Method in class com.google.common.collect.ForwardingListIterator
 
nextIndex - Variable in class com.google.common.collect.LinkedListMultimap.NodeIterator
 
nextIndex() - Method in class com.google.common.collect.LinkedListMultimap.NodeIterator
 
nextIndex - Variable in class com.google.common.collect.LinkedListMultimap.ValueForKeyIterator
 
nextIndex() - Method in class com.google.common.collect.LinkedListMultimap.ValueForKeyIterator
 
nextIndex() - Method in class com.google.common.collect.TransformedListIterator
 
nextInKeyBucket - Variable in class com.google.common.collect.RegularImmutableBiMap.NonTerminalBiMapEntry
 
nextInKeyBucket - Variable in class com.google.common.collect.RegularImmutableMap.NonTerminalMapEntry
 
nextInKToVBucket - Variable in class com.google.common.collect.HashBiMap.BiEntry
 
nextInTable() - Method in class com.google.common.cache.LocalCache.HashIterator
Finds the next entry in the current table.
nextInTable() - Method in class com.google.common.collect.MapMakerInternalMap.HashIterator
Finds the next entry in the current table.
nextInValueBucket - Variable in class com.google.common.collect.LinkedHashMultimap.ValueEntry
 
nextInValueBucket - Variable in class com.google.common.collect.RegularImmutableBiMap.NonTerminalBiMapEntry
 
nextInVToKBucket - Variable in class com.google.common.collect.HashBiMap.BiEntry
 
nextNotInSkipMe(int) - Method in class com.google.common.collect.MinMaxPriorityQueue.QueueIterator
Returns the index of the first element after c that is not in skipMe and returns size() if there is no such element.
nextOrNull - Variable in class com.google.common.collect.AbstractSequentialIterator
 
nextPermutation - Variable in class com.google.common.collect.Collections2.OrderedPermutationIterator
 
nextSegmentIndex - Variable in class com.google.common.cache.LocalCache.HashIterator
 
nextSegmentIndex - Variable in class com.google.common.collect.MapMakerInternalMap.HashIterator
 
nextSibling - Variable in class com.google.common.collect.LinkedListMultimap.Node
 
nextTableIndex - Variable in class com.google.common.cache.LocalCache.HashIterator
 
nextTableIndex - Variable in class com.google.common.collect.MapMakerInternalMap.HashIterator
 
nextWrite - Variable in class com.google.common.cache.LocalCache.StrongAccessWriteEntry
 
nextWrite - Variable in class com.google.common.cache.LocalCache.StrongWriteEntry
 
nextWrite - Variable in class com.google.common.cache.LocalCache.WeakAccessWriteEntry
 
nextWrite - Variable in class com.google.common.cache.LocalCache.WeakWriteEntry
 
NINES - Static variable in class com.google.common.base.CharMatcher
 
NL - Static variable in class com.google.common.base.Ascii
Alternate name for Ascii.LF.
NO_ARGS - Static variable in class com.google.common.reflect.AbstractInvocationHandler
 
NO_PORT - Static variable in class com.google.common.net.HostAndPort
Magic value indicating the absence of a port number.
NO_PUBLIC_SUFFIX_FOUND - Static variable in class com.google.common.net.InternetDomainName
Value of InternetDomainName.publicSuffixIndex which indicates that no public suffix was found.
Node(K, V) - Constructor for class com.google.common.collect.LinkedListMultimap.Node
 
nodeAggregate(TreeMultiset.AvlNode<?>) - Method in enum com.google.common.collect.TreeMultiset.Aggregate
 
NodeIterator(int) - Constructor for class com.google.common.collect.LinkedListMultimap.NodeIterator
 
nonCancellationPropagating(ListenableFuture<V>) - Static method in class com.google.common.util.concurrent.Futures
Creates a new ListenableFuture whose result is set from the supplied future when it completes.
NonCancellationPropagatingFuture(ListenableFuture<V>) - Constructor for class com.google.common.util.concurrent.Futures.NonCancellationPropagatingFuture
 
NONE - Static variable in class com.google.common.base.CharMatcher
Matches no characters.
noneOf(CharSequence) - Static method in class com.google.common.base.CharMatcher
Returns a char matcher that matches any character not present in the given character sequence.
NonTerminalBiMapEntry(K, V, ImmutableMapEntry<K, V>, ImmutableMapEntry<K, V>) - Constructor for class com.google.common.collect.RegularImmutableBiMap.NonTerminalBiMapEntry
 
NonTerminalBiMapEntry(ImmutableMapEntry<K, V>, ImmutableMapEntry<K, V>, ImmutableMapEntry<K, V>) - Constructor for class com.google.common.collect.RegularImmutableBiMap.NonTerminalBiMapEntry
 
NonTerminalMapEntry(K, V, ImmutableMapEntry<K, V>) - Constructor for class com.google.common.collect.RegularImmutableMap.NonTerminalMapEntry
 
NonTerminalMapEntry(ImmutableMapEntry<K, V>, ImmutableMapEntry<K, V>) - Constructor for class com.google.common.collect.RegularImmutableMap.NonTerminalMapEntry
 
NoOpService() - Constructor for class com.google.common.util.concurrent.ServiceManager.NoOpService
 
normalizeFirstWord(String) - Method in enum com.google.common.base.CaseFormat
 
normalizeParameterValue(String, String) - Static method in class com.google.common.net.MediaType
 
normalizeToken(String) - Static method in class com.google.common.net.MediaType
 
normalizeWord(String) - Method in enum com.google.common.base.CaseFormat
 
not(Predicate<T>) - Static method in class com.google.common.base.Predicates
Returns a predicate that evaluates to true if the given predicate evaluates to false.
notifyFailed(Throwable) - Method in class com.google.common.util.concurrent.AbstractService
Invoke this method to transition the service to the Service.State.FAILED.
notifyNewValue(V) - Method in class com.google.common.cache.LocalCache.LoadingValueReference
 
notifyNewValue(V) - Method in class com.google.common.cache.LocalCache.SoftValueReference
 
notifyNewValue(V) - Method in class com.google.common.cache.LocalCache.StrongValueReference
 
notifyNewValue(V) - Method in interface com.google.common.cache.LocalCache.ValueReference
Notifify pending loads that a new value was set.
notifyNewValue(V) - Method in class com.google.common.cache.LocalCache.WeakValueReference
 
notifyRemoval(K, V) - Method in class com.google.common.collect.MapMaker.NullConcurrentMap
 
notifyStarted() - Method in class com.google.common.util.concurrent.AbstractService
Implementing classes should invoke this method once their service has started.
notifyStopped() - Method in class com.google.common.util.concurrent.AbstractService
Implementing classes should invoke this method once their service has stopped.
notNull() - Static method in class com.google.common.base.Predicates
Returns a predicate that evaluates to true if the object reference being tested is not null.
notNull() - Static method in class com.google.common.collect.MapConstraints
Returns a constraint that verifies that neither the key nor the value is null.
NotNullMapConstraint() - Constructor for enum com.google.common.collect.MapConstraints.NotNullMapConstraint
 
NotPredicate(Predicate<T>) - Constructor for class com.google.common.base.Predicates.NotPredicate
 
NUL - Static variable in class com.google.common.base.Ascii
Null ('\0'): The all-zeros character which may serve to accomplish time fill and media fill.
NULL_ESCAPER - Static variable in class com.google.common.escape.Escapers
 
NULL_OUTPUT_STREAM - Static variable in class com.google.common.io.ByteStreams
 
NULL_STATS_COUNTER - Static variable in class com.google.common.cache.CacheBuilder
 
NULL_TICKER - Static variable in class com.google.common.cache.CacheBuilder
 
nullableSynchronizedEntry(Map.Entry<K, V>, Object) - Static method in class com.google.common.collect.Synchronized
 
NullComputingConcurrentMap(MapMaker, Function<? super K, ? extends V>) - Constructor for class com.google.common.collect.MapMaker.NullComputingConcurrentMap
 
NullConcurrentMap(MapMaker) - Constructor for class com.google.common.collect.MapMaker.NullConcurrentMap
 
nullEntry() - Static method in class com.google.common.cache.LocalCache
 
NullEntry() - Constructor for enum com.google.common.cache.LocalCache.NullEntry
 
nullEntry() - Static method in class com.google.common.collect.MapMakerInternalMap
 
NullEntry() - Constructor for enum com.google.common.collect.MapMakerInternalMap.NullEntry
 
nullEscaper() - Static method in class com.google.common.escape.Escapers
Returns an Escaper that does no escaping, passing all character data through unchanged.
nullifyAccessOrder(LocalCache.ReferenceEntry<K, V>) - Static method in class com.google.common.cache.LocalCache
 
nullifyEvictable(MapMakerInternalMap.ReferenceEntry<K, V>) - Static method in class com.google.common.collect.MapMakerInternalMap
 
nullifyExpirable(MapMakerInternalMap.ReferenceEntry<K, V>) - Static method in class com.google.common.collect.MapMakerInternalMap
 
nullifyWriteOrder(LocalCache.ReferenceEntry<K, V>) - Static method in class com.google.common.cache.LocalCache
 
NullListener() - Constructor for enum com.google.common.cache.CacheBuilder.NullListener
 
NullListener() - Constructor for enum com.google.common.collect.GenericMapMaker.NullListener
Deprecated.
 
nullOutputStream() - Static method in class com.google.common.io.ByteStreams
Returns an OutputStream that simply discards written bytes.
nullRemovalCause - Variable in class com.google.common.collect.MapMaker
 
nullsFirst() - Method in class com.google.common.collect.NullsFirstOrdering
 
nullsFirst() - Method in class com.google.common.collect.NullsLastOrdering
 
nullsFirst() - Method in class com.google.common.collect.Ordering
Returns an ordering that treats null as less than all other values and uses this to compare non-null values.
NullsFirstOrdering<T> - Class in com.google.common.collect
An ordering that treats null as less than all other values.
NullsFirstOrdering(Ordering<? super T>) - Constructor for class com.google.common.collect.NullsFirstOrdering
 
nullsLast() - Method in class com.google.common.collect.NullsFirstOrdering
 
nullsLast() - Method in class com.google.common.collect.NullsLastOrdering
 
nullsLast() - Method in class com.google.common.collect.Ordering
Returns an ordering that treats null as greater than all other values and uses this ordering to compare non-null values.
NullsLastOrdering<T> - Class in com.google.common.collect
An ordering that treats null as greater than all other values.
NullsLastOrdering(Ordering<? super T>) - Constructor for class com.google.common.collect.NullsLastOrdering
 
nullToEmpty(String) - Static method in class com.google.common.base.Strings
Returns the given string if it is non-null; the empty string otherwise.
nullWriter() - Static method in class com.google.common.io.CharStreams
Returns a Writer that simply discards written chars.
NullWriter() - Constructor for class com.google.common.io.CharStreams.NullWriter
 
numberOfServices - Variable in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState
 
numHashFunctions - Variable in class com.google.common.hash.BloomFilter
Number of hashes per element
numHashFunctions - Variable in class com.google.common.hash.BloomFilter.SerialForm
 

O

o - Variable in class com.google.common.collect.Collections2.PermutationIterator
 
ObjectArrays - Class in com.google.common.collect
Static utility methods pertaining to object arrays.
ObjectArrays() - Constructor for class com.google.common.collect.ObjectArrays
 
ObjectPredicate() - Constructor for enum com.google.common.base.Predicates.ObjectPredicate
 
Objects - Class in com.google.common.base
Helper functions that can operate on any Object.
Objects() - Constructor for class com.google.common.base.Objects
 
Objects.ToStringHelper - Class in com.google.common.base
Deprecated.
Use MoreObjects.ToStringHelper instead. This class is scheduled for removal in June 2016.
Objects.ToStringHelper.ValueHolder - Class in com.google.common.base
Deprecated.
 
occurrencesLeft - Variable in class com.google.common.collect.AbstractMapBasedMultiset.MapBasedMultisetIterator
 
OCTET_STREAM - Static variable in class com.google.common.net.MediaType
 
ODD_POWERS_OF_TWO - Static variable in class com.google.common.collect.MinMaxPriorityQueue
 
of(T) - Static method in class com.google.common.base.Optional
Returns an Optional instance containing the given non-null reference.
of(E[]) - Static method in class com.google.common.collect.FluentIterable
Returns a fluent iterable containing elements in the specified order.
of() - Static method in class com.google.common.collect.ImmutableBiMap
Returns the empty bimap.
of(K, V) - Static method in class com.google.common.collect.ImmutableBiMap
Returns an immutable bimap containing a single entry.
of(K, V, K, V) - Static method in class com.google.common.collect.ImmutableBiMap
Returns an immutable map containing the given entries, in order.
of(K, V, K, V, K, V) - Static method in class com.google.common.collect.ImmutableBiMap
Returns an immutable map containing the given entries, in order.
of(K, V, K, V, K, V, K, V) - Static method in class com.google.common.collect.ImmutableBiMap
Returns an immutable map containing the given entries, in order.
of(K, V, K, V, K, V, K, V, K, V) - Static method in class com.google.common.collect.ImmutableBiMap
Returns an immutable map containing the given entries, in order.
of() - Static method in class com.google.common.collect.ImmutableList
Returns the empty immutable list.
of(E) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing a single element.
of(E, E) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing the given elements, in order.
of(E, E, E) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing the given elements, in order.
of(E, E, E, E) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing the given elements, in order.
of(E, E, E, E, E) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing the given elements, in order.
of(E, E, E, E, E, E) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing the given elements, in order.
of(E, E, E, E, E, E, E) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing the given elements, in order.
of(E, E, E, E, E, E, E, E) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing the given elements, in order.
of(E, E, E, E, E, E, E, E, E) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing the given elements, in order.
of(E, E, E, E, E, E, E, E, E, E) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing the given elements, in order.
of(E, E, E, E, E, E, E, E, E, E, E) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing the given elements, in order.
of(E, E, E, E, E, E, E, E, E, E, E, E, E...) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing the given elements, in order.
of() - Static method in class com.google.common.collect.ImmutableListMultimap
Returns the empty multimap.
of(K, V) - Static method in class com.google.common.collect.ImmutableListMultimap
Returns an immutable multimap containing a single entry.
of(K, V, K, V) - Static method in class com.google.common.collect.ImmutableListMultimap
Returns an immutable multimap containing the given entries, in order.
of(K, V, K, V, K, V) - Static method in class com.google.common.collect.ImmutableListMultimap
Returns an immutable multimap containing the given entries, in order.
of(K, V, K, V, K, V, K, V) - Static method in class com.google.common.collect.ImmutableListMultimap
Returns an immutable multimap containing the given entries, in order.
of(K, V, K, V, K, V, K, V, K, V) - Static method in class com.google.common.collect.ImmutableListMultimap
Returns an immutable multimap containing the given entries, in order.
of() - Static method in class com.google.common.collect.ImmutableMap
Returns the empty map.
of(K, V) - Static method in class com.google.common.collect.ImmutableMap
Returns an immutable map containing a single entry.
of(K, V, K, V) - Static method in class com.google.common.collect.ImmutableMap
Returns an immutable map containing the given entries, in order.
of(K, V, K, V, K, V) - Static method in class com.google.common.collect.ImmutableMap
Returns an immutable map containing the given entries, in order.
of(K, V, K, V, K, V, K, V) - Static method in class com.google.common.collect.ImmutableMap
Returns an immutable map containing the given entries, in order.
of(K, V, K, V, K, V, K, V, K, V) - Static method in class com.google.common.collect.ImmutableMap
Returns an immutable map containing the given entries, in order.
of() - Static method in class com.google.common.collect.ImmutableMultimap
Returns an empty multimap.
of(K, V) - Static method in class com.google.common.collect.ImmutableMultimap
Returns an immutable multimap containing a single entry.
of(K, V, K, V) - Static method in class com.google.common.collect.ImmutableMultimap
Returns an immutable multimap containing the given entries, in order.
of(K, V, K, V, K, V) - Static method in class com.google.common.collect.ImmutableMultimap
Returns an immutable multimap containing the given entries, in order.
of(K, V, K, V, K, V, K, V) - Static method in class com.google.common.collect.ImmutableMultimap
Returns an immutable multimap containing the given entries, in order.
of(K, V, K, V, K, V, K, V, K, V) - Static method in class com.google.common.collect.ImmutableMultimap
Returns an immutable multimap containing the given entries, in order.
of() - Static method in class com.google.common.collect.ImmutableMultiset
Returns the empty immutable multiset.
of(E) - Static method in class com.google.common.collect.ImmutableMultiset
Returns an immutable multiset containing a single element.
of(E, E) - Static method in class com.google.common.collect.ImmutableMultiset
Returns an immutable multiset containing the given elements, in order.
of(E, E, E) - Static method in class com.google.common.collect.ImmutableMultiset
Returns an immutable multiset containing the given elements, in order.
of(E, E, E, E) - Static method in class com.google.common.collect.ImmutableMultiset
Returns an immutable multiset containing the given elements, in order.
of(E, E, E, E, E) - Static method in class com.google.common.collect.ImmutableMultiset
Returns an immutable multiset containing the given elements, in order.
of(E, E, E, E, E, E, E...) - Static method in class com.google.common.collect.ImmutableMultiset
Returns an immutable multiset containing the given elements, in order.
of() - Static method in class com.google.common.collect.ImmutableRangeMap
Returns an empty immutable range map.
of(Range<K>, V) - Static method in class com.google.common.collect.ImmutableRangeMap
Returns an immutable range map mapping a single range to a single value.
of() - Static method in class com.google.common.collect.ImmutableRangeSet
Returns an empty immutable range set.
of(Range<C>) - Static method in class com.google.common.collect.ImmutableRangeSet
Returns an immutable range set containing the specified single range.
of() - Static method in class com.google.common.collect.ImmutableSet
Returns the empty immutable set.
of(E) - Static method in class com.google.common.collect.ImmutableSet
Returns an immutable set containing a single element.
of(E, E) - Static method in class com.google.common.collect.ImmutableSet
Returns an immutable set containing the given elements, in order.
of(E, E, E) - Static method in class com.google.common.collect.ImmutableSet
Returns an immutable set containing the given elements, in order.
of(E, E, E, E) - Static method in class com.google.common.collect.ImmutableSet
Returns an immutable set containing the given elements, in order.
of(E, E, E, E, E) - Static method in class com.google.common.collect.ImmutableSet
Returns an immutable set containing the given elements, in order.
of(E, E, E, E, E, E, E...) - Static method in class com.google.common.collect.ImmutableSet
Returns an immutable set containing the given elements, in order.
of() - Static method in class com.google.common.collect.ImmutableSetMultimap
Returns the empty multimap.
of(K, V) - Static method in class com.google.common.collect.ImmutableSetMultimap
Returns an immutable multimap containing a single entry.
of(K, V, K, V) - Static method in class com.google.common.collect.ImmutableSetMultimap
Returns an immutable multimap containing the given entries, in order.
of(K, V, K, V, K, V) - Static method in class com.google.common.collect.ImmutableSetMultimap
Returns an immutable multimap containing the given entries, in order.
of(K, V, K, V, K, V, K, V) - Static method in class com.google.common.collect.ImmutableSetMultimap
Returns an immutable multimap containing the given entries, in order.
of(K, V, K, V, K, V, K, V, K, V) - Static method in class com.google.common.collect.ImmutableSetMultimap
Returns an immutable multimap containing the given entries, in order.
of() - Static method in class com.google.common.collect.ImmutableSortedMap
Returns the empty sorted map.
of(K, V) - Static method in class com.google.common.collect.ImmutableSortedMap
Returns an immutable map containing a single entry.
of(K, V, K, V) - Static method in class com.google.common.collect.ImmutableSortedMap
Returns an immutable sorted map containing the given entries, sorted by the natural ordering of their keys.
of(K, V, K, V, K, V) - Static method in class com.google.common.collect.ImmutableSortedMap
Returns an immutable sorted map containing the given entries, sorted by the natural ordering of their keys.
of(K, V, K, V, K, V, K, V) - Static method in class com.google.common.collect.ImmutableSortedMap
Returns an immutable sorted map containing the given entries, sorted by the natural ordering of their keys.
of(K, V, K, V, K, V, K, V, K, V) - Static method in class com.google.common.collect.ImmutableSortedMap
Returns an immutable sorted map containing the given entries, sorted by the natural ordering of their keys.
of(K, V) - Static method in class com.google.common.collect.ImmutableSortedMapFauxverideShim
Deprecated.
Pass a key of type Comparable to use ImmutableSortedMap.of(Comparable, Object).
of(K, V, K, V) - Static method in class com.google.common.collect.ImmutableSortedMapFauxverideShim
Deprecated.
of(K, V, K, V, K, V) - Static method in class com.google.common.collect.ImmutableSortedMapFauxverideShim
of(K, V, K, V, K, V, K, V) - Static method in class com.google.common.collect.ImmutableSortedMapFauxverideShim
of(K, V, K, V, K, V, K, V, K, V) - Static method in class com.google.common.collect.ImmutableSortedMapFauxverideShim
of() - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns the empty immutable sorted multiset.
of(E) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns an immutable sorted multiset containing a single element.
of(E, E) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns an immutable sorted multiset containing the given elements sorted by their natural ordering.
of(E, E, E) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns an immutable sorted multiset containing the given elements sorted by their natural ordering.
of(E, E, E, E) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns an immutable sorted multiset containing the given elements sorted by their natural ordering.
of(E, E, E, E, E) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns an immutable sorted multiset containing the given elements sorted by their natural ordering.
of(E, E, E, E, E, E, E...) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns an immutable sorted multiset containing the given elements sorted by their natural ordering.
of(E) - Static method in class com.google.common.collect.ImmutableSortedMultisetFauxverideShim
Deprecated.
Pass a parameter of type Comparable to use ImmutableSortedMultiset.of(Comparable).
of(E, E) - Static method in class com.google.common.collect.ImmutableSortedMultisetFauxverideShim
Deprecated.
Pass the parameters of type Comparable to use ImmutableSortedMultiset.of(Comparable, Comparable).
of(E, E, E) - Static method in class com.google.common.collect.ImmutableSortedMultisetFauxverideShim
Deprecated.
Pass the parameters of type Comparable to use ImmutableSortedMultiset.of(Comparable, Comparable, Comparable).
of(E, E, E, E) - Static method in class com.google.common.collect.ImmutableSortedMultisetFauxverideShim
Deprecated.
of(E, E, E, E, E) - Static method in class com.google.common.collect.ImmutableSortedMultisetFauxverideShim
Deprecated.
of(E, E, E, E, E, E, E...) - Static method in class com.google.common.collect.ImmutableSortedMultisetFauxverideShim
of() - Static method in class com.google.common.collect.ImmutableSortedSet
Returns the empty immutable sorted set.
of(E) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing a single element.
of(E, E) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by their natural ordering.
of(E, E, E) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by their natural ordering.
of(E, E, E, E) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by their natural ordering.
of(E, E, E, E, E) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by their natural ordering.
of(E, E, E, E, E, E, E...) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by their natural ordering.
of(E) - Static method in class com.google.common.collect.ImmutableSortedSetFauxverideShim
Deprecated.
Pass a parameter of type Comparable to use ImmutableSortedSet.of(Comparable).
of(E, E) - Static method in class com.google.common.collect.ImmutableSortedSetFauxverideShim
Deprecated.
Pass the parameters of type Comparable to use ImmutableSortedSet.of(Comparable, Comparable).
of(E, E, E) - Static method in class com.google.common.collect.ImmutableSortedSetFauxverideShim
Deprecated.
Pass the parameters of type Comparable to use ImmutableSortedSet.of(Comparable, Comparable, Comparable).
of(E, E, E, E) - Static method in class com.google.common.collect.ImmutableSortedSetFauxverideShim
Deprecated.
Pass the parameters of type Comparable to use ImmutableSortedSet.of(Comparable, Comparable, Comparable, Comparable).
of(E, E, E, E, E) - Static method in class com.google.common.collect.ImmutableSortedSetFauxverideShim
Deprecated.
of(E, E, E, E, E, E, E...) - Static method in class com.google.common.collect.ImmutableSortedSetFauxverideShim
of() - Static method in class com.google.common.collect.ImmutableTable
Returns an empty immutable table.
of(R, C, V) - Static method in class com.google.common.collect.ImmutableTable
Returns an immutable table containing a single cell.
of(String, ClassLoader) - Static method in class com.google.common.reflect.ClassPath.ResourceInfo
 
of() - Static method in class com.google.common.reflect.ImmutableTypeToInstanceMap
Returns an empty type to instance map.
of(Class<T>) - Static method in class com.google.common.reflect.TypeToken
Returns an instance of type token that wraps type.
of(Type) - Static method in class com.google.common.reflect.TypeToken
Returns an instance of type token that wraps type.
offer(LocalCache.ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.AccessQueue
 
offer(LocalCache.ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.WriteQueue
 
offer(E) - Method in class com.google.common.collect.EvictingQueue
Adds the given element to this queue.
offer(E, long, TimeUnit) - Method in class com.google.common.collect.ForwardingBlockingDeque
 
offer(E) - Method in class com.google.common.collect.ForwardingQueue
 
offer(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.EvictionQueue
 
offer(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.ExpirationQueue
 
offer(E) - Method in class com.google.common.collect.MinMaxPriorityQueue
Adds the given element to this queue.
offer(E) - Method in class com.google.common.collect.Synchronized.SynchronizedQueue
 
offer(E, long, TimeUnit) - Method in class com.google.common.util.concurrent.ForwardingBlockingQueue
 
offerFirst(E, long, TimeUnit) - Method in class com.google.common.collect.ForwardingBlockingDeque
 
offerFirst(E) - Method in class com.google.common.collect.ForwardingDeque
 
offerFirst(E) - Method in class com.google.common.collect.Synchronized.SynchronizedDeque
 
offerLast(E, long, TimeUnit) - Method in class com.google.common.collect.ForwardingBlockingDeque
 
offerLast(E) - Method in class com.google.common.collect.ForwardingDeque
 
offerLast(E) - Method in class com.google.common.collect.Synchronized.SynchronizedDeque
 
offset - Variable in class com.google.common.base.Splitter.SplittingIterator
 
offset - Variable in class com.google.common.collect.ImmutableList.SubList
 
offset - Variable in class com.google.common.collect.RegularImmutableList
 
offset - Variable in class com.google.common.collect.RegularImmutableSortedMultiset
 
offset - Variable in class com.google.common.io.ByteSource.SlicedByteSource
 
ofInstance(T) - Static method in class com.google.common.base.Suppliers
Returns a supplier that always supplies instance.
OGG_AUDIO - Static variable in class com.google.common.net.MediaType
 
OGG_CONTAINER - Static variable in class com.google.common.net.MediaType
 
OGG_VIDEO - Static variable in class com.google.common.net.MediaType
 
oldValue - Variable in class com.google.common.cache.LocalCache.LoadingValueReference
 
omitEmptyStrings - Variable in class com.google.common.base.Splitter
 
omitEmptyStrings() - Method in class com.google.common.base.Splitter
Returns a splitter that behaves equivalently to this splitter, but automatically omits empty strings from the results.
omitEmptyStrings - Variable in class com.google.common.base.Splitter.SplittingIterator
 
omitNullValues - Variable in class com.google.common.base.MoreObjects.ToStringHelper
 
omitNullValues() - Method in class com.google.common.base.MoreObjects.ToStringHelper
Configures the MoreObjects.ToStringHelper so MoreObjects.ToStringHelper.toString() will ignore properties with null value.
omitNullValues - Variable in class com.google.common.base.Objects.ToStringHelper
Deprecated.
 
omitNullValues() - Method in class com.google.common.base.Objects.ToStringHelper
Deprecated.
Configures the Objects.ToStringHelper so Objects.ToStringHelper.toString() will ignore properties with null value.
omitPadding() - Method in class com.google.common.io.BaseEncoding
Returns an encoding that behaves equivalently to this encoding, but omits any padding characters as specified by RFC 4648 section 3.2, Padding of Encoded Data.
omitPadding() - Method in class com.google.common.io.BaseEncoding.SeparatedBaseEncoding
 
omitPadding() - Method in class com.google.common.io.BaseEncoding.StandardBaseEncoding
 
on(String) - Static method in class com.google.common.base.Joiner
Returns a joiner which automatically places separator between consecutive elements.
on(char) - Static method in class com.google.common.base.Joiner
Returns a joiner which automatically places separator between consecutive elements.
on(char) - Static method in class com.google.common.base.Splitter
Returns a splitter that uses the given single-character separator.
on(CharMatcher) - Static method in class com.google.common.base.Splitter
Returns a splitter that considers any single character matched by the given CharMatcher to be a separator.
on(String) - Static method in class com.google.common.base.Splitter
Returns a splitter that uses the given fixed string as a separator.
on(Pattern) - Static method in class com.google.common.base.Splitter
Returns a splitter that considers any subsequence matching pattern to be a separator.
onBoth - Variable in class com.google.common.collect.Maps.MapDifferenceImpl
 
ONE - Static variable in class com.google.common.primitives.UnsignedInteger
 
ONE - Static variable in class com.google.common.primitives.UnsignedLong
 
ONE_BITS - Static variable in class com.google.common.math.DoubleUtils
 
OnePlusArrayList(E, E[]) - Constructor for class com.google.common.collect.Lists.OnePlusArrayList
 
OneWeigher() - Constructor for enum com.google.common.cache.CacheBuilder.OneWeigher
 
onFailure(Throwable) - Method in interface com.google.common.util.concurrent.FutureCallback
Invoked when a Future computation fails or is canceled.
onKeys() - Method in class com.google.common.collect.Ordering
 
onlyOnLeft - Variable in class com.google.common.collect.Maps.MapDifferenceImpl
 
onlyOnRight - Variable in class com.google.common.collect.Maps.MapDifferenceImpl
 
onPattern(String) - Static method in class com.google.common.base.Splitter
Returns a splitter that considers any subsequence matching a given pattern (regular expression) to be a separator.
onRemoval(RemovalNotification<Object, Object>) - Method in enum com.google.common.cache.CacheBuilder.NullListener
 
onRemoval(RemovalNotification<K, V>) - Method in interface com.google.common.cache.RemovalListener
Notifies the listener that a removal occurred at some point in the past.
onRemoval(MapMaker.RemovalNotification<Object, Object>) - Method in enum com.google.common.collect.GenericMapMaker.NullListener
Deprecated.
 
onRemoval(MapMaker.RemovalNotification<K, V>) - Method in interface com.google.common.collect.MapMaker.RemovalListener
Notifies the listener that a removal occurred at some point in the past.
onResultOf(Function<F, ? extends T>) - Method in class com.google.common.base.Equivalence
Returns a new equivalence relation for F which evaluates equivalence by first applying function to the argument, then evaluating using this.
onResultOf(Function<F, ? extends T>) - Method in class com.google.common.collect.Ordering
Returns a new ordering on F which orders elements by first applying a function to them, then comparing those results using this.
onSuccess(V) - Method in interface com.google.common.util.concurrent.FutureCallback
Invoked with the result of the Future computation when it is successful.
OOXML_DOCUMENT - Static variable in class com.google.common.net.MediaType
 
OOXML_PRESENTATION - Static variable in class com.google.common.net.MediaType
 
OOXML_SHEET - Static variable in class com.google.common.net.MediaType
 
open(C, C) - Static method in class com.google.common.collect.Range
Returns a range that contains all values strictly greater than lower and strictly less than upper.
openBufferedStream() - Method in class com.google.common.io.ByteSink
Opens a new buffered OutputStream for writing to this sink.
openBufferedStream() - Method in class com.google.common.io.ByteSource.ByteArrayByteSource
 
openBufferedStream() - Method in class com.google.common.io.ByteSource
Opens a new buffered InputStream for reading from this source.
openBufferedStream() - Method in class com.google.common.io.ByteSource.SlicedByteSource
 
openBufferedStream() - Method in class com.google.common.io.CharSink
Opens a new buffered Writer for writing to this sink.
openBufferedStream() - Method in class com.google.common.io.CharSource
Opens a new BufferedReader for reading from this source.
openClosed(C, C) - Static method in class com.google.common.collect.Range
Returns a range that contains all values strictly greater than lower and less than or equal to upper.
OPENDOCUMENT_GRAPHICS - Static variable in class com.google.common.net.MediaType
 
OPENDOCUMENT_PRESENTATION - Static variable in class com.google.common.net.MediaType
 
OPENDOCUMENT_SPREADSHEET - Static variable in class com.google.common.net.MediaType
 
OPENDOCUMENT_TEXT - Static variable in class com.google.common.net.MediaType
 
openInputStream() - Method in class com.google.common.io.FileBackedOutputStream
 
openStream() - Method in class com.google.common.io.ByteSink.AsCharSink
 
openStream() - Method in class com.google.common.io.ByteSink
Opens a new OutputStream for writing to this sink.
openStream() - Method in class com.google.common.io.ByteSource.AsCharSource
 
openStream() - Method in class com.google.common.io.ByteSource.ByteArrayByteSource
 
openStream() - Method in class com.google.common.io.ByteSource.ConcatenatedByteSource
 
openStream() - Method in class com.google.common.io.ByteSource
Opens a new InputStream for reading from this source.
openStream() - Method in class com.google.common.io.ByteSource.SlicedByteSource
 
openStream() - Method in class com.google.common.io.CharSink
Opens a new Writer for writing to this sink.
openStream() - Method in class com.google.common.io.CharSource.CharSequenceCharSource
 
openStream() - Method in class com.google.common.io.CharSource.ConcatenatedCharSource
 
openStream() - Method in class com.google.common.io.CharSource
Opens a new Reader for reading from this source.
openStream() - Method in class com.google.common.io.Files.FileByteSink
 
openStream() - Method in class com.google.common.io.Files.FileByteSource
 
openStream() - Method in class com.google.common.io.Resources.UrlByteSource
 
optimalNumOfBits(long, double) - Static method in class com.google.common.hash.BloomFilter
Computes m (total bits of Bloom filter) which is expected to achieve, for the specified expected insertions, the required false positive probability.
optimalNumOfHashFunctions(long, long) - Static method in class com.google.common.hash.BloomFilter
Computes the optimal k (number of hashes per element inserted in Bloom filter), given the expected insertions and total number of bits in the Bloom filter.
Optional<T> - Class in com.google.common.base
An immutable object that may contain a non-null reference to another object.
Optional() - Constructor for class com.google.common.base.Optional
 
or(T) - Method in class com.google.common.base.Absent
 
or(Optional<? extends T>) - Method in class com.google.common.base.Absent
 
or(Supplier<? extends T>) - Method in class com.google.common.base.Absent
 
or(CharMatcher) - Method in class com.google.common.base.CharMatcher
Returns a matcher that matches any character matched by either this matcher or other.
Or(CharMatcher, CharMatcher, String) - Constructor for class com.google.common.base.CharMatcher.Or
 
Or(CharMatcher, CharMatcher) - Constructor for class com.google.common.base.CharMatcher.Or
 
or(T) - Method in class com.google.common.base.Optional
Returns the contained instance if it is present; defaultValue otherwise.
or(Optional<? extends T>) - Method in class com.google.common.base.Optional
Returns this Optional if it has a value present; secondChoice otherwise.
or(Supplier<? extends T>) - Method in class com.google.common.base.Optional
Returns the contained instance if it is present; supplier.get() otherwise.
or(Iterable<? extends Predicate<? super T>>) - Static method in class com.google.common.base.Predicates
Returns a predicate that evaluates to true if any one of its components evaluates to true.
or(Predicate<? super T>...) - Static method in class com.google.common.base.Predicates
Returns a predicate that evaluates to true if any one of its components evaluates to true.
or(Predicate<? super T>, Predicate<? super T>) - Static method in class com.google.common.base.Predicates
Returns a predicate that evaluates to true if either of its components evaluates to true.
or(T) - Method in class com.google.common.base.Present
 
or(Optional<? extends T>) - Method in class com.google.common.base.Present
 
or(Supplier<? extends T>) - Method in class com.google.common.base.Present
 
orderColumnsBy(Comparator<? super C>) - Method in class com.google.common.collect.ImmutableTable.Builder
Specifies the ordering of the generated table's columns.
orderedBy(Comparator<K>) - Static method in class com.google.common.collect.ImmutableSortedMap
Returns a builder that creates immutable sorted maps with an explicit comparator.
orderedBy(Comparator<E>) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns a builder that creates immutable sorted multisets with an explicit comparator.
orderedBy(Comparator<E>) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns a builder that creates immutable sorted sets with an explicit comparator.
orderedBy(Comparator<B>) - Static method in class com.google.common.collect.MinMaxPriorityQueue
Creates and returns a new builder, configured to build MinMaxPriorityQueue instances that use comparator to determine the least and greatest elements.
OrderedPermutationCollection(Iterable<E>, Comparator<? super E>) - Constructor for class com.google.common.collect.Collections2.OrderedPermutationCollection
 
OrderedPermutationIterator(List<E>, Comparator<? super E>) - Constructor for class com.google.common.collect.Collections2.OrderedPermutationIterator
 
orderedPermutations(Iterable<E>) - Static method in class com.google.common.collect.Collections2
Returns a Collection of all the permutations of the specified Iterable.
orderedPermutations(Iterable<E>, Comparator<? super E>) - Static method in class com.google.common.collect.Collections2
Returns a Collection of all the permutations of the specified Iterable using the specified Comparator for establishing the lexicographical ordering.
ordering - Variable in class com.google.common.collect.ByFunctionOrdering
 
ordering() - Method in class com.google.common.collect.MinMaxPriorityQueue.Builder
 
ordering - Variable in class com.google.common.collect.MinMaxPriorityQueue.Heap
 
ordering - Variable in class com.google.common.collect.NullsFirstOrdering
 
ordering - Variable in class com.google.common.collect.NullsLastOrdering
 
Ordering<T> - Class in com.google.common.collect
A comparator, with additional methods to support common operations.
Ordering() - Constructor for class com.google.common.collect.Ordering
Constructs a new instance of this class (only invokable by the subclass constructor, typically implicit).
Ordering.ArbitraryOrdering - Class in com.google.common.collect
 
Ordering.ArbitraryOrderingHolder - Class in com.google.common.collect
 
Ordering.IncomparableValueException - Exception in com.google.common.collect
Exception thrown by a Ordering.explicit(List) or Ordering.explicit(Object, Object[]) comparator when comparing a value outside the set of values it can compare.
orderKeysBy(Comparator<? super K>) - Method in class com.google.common.collect.ImmutableListMultimap.Builder
Specifies the ordering of the generated multimap's keys.
orderKeysBy(Comparator<? super K>) - Method in class com.google.common.collect.ImmutableMultimap.Builder
Specifies the ordering of the generated multimap's keys.
orderKeysBy(Comparator<? super K>) - Method in class com.google.common.collect.ImmutableSetMultimap.Builder
Specifies the ordering of the generated multimap's keys.
orderRowsBy(Comparator<? super R>) - Method in class com.google.common.collect.ImmutableTable.Builder
Specifies the ordering of the generated table's rows.
orderValuesBy(Comparator<? super V>) - Method in class com.google.common.collect.ImmutableListMultimap.Builder
Specifies the ordering of the generated multimap's values for each key.
orderValuesBy(Comparator<? super V>) - Method in class com.google.common.collect.ImmutableMultimap.Builder
Specifies the ordering of the generated multimap's values for each key.
orderValuesBy(Comparator<? super V>) - Method in class com.google.common.collect.ImmutableSetMultimap.Builder
Specifies the ordering of the generated multimap's values for each key.
ordinal() - Method in interface com.google.common.hash.BloomFilter.Strategy
Identifier used to encode this strategy, when marshalled as part of a BloomFilter.
ORIGIN - Static variable in class com.google.common.net.HttpHeaders
The HTTP Origin header field name.
original - Variable in class com.google.common.base.CharMatcher.NegatedMatcher
 
original - Variable in class com.google.common.base.Converter.ReverseConverter
 
original - Variable in class com.google.common.collect.Tables.TransposeTable
 
originalDelegate - Variable in class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection.WrappedIterator
 
orNaturalOrder(Comparator<? super E>) - Static method in class com.google.common.collect.Maps
Returns the specified comparator if not null; otherwise returns Ordering.natural().
orNull() - Method in class com.google.common.base.Absent
 
orNull() - Method in class com.google.common.base.Optional
Returns the contained instance if it is present; null otherwise.
orNull() - Method in class com.google.common.base.Present
 
OrPredicate(List<? extends Predicate<? super T>>) - Constructor for class com.google.common.base.Predicates.OrPredicate
 
otherHeap - Variable in class com.google.common.collect.MinMaxPriorityQueue.Heap
 
out - Variable in class com.google.common.io.FileBackedOutputStream
 
outerSplitter - Variable in class com.google.common.base.Splitter.MapSplitter
 
output(K, V) - Method in class com.google.common.collect.AbstractMapBasedMultimap.Itr
 
output(HashBiMap.BiEntry<K, V>) - Method in class com.google.common.collect.HashBiMap.Itr
 
output(K, V) - Method in class com.google.common.collect.ImmutableMultimap.Itr
 
output - Variable in class com.google.common.io.ByteStreams.ByteArrayDataOutputStream
 
outputFuture - Variable in class com.google.common.util.concurrent.Futures.ChainingListenableFuture
 
outputFuture - Variable in class com.google.common.util.concurrent.Futures.WrappedCombiner
 
OutputSupplier<T> - Interface in com.google.common.io
Deprecated.
For OutputSupplier<? extends OutputStream>, use ByteSink instead. For OutputSupplier<? extends Writer>, use CharSink. Implementations of OutputSupplier that don't fall into one of those categories do not benefit from any of the methods in common.io and should use a different interface. This interface is scheduled for removal in December 2015.
overflowInParse(long, int, int) - Static method in class com.google.common.primitives.UnsignedLongs
Returns true if (current * radix) + digit is a number too large to be represented by an unsigned long.
ownerType - Variable in class com.google.common.reflect.Types.ParameterizedTypeImpl
 

P

p - Variable in class com.google.common.base.Predicates.CompositionPredicate
 
p0 - Variable in class com.google.common.cache.Striped64.Cell
 
p1 - Variable in class com.google.common.cache.Striped64.Cell
 
p2 - Variable in class com.google.common.cache.Striped64.Cell
 
p3 - Variable in class com.google.common.cache.Striped64.Cell
 
P3P - Static variable in class com.google.common.net.HttpHeaders
The HTTP P3P header field name.
p4 - Variable in class com.google.common.cache.Striped64.Cell
 
p5 - Variable in class com.google.common.cache.Striped64.Cell
 
p6 - Variable in class com.google.common.cache.Striped64.Cell
 
PaddedLock() - Constructor for class com.google.common.util.concurrent.Striped.PaddedLock
 
paddedPartition(Iterable<T>, int) - Static method in class com.google.common.collect.Iterables
Divides an iterable into unmodifiable sublists of the given size, padding the final iterable with null values if necessary.
paddedPartition(Iterator<T>, int) - Static method in class com.google.common.collect.Iterators
Divides an iterator into unmodifiable sublists of the given size, padding the final iterator with null values if necessary.
PaddedSemaphore(int) - Constructor for class com.google.common.util.concurrent.Striped.PaddedSemaphore
 
padding() - Method in class com.google.common.io.BaseEncoding
 
padding() - Method in class com.google.common.io.BaseEncoding.SeparatedBaseEncoding
 
padding() - Method in class com.google.common.io.BaseEncoding.StandardBaseEncoding
 
paddingChar - Variable in class com.google.common.io.BaseEncoding.StandardBaseEncoding
 
padEnd(String, int, char) - Static method in class com.google.common.base.Strings
Returns a string, of length at least minLength, consisting of string appended with as many copies of padChar as are necessary to reach that length.
padStart(String, int, char) - Static method in class com.google.common.base.Strings
Returns a string, of length at least minLength, consisting of string prepended with as many copies of padChar as are necessary to reach that length.
padToLong() - Method in class com.google.common.hash.HashCode.BytesHashCode
 
padToLong() - Method in class com.google.common.hash.HashCode.IntHashCode
 
padToLong() - Method in class com.google.common.hash.HashCode.LongHashCode
 
padToLong() - Method in class com.google.common.hash.HashCode
If this hashcode has enough bits, returns asLong(), otherwise returns a long value with asBytes() as the least-significant bytes and 0x00 as the remaining most-significant bytes.
pairwise() - Method in class com.google.common.base.Equivalence
Returns an equivalence over iterables based on the equivalence of their elements.
PairwiseEquivalence<T> - Class in com.google.common.base
 
PairwiseEquivalence(Equivalence<? super T>) - Constructor for class com.google.common.base.PairwiseEquivalence
 
Parameter - Class in com.google.common.reflect
Represents a method or constructor parameter.
Parameter(Invokable<?, ?>, int, TypeToken<?>, Annotation[]) - Constructor for class com.google.common.reflect.Parameter
 
PARAMETER_JOINER - Static variable in class com.google.common.net.MediaType
 
ParameterizedTypeImpl(Type, Class<?>, Type[]) - Constructor for class com.google.common.reflect.Types.ParameterizedTypeImpl
 
parameters - Variable in class com.google.common.net.MediaType
 
parameters() - Method in class com.google.common.net.MediaType
Returns a multimap containing the parameters of this media type.
parametersAsMap() - Method in class com.google.common.net.MediaType
 
parameterTypes - Variable in class com.google.common.eventbus.AnnotatedSubscriberFinder.MethodIdentifier
 
parent() - Method in class com.google.common.net.InternetDomainName
Returns an InternetDomainName that is the immediate ancestor of this one; that is, the current domain with the leftmost part removed.
parse(CacheBuilderSpec, String, String) - Method in class com.google.common.cache.CacheBuilderSpec.DurationParser
 
parse(CacheBuilderSpec, String, String) - Method in class com.google.common.cache.CacheBuilderSpec.IntegerParser
 
parse(CacheBuilderSpec, String, String) - Method in class com.google.common.cache.CacheBuilderSpec.KeyStrengthParser
 
parse(CacheBuilderSpec, String, String) - Method in class com.google.common.cache.CacheBuilderSpec.LongParser
 
parse(String) - Static method in class com.google.common.cache.CacheBuilderSpec
Creates a CacheBuilderSpec from a string.
parse(CacheBuilderSpec, String, String) - Method in class com.google.common.cache.CacheBuilderSpec.RecordStatsParser
 
parse(CacheBuilderSpec, String, String) - Method in interface com.google.common.cache.CacheBuilderSpec.ValueParser
 
parse(CacheBuilderSpec, String, String) - Method in class com.google.common.cache.CacheBuilderSpec.ValueStrengthParser
 
parse(String) - Static method in class com.google.common.net.MediaType
Parses a media type from its string representation.
parseDuration(CacheBuilderSpec, long, TimeUnit) - Method in class com.google.common.cache.CacheBuilderSpec.AccessDurationParser
 
parseDuration(CacheBuilderSpec, long, TimeUnit) - Method in class com.google.common.cache.CacheBuilderSpec.DurationParser
 
parseDuration(CacheBuilderSpec, long, TimeUnit) - Method in class com.google.common.cache.CacheBuilderSpec.RefreshDurationParser
 
parseDuration(CacheBuilderSpec, long, TimeUnit) - Method in class com.google.common.cache.CacheBuilderSpec.WriteDurationParser
 
parseHextet(String) - Static method in class com.google.common.net.InetAddresses
 
parseInteger(CacheBuilderSpec, int) - Method in class com.google.common.cache.CacheBuilderSpec.ConcurrencyLevelParser
 
parseInteger(CacheBuilderSpec, int) - Method in class com.google.common.cache.CacheBuilderSpec.InitialCapacityParser
 
parseInteger(CacheBuilderSpec, int) - Method in class com.google.common.cache.CacheBuilderSpec.IntegerParser
 
parseLong(CacheBuilderSpec, long) - Method in class com.google.common.cache.CacheBuilderSpec.LongParser
 
parseLong(CacheBuilderSpec, long) - Method in class com.google.common.cache.CacheBuilderSpec.MaximumSizeParser
 
parseLong(CacheBuilderSpec, long) - Method in class com.google.common.cache.CacheBuilderSpec.MaximumWeightParser
 
parseOctet(String) - Static method in class com.google.common.net.InetAddresses
 
ParseRequest - Class in com.google.common.primitives
A string to be parsed as a number and the radix to interpret it in.
ParseRequest(String, int) - Constructor for class com.google.common.primitives.ParseRequest
 
parseTrie(CharSequence) - Static method in class com.google.thirdparty.publicsuffix.TrieParser
Parses a serialized trie representation of a map of reversed public suffixes into an immutable map of public suffixes.
parseUnsignedByte(String) - Static method in class com.google.common.primitives.UnsignedBytes
Returns the unsigned byte value represented by the given decimal string.
parseUnsignedByte(String, int) - Static method in class com.google.common.primitives.UnsignedBytes
Returns the unsigned byte value represented by a string with the given radix.
parseUnsignedInt(String) - Static method in class com.google.common.primitives.UnsignedInts
Returns the unsigned int value represented by the given decimal string.
parseUnsignedInt(String, int) - Static method in class com.google.common.primitives.UnsignedInts
Returns the unsigned int value represented by a string with the given radix.
parseUnsignedLong(String) - Static method in class com.google.common.primitives.UnsignedLongs
Returns the unsigned long value represented by the given decimal string.
parseUnsignedLong(String, int) - Static method in class com.google.common.primitives.UnsignedLongs
Returns the unsigned long value represented by a string with the given radix.
PART_CHAR_MATCHER - Static variable in class com.google.common.net.InternetDomainName
 
partition(Iterable<T>, int) - Static method in class com.google.common.collect.Iterables
Divides an iterable into unmodifiable sublists of the given size (the final iterable may be smaller).
partition(Iterator<T>, int) - Static method in class com.google.common.collect.Iterators
Divides an iterator into unmodifiable sublists of the given size (the final list may be smaller).
partition(List<T>, int) - Static method in class com.google.common.collect.Lists
Returns consecutive sublists of a list, each of the same size (the final list may be smaller).
Partition(List<T>, int) - Constructor for class com.google.common.collect.Lists.Partition
 
partition(E[], int, int, int) - Method in class com.google.common.collect.Ordering
 
partitionImpl(Iterator<T>, int, boolean) - Static method in class com.google.common.collect.Iterators
 
parts - Variable in class com.google.common.net.InternetDomainName
The parts of the domain name, converted to lower case.
parts() - Method in class com.google.common.net.InternetDomainName
Returns the individual components of this domain name, normalized to all lower case.
pattern - Variable in class com.google.common.base.Predicates.ContainsPatternPredicate
 
pattern - Variable in class com.google.common.io.PatternFilenameFilter
 
PatternFilenameFilter - Class in com.google.common.io
File name filter that only accepts files matching a regular expression.
PatternFilenameFilter(String) - Constructor for class com.google.common.io.PatternFilenameFilter
Constructs a pattern file name filter object.
PatternFilenameFilter(Pattern) - Constructor for class com.google.common.io.PatternFilenameFilter
Constructs a pattern file name filter object.
PDF - Static variable in class com.google.common.net.MediaType
 
peek() - Method in class com.google.common.cache.LocalCache.AccessQueue
 
peek() - Method in class com.google.common.cache.LocalCache.WriteQueue
 
peek() - Method in class com.google.common.collect.AbstractIterator
Returns the next element in the iteration without advancing the iteration, according to the contract of PeekingIterator.peek().
peek() - Method in class com.google.common.collect.BinaryTreeTraverser.PreOrderIterator
 
peek() - Method in class com.google.common.collect.ForwardingQueue
 
peek() - Method in class com.google.common.collect.Iterators.PeekingImpl
 
peek() - Method in class com.google.common.collect.MapMakerInternalMap.EvictionQueue
 
peek() - Method in class com.google.common.collect.MapMakerInternalMap.ExpirationQueue
 
peek() - Method in class com.google.common.collect.MinMaxPriorityQueue
 
peek() - Method in interface com.google.common.collect.PeekingIterator
Returns the next element in the iteration, without advancing the iteration.
peek() - Method in class com.google.common.collect.Synchronized.SynchronizedQueue
 
peek() - Method in class com.google.common.collect.TreeTraverser.BreadthFirstIterator
 
peekedElement - Variable in class com.google.common.collect.Iterators.PeekingImpl
 
peekFirst() - Method in class com.google.common.collect.ForwardingDeque
 
peekFirst() - Method in class com.google.common.collect.MinMaxPriorityQueue
Retrieves, but does not remove, the least element of this queue, or returns null if the queue is empty.
peekFirst() - Method in class com.google.common.collect.Synchronized.SynchronizedDeque
 
PeekingImpl(Iterator<? extends E>) - Constructor for class com.google.common.collect.Iterators.PeekingImpl
 
peekingIterator(Iterator<? extends T>) - Static method in class com.google.common.collect.Iterators
Returns a PeekingIterator backed by the given iterator.
peekingIterator(PeekingIterator<T>) - Static method in class com.google.common.collect.Iterators
Deprecated.
no need to use this
PeekingIterator<E> - Interface in com.google.common.collect
An iterator that supports a one-element lookahead while iterating.
peekLast() - Method in class com.google.common.collect.ForwardingDeque
 
peekLast() - Method in class com.google.common.collect.MinMaxPriorityQueue
Retrieves, but does not remove, the greatest element of this queue, or returns null if the queue is empty.
peekLast() - Method in class com.google.common.collect.Synchronized.SynchronizedDeque
 
PercentEscaper - Class in com.google.common.net
A UnicodeEscaper that escapes some set of Java characters using a UTF-8 based percent encoding scheme.
PercentEscaper(String, boolean) - Constructor for class com.google.common.net.PercentEscaper
Constructs a percent escaper with the specified safe characters and optional handling of the space character.
permitsToTime(double) - Method in class com.google.common.util.concurrent.SmoothRateLimiter.SmoothWarmingUp
 
PermutationCollection(ImmutableList<E>) - Constructor for class com.google.common.collect.Collections2.PermutationCollection
 
PermutationIterator(List<E>) - Constructor for class com.google.common.collect.Collections2.PermutationIterator
 
permutations(Collection<E>) - Static method in class com.google.common.collect.Collections2
Returns a Collection of all the permutations of the specified Collection.
PLAIN_TEXT_UTF_8 - Static variable in class com.google.common.net.MediaType
 
Platform - Class in com.google.common.base
Methods factored out so that they can be emulated differently in GWT.
Platform() - Constructor for class com.google.common.base.Platform
 
Platform - Class in com.google.common.collect
Methods factored out so that they can be emulated differently in GWT.
Platform() - Constructor for class com.google.common.collect.Platform
 
Platform - Class in com.google.common.escape
Methods factored out so that they can be emulated differently in GWT.
Platform() - Constructor for class com.google.common.escape.Platform
 
platformThreadFactory() - Static method in class com.google.common.util.concurrent.MoreExecutors
Returns a default thread factory used to create new threads.
plus(CacheStats) - Method in class com.google.common.cache.CacheStats
Returns a new CacheStats representing the sum of this CacheStats and other.
plus(UnsignedInteger) - Method in class com.google.common.primitives.UnsignedInteger
Returns the result of adding this and val.
plus(UnsignedLong) - Method in class com.google.common.primitives.UnsignedLong
Returns the result of adding this and val.
PLUS_SIGN - Static variable in class com.google.common.net.PercentEscaper
 
plusForSpace - Variable in class com.google.common.net.PercentEscaper
If true we should convert space to the + character.
PNG - Static variable in class com.google.common.net.MediaType
 
Policies() - Constructor for enum com.google.common.util.concurrent.CycleDetectingLockFactory.Policies
 
policy - Variable in class com.google.common.util.concurrent.CycleDetectingLockFactory
 
poll() - Method in class com.google.common.cache.LocalCache.AccessQueue
 
poll() - Method in class com.google.common.cache.LocalCache.WriteQueue
 
poll(long, TimeUnit) - Method in class com.google.common.collect.ForwardingBlockingDeque
 
poll() - Method in class com.google.common.collect.ForwardingQueue
 
poll() - Method in class com.google.common.collect.MapMakerInternalMap.EvictionQueue
 
poll() - Method in class com.google.common.collect.MapMakerInternalMap.ExpirationQueue
 
poll() - Method in class com.google.common.collect.MinMaxPriorityQueue
 
poll() - Method in class com.google.common.collect.Synchronized.SynchronizedQueue
 
poll(long, TimeUnit) - Method in class com.google.common.util.concurrent.ForwardingBlockingQueue
 
pollAsMapEntry(Iterator<Map.Entry<K, Collection<V>>>) - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableAsMap
 
pollFirst() - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableKeySet
 
pollFirst() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedNavigableSet
 
pollFirst(long, TimeUnit) - Method in class com.google.common.collect.ForwardingBlockingDeque
 
pollFirst() - Method in class com.google.common.collect.ForwardingDeque
 
pollFirst() - Method in class com.google.common.collect.ForwardingNavigableSet
 
pollFirst() - Method in class com.google.common.collect.ImmutableSortedSet
Deprecated.
Unsupported operation.
pollFirst() - Method in class com.google.common.collect.Maps.NavigableKeySet
 
pollFirst() - Method in class com.google.common.collect.MinMaxPriorityQueue
Removes and returns the least element of this queue, or returns null if the queue is empty.
pollFirst() - Method in class com.google.common.collect.Sets.DescendingSet
 
pollFirst() - Method in class com.google.common.collect.Sets.FilteredNavigableSet
 
pollFirst() - Method in class com.google.common.collect.Sets.UnmodifiableNavigableSet
 
pollFirst() - Method in class com.google.common.collect.SortedMultisets.NavigableElementSet
 
pollFirst() - Method in class com.google.common.collect.Synchronized.SynchronizedDeque
 
pollFirst() - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableSet
 
pollFirstEntry() - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableAsMap
 
pollFirstEntry() - Method in class com.google.common.collect.AbstractNavigableMap
 
pollFirstEntry() - Method in class com.google.common.collect.AbstractSortedMultiset
 
pollFirstEntry() - Method in class com.google.common.collect.DescendingMultiset
 
pollFirstEntry() - Method in class com.google.common.collect.ForwardingNavigableMap
 
pollFirstEntry() - Method in class com.google.common.collect.ForwardingSortedMultiset
 
pollFirstEntry() - Method in class com.google.common.collect.ImmutableSortedMap
Deprecated.
Unsupported operation.
pollFirstEntry() - Method in class com.google.common.collect.ImmutableSortedMultiset
Deprecated.
Unsupported operation.
pollFirstEntry() - Method in class com.google.common.collect.Maps.DescendingMap
 
pollFirstEntry() - Method in class com.google.common.collect.Maps.FilteredEntryNavigableMap
 
pollFirstEntry() - Method in class com.google.common.collect.Maps.TransformedEntriesNavigableMap
 
pollFirstEntry() - Method in class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
pollFirstEntry() - Method in interface com.google.common.collect.SortedMultiset
Returns and removes the entry associated with the lowest element in this multiset, or returns null if this multiset is empty.
pollFirstEntry() - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableMap
 
pollFirstEntry() - Method in class com.google.common.collect.UnmodifiableSortedMultiset
 
pollLast() - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableKeySet
 
pollLast() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedNavigableSet
 
pollLast(long, TimeUnit) - Method in class com.google.common.collect.ForwardingBlockingDeque
 
pollLast() - Method in class com.google.common.collect.ForwardingDeque
 
pollLast() - Method in class com.google.common.collect.ForwardingNavigableSet
 
pollLast() - Method in class com.google.common.collect.ImmutableSortedSet
Deprecated.
Unsupported operation.
pollLast() - Method in class com.google.common.collect.Maps.NavigableKeySet
 
pollLast() - Method in class com.google.common.collect.MinMaxPriorityQueue
Removes and returns the greatest element of this queue, or returns null if the queue is empty.
pollLast() - Method in class com.google.common.collect.Sets.DescendingSet
 
pollLast() - Method in class com.google.common.collect.Sets.FilteredNavigableSet
 
pollLast() - Method in class com.google.common.collect.Sets.UnmodifiableNavigableSet
 
pollLast() - Method in class com.google.common.collect.SortedMultisets.NavigableElementSet
 
pollLast() - Method in class com.google.common.collect.Synchronized.SynchronizedDeque
 
pollLast() - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableSet
 
pollLastEntry() - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableAsMap
 
pollLastEntry() - Method in class com.google.common.collect.AbstractNavigableMap
 
pollLastEntry() - Method in class com.google.common.collect.AbstractSortedMultiset
 
pollLastEntry() - Method in class com.google.common.collect.DescendingMultiset
 
pollLastEntry() - Method in class com.google.common.collect.ForwardingNavigableMap
 
pollLastEntry() - Method in class com.google.common.collect.ForwardingSortedMultiset
 
pollLastEntry() - Method in class com.google.common.collect.ImmutableSortedMap
Deprecated.
Unsupported operation.
pollLastEntry() - Method in class com.google.common.collect.ImmutableSortedMultiset
Deprecated.
Unsupported operation.
pollLastEntry() - Method in class com.google.common.collect.Maps.DescendingMap
 
pollLastEntry() - Method in class com.google.common.collect.Maps.FilteredEntryNavigableMap
 
pollLastEntry() - Method in class com.google.common.collect.Maps.TransformedEntriesNavigableMap
 
pollLastEntry() - Method in class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
pollLastEntry() - Method in interface com.google.common.collect.SortedMultiset
Returns and removes the entry associated with the greatest element in this multiset, or returns null if this multiset is empty.
pollLastEntry() - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableMap
 
pollLastEntry() - Method in class com.google.common.collect.UnmodifiableSortedMultiset
 
pollNext(Iterator<T>) - Static method in class com.google.common.collect.Iterators
Deletes and returns the next value from the iterator, or returns null if there is no such value.
pop() - Method in class com.google.common.collect.ForwardingDeque
 
pop() - Method in class com.google.common.collect.Synchronized.SynchronizedDeque
 
populateCache(Class<T>) - Static method in class com.google.common.base.Enums
 
populateMap(Map<K, V>, ObjectInputStream) - Static method in class com.google.common.collect.Serialization
Populates a map by reading an input stream, as part of deserialization.
populateMap(Map<K, V>, ObjectInputStream, int) - Static method in class com.google.common.collect.Serialization
Populates a map by reading an input stream, as part of deserialization.
populateMultimap(Multimap<K, V>, ObjectInputStream) - Static method in class com.google.common.collect.Serialization
Populates a multimap by reading an input stream, as part of deserialization.
populateMultimap(Multimap<K, V>, ObjectInputStream, int) - Static method in class com.google.common.collect.Serialization
Populates a multimap by reading an input stream, as part of deserialization.
populateMultiset(Multiset<E>, ObjectInputStream) - Static method in class com.google.common.collect.Serialization
Populates a multiset by reading an input stream, as part of deserialization.
populateMultiset(Multiset<E>, ObjectInputStream, int) - Static method in class com.google.common.collect.Serialization
Populates a multiset by reading an input stream, as part of deserialization.
populateTypeMappings(Map<TypeResolver.TypeVariableKey, Type>, Type, Type) - Static method in class com.google.common.reflect.TypeResolver
 
port - Variable in class com.google.common.net.HostAndPort
Validated port number in the range [0..65535], or NO_PORT
port - Variable in class com.google.common.net.InetAddresses.TeredoInfo
 
pos - Variable in class com.google.common.io.CharSequenceReader
 
position - Variable in class com.google.common.collect.AbstractIndexedListIterator
 
position - Variable in class com.google.common.net.MediaType.Tokenizer
 
position - Variable in class com.google.common.reflect.Parameter
 
positiveBoundedAbove - Variable in class com.google.common.collect.ImmutableRangeSet.ComplementRanges
 
positiveBoundedBelow - Variable in class com.google.common.collect.ImmutableRangeSet.ComplementRanges
 
positiveRangesByLowerBound - Variable in class com.google.common.collect.TreeRangeSet.ComplementRangesByLowerBound
 
positiveRangesByUpperBound - Variable in class com.google.common.collect.TreeRangeSet.ComplementRangesByLowerBound
 
post(Object) - Method in class com.google.common.eventbus.EventBus
Posts an event to all registered subscribers.
postOrderIterator(T) - Method in class com.google.common.collect.BinaryTreeTraverser
 
PostOrderIterator(T) - Constructor for class com.google.common.collect.BinaryTreeTraverser.PostOrderIterator
 
postOrderIterator(T) - Method in class com.google.common.collect.TreeTraverser
 
PostOrderIterator(T) - Constructor for class com.google.common.collect.TreeTraverser.PostOrderIterator
 
PostOrderNode(T, Iterator<T>) - Constructor for class com.google.common.collect.TreeTraverser.PostOrderNode
 
postOrderTraversal(T) - Method in class com.google.common.collect.TreeTraverser
Returns an unmodifiable iterable over the nodes in a tree structure, using post-order traversal.
postReadCleanup() - Method in class com.google.common.cache.LocalCache.Segment
Performs routine cleanup following a read.
postReadCleanup() - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Performs routine cleanup following a read.
POSTSCRIPT - Static variable in class com.google.common.net.MediaType
 
postWriteCleanup() - Method in class com.google.common.cache.LocalCache.Segment
Performs routine cleanup following a write.
postWriteCleanup() - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Performs routine cleanup following a write.
PotentialDeadlockException(CycleDetectingLockFactory.LockGraphNode, CycleDetectingLockFactory.LockGraphNode, CycleDetectingLockFactory.ExampleStackTrace) - Constructor for exception com.google.common.util.concurrent.CycleDetectingLockFactory.PotentialDeadlockException
 
pow(int, int) - Static method in class com.google.common.math.IntMath
Returns b to the kth power.
pow(long, int) - Static method in class com.google.common.math.LongMath
Returns b to the kth power.
PowerOfTwoStriped(int) - Constructor for class com.google.common.util.concurrent.Striped.PowerOfTwoStriped
 
powerSet(Set<E>) - Static method in class com.google.common.collect.Sets
Returns the set of all possible subsets of set.
PowerSet(Set<E>) - Constructor for class com.google.common.collect.Sets.PowerSet
 
powersOf10 - Static variable in class com.google.common.math.IntMath
 
powersOf10 - Static variable in class com.google.common.math.LongMath
 
PRAGMA - Static variable in class com.google.common.net.HttpHeaders
The HTTP Pragma header field name.
precomputeCharMatcher(CharMatcher) - Static method in class com.google.common.base.Platform
 
precomputed() - Method in class com.google.common.base.CharMatcher.FastMatcher
 
precomputed() - Method in class com.google.common.base.CharMatcher.NegatedFastMatcher
 
precomputed() - Method in class com.google.common.base.CharMatcher
Returns a char matcher functionally equivalent to this one, but which may be faster to query than the original; your mileage may vary.
precomputedInternal() - Method in class com.google.common.base.CharMatcher
This is the actual implementation of CharMatcher.precomputed(), but we bounce calls through a method on Platform so that we can have different behavior in GWT.
precomputedPositive(int, BitSet, String) - Static method in class com.google.common.base.CharMatcher
Helper method for CharMatcher.precomputedInternal() that doesn't test if the negation is cheaper.
Preconditions - Class in com.google.common.base
Static convenience methods that help a method or constructor check whether it was invoked correctly (whether its preconditions have been met).
Preconditions() - Constructor for class com.google.common.base.Preconditions
 
pred - Variable in class com.google.common.collect.TreeMultiset.AvlNode
 
predecessorInMultimap - Variable in class com.google.common.collect.LinkedHashMultimap.ValueEntry
 
predecessorInValueSet - Variable in class com.google.common.collect.LinkedHashMultimap.ValueEntry
 
predicate - Variable in class com.google.common.base.Functions.PredicateFunction
 
Predicate<T> - Interface in com.google.common.base
Determines a true or false value for a given input.
predicate - Variable in class com.google.common.base.Predicates.NotPredicate
 
predicate - Variable in class com.google.common.collect.Collections2.FilteredCollection
 
predicate - Variable in class com.google.common.collect.FilteredEntryMultimap
 
predicate - Variable in class com.google.common.collect.Maps.AbstractFilteredMap
 
predicate - Variable in class com.google.common.collect.Maps.FilteredMapValues
 
predicate - Variable in class com.google.common.collect.Multisets.FilteredMultiset
 
PredicateFunction(Predicate<T>) - Constructor for class com.google.common.base.Functions.PredicateFunction
 
Predicates - Class in com.google.common.base
Static utility methods pertaining to Predicate instances.
Predicates() - Constructor for class com.google.common.base.Predicates
 
Predicates.AndPredicate<T> - Class in com.google.common.base
 
Predicates.AssignableFromPredicate - Class in com.google.common.base
 
Predicates.CompositionPredicate<A,B> - Class in com.google.common.base
 
Predicates.ContainsPatternFromStringPredicate - Class in com.google.common.base
 
Predicates.ContainsPatternPredicate - Class in com.google.common.base
 
Predicates.InPredicate<T> - Class in com.google.common.base
 
Predicates.InstanceOfPredicate - Class in com.google.common.base
 
Predicates.IsEqualToPredicate<T> - Class in com.google.common.base
 
Predicates.NotPredicate<T> - Class in com.google.common.base
 
Predicates.ObjectPredicate - Enum in com.google.common.base
 
Predicates.OrPredicate<T> - Class in com.google.common.base
 
preferringStrings(List<Constructor<X>>) - Static method in class com.google.common.util.concurrent.Futures
 
PREFIX_JOINER - Static variable in class com.google.thirdparty.publicsuffix.TrieParser
 
preOrderIterator(T) - Method in class com.google.common.collect.BinaryTreeTraverser
 
PreOrderIterator(T) - Constructor for class com.google.common.collect.BinaryTreeTraverser.PreOrderIterator
 
preOrderIterator(T) - Method in class com.google.common.collect.TreeTraverser
 
PreOrderIterator(T) - Constructor for class com.google.common.collect.TreeTraverser.PreOrderIterator
 
preOrderTraversal(T) - Method in class com.google.common.collect.TreeTraverser
Returns an unmodifiable iterable over the nodes in a tree structure, using pre-order traversal.
Present<T> - Class in com.google.common.base
Implementation of an Optional containing a reference.
Present(T) - Constructor for class com.google.common.base.Present
 
presentInstances(Iterable<? extends Optional<? extends T>>) - Static method in class com.google.common.base.Optional
Returns the value of each present instance from the supplied optionals, in order, skipping over occurrences of Optional.absent().
previewChar() - Method in class com.google.common.net.MediaType.Tokenizer
 
previous() - Method in class com.google.common.collect.AbstractIndexedListIterator
 
previous() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedList.WrappedListIterator
 
previous(BigInteger) - Method in class com.google.common.collect.DiscreteDomain.BigIntegerDomain
 
previous(Integer) - Method in class com.google.common.collect.DiscreteDomain.IntegerDomain
 
previous(Long) - Method in class com.google.common.collect.DiscreteDomain.LongDomain
 
previous(C) - Method in class com.google.common.collect.DiscreteDomain
Returns the unique greatest value of type C that is less than value, or null if none exists.
previous() - Method in class com.google.common.collect.ForwardingListIterator
 
previous - Variable in class com.google.common.collect.LinkedListMultimap.Node
 
previous - Variable in class com.google.common.collect.LinkedListMultimap.NodeIterator
 
previous() - Method in class com.google.common.collect.LinkedListMultimap.NodeIterator
 
previous - Variable in class com.google.common.collect.LinkedListMultimap.ValueForKeyIterator
 
previous() - Method in class com.google.common.collect.LinkedListMultimap.ValueForKeyIterator
 
previous() - Method in class com.google.common.collect.TransformedListIterator
 
previousAccess - Variable in class com.google.common.cache.LocalCache.StrongAccessEntry
 
previousAccess - Variable in class com.google.common.cache.LocalCache.StrongAccessWriteEntry
 
previousAccess - Variable in class com.google.common.cache.LocalCache.WeakAccessEntry
 
previousAccess - Variable in class com.google.common.cache.LocalCache.WeakAccessWriteEntry
 
previousEvictable - Variable in class com.google.common.collect.MapMakerInternalMap.SoftEvictableEntry
 
previousEvictable - Variable in class com.google.common.collect.MapMakerInternalMap.SoftExpirableEvictableEntry
 
previousEvictable - Variable in class com.google.common.collect.MapMakerInternalMap.StrongEvictableEntry
 
previousEvictable - Variable in class com.google.common.collect.MapMakerInternalMap.StrongExpirableEvictableEntry
 
previousEvictable - Variable in class com.google.common.collect.MapMakerInternalMap.WeakEvictableEntry
 
previousEvictable - Variable in class com.google.common.collect.MapMakerInternalMap.WeakExpirableEvictableEntry
 
previousExpirable - Variable in class com.google.common.collect.MapMakerInternalMap.SoftExpirableEntry
 
previousExpirable - Variable in class com.google.common.collect.MapMakerInternalMap.SoftExpirableEvictableEntry
 
previousExpirable - Variable in class com.google.common.collect.MapMakerInternalMap.StrongExpirableEntry
 
previousExpirable - Variable in class com.google.common.collect.MapMakerInternalMap.StrongExpirableEvictableEntry
 
previousExpirable - Variable in class com.google.common.collect.MapMakerInternalMap.WeakExpirableEntry
 
previousExpirable - Variable in class com.google.common.collect.MapMakerInternalMap.WeakExpirableEvictableEntry
 
previousIndex() - Method in class com.google.common.collect.AbstractIndexedListIterator
 
previousIndex() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedList.WrappedListIterator
 
previousIndex() - Method in class com.google.common.collect.ForwardingListIterator
 
previousIndex() - Method in class com.google.common.collect.LinkedListMultimap.NodeIterator
 
previousIndex() - Method in class com.google.common.collect.LinkedListMultimap.ValueForKeyIterator
 
previousIndex() - Method in class com.google.common.collect.TransformedListIterator
 
previousSibling - Variable in class com.google.common.collect.LinkedListMultimap.Node
 
previousWrite - Variable in class com.google.common.cache.LocalCache.StrongAccessWriteEntry
 
previousWrite - Variable in class com.google.common.cache.LocalCache.StrongWriteEntry
 
previousWrite - Variable in class com.google.common.cache.LocalCache.WeakAccessWriteEntry
 
previousWrite - Variable in class com.google.common.cache.LocalCache.WeakWriteEntry
 
preWriteCleanup(long) - Method in class com.google.common.cache.LocalCache.Segment
Performs routine cleanup prior to executing a write.
preWriteCleanup() - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Performs routine cleanup prior to executing a write.
PRIMITIVE_TO_WRAPPER_TYPE - Static variable in class com.google.common.primitives.Primitives
A map from primitive types to their corresponding wrapper types.
Primitives - Class in com.google.common.primitives
Contains static utility methods pertaining to primitive types and their corresponding wrapper types.
Primitives() - Constructor for class com.google.common.primitives.Primitives
 
PrimitiveSink - Interface in com.google.common.hash
An object which can receive a stream of primitive values.
priority - Variable in class com.google.common.util.concurrent.ThreadFactoryBuilder
 
process(ByteBuffer) - Method in class com.google.common.hash.AbstractStreamingHashFunction.AbstractStreamingHasher
Processes the available bytes of the buffer (at most chunk bytes).
process(ByteBuffer) - Method in class com.google.common.hash.Murmur3_128HashFunction.Murmur3_128Hasher
 
process(ByteBuffer) - Method in class com.google.common.hash.Murmur3_32HashFunction.Murmur3_32Hasher
 
process(ByteBuffer) - Method in class com.google.common.hash.SipHashFunction.SipHasher
 
processBytes(byte[], int, int) - Method in interface com.google.common.io.ByteProcessor
This method will be called for each chunk of bytes in an input stream.
processLine(String) - Method in interface com.google.common.io.LineProcessor
This method will be called once for each line.
processM(long) - Method in class com.google.common.hash.SipHashFunction.SipHasher
 
processPendingNotifications() - Method in class com.google.common.cache.LocalCache
Notifies listeners that an entry has been automatically removed due to expiration, eviction, or eligibility for garbage collection.
processPendingNotifications() - Method in class com.google.common.collect.MapMakerInternalMap
Notifies listeners that an entry has been automatically removed due to expiration, eviction, or eligibility for garbage collection.
processRemaining(ByteBuffer) - Method in class com.google.common.hash.AbstractStreamingHashFunction.AbstractStreamingHasher
This is invoked for the last bytes of the input, which are not enough to fill a whole chunk.
processRemaining(ByteBuffer) - Method in class com.google.common.hash.Murmur3_128HashFunction.Murmur3_128Hasher
 
processRemaining(ByteBuffer) - Method in class com.google.common.hash.Murmur3_32HashFunction.Murmur3_32Hasher
 
processRemaining(ByteBuffer) - Method in class com.google.common.hash.SipHashFunction.SipHasher
 
propagate(Throwable) - Static method in class com.google.common.base.Throwables
Propagates throwable as-is if it is an instance of RuntimeException or Error, or else as a last resort, wraps it in a RuntimeException then propagates.
propagateIfInstanceOf(Throwable, Class<X>) - Static method in class com.google.common.base.Throwables
Propagates throwable exactly as-is, if and only if it is an instance of declaredType.
propagateIfPossible(Throwable) - Static method in class com.google.common.base.Throwables
Propagates throwable exactly as-is, if and only if it is an instance of RuntimeException or Error.
propagateIfPossible(Throwable, Class<X>) - Static method in class com.google.common.base.Throwables
Propagates throwable exactly as-is, if and only if it is an instance of RuntimeException, Error, or declaredType.
propagateIfPossible(Throwable, Class<X1>, Class<X2>) - Static method in class com.google.common.base.Throwables
Propagates throwable exactly as-is, if and only if it is an instance of RuntimeException, Error, declaredType1, or declaredType2.
PROTOBUF - Static variable in class com.google.common.net.MediaType
prototype - Variable in class com.google.common.hash.MessageDigestHashFunction
 
PROXY_AUTHENTICATE - Static variable in class com.google.common.net.HttpHeaders
The HTTP Proxy-Authenticate header field name.
PROXY_AUTHORIZATION - Static variable in class com.google.common.net.HttpHeaders
The HTTP Proxy-Authorization header field name.
PSD - Static variable in class com.google.common.net.MediaType
The media type for the Photoshop File Format (psd files) as defined by IANA, and found in /etc/mime.types, e.g.
PUBLIC_KEY_PINS - Static variable in class com.google.common.net.HttpHeaders
The HTTP Public-Key-Pins header field name.
PUBLIC_KEY_PINS_REPORT_ONLY - Static variable in class com.google.common.net.HttpHeaders
The HTTP Public-Key-Pins-Report-Only header field name.
publicSuffix() - Method in class com.google.common.net.InternetDomainName
Returns the public suffix portion of the domain name, or null if no public suffix is present.
publicSuffixIndex - Variable in class com.google.common.net.InternetDomainName
The index in the InternetDomainName.parts() list at which the public suffix begins.
PublicSuffixPatterns - Class in com.google.thirdparty.publicsuffix
Do not use this class directly.
PublicSuffixPatterns() - Constructor for class com.google.thirdparty.publicsuffix.PublicSuffixPatterns
 
PublicSuffixType - Enum in com.google.thirdparty.publicsuffix
Specifies the type of a top-level domain definition.
PublicSuffixType(char, char) - Constructor for enum com.google.thirdparty.publicsuffix.PublicSuffixType
 
PureJavaComparator() - Constructor for enum com.google.common.primitives.UnsignedBytes.LexicographicalComparatorHolder.PureJavaComparator
 
PureJavaLongAddable() - Constructor for class com.google.common.cache.LongAddables.PureJavaLongAddable
 
push(E) - Method in class com.google.common.collect.ForwardingDeque
 
push(E) - Method in class com.google.common.collect.Synchronized.SynchronizedDeque
 
pushIfPresent(Deque<T>, Optional<T>) - Static method in class com.google.common.collect.BinaryTreeTraverser
 
put(Map<Class<?>, Object>, Class<T>, T) - Static method in class com.google.common.base.Defaults
 
put(K, V) - Method in class com.google.common.cache.AbstractCache
 
put(K, V) - Method in interface com.google.common.cache.Cache
Associates value with key in this cache.
put(K, V) - Method in class com.google.common.cache.ForwardingCache
 
put(K, V) - Method in class com.google.common.cache.LocalCache.LocalManualCache
 
put(K, V) - Method in class com.google.common.cache.LocalCache
 
put(K, int, V, boolean) - Method in class com.google.common.cache.LocalCache.Segment
 
put(K, V) - Method in class com.google.common.collect.AbstractBiMap
 
put(K, V) - Method in class com.google.common.collect.AbstractListMultimap
Stores a key-value pair in the multimap.
put(K, V) - Method in class com.google.common.collect.AbstractMapBasedMultimap
 
put(K, V) - Method in class com.google.common.collect.AbstractMultimap
 
put(K, V) - Method in class com.google.common.collect.AbstractSetMultimap
Stores a key-value pair in the multimap.
put(R, C, V) - Method in class com.google.common.collect.AbstractTable
 
put(K, V) - Method in class com.google.common.collect.ArrayTable.ArrayMap
 
put(C, Map<R, V>) - Method in class com.google.common.collect.ArrayTable.ColumnMap
 
put(R, C, V) - Method in class com.google.common.collect.ArrayTable
Associates the specified value with the specified keys.
put(R, Map<C, V>) - Method in class com.google.common.collect.ArrayTable.RowMap
 
put(K, V) - Method in interface com.google.common.collect.BiMap
put(K, V) - Method in class com.google.common.collect.EnumHashBiMap
 
put(E) - Method in class com.google.common.collect.ForwardingBlockingDeque
 
put(K, V) - Method in class com.google.common.collect.ForwardingMap
 
put(K, V) - Method in class com.google.common.collect.ForwardingMultimap
 
put(R, C, V) - Method in class com.google.common.collect.ForwardingTable
 
put(V, K) - Method in class com.google.common.collect.HashBiMap.Inverse
 
put(K, V) - Method in class com.google.common.collect.HashBiMap
 
put(K, V, boolean) - Method in class com.google.common.collect.HashBiMap
 
put(K, V) - Method in class com.google.common.collect.ImmutableBiMap.Builder
Associates key with value in the built bimap.
put(Class<T>, T) - Method in class com.google.common.collect.ImmutableClassToInstanceMap.Builder
Associates key with value in the built map.
put(K, V) - Method in class com.google.common.collect.ImmutableListMultimap.Builder
 
put(Map.Entry<? extends K, ? extends V>) - Method in class com.google.common.collect.ImmutableListMultimap.Builder
Adds an entry to the built multimap.
put(K, V) - Method in class com.google.common.collect.ImmutableMap.Builder
Associates key with value in the built map.
put(Map.Entry<? extends K, ? extends V>) - Method in class com.google.common.collect.ImmutableMap.Builder
Adds the given entry to the map, making it immutable if necessary.
put(K, V) - Method in class com.google.common.collect.ImmutableMap
Deprecated.
Unsupported operation.
put(K, V) - Method in class com.google.common.collect.ImmutableMultimap.Builder
Adds a key-value mapping to the built multimap.
put(Map.Entry<? extends K, ? extends V>) - Method in class com.google.common.collect.ImmutableMultimap.Builder
Adds an entry to the built multimap.
put(K, V) - Method in class com.google.common.collect.ImmutableMultimap
Deprecated.
Unsupported operation.
put(Range<K>, V) - Method in class com.google.common.collect.ImmutableRangeMap.Builder
Associates the specified range with the specified value.
put(Range<K>, V) - Method in class com.google.common.collect.ImmutableRangeMap
 
put(K, V) - Method in class com.google.common.collect.ImmutableSetMultimap.Builder
Adds a key-value mapping to the built multimap if it is not already present.
put(Map.Entry<? extends K, ? extends V>) - Method in class com.google.common.collect.ImmutableSetMultimap.Builder
Adds an entry to the built multimap if it is not already present.
put(K, V) - Method in class com.google.common.collect.ImmutableSortedMap.Builder
Associates key with value in the built map.
put(Map.Entry<? extends K, ? extends V>) - Method in class com.google.common.collect.ImmutableSortedMap.Builder
Adds the given entry to the map, making it immutable if necessary.
put(R, C, V) - Method in class com.google.common.collect.ImmutableTable.Builder
Associates the (rowKey, columnKey) pair with value in the built table.
put(Table.Cell<? extends R, ? extends C, ? extends V>) - Method in class com.google.common.collect.ImmutableTable.Builder
Adds the given cell to the table, making it immutable if necessary.
put(R, C, V) - Method in class com.google.common.collect.ImmutableTable
Deprecated.
Unsupported operation.
put(K, V) - Method in class com.google.common.collect.LinkedListMultimap
Stores a key-value pair in the multimap.
put(K, V) - Method in class com.google.common.collect.MapConstraints.ConstrainedMap
 
put(K, V) - Method in class com.google.common.collect.MapConstraints.ConstrainedMultimap
 
put(K, V) - Method in class com.google.common.collect.MapMaker.NullConcurrentMap
 
put(K, V) - Method in class com.google.common.collect.MapMakerInternalMap
 
put(K, int, V, boolean) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
 
put(K, V) - Method in class com.google.common.collect.Maps.AbstractFilteredMap
 
put(K, V) - Method in class com.google.common.collect.Maps.FilteredEntryNavigableMap
 
put(K, V) - Method in interface com.google.common.collect.Multimap
Stores a key-value pair in this multimap.
put(K, V) - Method in class com.google.common.collect.Multimaps.MapMultimap
 
put(K, V2) - Method in class com.google.common.collect.Multimaps.TransformedEntriesMultimap
 
put(K, V) - Method in class com.google.common.collect.Multimaps.UnmodifiableMultimap
 
put(Range<K>, V) - Method in interface com.google.common.collect.RangeMap
Maps a range to a specified value (optional operation).
put(R, V) - Method in class com.google.common.collect.StandardTable.Column
 
put(R, C, V) - Method in class com.google.common.collect.StandardTable
 
put(C, V) - Method in class com.google.common.collect.StandardTable.Row
 
put(K, V) - Method in class com.google.common.collect.Synchronized.SynchronizedMap
 
put(K, V) - Method in class com.google.common.collect.Synchronized.SynchronizedMultimap
 
put(R, C, V) - Method in interface com.google.common.collect.Table
Associates the specified value with the specified keys.
put(R, C, V2) - Method in class com.google.common.collect.Tables.TransformedTable
 
put(C, R, V) - Method in class com.google.common.collect.Tables.TransposeTable
 
put(R, C, V) - Method in class com.google.common.collect.Tables.UnmodifiableTable
 
put(C, V) - Method in class com.google.common.collect.TreeBasedTable.TreeRow
 
put(Range<K>, V) - Method in class com.google.common.collect.TreeRangeMap
 
put(Range<K>, V) - Method in class com.google.common.collect.TreeRangeMap.SubRangeMap
 
put(T) - Method in class com.google.common.hash.BloomFilter
Puts an element into this BloomFilter.
put(T, Funnel<? super T>, int, BloomFilterStrategies.BitArray) - Method in interface com.google.common.hash.BloomFilter.Strategy
Sets numHashFunctions bits of the given bit array, by hashing a user element.
put(Class<T>, T) - Method in class com.google.common.reflect.ImmutableTypeToInstanceMap.Builder
Associates key with value in the built map.
put(TypeToken<T>, T) - Method in class com.google.common.reflect.ImmutableTypeToInstanceMap.Builder
Associates key with value in the built map.
put(TypeToken<? extends B>, B) - Method in class com.google.common.reflect.MutableTypeToInstanceMap
Not supported.
put(K, long) - Method in class com.google.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.google.common.util.concurrent.ForwardingBlockingQueue
 
putAll(Map<? extends K, ? extends V>) - Method in class com.google.common.cache.AbstractCache
 
putAll(Map<? extends K, ? extends V>) - Method in interface com.google.common.cache.Cache
Copies all of the mappings from the specified map to the cache.
putAll(Map<? extends K, ? extends V>) - Method in class com.google.common.cache.ForwardingCache
 
putAll(Map<? extends K, ? extends V>) - Method in class com.google.common.cache.LocalCache.LocalManualCache
 
putAll(Map<? extends K, ? extends V>) - Method in class com.google.common.cache.LocalCache
 
putAll(Map<? extends K, ? extends V>) - Method in class com.google.common.collect.AbstractBiMap
 
putAll(K, Iterable<? extends V>) - Method in class com.google.common.collect.AbstractMultimap
 
putAll(Multimap<? extends K, ? extends V>) - Method in class com.google.common.collect.AbstractMultimap
 
putAll(Table<? extends R, ? extends C, ? extends V>) - Method in class com.google.common.collect.AbstractTable
 
putAll(Table<? extends R, ? extends C, ? extends V>) - Method in class com.google.common.collect.ArrayTable
Copies all mappings from the specified table to this table.
putAll(Map<? extends K, ? extends V>) - Method in interface com.google.common.collect.BiMap
putAll(Map<? extends K, ? extends V>) - Method in class com.google.common.collect.ForwardingMap
 
putAll(K, Iterable<? extends V>) - Method in class com.google.common.collect.ForwardingMultimap
 
putAll(Multimap<? extends K, ? extends V>) - Method in class com.google.common.collect.ForwardingMultimap
 
putAll(Table<? extends R, ? extends C, ? extends V>) - Method in class com.google.common.collect.ForwardingTable
 
putAll(Map<? extends K, ? extends V>) - Method in class com.google.common.collect.ImmutableBiMap.Builder
Associates all of the given map's keys and values in the built bimap.
putAll(Map<? extends Class<? extends T>, ? extends T>) - Method in class com.google.common.collect.ImmutableClassToInstanceMap.Builder
Associates all of map's keys and values in the built map.
putAll(K, Iterable<? extends V>) - Method in class com.google.common.collect.ImmutableListMultimap.Builder
 
putAll(K, V...) - Method in class com.google.common.collect.ImmutableListMultimap.Builder
 
putAll(Multimap<? extends K, ? extends V>) - Method in class com.google.common.collect.ImmutableListMultimap.Builder
 
putAll(Map<? extends K, ? extends V>) - Method in class com.google.common.collect.ImmutableMap.Builder
Associates all of the given map's keys and values in the built map.
putAll(Map<? extends K, ? extends V>) - Method in class com.google.common.collect.ImmutableMap
Deprecated.
Unsupported operation.
putAll(K, Iterable<? extends V>) - Method in class com.google.common.collect.ImmutableMultimap.Builder
Stores a collection of values with the same key in the built multimap.
putAll(K, V...) - Method in class com.google.common.collect.ImmutableMultimap.Builder
Stores an array of values with the same key in the built multimap.
putAll(Multimap<? extends K, ? extends V>) - Method in class com.google.common.collect.ImmutableMultimap.Builder
Stores another multimap's entries in the built multimap.
putAll(K, Iterable<? extends V>) - Method in class com.google.common.collect.ImmutableMultimap
Deprecated.
Unsupported operation.
putAll(Multimap<? extends K, ? extends V>) - Method in class com.google.common.collect.ImmutableMultimap
Deprecated.
Unsupported operation.
putAll(RangeMap<K, ? extends V>) - Method in class com.google.common.collect.ImmutableRangeMap.Builder
Copies all associations from the specified range map into this builder.
putAll(RangeMap<K, V>) - Method in class com.google.common.collect.ImmutableRangeMap
 
putAll(K, Iterable<? extends V>) - Method in class com.google.common.collect.ImmutableSetMultimap.Builder
 
putAll(K, V...) - Method in class com.google.common.collect.ImmutableSetMultimap.Builder
 
putAll(Multimap<? extends K, ? extends V>) - Method in class com.google.common.collect.ImmutableSetMultimap.Builder
 
putAll(Map<? extends K, ? extends V>) - Method in class com.google.common.collect.ImmutableSortedMap.Builder
Associates all of the given map's keys and values in the built map.
putAll(Table<? extends R, ? extends C, ? extends V>) - Method in class com.google.common.collect.ImmutableTable.Builder
Associates all of the given table's keys and values in the built table.
putAll(Table<? extends R, ? extends C, ? extends V>) - Method in class com.google.common.collect.ImmutableTable
Deprecated.
Unsupported operation.
putAll(Map<? extends K, ? extends V>) - Method in class com.google.common.collect.MapConstraints.ConstrainedMap
 
putAll(K, Iterable<? extends V>) - Method in class com.google.common.collect.MapConstraints.ConstrainedMultimap
 
putAll(Multimap<? extends K, ? extends V>) - Method in class com.google.common.collect.MapConstraints.ConstrainedMultimap
 
putAll(Map<? extends K, ? extends V>) - Method in class com.google.common.collect.MapMakerInternalMap
 
putAll(Map<? extends K, ? extends V>) - Method in class com.google.common.collect.Maps.AbstractFilteredMap
 
putAll(Map<? extends K, ? extends V>) - Method in class com.google.common.collect.Maps.FilteredEntryNavigableMap
 
putAll(K, Iterable<? extends V>) - Method in interface com.google.common.collect.Multimap
Stores a key-value pair in this multimap for each of values, all using the same key, key.
putAll(Multimap<? extends K, ? extends V>) - Method in interface com.google.common.collect.Multimap
Stores all key-value pairs of multimap in this multimap, in the order returned by multimap.entries().
putAll(K, Iterable<? extends V>) - Method in class com.google.common.collect.Multimaps.MapMultimap
 
putAll(Multimap<? extends K, ? extends V>) - Method in class com.google.common.collect.Multimaps.MapMultimap
 
putAll(K, Iterable<? extends V2>) - Method in class com.google.common.collect.Multimaps.TransformedEntriesMultimap
 
putAll(Multimap<? extends K, ? extends V2>) - Method in class com.google.common.collect.Multimaps.TransformedEntriesMultimap
 
putAll(K, Iterable<? extends V>) - Method in class com.google.common.collect.Multimaps.UnmodifiableMultimap
 
putAll(Multimap<? extends K, ? extends V>) - Method in class com.google.common.collect.Multimaps.UnmodifiableMultimap
 
putAll(RangeMap<K, V>) - Method in interface com.google.common.collect.RangeMap
Puts all the associations from rangeMap into this range map (optional operation).
putAll(Map<? extends K, ? extends V>) - Method in class com.google.common.collect.Synchronized.SynchronizedMap
 
putAll(K, Iterable<? extends V>) - Method in class com.google.common.collect.Synchronized.SynchronizedMultimap
 
putAll(Multimap<? extends K, ? extends V>) - Method in class com.google.common.collect.Synchronized.SynchronizedMultimap
 
putAll(Table<? extends R, ? extends C, ? extends V>) - Method in interface com.google.common.collect.Table
Copies all mappings from the specified table to this table.
putAll(Table<? extends R, ? extends C, ? extends V2>) - Method in class com.google.common.collect.Tables.TransformedTable
 
putAll(Table<? extends C, ? extends R, ? extends V>) - Method in class com.google.common.collect.Tables.TransposeTable
 
putAll(Table<? extends R, ? extends C, ? extends V>) - Method in class com.google.common.collect.Tables.UnmodifiableTable
 
putAll(RangeMap<K, V>) - Method in class com.google.common.collect.TreeRangeMap
 
putAll(RangeMap<K, V>) - Method in class com.google.common.collect.TreeRangeMap.SubRangeMap
 
putAll(BloomFilter<T>) - Method in class com.google.common.hash.BloomFilter
Combines this bloom filter with another bloom filter by performing a bitwise OR of the underlying data.
putAll(BloomFilterStrategies.BitArray) - Method in class com.google.common.hash.BloomFilterStrategies.BitArray
Combines the two BitArrays using bitwise OR.
putAll(Map<? extends TypeToken<? extends B>, ? extends B>) - Method in class com.google.common.reflect.MutableTypeToInstanceMap
Not supported.
putAll(Map<? extends K, ? extends Long>) - Method in class com.google.common.util.concurrent.AtomicLongMap
Copies all of the mappings from the specified map to this map.
putAllImpl(Map<K, V>, Map<? extends K, ? extends V>) - Static method in class com.google.common.collect.Maps
An implementation of Map.putAll(java.util.Map<? extends K, ? extends V>).
putBoolean(boolean) - Method in class com.google.common.hash.AbstractHasher
 
putBoolean(boolean) - Method in interface com.google.common.hash.Hasher
Equivalent to putByte(b ? (byte) 1 : (byte) 0).
putBoolean(boolean) - Method in interface com.google.common.hash.PrimitiveSink
Puts a boolean into this sink.
putByte(byte) - Method in class com.google.common.hash.AbstractByteHasher
 
putByte(byte) - Method in class com.google.common.hash.AbstractNonStreamingHashFunction.BufferingHasher
 
putByte(byte) - Method in class com.google.common.hash.AbstractStreamingHashFunction.AbstractStreamingHasher
 
putByte(byte) - Method in interface com.google.common.hash.Hasher
 
putByte(byte) - Method in interface com.google.common.hash.PrimitiveSink
Puts a byte into this sink.
putBytes(byte[]) - Method in class com.google.common.hash.AbstractByteHasher
 
putBytes(byte[], int, int) - Method in class com.google.common.hash.AbstractByteHasher
 
putBytes(byte[]) - Method in class com.google.common.hash.AbstractNonStreamingHashFunction.BufferingHasher
 
putBytes(byte[], int, int) - Method in class com.google.common.hash.AbstractNonStreamingHashFunction.BufferingHasher
 
putBytes(byte[]) - Method in class com.google.common.hash.AbstractStreamingHashFunction.AbstractStreamingHasher
 
putBytes(byte[], int, int) - Method in class com.google.common.hash.AbstractStreamingHashFunction.AbstractStreamingHasher
 
putBytes(ByteBuffer) - Method in class com.google.common.hash.AbstractStreamingHashFunction.AbstractStreamingHasher
 
putBytes(byte[]) - Method in interface com.google.common.hash.Hasher
 
putBytes(byte[], int, int) - Method in interface com.google.common.hash.Hasher
 
putBytes(byte[]) - Method in interface com.google.common.hash.PrimitiveSink
Puts an array of bytes into this sink.
putBytes(byte[], int, int) - Method in interface com.google.common.hash.PrimitiveSink
Puts a chunk of an array of bytes into this sink.
putChar(char) - Method in class com.google.common.hash.AbstractByteHasher
 
putChar(char) - Method in class com.google.common.hash.AbstractNonStreamingHashFunction.BufferingHasher
 
putChar(char) - Method in class com.google.common.hash.AbstractStreamingHashFunction.AbstractStreamingHasher
 
putChar(char) - Method in interface com.google.common.hash.Hasher
 
putChar(char) - Method in interface com.google.common.hash.PrimitiveSink
Puts a character into this sink.
putDouble(double) - Method in class com.google.common.hash.AbstractHasher
 
putDouble(double) - Method in interface com.google.common.hash.Hasher
Equivalent to putLong(Double.doubleToRawLongBits(d)).
putDouble(double) - Method in interface com.google.common.hash.PrimitiveSink
Puts a double into this sink.
putFirst(E) - Method in class com.google.common.collect.ForwardingBlockingDeque
 
putFloat(float) - Method in class com.google.common.hash.AbstractHasher
 
putFloat(float) - Method in interface com.google.common.hash.Hasher
Equivalent to putInt(Float.floatToRawIntBits(f)).
putFloat(float) - Method in interface com.google.common.hash.PrimitiveSink
Puts a float into this sink.
putIfAbsent(K, V) - Method in class com.google.common.cache.LocalCache
 
putIfAbsent(K, V) - Method in class com.google.common.collect.ForwardingConcurrentMap
 
putIfAbsent(K, V) - Method in class com.google.common.collect.MapMaker.NullConcurrentMap
 
putIfAbsent(K, V) - Method in class com.google.common.collect.MapMakerInternalMap
 
putIfAbsent(K, long) - Method in class com.google.common.util.concurrent.AtomicLongMap
If key is not already associated with a value or if key is associated with zero, associate it with newValue.
putInBothMaps(K, V, boolean) - Method in class com.google.common.collect.AbstractBiMap
 
putInstance(Class<T>, T) - Method in interface com.google.common.collect.ClassToInstanceMap
Maps the specified class to the specified value.
putInstance(Class<T>, T) - Method in class com.google.common.collect.ImmutableClassToInstanceMap
Deprecated.
Unsupported operation.
putInstance(Class<T>, T) - Method in class com.google.common.collect.MutableClassToInstanceMap
 
putInstance(TypeToken<T>, T) - Method in class com.google.common.reflect.ImmutableTypeToInstanceMap
Guaranteed to throw an exception and leave the map unmodified.
putInstance(Class<T>, T) - Method in class com.google.common.reflect.ImmutableTypeToInstanceMap
Guaranteed to throw an exception and leave the map unmodified.
putInstance(Class<T>, T) - Method in class com.google.common.reflect.MutableTypeToInstanceMap
 
putInstance(TypeToken<T>, T) - Method in class com.google.common.reflect.MutableTypeToInstanceMap
 
putInstance(Class<T>, T) - Method in interface com.google.common.reflect.TypeToInstanceMap
Maps the specified class to the specified value.
putInstance(TypeToken<T>, T) - Method in interface com.google.common.reflect.TypeToInstanceMap
Maps the specified type to the specified value.
putInt(int) - Method in class com.google.common.hash.AbstractByteHasher
 
putInt(int) - Method in class com.google.common.hash.AbstractNonStreamingHashFunction.BufferingHasher
 
putInt(int) - Method in class com.google.common.hash.AbstractStreamingHashFunction.AbstractStreamingHasher
 
putInt(int) - Method in interface com.google.common.hash.Hasher
 
putInt(int) - Method in interface com.google.common.hash.PrimitiveSink
Puts an int into this sink.
putInverse(V, K, boolean) - Method in class com.google.common.collect.HashBiMap
 
putLast(E) - Method in class com.google.common.collect.ForwardingBlockingDeque
 
putLong(long) - Method in class com.google.common.hash.AbstractByteHasher
 
putLong(long) - Method in class com.google.common.hash.AbstractNonStreamingHashFunction.BufferingHasher
 
putLong(long) - Method in class com.google.common.hash.AbstractStreamingHashFunction.AbstractStreamingHasher
 
putLong(long) - Method in interface com.google.common.hash.Hasher
 
putLong(long) - Method in interface com.google.common.hash.PrimitiveSink
Puts a long into this sink.
putObject(T, Funnel<? super T>) - Method in class com.google.common.hash.AbstractByteHasher
 
putObject(T, Funnel<? super T>) - Method in class com.google.common.hash.AbstractNonStreamingHashFunction.BufferingHasher
 
putObject(T, Funnel<? super T>) - Method in class com.google.common.hash.AbstractStreamingHashFunction.AbstractStreamingHasher
 
putObject(T, Funnel<? super T>) - Method in interface com.google.common.hash.Hasher
A simple convenience for funnel.funnel(object, this).
putRangeMapEntry(Cut<K>, Cut<K>, V) - Method in class com.google.common.collect.TreeRangeMap
 
putShort(short) - Method in class com.google.common.hash.AbstractByteHasher
 
putShort(short) - Method in class com.google.common.hash.AbstractNonStreamingHashFunction.BufferingHasher
 
putShort(short) - Method in class com.google.common.hash.AbstractStreamingHashFunction.AbstractStreamingHasher
 
putShort(short) - Method in interface com.google.common.hash.Hasher
 
putShort(short) - Method in interface com.google.common.hash.PrimitiveSink
Puts a short into this sink.
putString(CharSequence, Charset) - Method in class com.google.common.hash.AbstractHasher
 
putString(CharSequence, Charset) - Method in interface com.google.common.hash.Hasher
Equivalent to putBytes(charSequence.toString().getBytes(charset)).
putString(CharSequence, Charset) - Method in interface com.google.common.hash.PrimitiveSink
Puts a string into this sink using the given charset.
putUnencodedChars(CharSequence) - Method in class com.google.common.hash.AbstractHasher
 
putUnencodedChars(CharSequence) - Method in class com.google.common.hash.AbstractStreamingHashFunction.AbstractStreamingHasher
 
putUnencodedChars(CharSequence) - Method in interface com.google.common.hash.Hasher
Equivalent to processing each char value in the CharSequence, in order.
putUnencodedChars(CharSequence) - Method in interface com.google.common.hash.PrimitiveSink
Puts each 16-bit code unit from the CharSequence into this sink.
putUninterruptibly(BlockingQueue<E>, E) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes queue.put(element) uninterruptibly.

Q

q0 - Variable in class com.google.common.cache.Striped64.Cell
 
q1 - Variable in class com.google.common.cache.Striped64.Cell
 
q1 - Variable in class com.google.common.util.concurrent.Striped.PaddedLock
 
q1 - Variable in class com.google.common.util.concurrent.Striped.PaddedSemaphore
 
q2 - Variable in class com.google.common.cache.Striped64.Cell
 
q2 - Variable in class com.google.common.util.concurrent.Striped.PaddedLock
 
q2 - Variable in class com.google.common.util.concurrent.Striped.PaddedSemaphore
 
q3 - Variable in class com.google.common.cache.Striped64.Cell
 
q3 - Variable in class com.google.common.util.concurrent.Striped.PaddedLock
 
q3 - Variable in class com.google.common.util.concurrent.Striped.PaddedSemaphore
 
q4 - Variable in class com.google.common.cache.Striped64.Cell
 
q5 - Variable in class com.google.common.cache.Striped64.Cell
 
q6 - Variable in class com.google.common.cache.Striped64.Cell
 
queryEarliestAvailable(long) - Method in class com.google.common.util.concurrent.RateLimiter
Returns the earliest time that permits are available (with one caveat).
queryEarliestAvailable(long) - Method in class com.google.common.util.concurrent.SmoothRateLimiter
 
queue - Variable in class com.google.common.base.FinalizableReferenceQueue
The actual reference queue that our background thread will poll.
queue - Variable in class com.google.common.base.internal.Finalizer
 
queue - Variable in class com.google.common.collect.Iterables.ConsumingQueueIterator
 
queue - Variable in class com.google.common.collect.Iterators.MergingIterator
 
queue - Variable in class com.google.common.collect.MinMaxPriorityQueue
 
queue(Queue<E>, Object) - Static method in class com.google.common.collect.Synchronized
 
queue - Variable in class com.google.common.collect.TreeTraverser.BreadthFirstIterator
 
queue - Variable in class com.google.common.util.concurrent.Striped.SmallLazyStriped
 
QueueIterator() - Constructor for class com.google.common.collect.MinMaxPriorityQueue.QueueIterator
 
Queues - Class in com.google.common.collect
Static utility methods pertaining to Queue and Deque instances.
Queues() - Constructor for class com.google.common.collect.Queues
 
QUICKTIME - Static variable in class com.google.common.net.MediaType
 
QUOTED_TEXT_MATCHER - Static variable in class com.google.common.net.MediaType
 

R

radix - Variable in class com.google.common.primitives.ParseRequest
 
RandomAccessListWrapper(List<E>) - Constructor for class com.google.common.collect.Lists.RandomAccessListWrapper
 
RandomAccessPartition(List<T>, int) - Constructor for class com.google.common.collect.Lists.RandomAccessPartition
 
RandomAccessReverseList(List<T>) - Constructor for class com.google.common.collect.Lists.RandomAccessReverseList
 
RandomAccessWrappedList(K, List<V>, AbstractMapBasedMultimap<K, V>.WrappedCollection) - Constructor for class com.google.common.collect.AbstractMapBasedMultimap.RandomAccessWrappedList
 
range() - Method in class com.google.common.collect.ContiguousSet
Returns a range, closed on both ends, whose endpoints are the minimum and maximum values contained in this set.
range(BoundType, BoundType) - Method in class com.google.common.collect.ContiguousSet
Returns the minimal range with the given boundary types for which all values in this set are contained within the range.
range() - Method in class com.google.common.collect.EmptyContiguousSet
 
range(BoundType, BoundType) - Method in class com.google.common.collect.EmptyContiguousSet
 
range(Comparator<? super T>, T, BoundType, T, BoundType) - Static method in class com.google.common.collect.GeneralRange
Returns everything between the endpoints relative to the specified comparator, with the specified endpoint behavior.
Range<C extends java.lang.Comparable> - Class in com.google.common.collect
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.
Range(Cut<C>, Cut<C>) - Constructor for class com.google.common.collect.Range
 
range(C, BoundType, C, BoundType) - Static method in class com.google.common.collect.Range
Returns a range that contains any value from lower to upper, where each endpoint may be either inclusive (closed) or exclusive (open).
range - Variable in class com.google.common.collect.RegularContiguousSet
 
range() - Method in class com.google.common.collect.RegularContiguousSet
 
range(BoundType, BoundType) - Method in class com.google.common.collect.RegularContiguousSet
 
range - Variable in class com.google.common.collect.RegularContiguousSet.SerializedForm
 
range - Variable in class com.google.common.collect.TreeMultiset
 
range - Variable in class com.google.common.collect.TreeRangeMap.RangeMapEntry
 
RANGE - Static variable in class com.google.common.net.HttpHeaders
The HTTP Range header field name.
RANGE_LEX_ORDERING - Static variable in class com.google.common.collect.Range
 
rangeContaining(C) - Method in class com.google.common.collect.AbstractRangeSet
 
rangeContaining(C) - Method in class com.google.common.collect.ImmutableRangeSet
 
rangeContaining(C) - Method in interface com.google.common.collect.RangeSet
Returns the unique range from this range set that contains value, or null if this range set does not contain value.
rangeContaining(C) - Method in class com.google.common.collect.TreeRangeSet
 
rangeContaining(C) - Method in class com.google.common.collect.TreeRangeSet.SubRangeSet
 
rangeContains(Object) - Method in class com.google.common.collect.TreeBasedTable.TreeRow
 
rangeEnclosing(Range<C>) - Method in class com.google.common.collect.TreeRangeSet
 
rangeEnds - Variable in class com.google.common.base.CharMatcher.RangesMatcher
 
rangeMap - Variable in class com.google.common.collect.ImmutableRangeMap.Builder
 
RangeMap<K extends java.lang.Comparable,V> - Interface in com.google.common.collect
A mapping from disjoint nonempty ranges to non-null values.
RangeMapEntry(Cut<K>, Cut<K>, V) - Constructor for class com.google.common.collect.TreeRangeMap.RangeMapEntry
 
RangeMapEntry(Range<K>, V) - Constructor for class com.google.common.collect.TreeRangeMap.RangeMapEntry
 
ranges - Variable in class com.google.common.collect.ImmutableRangeMap
 
ranges - Variable in class com.google.common.collect.ImmutableRangeSet.AsSetSerializedForm
 
ranges - Variable in class com.google.common.collect.ImmutableRangeSet
 
ranges - Variable in class com.google.common.collect.ImmutableRangeSet.SerializedForm
 
rangesByLowerBound - Variable in class com.google.common.collect.TreeRangeSet
 
rangesByLowerBound - Variable in class com.google.common.collect.TreeRangeSet.RangesByUpperBound
 
rangesByLowerBound - Variable in class com.google.common.collect.TreeRangeSet.SubRangeSetRangesByLowerBound
 
RangesByUpperBound(NavigableMap<Cut<C>, Range<C>>) - Constructor for class com.google.common.collect.TreeRangeSet.RangesByUpperBound
 
RangesByUpperBound(NavigableMap<Cut<C>, Range<C>>, Range<Cut<C>>) - Constructor for class com.google.common.collect.TreeRangeSet.RangesByUpperBound
 
rangesByUpperBound - Variable in class com.google.common.collect.TreeRangeSet.SubRangeSetRangesByLowerBound
 
rangeSet - Variable in class com.google.common.collect.ImmutableRangeSet.Builder
 
RangeSet<C extends java.lang.Comparable> - Interface in com.google.common.collect
A set comprising zero or more nonempty, disconnected ranges of type C.
RangesMatcher(String, char[], char[]) - Constructor for class com.google.common.base.CharMatcher.RangesMatcher
 
rangeStarts - Variable in class com.google.common.base.CharMatcher.RangesMatcher
 
rank(T) - Method in class com.google.common.collect.ExplicitOrdering
 
rankMap - Variable in class com.google.common.collect.ExplicitOrdering
 
RateLimiter - Class in com.google.common.util.concurrent
A rate limiter.
RateLimiter(RateLimiter.SleepingStopwatch) - Constructor for class com.google.common.util.concurrent.RateLimiter
 
RateLimiter.SleepingStopwatch - Class in com.google.common.util.concurrent
 
rawType - Variable in class com.google.common.reflect.Types.ParameterizedTypeImpl
 
rawTypes() - Method in class com.google.common.reflect.TypeToken.ClassSet
 
rawTypes() - Method in class com.google.common.reflect.TypeToken.InterfaceSet
 
rawTypes() - Method in class com.google.common.reflect.TypeToken.TypeSet
Returns the raw types of the types in this set, in the same order.
rawValue - Variable in class com.google.common.primitives.ParseRequest
 
RDF_XML_UTF_8 - Static variable in class com.google.common.net.MediaType
 
read() - Method in class com.google.common.base.Ticker
Returns the number of nanoseconds elapsed since this ticker's fixed point of reference.
read() - Method in class com.google.common.hash.HashingInputStream
Reads the next byte of data from the underlying input stream and updates the hasher with the byte read.
read(byte[], int, int) - Method in class com.google.common.hash.HashingInputStream
Reads the specified bytes of data from the underlying input stream and updates the hasher with the bytes read.
read() - Method in class com.google.common.io.ByteSource.ByteArrayByteSource
 
read(ByteProcessor<T>) - Method in class com.google.common.io.ByteSource.ByteArrayByteSource
 
read() - Method in class com.google.common.io.ByteSource.EmptyByteSource
 
read() - Method in class com.google.common.io.ByteSource
Reads the full contents of this byte source as a byte array.
read(ByteProcessor<T>) - Method in class com.google.common.io.ByteSource
Reads the contents of this byte source using the given processor to process bytes as they are read.
read() - Method in class com.google.common.io.ByteStreams.LimitedInputStream
 
read(byte[], int, int) - Method in class com.google.common.io.ByteStreams.LimitedInputStream
 
read(InputStream, byte[], int, int) - Static method in class com.google.common.io.ByteStreams
Reads some bytes from an input stream and stores them into the buffer array b.
read(CharBuffer) - Method in class com.google.common.io.CharSequenceReader
 
read() - Method in class com.google.common.io.CharSequenceReader
 
read(char[], int, int) - Method in class com.google.common.io.CharSequenceReader
 
read() - Method in class com.google.common.io.CharSource.CharSequenceCharSource
 
read() - Method in class com.google.common.io.CharSource
Reads the contents of this source as a string.
read() - Method in class com.google.common.io.CountingInputStream
 
read(byte[], int, int) - Method in class com.google.common.io.CountingInputStream
 
read() - Method in class com.google.common.io.Files.FileByteSource
 
read() - Method in interface com.google.common.io.GwtWorkarounds.ByteInput
 
read() - Method in interface com.google.common.io.GwtWorkarounds.CharInput
 
read() - Method in class com.google.common.io.MultiInputStream
 
read(byte[], int, int) - Method in class com.google.common.io.MultiInputStream
 
read(char[], int, int) - Method in class com.google.common.io.MultiReader
 
READ_WRITE_LOCK_SUPPLIER - Static variable in class com.google.common.util.concurrent.Striped
 
readable - Variable in class com.google.common.io.LineReader
 
readAndCheckByte() - Method in class com.google.common.io.LittleEndianDataInputStream
Reads a byte from the input stream checking that the end of file (EOF) has not been encountered.
readBoolean() - Method in interface com.google.common.io.ByteArrayDataInput
 
readBoolean() - Method in class com.google.common.io.ByteStreams.ByteArrayDataInputStream
 
readBoolean() - Method in class com.google.common.io.LittleEndianDataInputStream
 
readByte() - Method in interface com.google.common.io.ByteArrayDataInput
 
readByte() - Method in class com.google.common.io.ByteStreams.ByteArrayDataInputStream
 
readByte() - Method in class com.google.common.io.LittleEndianDataInputStream
 
readBytes(InputStream, ByteProcessor<T>) - Static method in class com.google.common.io.ByteStreams
Process the bytes of the given input stream using the given processor.
readBytes(File, ByteProcessor<T>) - Static method in class com.google.common.io.Files
Process the bytes of a file.
readChar() - Method in interface com.google.common.io.ByteArrayDataInput
 
readChar() - Method in class com.google.common.io.ByteStreams.ByteArrayDataInputStream
 
readChar() - Method in class com.google.common.io.LittleEndianDataInputStream
Reads a char as specified by DataInputStream.readChar(), except using little-endian byte order.
readCount - Variable in class com.google.common.cache.LocalCache.Segment
A counter of the number of reads since the last write, used to drain queues on a small fraction of read operations.
readCount - Variable in class com.google.common.collect.MapMakerInternalMap.Segment
A counter of the number of reads since the last write, used to drain queues on a small fraction of read operations.
readCount(ObjectInputStream) - Static method in class com.google.common.collect.Serialization
Reads a count corresponding to a serialized map, multiset, or multimap.
readDouble() - Method in interface com.google.common.io.ByteArrayDataInput
 
readDouble() - Method in class com.google.common.io.ByteStreams.ByteArrayDataInputStream
 
readDouble() - Method in class com.google.common.io.LittleEndianDataInputStream
Reads a double as specified by DataInputStream.readDouble(), except using little-endian byte order.
readEntries(ObjectInputStream) - Method in class com.google.common.collect.MapMakerInternalMap.AbstractSerializationProxy
 
reader - Variable in class com.google.common.io.LineReader
 
readFile(InputStream, long) - Static method in class com.google.common.io.Files
Reads a file of the given expected size from the given input stream, if it will fit into a byte array.
readFirstLine() - Method in class com.google.common.io.CharSource.CharSequenceCharSource
 
readFirstLine() - Method in class com.google.common.io.CharSource
Reads the first link of this source as a string.
readFirstLine(File, Charset) - Static method in class com.google.common.io.Files
Reads the first line from a file.
readFloat() - Method in interface com.google.common.io.ByteArrayDataInput
 
readFloat() - Method in class com.google.common.io.ByteStreams.ByteArrayDataInputStream
 
readFloat() - Method in class com.google.common.io.LittleEndianDataInputStream
Reads a float as specified by DataInputStream.readFloat(), except using little-endian byte order.
readFrom(InputStream, Funnel<T>) - Static method in class com.google.common.hash.BloomFilter
Reads a byte stream, which was written by BloomFilter.writeTo(OutputStream), into a BloomFilter<T>.
readFully(byte[]) - Method in interface com.google.common.io.ByteArrayDataInput
 
readFully(byte[], int, int) - Method in interface com.google.common.io.ByteArrayDataInput
 
readFully(byte[]) - Method in class com.google.common.io.ByteStreams.ByteArrayDataInputStream
 
readFully(byte[], int, int) - Method in class com.google.common.io.ByteStreams.ByteArrayDataInputStream
 
readFully(InputStream, byte[]) - Static method in class com.google.common.io.ByteStreams
Attempts to read enough bytes from the stream to fill the given byte array, with the same behavior as DataInput.readFully(byte[]).
readFully(InputStream, byte[], int, int) - Static method in class com.google.common.io.ByteStreams
Attempts to read len bytes from the stream into the given array starting at off, with the same behavior as DataInput.readFully(byte[], int, int).
readFully(byte[]) - Method in class com.google.common.io.LittleEndianDataInputStream
 
readFully(byte[], int, int) - Method in class com.google.common.io.LittleEndianDataInputStream
 
readInt() - Method in interface com.google.common.io.ByteArrayDataInput
 
readInt() - Method in class com.google.common.io.ByteStreams.ByteArrayDataInputStream
 
readInt() - Method in class com.google.common.io.LittleEndianDataInputStream
Reads an integer as specified by DataInputStream.readInt(), except using little-endian byte order.
readLine() - Method in interface com.google.common.io.ByteArrayDataInput
 
readLine() - Method in class com.google.common.io.ByteStreams.ByteArrayDataInputStream
 
readLine() - Method in class com.google.common.io.LineReader
Reads a line of text.
readLine() - Method in class com.google.common.io.LittleEndianDataInputStream
This method will throw an UnsupportedOperationException.
readLines() - Method in class com.google.common.io.CharSource.CharSequenceCharSource
 
readLines(LineProcessor<T>) - Method in class com.google.common.io.CharSource.CharSequenceCharSource
 
readLines() - Method in class com.google.common.io.CharSource
Reads all the lines of this source as a list of strings.
readLines(LineProcessor<T>) - Method in class com.google.common.io.CharSource
Reads lines of text from this source, processing each line as it is read using the given processor.
readLines(Readable) - Static method in class com.google.common.io.CharStreams
Reads all of the lines from a Readable object.
readLines(Readable, LineProcessor<T>) - Static method in class com.google.common.io.CharStreams
Streams lines from a Readable object, stopping when the processor returns false or all lines have been read and returning the result produced by the processor.
readLines(File, Charset) - Static method in class com.google.common.io.Files
Reads all of the lines from a file.
readLines(File, Charset, LineProcessor<T>) - Static method in class com.google.common.io.Files
Streams lines from a File, stopping when our callback returns false, or we have read all of the lines.
readLines(URL, Charset, LineProcessor<T>) - Static method in class com.google.common.io.Resources
Streams lines from a URL, stopping when our callback returns false, or we have read all of the lines.
readLines(URL, Charset) - Static method in class com.google.common.io.Resources
Reads all of the lines from a URL.
readLock - Variable in class com.google.common.util.concurrent.CycleDetectingLockFactory.CycleDetectingReentrantReadWriteLock
 
readLock() - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory.CycleDetectingReentrantReadWriteLock
 
readLong() - Method in interface com.google.common.io.ByteArrayDataInput
 
readLong() - Method in class com.google.common.io.ByteStreams.ByteArrayDataInputStream
 
readLong() - Method in class com.google.common.io.LittleEndianDataInputStream
Reads a long as specified by DataInputStream.readLong(), except using little-endian byte order.
readMapMaker(ObjectInputStream) - Method in class com.google.common.collect.MapMakerInternalMap.AbstractSerializationProxy
 
readMicros() - Method in class com.google.common.util.concurrent.RateLimiter.SleepingStopwatch
 
readObject(ObjectInputStream) - Method in class com.google.common.cache.LocalCache.LoadingSerializationProxy
 
readObject(ObjectInputStream) - Method in class com.google.common.cache.LocalCache.ManualSerializationProxy
 
readObject(ObjectInputStream) - Method in class com.google.common.cache.LongAdder
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.AbstractBiMap.Inverse
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.ArrayListMultimap
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.ComputingConcurrentHashMap.ComputingSerializationProxy
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.ConcurrentHashMultiset
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.EnumBiMap
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.EnumHashBiMap
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.EnumMultiset
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.HashBiMap
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.HashMultimap
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.HashMultiset
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.ImmutableAsList
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.ImmutableList
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.ImmutableListMultimap
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.ImmutableSetMultimap
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.ImmutableSortedSet
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.LinkedHashMultimap
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.LinkedHashMultiset
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.LinkedListMultimap
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.MapMakerInternalMap.SerializationProxy
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.Multimaps.CustomListMultimap
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.Multimaps.CustomMultimap
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.Multimaps.CustomSetMultimap
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.Multimaps.CustomSortedSetMultimap
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.TreeMultimap
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.TreeMultiset
 
readObject(ObjectInputStream) - Method in class com.google.common.util.concurrent.AtomicDouble
Reconstitutes the instance from a stream (that is, deserializes it).
readObject(ObjectInputStream) - Method in class com.google.common.util.concurrent.AtomicDoubleArray
Reconstitutes the instance from a stream (that is, deserializes it).
readObjectNoData() - Method in class com.google.common.collect.AbstractMapBasedMultiset
 
readResolve() - Method in class com.google.common.base.Absent
 
readResolve() - Method in class com.google.common.base.Converter.IdentityConverter
 
readResolve() - Method in class com.google.common.base.Equivalence.Equals
 
readResolve() - Method in class com.google.common.base.Equivalence.Identity
 
readResolve() - Method in class com.google.common.cache.LocalCache.LoadingSerializationProxy
 
readResolve() - Method in class com.google.common.cache.LocalCache.ManualSerializationProxy
 
readResolve() - Method in class com.google.common.collect.AbstractBiMap.Inverse
 
readResolve() - Method in class com.google.common.collect.AllEqualOrdering
 
readResolve() - Method in class com.google.common.collect.ComputingConcurrentHashMap.ComputingSerializationProxy
 
readResolve() - Method in class com.google.common.collect.Cut.AboveAll
 
readResolve() - Method in class com.google.common.collect.Cut.BelowAll
 
readResolve() - Method in class com.google.common.collect.DiscreteDomain.BigIntegerDomain
 
readResolve() - Method in class com.google.common.collect.DiscreteDomain.IntegerDomain
 
readResolve() - Method in class com.google.common.collect.DiscreteDomain.LongDomain
 
readResolve() - Method in class com.google.common.collect.EmptyContiguousSet.SerializedForm
 
readResolve() - Method in class com.google.common.collect.EmptyImmutableBiMap
 
readResolve() - Method in class com.google.common.collect.EmptyImmutableListMultimap
 
readResolve() - Method in class com.google.common.collect.EmptyImmutableSet
 
readResolve() - Method in class com.google.common.collect.EmptyImmutableSetMultimap
 
readResolve() - Method in class com.google.common.collect.HashBiMap.InverseSerializedForm
 
readResolve() - Method in class com.google.common.collect.ImmutableAsList.SerializedForm
 
readResolve() - Method in class com.google.common.collect.ImmutableBiMap.SerializedForm
 
readResolve() - Method in class com.google.common.collect.ImmutableEnumMap.EnumSerializedForm
 
readResolve() - Method in class com.google.common.collect.ImmutableEnumSet.EnumSerializedForm
 
readResolve() - Method in class com.google.common.collect.ImmutableList.SerializedForm
 
readResolve() - Method in class com.google.common.collect.ImmutableMap.SerializedForm
 
readResolve() - Method in class com.google.common.collect.ImmutableMapEntrySet.EntrySetSerializedForm
 
readResolve() - Method in class com.google.common.collect.ImmutableMapKeySet.KeySetSerializedForm
 
readResolve() - Method in class com.google.common.collect.ImmutableMapValues.SerializedForm
 
readResolve() - Method in class com.google.common.collect.ImmutableMultiset.EntrySetSerializedForm
 
readResolve() - Method in class com.google.common.collect.ImmutableMultiset.SerializedForm
 
readResolve() - Method in class com.google.common.collect.ImmutableRangeSet.AsSetSerializedForm
 
readResolve() - Method in class com.google.common.collect.ImmutableRangeSet.SerializedForm
 
readResolve() - Method in class com.google.common.collect.ImmutableSet.SerializedForm
 
readResolve() - Method in class com.google.common.collect.ImmutableSortedMap.SerializedForm
 
readResolve() - Method in class com.google.common.collect.ImmutableSortedMultiset.SerializedForm
 
readResolve() - Method in class com.google.common.collect.ImmutableSortedSet.SerializedForm
 
readResolve() - Method in class com.google.common.collect.MapMakerInternalMap.SerializationProxy
 
readResolve() - Method in class com.google.common.collect.NaturalOrdering
 
readResolve() - Method in class com.google.common.collect.Range
 
readResolve() - Method in class com.google.common.collect.RegularContiguousSet.SerializedForm
 
readResolve() - Method in class com.google.common.collect.RegularImmutableBiMap.InverseSerializedForm
 
readResolve() - Method in class com.google.common.collect.ReverseNaturalOrdering
 
readResolve() - Method in class com.google.common.collect.UsingToStringOrdering
 
readResolve() - Method in class com.google.common.hash.BloomFilter.SerialForm
 
readResolve() - Method in class com.google.common.hash.Funnels.StringCharsetFunnel.SerializedForm
 
readResolve() - Method in class com.google.common.hash.MessageDigestHashFunction.SerializedForm
 
readResolve() - Method in class com.google.common.primitives.Doubles.DoubleConverter
 
readResolve() - Method in class com.google.common.primitives.Floats.FloatConverter
 
readResolve() - Method in class com.google.common.primitives.Ints.IntConverter
 
readResolve() - Method in class com.google.common.primitives.Longs.LongConverter
 
readResolve() - Method in class com.google.common.primitives.Shorts.ShortConverter
 
readResolve() - Method in class com.google.common.reflect.TypeToken.ClassSet
 
readResolve() - Method in class com.google.common.reflect.TypeToken.InterfaceSet
 
readShort() - Method in interface com.google.common.io.ByteArrayDataInput
 
readShort() - Method in class com.google.common.io.ByteStreams.ByteArrayDataInputStream
 
readShort() - Method in class com.google.common.io.LittleEndianDataInputStream
Reads a short as specified by DataInputStream.readShort(), except using little-endian byte order.
readUnsignedByte() - Method in interface com.google.common.io.ByteArrayDataInput
 
readUnsignedByte() - Method in class com.google.common.io.ByteStreams.ByteArrayDataInputStream
 
readUnsignedByte() - Method in class com.google.common.io.LittleEndianDataInputStream
 
readUnsignedShort() - Method in interface com.google.common.io.ByteArrayDataInput
 
readUnsignedShort() - Method in class com.google.common.io.ByteStreams.ByteArrayDataInputStream
 
readUnsignedShort() - Method in class com.google.common.io.LittleEndianDataInputStream
Reads an unsigned short as specified by DataInputStream.readUnsignedShort(), except using little-endian byte order.
readUTF() - Method in interface com.google.common.io.ByteArrayDataInput
 
readUTF() - Method in class com.google.common.io.ByteStreams.ByteArrayDataInputStream
 
readUTF() - Method in class com.google.common.io.LittleEndianDataInputStream
 
readWriteLock - Variable in class com.google.common.util.concurrent.CycleDetectingLockFactory.CycleDetectingReentrantReadLock
 
readWriteLock - Variable in class com.google.common.util.concurrent.CycleDetectingLockFactory.CycleDetectingReentrantWriteLock
 
readWriteLock(int) - Static method in class com.google.common.util.concurrent.Striped
Creates a Striped<ReadWriteLock> with eagerly initialized, strongly referenced read-write locks.
ready() - Method in class com.google.common.io.CharSequenceReader
 
ready() - Method in class com.google.common.io.MultiReader
 
ready - Variable in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState
These two booleans are used to mark the state as ready to start.
rebalance() - Method in class com.google.common.collect.TreeMultiset.AvlNode
 
recencyQueue - Variable in class com.google.common.cache.LocalCache.Segment
The recency queue is used to record which entries were accessed for updating the access list's ordering.
recencyQueue - Variable in class com.google.common.collect.MapMakerInternalMap.Segment
The recency queue is used to record which entries were accessed for updating the eviction list's ordering.
reclaimKey(LocalCache.ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache
 
reclaimKey(LocalCache.ReferenceEntry<K, V>, int) - Method in class com.google.common.cache.LocalCache.Segment
Removes an entry whose key has been garbage collected.
reclaimKey(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap
 
reclaimKey(MapMakerInternalMap.ReferenceEntry<K, V>, int) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Removes an entry whose key has been garbage collected.
reclaimValue(LocalCache.ValueReference<K, V>) - Method in class com.google.common.cache.LocalCache
 
reclaimValue(K, int, LocalCache.ValueReference<K, V>) - Method in class com.google.common.cache.LocalCache.Segment
Removes an entry whose value has been garbage collected.
reclaimValue(MapMakerInternalMap.ValueReference<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap
 
reclaimValue(K, int, MapMakerInternalMap.ValueReference<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Removes an entry whose value has been garbage collected.
recompute() - Method in class com.google.common.collect.TreeMultiset.AvlNode
 
recomputeHeight() - Method in class com.google.common.collect.TreeMultiset.AvlNode
 
recomputeMultiset() - Method in class com.google.common.collect.TreeMultiset.AvlNode
 
recordEviction() - Method in class com.google.common.cache.AbstractCache.SimpleStatsCounter
 
recordEviction() - Method in interface com.google.common.cache.AbstractCache.StatsCounter
Records the eviction of an entry from the cache.
recordExpirationTime(MapMakerInternalMap.ReferenceEntry<K, V>, long) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
 
recordHits(int) - Method in class com.google.common.cache.AbstractCache.SimpleStatsCounter
 
recordHits(int) - Method in interface com.google.common.cache.AbstractCache.StatsCounter
Records cache hits.
recordLoadException(long) - Method in class com.google.common.cache.AbstractCache.SimpleStatsCounter
 
recordLoadException(long) - Method in interface com.google.common.cache.AbstractCache.StatsCounter
Records the failed load of a new entry.
recordLoadSuccess(long) - Method in class com.google.common.cache.AbstractCache.SimpleStatsCounter
 
recordLoadSuccess(long) - Method in interface com.google.common.cache.AbstractCache.StatsCounter
Records the successful load of a new entry.
recordLockedRead(LocalCache.ReferenceEntry<K, V>, long) - Method in class com.google.common.cache.LocalCache.Segment
Updates the eviction metadata that entry was just read.
recordLockedRead(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Updates the eviction metadata that entry was just read.
recordMisses(int) - Method in class com.google.common.cache.AbstractCache.SimpleStatsCounter
 
recordMisses(int) - Method in interface com.google.common.cache.AbstractCache.StatsCounter
Records cache misses.
recordRead(LocalCache.ReferenceEntry<K, V>, long) - Method in class com.google.common.cache.LocalCache.Segment
Records the relative order in which this read was performed by adding entry to the recency queue.
recordRead(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Records the relative order in which this read was performed by adding entry to the recency queue.
recordsAccess() - Method in class com.google.common.cache.LocalCache
 
recordStats() - Method in class com.google.common.cache.CacheBuilder
Enable the accumulation of CacheStats during the operation of the cache.
recordStats - Variable in class com.google.common.cache.CacheBuilderSpec
 
RecordStatsParser() - Constructor for class com.google.common.cache.CacheBuilderSpec.RecordStatsParser
 
recordsTime() - Method in class com.google.common.cache.LocalCache
 
recordsWrite() - Method in class com.google.common.cache.LocalCache
 
recordWrite(LocalCache.ReferenceEntry<K, V>, int, long) - Method in class com.google.common.cache.LocalCache.Segment
Updates eviction metadata that entry was just written.
recordWrite(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Updates eviction metadata that entry was just written.
recreateCacheBuilder() - Method in class com.google.common.cache.LocalCache.ManualSerializationProxy
 
reference - Variable in class com.google.common.base.Equivalence.Wrapper
 
reference - Variable in class com.google.common.base.Present
 
Reference() - Constructor for class com.google.common.collect.TreeMultiset.Reference
 
referenceValue(LocalCache.Segment<K, V>, LocalCache.ReferenceEntry<K, V>, V, int) - Method in enum com.google.common.cache.LocalCache.Strength
Creates a reference for the given value according to this value strength.
referenceValue(MapMakerInternalMap.Segment<K, V>, MapMakerInternalMap.ReferenceEntry<K, V>, V) - Method in enum com.google.common.collect.MapMakerInternalMap.Strength
Creates a reference for the given value according to this value strength.
referent - Variable in class com.google.common.cache.LocalCache.StrongValueReference
 
referent - Variable in class com.google.common.collect.MapMakerInternalMap.StrongValueReference
 
REFERER - Static variable in class com.google.common.net.HttpHeaders
The HTTP Referer header field name.
Reflection - Class in com.google.common.reflect
Static utilities relating to Java reflection.
Reflection() - Constructor for class com.google.common.reflect.Reflection
 
refresh(K) - Method in class com.google.common.cache.AbstractLoadingCache
 
refresh(K) - Method in class com.google.common.cache.ForwardingLoadingCache
 
refresh(K) - Method in interface com.google.common.cache.LoadingCache
Loads a new value for key key, possibly asynchronously.
refresh(K) - Method in class com.google.common.cache.LocalCache.LoadingSerializationProxy
 
refresh(K) - Method in class com.google.common.cache.LocalCache.LocalLoadingCache
 
refresh(K) - Method in class com.google.common.cache.LocalCache
 
refresh(K, int, CacheLoader<? super K, V>, boolean) - Method in class com.google.common.cache.LocalCache.Segment
Refreshes the value associated with key, unless another thread is already doing so.
REFRESH - Static variable in class com.google.common.net.HttpHeaders
The HTTP Refresh header field name.
refreshAfterWrite(long, TimeUnit) - Method in class com.google.common.cache.CacheBuilder
Specifies that active entries are eligible for automatic refresh once a fixed duration has elapsed after the entry's creation, or the most recent replacement of its value.
refreshDuration - Variable in class com.google.common.cache.CacheBuilderSpec
 
RefreshDurationParser() - Constructor for class com.google.common.cache.CacheBuilderSpec.RefreshDurationParser
 
refreshes() - Method in class com.google.common.cache.LocalCache
 
refreshIfEmpty() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection
If the delegate collection is empty, but the multimap has values for the key, replace the delegate with the new collection for the key.
refreshNanos - Variable in class com.google.common.cache.CacheBuilder
 
refreshNanos - Variable in class com.google.common.cache.LocalCache
How long after the last write an entry becomes a candidate for refresh.
refreshTimeUnit - Variable in class com.google.common.cache.CacheBuilderSpec
 
register(Object) - Method in class com.google.common.eventbus.EventBus
Registers all subscriber methods on object to receive events.
register(C) - Method in class com.google.common.io.Closer
Registers the given closeable to be closed when this Closer is closed.
RegularContiguousSet<C extends java.lang.Comparable> - Class in com.google.common.collect
An implementation of ContiguousSet that contains one or more elements.
RegularContiguousSet(Range<C>, DiscreteDomain<C>) - Constructor for class com.google.common.collect.RegularContiguousSet
 
RegularContiguousSet.SerializedForm<C extends java.lang.Comparable> - Class in com.google.common.collect
 
RegularImmutableAsList<E> - Class in com.google.common.collect
An ImmutableAsList implementation specialized for when the delegate collection is already backed by an ImmutableList or array.
RegularImmutableAsList(ImmutableCollection<E>, ImmutableList<? extends E>) - Constructor for class com.google.common.collect.RegularImmutableAsList
 
RegularImmutableAsList(ImmutableCollection<E>, Object[]) - Constructor for class com.google.common.collect.RegularImmutableAsList
 
RegularImmutableBiMap<K,V> - Class in com.google.common.collect
Bimap with two or more mappings.
RegularImmutableBiMap(ImmutableMapEntry.TerminalEntry<?, ?>...) - Constructor for class com.google.common.collect.RegularImmutableBiMap
 
RegularImmutableBiMap(int, ImmutableMapEntry.TerminalEntry<?, ?>[]) - Constructor for class com.google.common.collect.RegularImmutableBiMap
Constructor for RegularImmutableBiMap that takes as input an array of TerminalEntry entries.
RegularImmutableBiMap(Map.Entry<?, ?>[]) - Constructor for class com.google.common.collect.RegularImmutableBiMap
Constructor for RegularImmutableBiMap that makes no assumptions about the input entries.
RegularImmutableBiMap.Inverse - Class in com.google.common.collect
 
RegularImmutableBiMap.Inverse.InverseEntrySet - Class in com.google.common.collect
 
RegularImmutableBiMap.InverseSerializedForm<K,V> - Class in com.google.common.collect
 
RegularImmutableBiMap.NonTerminalBiMapEntry<K,V> - Class in com.google.common.collect
 
RegularImmutableList<E> - Class in com.google.common.collect
Implementation of ImmutableList with one or more elements.
RegularImmutableList(Object[], int, int) - Constructor for class com.google.common.collect.RegularImmutableList
 
RegularImmutableList(Object[]) - Constructor for class com.google.common.collect.RegularImmutableList
 
RegularImmutableMap<K,V> - Class in com.google.common.collect
Implementation of ImmutableMap with two or more entries.
RegularImmutableMap(ImmutableMapEntry.TerminalEntry<?, ?>...) - Constructor for class com.google.common.collect.RegularImmutableMap
 
RegularImmutableMap(int, ImmutableMapEntry.TerminalEntry<?, ?>[]) - Constructor for class com.google.common.collect.RegularImmutableMap
Constructor for RegularImmutableMap that takes as input an array of TerminalEntry entries.
RegularImmutableMap(Map.Entry<?, ?>[]) - Constructor for class com.google.common.collect.RegularImmutableMap
Constructor for RegularImmutableMap that makes no assumptions about the input entries.
RegularImmutableMap.EntrySet - Class in com.google.common.collect
 
RegularImmutableMap.NonTerminalMapEntry<K,V> - Class in com.google.common.collect
 
RegularImmutableMultiset<E> - Class in com.google.common.collect
Implementation of ImmutableMultiset with zero or more elements.
RegularImmutableMultiset(ImmutableMap<E, Integer>, int) - Constructor for class com.google.common.collect.RegularImmutableMultiset
 
RegularImmutableSet<E> - Class in com.google.common.collect
Implementation of ImmutableSet with two or more elements.
RegularImmutableSet(Object[], int, Object[], int) - Constructor for class com.google.common.collect.RegularImmutableSet
 
RegularImmutableSortedMap<K,V> - Class in com.google.common.collect
An implementation of an immutable sorted map with one or more entries.
RegularImmutableSortedMap(RegularImmutableSortedSet<K>, ImmutableList<V>) - Constructor for class com.google.common.collect.RegularImmutableSortedMap
 
RegularImmutableSortedMap(RegularImmutableSortedSet<K>, ImmutableList<V>, ImmutableSortedMap<K, V>) - Constructor for class com.google.common.collect.RegularImmutableSortedMap
 
RegularImmutableSortedMap.EntrySet - Class in com.google.common.collect
 
RegularImmutableSortedMultiset<E> - Class in com.google.common.collect
An immutable sorted multiset with one or more distinct elements.
RegularImmutableSortedMultiset(RegularImmutableSortedSet<E>, int[], long[], int, int) - Constructor for class com.google.common.collect.RegularImmutableSortedMultiset
 
RegularImmutableSortedSet<E> - Class in com.google.common.collect
An immutable sorted set with one or more elements.
RegularImmutableSortedSet(ImmutableList<E>, Comparator<? super E>) - Constructor for class com.google.common.collect.RegularImmutableSortedSet
 
RegularImmutableTable<R,C,V> - Class in com.google.common.collect
An implementation of ImmutableTable holding an arbitrary number of cells.
RegularImmutableTable() - Constructor for class com.google.common.collect.RegularImmutableTable
 
RegularImmutableTable.CellSet - Class in com.google.common.collect
 
RegularImmutableTable.Values - Class in com.google.common.collect
 
rehash(int) - Static method in class com.google.common.cache.LocalCache
Applies a supplemental hash function to a given hash code, which defends against poor quality hash functions.
rehash(int) - Static method in class com.google.common.collect.MapMakerInternalMap
Applies a supplemental hash function to a given hash code, which defends against poor quality hash functions.
rehashIfNecessary() - Method in class com.google.common.collect.HashBiMap
 
rehashIfNecessary() - Method in class com.google.common.collect.LinkedHashMultimap.ValueSet
 
rejectionPropagatingRunnable(AbstractFuture<?>, Runnable, Executor) - Static method in class com.google.common.util.concurrent.Futures
Returns a Runnable that will invoke the delegate Runnable on the delegate executor, but if the task is rejected, it will propagate that rejection to the output future.
rejectTypeVariables() - Method in class com.google.common.reflect.TypeToken
Ensures that this type token doesn't contain type variables, which can cause unchecked type errors for callers like TypeToInstanceMap.
reload(K, V) - Method in class com.google.common.cache.CacheLoader
Computes or retrieves a replacement value corresponding to an already-cached key.
remainder(int, int) - Static method in class com.google.common.primitives.UnsignedInts
Returns dividend % divisor, where the dividend and divisor are treated as unsigned 32-bit quantities.
remainder(long, long) - Static method in class com.google.common.primitives.UnsignedLongs
Returns dividend % divisor, where the dividend and divisor are treated as unsigned 64-bit quantities.
remaining() - Method in class com.google.common.io.CharSequenceReader
 
remaining - Variable in class com.google.common.util.concurrent.Futures.CombinedFuture
 
remainingCapacity() - Method in class com.google.common.collect.EvictingQueue
Returns the number of additional elements that this queue can accept without evicting; zero if the queue is currently full.
remainingCapacity() - Method in class com.google.common.collect.ForwardingBlockingDeque
 
remainingCapacity() - Method in class com.google.common.util.concurrent.ForwardingBlockingQueue
 
RemovalCause - Enum in com.google.common.cache
The reason why a cached entry was removed.
RemovalCause() - Constructor for enum com.google.common.cache.RemovalCause
 
removalCause - Variable in class com.google.common.collect.MapMaker.NullConcurrentMap
 
RemovalCause() - Constructor for enum com.google.common.collect.MapMaker.RemovalCause
 
removalListener - Variable in class com.google.common.cache.CacheBuilder
 
removalListener(RemovalListener<? super K1, ? super V1>) - Method in class com.google.common.cache.CacheBuilder
Specifies a listener instance that caches should notify each time an entry is removed for any reason.
removalListener - Variable in class com.google.common.cache.LocalCache.ManualSerializationProxy
 
removalListener - Variable in class com.google.common.cache.LocalCache
A listener that is invoked when an entry is removed due to expiration or garbage collection of soft/weak entries.
RemovalListener<K,V> - Interface in com.google.common.cache
An object that can receive a notification when an entry is removed from a cache.
removalListener - Variable in class com.google.common.collect.GenericMapMaker
Deprecated.
 
removalListener - Variable in class com.google.common.collect.MapMaker.NullConcurrentMap
 
removalListener(MapMaker.RemovalListener<K, V>) - Method in class com.google.common.collect.MapMaker
Deprecated.
Caching functionality in MapMaker has been moved to CacheBuilder, with MapMaker.removalListener(com.google.common.collect.MapMaker.RemovalListener<K, V>) being replaced by CacheBuilder.removalListener. Note that CacheBuilder is simply an enhanced API for an implementation which was branched from MapMaker.
removalListener - Variable in class com.google.common.collect.MapMakerInternalMap.AbstractSerializationProxy
 
removalListener - Variable in class com.google.common.collect.MapMakerInternalMap
A listener that is invoked when an entry is removed due to expiration or garbage collection of soft/weak entries.
RemovalListeners - Class in com.google.common.cache
A collection of common removal listeners.
RemovalListeners() - Constructor for class com.google.common.cache.RemovalListeners
 
RemovalNotification<K,V> - Class in com.google.common.cache
A notification of the removal of a single entry.
RemovalNotification(K, V, RemovalCause) - Constructor for class com.google.common.cache.RemovalNotification
 
RemovalNotification(K, V, MapMaker.RemovalCause) - Constructor for class com.google.common.collect.MapMaker.RemovalNotification
 
removalNotificationQueue - Variable in class com.google.common.cache.LocalCache
Entries waiting to be consumed by the removal listener.
removalNotificationQueue - Variable in class com.google.common.collect.MapMakerInternalMap
Entries waiting to be consumed by the removal listener.
remove() - Method in class com.google.common.base.AbstractIterator
 
remove(Object) - Method in class com.google.common.cache.LocalCache.AccessQueue
 
remove(Object) - Method in class com.google.common.cache.LocalCache.EntrySet
 
remove() - Method in class com.google.common.cache.LocalCache.HashIterator
 
remove(Object) - Method in class com.google.common.cache.LocalCache.KeySet
 
remove(Object) - Method in class com.google.common.cache.LocalCache
 
remove(Object, Object) - Method in class com.google.common.cache.LocalCache
 
remove(Object, int) - Method in class com.google.common.cache.LocalCache.Segment
 
remove(Object, int, Object) - Method in class com.google.common.cache.LocalCache.Segment
 
remove(Object) - Method in class com.google.common.cache.LocalCache.WriteQueue
 
remove(Object) - Method in class com.google.common.collect.AbstractBiMap.EntrySet
 
remove(Object) - Method in class com.google.common.collect.AbstractBiMap.KeySet
 
remove(Object) - Method in class com.google.common.collect.AbstractBiMap
 
remove(Object) - Method in class com.google.common.collect.AbstractMapBasedMultimap.AsMap.AsMapEntries
 
remove() - Method in class com.google.common.collect.AbstractMapBasedMultimap.AsMap.AsMapIterator
 
remove(Object) - Method in class com.google.common.collect.AbstractMapBasedMultimap.AsMap
 
remove() - Method in class com.google.common.collect.AbstractMapBasedMultimap.Itr
 
remove(Object) - Method in class com.google.common.collect.AbstractMapBasedMultimap.KeySet
 
remove(Object) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection
 
remove() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection.WrappedIterator
 
remove(int) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedList
 
remove() - Method in class com.google.common.collect.AbstractMapBasedMultiset.MapBasedMultisetIterator
 
remove(Object, int) - Method in class com.google.common.collect.AbstractMapBasedMultiset
 
remove(Object, Object) - Method in class com.google.common.collect.AbstractMultimap
 
remove(Object) - Method in class com.google.common.collect.AbstractMultiset
 
remove(Object, int) - Method in class com.google.common.collect.AbstractMultiset
 
remove(Range<C>) - Method in class com.google.common.collect.AbstractRangeSet
 
remove(Object) - Method in class com.google.common.collect.AbstractTable.CellSet
 
remove(Object, Object) - Method in class com.google.common.collect.AbstractTable
 
remove(Object) - Method in class com.google.common.collect.ArrayTable.ArrayMap
 
remove(Object, Object) - Method in class com.google.common.collect.ArrayTable
remove(Object) - Method in class com.google.common.collect.Collections2.FilteredCollection
 
remove(Object, int) - Method in class com.google.common.collect.ConcurrentHashMultiset
Removes a number of occurrences of the specified element from this multiset.
remove(Object) - Method in class com.google.common.collect.EvictingQueue
 
remove(Object) - Method in class com.google.common.collect.FilteredEntryMultimap.AsMap
 
remove(Object, int) - Method in class com.google.common.collect.FilteredEntryMultimap.Keys
 
remove(Object) - Method in class com.google.common.collect.FilteredKeyMultimap.Entries
 
remove(Object) - Method in class com.google.common.collect.FilteredMultimapValues
 
remove(Object) - Method in class com.google.common.collect.ForwardingCollection
 
remove(Object, Object) - Method in class com.google.common.collect.ForwardingConcurrentMap
 
remove() - Method in class com.google.common.collect.ForwardingIterator
 
remove(int) - Method in class com.google.common.collect.ForwardingList
 
remove(Object) - Method in class com.google.common.collect.ForwardingMap
 
remove(Object, Object) - Method in class com.google.common.collect.ForwardingMultimap
 
remove(Object, int) - Method in class com.google.common.collect.ForwardingMultiset
 
remove() - Method in class com.google.common.collect.ForwardingQueue
 
remove(Object, Object) - Method in class com.google.common.collect.ForwardingTable
 
remove(Object, Object) - Method in class com.google.common.collect.HashBasedTable
 
remove(Object) - Method in class com.google.common.collect.HashBiMap.Inverse.InverseKeySet
 
remove(Object) - Method in class com.google.common.collect.HashBiMap.Inverse
 
remove() - Method in class com.google.common.collect.HashBiMap.Itr
 
remove(Object) - Method in class com.google.common.collect.HashBiMap.KeySet
 
remove(Object) - Method in class com.google.common.collect.HashBiMap
 
remove(Object) - Method in class com.google.common.collect.ImmutableCollection
Deprecated.
Unsupported operation.
remove(int) - Method in class com.google.common.collect.ImmutableList
Deprecated.
Unsupported operation.
remove(Object) - Method in class com.google.common.collect.ImmutableMap
Deprecated.
Unsupported operation.
remove(Object, Object) - Method in class com.google.common.collect.ImmutableMultimap
Deprecated.
Unsupported operation.
remove(Object, int) - Method in class com.google.common.collect.ImmutableMultiset
Deprecated.
Unsupported operation.
remove(Range<K>) - Method in class com.google.common.collect.ImmutableRangeMap
 
remove(Range<C>) - Method in class com.google.common.collect.ImmutableRangeSet
 
remove(Object, Object) - Method in class com.google.common.collect.ImmutableTable
Deprecated.
Unsupported operation.
remove() - Method in class com.google.common.collect.Iterators.PeekingImpl
 
remove(Object) - Method in class com.google.common.collect.LinkedHashMultimap.ValueSet
 
remove() - Method in class com.google.common.collect.LinkedListMultimap.DistinctKeyIterator
 
remove() - Method in class com.google.common.collect.LinkedListMultimap.NodeIterator
 
remove() - Method in class com.google.common.collect.LinkedListMultimap.ValueForKeyIterator
 
remove(int) - Method in class com.google.common.collect.Lists.AbstractListWrapper
 
remove(int) - Method in class com.google.common.collect.Lists.ReverseList
 
remove(int) - Method in class com.google.common.collect.Lists.TransformingRandomAccessList
 
remove(Object) - Method in class com.google.common.collect.MapConstraints.ConstrainedAsMapEntries
 
remove(Object) - Method in class com.google.common.collect.MapConstraints.ConstrainedAsMapValues
 
remove(Object) - Method in class com.google.common.collect.MapConstraints.ConstrainedEntries
 
remove(Object) - Method in class com.google.common.collect.MapMaker.NullConcurrentMap
 
remove(Object, Object) - Method in class com.google.common.collect.MapMaker.NullConcurrentMap
 
remove(Object) - Method in class com.google.common.collect.MapMakerInternalMap.EntrySet
 
remove(Object) - Method in class com.google.common.collect.MapMakerInternalMap.EvictionQueue
 
remove(Object) - Method in class com.google.common.collect.MapMakerInternalMap.ExpirationQueue
 
remove() - Method in class com.google.common.collect.MapMakerInternalMap.HashIterator
 
remove(Object) - Method in class com.google.common.collect.MapMakerInternalMap.KeySet
 
remove(Object) - Method in class com.google.common.collect.MapMakerInternalMap
 
remove(Object, Object) - Method in class com.google.common.collect.MapMakerInternalMap
 
remove(Object, int) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
 
remove(Object, int, Object) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
 
remove(Object) - Method in class com.google.common.collect.Maps.AbstractFilteredMap
 
remove(Object) - Method in class com.google.common.collect.Maps.AsMapView
 
remove(Object) - Method in class com.google.common.collect.Maps.EntrySet
 
remove(Object) - Method in class com.google.common.collect.Maps.FilteredEntryMap.KeySet
 
remove(Object) - Method in class com.google.common.collect.Maps.FilteredEntryNavigableMap
 
remove(Object) - Method in class com.google.common.collect.Maps.FilteredMapValues
 
remove(Object) - Method in class com.google.common.collect.Maps.KeySet
 
remove(Object) - Method in class com.google.common.collect.Maps.TransformedEntriesMap
 
remove(Object) - Method in class com.google.common.collect.Maps.Values
 
remove() - Method in class com.google.common.collect.MinMaxPriorityQueue.QueueIterator
 
remove(Object, Object) - Method in interface com.google.common.collect.Multimap
Removes a single key-value pair with the key key and the value value from this multimap, if such exists.
remove(Object) - Method in class com.google.common.collect.Multimaps.AsMap.EntrySet
 
remove(Object) - Method in class com.google.common.collect.Multimaps.AsMap
 
remove(Object) - Method in class com.google.common.collect.Multimaps.Entries
 
remove(Object) - Method in class com.google.common.collect.Multimaps.Keys.KeysEntrySet
 
remove(Object, int) - Method in class com.google.common.collect.Multimaps.Keys
 
remove(Object, Object) - Method in class com.google.common.collect.Multimaps.MapMultimap
 
remove(Object, Object) - Method in class com.google.common.collect.Multimaps.TransformedEntriesMultimap
 
remove(Object, Object) - Method in class com.google.common.collect.Multimaps.UnmodifiableMultimap
 
remove(Object, int) - Method in interface com.google.common.collect.Multiset
Removes a number of occurrences of the specified element from this multiset.
remove(Object) - Method in interface com.google.common.collect.Multiset
Removes a single occurrence of the specified element from this multiset, if present.
remove(Object) - Method in class com.google.common.collect.Multisets.ElementSet
 
remove(Object) - Method in class com.google.common.collect.Multisets.EntrySet
 
remove(Object, int) - Method in class com.google.common.collect.Multisets.FilteredMultiset
 
remove() - Method in class com.google.common.collect.Multisets.MultisetIteratorImpl
 
remove(Object) - Method in class com.google.common.collect.Multisets.UnmodifiableMultiset
 
remove(Object, int) - Method in class com.google.common.collect.Multisets.UnmodifiableMultiset
 
remove() - Method in interface com.google.common.collect.PeekingIterator
remove(Range<K>) - Method in interface com.google.common.collect.RangeMap
Removes all associations from this range map in the specified range (optional operation).
remove(Range<C>) - Method in interface com.google.common.collect.RangeSet
Removes the specified range from this RangeSet (optional operation).
remove() - Method in class com.google.common.collect.StandardTable.CellIterator
 
remove(Object) - Method in class com.google.common.collect.StandardTable.Column.EntrySet
 
remove(Object) - Method in class com.google.common.collect.StandardTable.Column.KeySet
 
remove(Object) - Method in class com.google.common.collect.StandardTable.Column
 
remove(Object) - Method in class com.google.common.collect.StandardTable.Column.Values
 
remove(Object) - Method in class com.google.common.collect.StandardTable.ColumnKeySet
 
remove(Object) - Method in class com.google.common.collect.StandardTable.ColumnMap.ColumnMapEntrySet
 
remove(Object) - Method in class com.google.common.collect.StandardTable.ColumnMap.ColumnMapValues
 
remove(Object) - Method in class com.google.common.collect.StandardTable.ColumnMap
 
remove(Object, Object) - Method in class com.google.common.collect.StandardTable
 
remove(Object) - Method in class com.google.common.collect.StandardTable.Row
 
remove(Object) - Method in class com.google.common.collect.StandardTable.RowMap.EntrySet
 
remove(Object) - Method in class com.google.common.collect.StandardTable.RowMap
 
remove(Object) - Method in class com.google.common.collect.Synchronized.SynchronizedAsMapEntries
 
remove(Object) - Method in class com.google.common.collect.Synchronized.SynchronizedCollection
 
remove(int) - Method in class com.google.common.collect.Synchronized.SynchronizedList
 
remove(Object) - Method in class com.google.common.collect.Synchronized.SynchronizedMap
 
remove(Object, Object) - Method in class com.google.common.collect.Synchronized.SynchronizedMultimap
 
remove(Object, int) - Method in class com.google.common.collect.Synchronized.SynchronizedMultiset
 
remove() - Method in class com.google.common.collect.Synchronized.SynchronizedQueue
 
remove(Object, Object) - Method in interface com.google.common.collect.Table
Removes the mapping, if any, associated with the given keys.
remove(Object, Object) - Method in class com.google.common.collect.Tables.TransformedTable
 
remove(Object, Object) - Method in class com.google.common.collect.Tables.TransposeTable
 
remove(Object, Object) - Method in class com.google.common.collect.Tables.UnmodifiableTable
 
remove() - Method in class com.google.common.collect.TransformedIterator
 
remove(Comparator<? super E>, E, int, int[]) - Method in class com.google.common.collect.TreeMultiset.AvlNode
 
remove(Object, int) - Method in class com.google.common.collect.TreeMultiset
 
remove(Range<K>) - Method in class com.google.common.collect.TreeRangeMap
 
remove(Range<K>) - Method in class com.google.common.collect.TreeRangeMap.SubRangeMap
 
remove(Object) - Method in class com.google.common.collect.TreeRangeMap.SubRangeMap.SubRangeMapAsMap
 
remove(Range<C>) - Method in class com.google.common.collect.TreeRangeSet.Complement
 
remove(Range<C>) - Method in class com.google.common.collect.TreeRangeSet
 
remove(Range<C>) - Method in class com.google.common.collect.TreeRangeSet.SubRangeSet
 
remove() - Method in class com.google.common.collect.UnmodifiableIterator
Deprecated.
Unsupported operation.
remove(K) - Method in class com.google.common.util.concurrent.AtomicLongMap
Removes and returns the value associated with key.
remove(K, long) - Method in class com.google.common.util.concurrent.AtomicLongMap
If (key, value) is currently in the map, this method removes it and returns true; otherwise, this method returns false.
removeAll(Collection<?>) - Method in class com.google.common.collect.AbstractBiMap.EntrySet
 
removeAll(Collection<?>) - Method in class com.google.common.collect.AbstractBiMap.KeySet
 
removeAll(Object) - Method in class com.google.common.collect.AbstractListMultimap
Removes all values associated with the key key.
removeAll(Object) - Method in class com.google.common.collect.AbstractMapBasedMultimap
Removes all values associated with the key key.
removeAll(Collection<?>) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection
 
removeAll(Collection<?>) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedSet
 
removeAll(Collection<?>) - Method in class com.google.common.collect.AbstractMultiset
 
removeAll(RangeSet<C>) - Method in class com.google.common.collect.AbstractRangeSet
 
removeAll(Object) - Method in class com.google.common.collect.AbstractSetMultimap
Removes all values associated with the key key.
removeAll(Object) - Method in class com.google.common.collect.AbstractSortedSetMultimap
Removes all values associated with a given key.
removeAll(Collection<?>) - Method in class com.google.common.collect.Collections2.FilteredCollection
 
removeAll(Object) - Method in class com.google.common.collect.FilteredEntryMultimap
 
removeAll(Object) - Method in class com.google.common.collect.FilteredEntrySetMultimap
 
removeAll(Object) - Method in class com.google.common.collect.FilteredKeyListMultimap
 
removeAll(Object) - Method in class com.google.common.collect.FilteredKeyMultimap
 
removeAll(Object) - Method in class com.google.common.collect.FilteredKeySetMultimap
 
removeAll(Collection<?>) - Method in class com.google.common.collect.FilteredMultimapValues
 
removeAll(Collection<?>) - Method in class com.google.common.collect.ForwardingCollection
 
removeAll(Object) - Method in class com.google.common.collect.ForwardingListMultimap
 
removeAll(Object) - Method in class com.google.common.collect.ForwardingMultimap
 
removeAll(Object) - Method in class com.google.common.collect.ForwardingSetMultimap
 
removeAll(Object) - Method in class com.google.common.collect.ForwardingSortedSetMultimap
 
removeAll(Collection<?>) - Method in class com.google.common.collect.ImmutableCollection
Deprecated.
Unsupported operation.
removeAll(Object) - Method in class com.google.common.collect.ImmutableListMultimap
Deprecated.
Unsupported operation.
removeAll(Object) - Method in class com.google.common.collect.ImmutableMultimap
Deprecated.
Unsupported operation.
removeAll(RangeSet<C>) - Method in class com.google.common.collect.ImmutableRangeSet
 
removeAll(Object) - Method in class com.google.common.collect.ImmutableSetMultimap
Deprecated.
Unsupported operation.
removeAll(Iterable<?>, Collection<?>) - Static method in class com.google.common.collect.Iterables
Removes, from an iterable, every element that belongs to the provided collection.
removeAll(Iterator<?>, Collection<?>) - Static method in class com.google.common.collect.Iterators
Traverses an iterator and removes every element that belongs to the provided collection.
removeAll(Object) - Method in class com.google.common.collect.LinkedListMultimap
Removes all values associated with the key key.
removeAll(Object) - Method in interface com.google.common.collect.ListMultimap
Removes all values associated with the key key.
removeAll(Collection<?>) - Method in class com.google.common.collect.MapConstraints.ConstrainedAsMapEntries
 
removeAll(Collection<?>) - Method in class com.google.common.collect.MapConstraints.ConstrainedAsMapValues
 
removeAll(Collection<?>) - Method in class com.google.common.collect.MapConstraints.ConstrainedEntries
 
removeAll(Object) - Method in class com.google.common.collect.MapConstraints.ConstrainedListMultimap
 
removeAll(Object) - Method in class com.google.common.collect.MapConstraints.ConstrainedSetMultimap
 
removeAll(Object) - Method in class com.google.common.collect.MapConstraints.ConstrainedSortedSetMultimap
 
removeAll(Collection<?>) - Method in class com.google.common.collect.Maps.EntrySet
 
removeAll(Collection<?>) - Method in class com.google.common.collect.Maps.FilteredEntryMap.KeySet
 
removeAll(Collection<?>) - Method in class com.google.common.collect.Maps.FilteredMapValues
 
removeAll(Collection<?>) - Method in class com.google.common.collect.Maps.Values
 
removeAll(Object) - Method in interface com.google.common.collect.Multimap
Removes all values associated with the key key.
removeAll(Object) - Method in class com.google.common.collect.Multimaps.MapMultimap
 
removeAll(Object) - Method in class com.google.common.collect.Multimaps.TransformedEntriesListMultimap
 
removeAll(Object) - Method in class com.google.common.collect.Multimaps.TransformedEntriesMultimap
 
removeAll(Object) - Method in class com.google.common.collect.Multimaps.UnmodifiableListMultimap
 
removeAll(Object) - Method in class com.google.common.collect.Multimaps.UnmodifiableMultimap
 
removeAll(Object) - Method in class com.google.common.collect.Multimaps.UnmodifiableSetMultimap
 
removeAll(Object) - Method in class com.google.common.collect.Multimaps.UnmodifiableSortedSetMultimap
 
removeAll(Collection<?>) - Method in interface com.google.common.collect.Multiset
removeAll(Collection<?>) - Method in class com.google.common.collect.Multisets.UnmodifiableMultiset
 
removeAll(RangeSet<C>) - Method in interface com.google.common.collect.RangeSet
Removes all of the ranges from the specified range set from this range set (optional operation).
removeAll(Object) - Method in interface com.google.common.collect.SetMultimap
Removes all values associated with the key key.
removeAll(Collection<?>) - Method in class com.google.common.collect.Sets.ImprovedAbstractSet
 
removeAll(Object) - Method in interface com.google.common.collect.SortedSetMultimap
Removes all values associated with a given key.
removeAll(Collection<?>) - Method in class com.google.common.collect.StandardTable.Column.Values
 
removeAll(Collection<?>) - Method in class com.google.common.collect.StandardTable.ColumnKeySet
 
removeAll(Collection<?>) - Method in class com.google.common.collect.StandardTable.ColumnMap.ColumnMapEntrySet
 
removeAll(Collection<?>) - Method in class com.google.common.collect.StandardTable.ColumnMap.ColumnMapValues
 
removeAll(Collection<?>) - Method in class com.google.common.collect.Synchronized.SynchronizedAsMapEntries
 
removeAll(Collection<?>) - Method in class com.google.common.collect.Synchronized.SynchronizedCollection
 
removeAll(Object) - Method in class com.google.common.collect.Synchronized.SynchronizedListMultimap
 
removeAll(Object) - Method in class com.google.common.collect.Synchronized.SynchronizedMultimap
 
removeAll(Object) - Method in class com.google.common.collect.Synchronized.SynchronizedSetMultimap
 
removeAll(Object) - Method in class com.google.common.collect.Synchronized.SynchronizedSortedSetMultimap
 
removeAllImpl(Multiset<?>, Collection<?>) - Static method in class com.google.common.collect.Multisets
removeAllImpl(Set<?>, Iterator<?>) - Static method in class com.google.common.collect.Sets
Remove each element in an iterable from a set.
removeAllImpl(Set<?>, Collection<?>) - Static method in class com.google.common.collect.Sets
 
removeAllNodes(Object) - Method in class com.google.common.collect.LinkedListMultimap
Removes all nodes for the specified key.
removeAllZeros() - Method in class com.google.common.util.concurrent.AtomicLongMap
Removes all mappings from this map whose values are zero.
removeAndGet(int) - Method in class com.google.common.collect.MinMaxPriorityQueue
Removes and returns the value at index.
removeAt(int) - Method in class com.google.common.collect.MinMaxPriorityQueue
Removes the element at position index.
removeCollectedEntry(LocalCache.ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.Segment
 
removeCollectedEntry(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
 
removeColumn(Object) - Method in class com.google.common.collect.StandardTable
 
removeEntriesIf(Predicate<? super Map.Entry<K, Collection<V>>>) - Method in class com.google.common.collect.FilteredEntryMultimap
 
removeEntry(LocalCache.ReferenceEntry<K, V>, int, RemovalCause) - Method in class com.google.common.cache.LocalCache.Segment
 
removeEntry(MapMakerInternalMap.ReferenceEntry<K, V>, int, MapMaker.RemovalCause) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
 
removeEntryFromChain(LocalCache.ReferenceEntry<K, V>, LocalCache.ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.Segment
 
removeEntryIf(Predicate<? super Map.Entry<Range<K>, V>>) - Method in class com.google.common.collect.TreeRangeMap.SubRangeMap.SubRangeMapAsMap
 
removeEntryImpl(Collection<Map.Entry<K, V>>, Object) - Static method in class com.google.common.collect.Maps
Implements Collection.remove safely for forwarding collections of map entries.
removeExact(Object) - Method in class com.google.common.collect.MinMaxPriorityQueue.QueueIterator
 
removeExactly(Object, int) - Method in class com.google.common.collect.ConcurrentHashMultiset
Removes exactly the specified number of occurrences of element, or makes no change if this is not possible.
removeFirst() - Method in class com.google.common.collect.ForwardingDeque
 
removeFirst() - Method in class com.google.common.collect.MinMaxPriorityQueue
Removes and returns the least element of this queue.
removeFirst() - Method in class com.google.common.collect.Synchronized.SynchronizedDeque
 
removeFirstMatching(Iterable<T>, Predicate<? super T>) - Static method in class com.google.common.collect.Iterables
Removes and returns the first matching element, or returns null if there is none.
removeFirstOccurrence(Object) - Method in class com.google.common.collect.ForwardingDeque
 
removeFirstOccurrence(Object) - Method in class com.google.common.collect.Synchronized.SynchronizedDeque
 
removeFrom(CharSequence) - Method in class com.google.common.base.CharMatcher
Returns a string containing all non-matching characters of a character sequence, in order.
removeFromBothMaps(Object) - Method in class com.google.common.collect.AbstractBiMap
 
removeFromChain(MapMakerInternalMap.ReferenceEntry<K, V>, MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Removes an entry from within a table.
removeFromColumnIf(Predicate<? super Map.Entry<R, V>>) - Method in class com.google.common.collect.StandardTable.Column
Removes all Column mappings whose row key and value satisfy the given predicate.
removeFromInverseMap(V) - Method in class com.google.common.collect.AbstractBiMap
 
removeIf(Iterable<T>, Predicate<? super T>) - Static method in class com.google.common.collect.Iterables
Removes, from an iterable, every element that satisfies the provided predicate.
removeIf(Iterator<T>, Predicate<? super T>) - Static method in class com.google.common.collect.Iterators
Removes every element that satisfies the provided predicate from the iterator.
removeIf(Predicate<? super K>) - Method in class com.google.common.collect.Maps.FilteredEntryMap.KeySet
 
removeIf(Predicate<? super V>) - Method in class com.google.common.collect.Maps.FilteredMapValues
 
removeIfEmpty() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection
If collection is empty, remove it from AbstractMapBasedMultimap.this.map.
removeIfFromRandomAccessList(List<T>, Predicate<? super T>) - Static method in class com.google.common.collect.Iterables
 
removeLast() - Method in class com.google.common.collect.ForwardingDeque
 
removeLast() - Method in class com.google.common.collect.MinMaxPriorityQueue
Removes and returns the greatest element of this queue.
removeLast() - Method in class com.google.common.collect.Synchronized.SynchronizedDeque
 
removeLastOccurrence(Object) - Method in class com.google.common.collect.ForwardingDeque
 
removeLastOccurrence(Object) - Method in class com.google.common.collect.Synchronized.SynchronizedDeque
 
removeLoadingValue(K, int, LocalCache.LoadingValueReference<K, V>) - Method in class com.google.common.cache.LocalCache.Segment
 
removeMapping(Object, Object, Object) - Method in class com.google.common.collect.StandardTable
Remove a row key / column key / value mapping, if present.
removeMax(TreeMultiset.AvlNode<E>) - Method in class com.google.common.collect.TreeMultiset.AvlNode
 
removeMin(TreeMultiset.AvlNode<E>) - Method in class com.google.common.collect.TreeMultiset.AvlNode
 
removeNode(LinkedListMultimap.Node<K, V>) - Method in class com.google.common.collect.LinkedListMultimap
Removes the specified node from the linked list.
removeOccurrences(Multiset<?>, Iterable<?>) - Static method in class com.google.common.collect.Multisets
For each occurrence of an element e in occurrencesToRemove, removes one occurrence of e in multisetToModify.
removeOccurrencesImpl(Multiset<?>, Iterable<?>) - Static method in class com.google.common.collect.Multisets
 
removeOccurrencesImpl(Multiset<E>, Multiset<?>) - Static method in class com.google.common.collect.Multisets
Delegate that cares about the element types in multisetToModify.
removeOnlyNavigableSet(NavigableSet<E>) - Static method in class com.google.common.collect.Maps
 
removeOnlySet(Set<E>) - Static method in class com.google.common.collect.Maps
 
removeOnlySortedSet(SortedSet<E>) - Static method in class com.google.common.collect.Maps
 
removeRange(int, int) - Method in class com.google.common.collect.Lists.ReverseList
 
removeValueFromChain(LocalCache.ReferenceEntry<K, V>, LocalCache.ReferenceEntry<K, V>, K, int, LocalCache.ValueReference<K, V>, RemovalCause) - Method in class com.google.common.cache.LocalCache.Segment
 
removeValuesForKey(Object) - Method in class com.google.common.collect.AbstractMapBasedMultimap
Removes all values for the provided key.
removeValuesForKey(Object) - Method in class com.google.common.collect.Multimaps.AsMap
 
renamingDecorator(Executor, Supplier<String>) - Static method in class com.google.common.util.concurrent.MoreExecutors
Creates an Executor that renames the threads that its tasks run in.
renamingDecorator(ExecutorService, Supplier<String>) - Static method in class com.google.common.util.concurrent.MoreExecutors
Creates an ExecutorService that renames the threads that its tasks run in.
renamingDecorator(ScheduledExecutorService, Supplier<String>) - Static method in class com.google.common.util.concurrent.MoreExecutors
Creates a ScheduledExecutorService that renames the threads that its tasks run in.
repeat(String, int) - Static method in class com.google.common.base.Strings
Returns a string consisting of a specific number of concatenated copies of an input string.
replace(K, V, V) - Method in class com.google.common.cache.LocalCache
 
replace(K, V) - Method in class com.google.common.cache.LocalCache
 
replace(K, int, V, V) - Method in class com.google.common.cache.LocalCache.Segment
 
replace(K, int, V) - Method in class com.google.common.cache.LocalCache.Segment
 
replace(K, V) - Method in class com.google.common.collect.ForwardingConcurrentMap
 
replace(K, V, V) - Method in class com.google.common.collect.ForwardingConcurrentMap
 
replace(K, V) - Method in class com.google.common.collect.MapMaker.NullConcurrentMap
 
replace(K, V, V) - Method in class com.google.common.collect.MapMaker.NullConcurrentMap
 
replace(K, V, V) - Method in class com.google.common.collect.MapMakerInternalMap
 
replace(K, V) - Method in class com.google.common.collect.MapMakerInternalMap
 
replace(K, int, V, V) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
 
replace(K, int, V) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
 
replace(K, long, long) - Method in class com.google.common.util.concurrent.AtomicLongMap
If (key, expectedOldValue) is currently in the map, this method replaces expectedOldValue with newValue and returns true; otherwise, this method returns false.
replaced - Variable in class com.google.common.collect.MinMaxPriorityQueue.MoveDesc
 
replaceFrom(CharSequence, char) - Method in class com.google.common.base.CharMatcher
Returns a string copy of the input character sequence, with each character that matches this matcher replaced by a given replacement character.
replaceFrom(CharSequence, CharSequence) - Method in class com.google.common.base.CharMatcher
Returns a string copy of the input character sequence, with each character that matches this matcher replaced by a given replacement sequence.
replaceLength - Variable in class com.google.common.escape.CharEscaperBuilder.CharArrayDecorator
 
replacementArray - Variable in class com.google.common.escape.ArrayBasedEscaperMap
 
replacementMap - Variable in class com.google.common.escape.Escapers.Builder
 
replacements - Variable in class com.google.common.escape.ArrayBasedCharEscaper
 
replacements - Variable in class com.google.common.escape.ArrayBasedUnicodeEscaper
 
replacements - Variable in class com.google.common.escape.CharEscaperBuilder.CharArrayDecorator
 
replacementsLength - Variable in class com.google.common.escape.ArrayBasedCharEscaper
 
replacementsLength - Variable in class com.google.common.escape.ArrayBasedUnicodeEscaper
 
replaceRangeWithSameLowerBound(Range<C>) - Method in class com.google.common.collect.TreeRangeSet
 
replaceValues(K, Iterable<? extends V>) - Method in class com.google.common.collect.AbstractListMultimap
Stores a collection of values with the same key, replacing any existing values for that key.
replaceValues(K, Iterable<? extends V>) - Method in class com.google.common.collect.AbstractMapBasedMultimap
Stores a collection of values with the same key, replacing any existing values for that key.
replaceValues(K, Iterable<? extends V>) - Method in class com.google.common.collect.AbstractMultimap
 
replaceValues(K, Iterable<? extends V>) - Method in class com.google.common.collect.AbstractSetMultimap
Stores a collection of values with the same key, replacing any existing values for that key.
replaceValues(K, Iterable<? extends V>) - Method in class com.google.common.collect.AbstractSortedSetMultimap
Stores a collection of values with the same key, replacing any existing values for that key.
replaceValues(K, Iterable<? extends V>) - Method in class com.google.common.collect.FilteredEntrySetMultimap
 
replaceValues(K, Iterable<? extends V>) - Method in class com.google.common.collect.FilteredKeyListMultimap
 
replaceValues(K, Iterable<? extends V>) - Method in class com.google.common.collect.FilteredKeySetMultimap
 
replaceValues(K, Iterable<? extends V>) - Method in class com.google.common.collect.ForwardingListMultimap
 
replaceValues(K, Iterable<? extends V>) - Method in class com.google.common.collect.ForwardingMultimap
 
replaceValues(K, Iterable<? extends V>) - Method in class com.google.common.collect.ForwardingSetMultimap
 
replaceValues(K, Iterable<? extends V>) - Method in class com.google.common.collect.ForwardingSortedSetMultimap
 
replaceValues(K, Iterable<? extends V>) - Method in class com.google.common.collect.ImmutableListMultimap
Deprecated.
Unsupported operation.
replaceValues(K, Iterable<? extends V>) - Method in class com.google.common.collect.ImmutableMultimap
Deprecated.
Unsupported operation.
replaceValues(K, Iterable<? extends V>) - Method in class com.google.common.collect.ImmutableSetMultimap
Deprecated.
Unsupported operation.
replaceValues(K, Iterable<? extends V>) - Method in class com.google.common.collect.LinkedHashMultimap
Stores a collection of values with the same key, replacing any existing values for that key.
replaceValues(K, Iterable<? extends V>) - Method in class com.google.common.collect.LinkedListMultimap
Stores a collection of values with the same key, replacing any existing values for that key.
replaceValues(K, Iterable<? extends V>) - Method in interface com.google.common.collect.ListMultimap
Stores a collection of values with the same key, replacing any existing values for that key.
replaceValues(K, Iterable<? extends V>) - Method in class com.google.common.collect.MapConstraints.ConstrainedListMultimap
 
replaceValues(K, Iterable<? extends V>) - Method in class com.google.common.collect.MapConstraints.ConstrainedMultimap
 
replaceValues(K, Iterable<? extends V>) - Method in class com.google.common.collect.MapConstraints.ConstrainedSetMultimap
 
replaceValues(K, Iterable<? extends V>) - Method in class com.google.common.collect.MapConstraints.ConstrainedSortedSetMultimap
 
replaceValues(K, Iterable<? extends V>) - Method in interface com.google.common.collect.Multimap
Stores a collection of values with the same key, replacing any existing values for that key.
replaceValues(K, Iterable<? extends V>) - Method in class com.google.common.collect.Multimaps.MapMultimap
 
replaceValues(K, Iterable<? extends V2>) - Method in class com.google.common.collect.Multimaps.TransformedEntriesListMultimap
 
replaceValues(K, Iterable<? extends V2>) - Method in class com.google.common.collect.Multimaps.TransformedEntriesMultimap
 
replaceValues(K, Iterable<? extends V>) - Method in class com.google.common.collect.Multimaps.UnmodifiableListMultimap
 
replaceValues(K, Iterable<? extends V>) - Method in class com.google.common.collect.Multimaps.UnmodifiableMultimap
 
replaceValues(K, Iterable<? extends V>) - Method in class com.google.common.collect.Multimaps.UnmodifiableSetMultimap
 
replaceValues(K, Iterable<? extends V>) - Method in class com.google.common.collect.Multimaps.UnmodifiableSortedSetMultimap
 
replaceValues(K, Iterable<? extends V>) - Method in interface com.google.common.collect.SetMultimap
Stores a collection of values with the same key, replacing any existing values for that key.
replaceValues(K, Iterable<? extends V>) - Method in interface com.google.common.collect.SortedSetMultimap
Stores a collection of values with the same key, replacing any existing values for that key.
replaceValues(K, Iterable<? extends V>) - Method in class com.google.common.collect.Synchronized.SynchronizedListMultimap
 
replaceValues(K, Iterable<? extends V>) - Method in class com.google.common.collect.Synchronized.SynchronizedMultimap
 
replaceValues(K, Iterable<? extends V>) - Method in class com.google.common.collect.Synchronized.SynchronizedSetMultimap
 
replaceValues(K, Iterable<? extends V>) - Method in class com.google.common.collect.Synchronized.SynchronizedSortedSetMultimap
 
requestCount() - Method in class com.google.common.cache.CacheStats
Returns the number of times Cache lookup methods have returned either a cached or uncached value.
requireBracketsForIPv6() - Method in class com.google.common.net.HostAndPort
Generate an error if the host might be a non-bracketed IPv6 literal.
ReschedulableCallable(AbstractService, ScheduledExecutorService, Runnable) - Constructor for class com.google.common.util.concurrent.AbstractScheduledService.CustomScheduler.ReschedulableCallable
 
reschedule() - Method in class com.google.common.util.concurrent.AbstractScheduledService.CustomScheduler.ReschedulableCallable
Atomically reschedules this task and assigns the new future to AbstractScheduledService.CustomScheduler.ReschedulableCallable.currentFuture.
reserve(int) - Method in class com.google.common.util.concurrent.RateLimiter
Reserves the given number of permits from this RateLimiter for future use, returning the number of microseconds until the reservation can be consumed.
reserveAndGetWaitLength(int, long) - Method in class com.google.common.util.concurrent.RateLimiter
Reserves next ticket and returns the wait time that the caller must wait for.
reserveEarliestAvailable(int, long) - Method in class com.google.common.util.concurrent.RateLimiter
Reserves the requested number of permits and returns the time that those permits can be used (with one caveat).
reserveEarliestAvailable(int, long) - Method in class com.google.common.util.concurrent.SmoothRateLimiter
 
reset() - Method in class com.google.common.base.Stopwatch
Sets the elapsed time for this stopwatch to zero, and places it in a stopped state.
reset() - Method in class com.google.common.cache.LongAdder
Resets variables maintaining the sum to zero.
reset() - Method in class com.google.common.hash.HashingInputStream
reset() is not supported for HashingInputStream.
reset() - Method in class com.google.common.io.ByteStreams.LimitedInputStream
 
reset() - Method in class com.google.common.io.CharSequenceReader
 
reset() - Method in class com.google.common.io.CountingInputStream
 
reset() - Method in class com.google.common.io.FileBackedOutputStream
Calls FileBackedOutputStream.close() if not already closed, and then resets this object back to its initial state, for reuse.
resetOnFinalize - Variable in class com.google.common.io.FileBackedOutputStream
 
resolve(TypeVariable<?>) - Method in class com.google.common.reflect.TypeResolver.TypeTable
 
resolveGenericArrayType(GenericArrayType) - Method in class com.google.common.reflect.TypeResolver
 
resolveInPlace(Type[]) - Method in class com.google.common.reflect.TypeToken
 
resolveInternal(TypeVariable<?>, TypeResolver.TypeTable) - Method in class com.google.common.reflect.TypeResolver.TypeTable
Resolves var using the encapsulated type mapping.
resolveParameterizedType(ParameterizedType) - Method in class com.google.common.reflect.TypeResolver
 
resolveSupertype(Type) - Method in class com.google.common.reflect.TypeToken
 
resolveType(Type) - Method in class com.google.common.reflect.TypeResolver
Resolves all type variables in type and all downstream types and returns a corresponding type with type variables resolved.
resolveType(Type) - Method in class com.google.common.reflect.TypeToken
Resolves the given type against the type context represented by this type.
resolveTypeArgsForSubclass(Class<?>) - Method in class com.google.common.reflect.TypeToken
 
resolveTypes(Type[]) - Method in class com.google.common.reflect.TypeResolver
 
resolveWildcardType(WildcardType) - Method in class com.google.common.reflect.TypeResolver
 
ResourceInfo(String, ClassLoader) - Constructor for class com.google.common.reflect.ClassPath.ResourceInfo
 
resourceName - Variable in class com.google.common.reflect.ClassPath.ResourceInfo
 
Resources - Class in com.google.common.io
Provides utility methods for working with resources in the classpath.
Resources() - Constructor for class com.google.common.io.Resources
 
resources - Variable in class com.google.common.reflect.ClassPath
 
resources - Variable in class com.google.common.reflect.ClassPath.Scanner
 
Resources.UrlByteSource - Class in com.google.common.io
A byte source that reads from a URL using URL.openStream().
rest - Variable in class com.google.common.collect.Lists.OnePlusArrayList
 
rest - Variable in class com.google.common.collect.Lists.TwoPlusArrayList
 
restriction - Variable in class com.google.common.collect.TreeRangeSet.SubRangeSet
 
restriction - Variable in class com.google.common.collect.TreeRangeSet.SubRangeSetRangesByLowerBound
restriction is the subRangeSet view; ranges are truncated to their intersection with restriction.
result - Variable in class com.google.common.collect.ComparisonChain.InactiveComparisonChain
 
result() - Method in class com.google.common.collect.ComparisonChain.InactiveComparisonChain
 
result() - Method in class com.google.common.collect.ComparisonChain
Ends this comparison chain and returns its result: a value having the same sign as the first nonzero comparison result in the chain, or zero if every result was zero.
resultEquivalence - Variable in class com.google.common.base.FunctionalEquivalence
 
resultIndex(int) - Method in enum com.google.common.collect.SortedLists.KeyAbsentBehavior
 
resultIndex(Comparator<? super E>, E, List<? extends E>, int) - Method in enum com.google.common.collect.SortedLists.KeyPresentBehavior
 
resync(long) - Method in class com.google.common.util.concurrent.SmoothRateLimiter
 
retainAll(Collection<?>) - Method in class com.google.common.collect.AbstractBiMap.EntrySet
 
retainAll(Collection<?>) - Method in class com.google.common.collect.AbstractBiMap.KeySet
 
retainAll(Collection<?>) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection
 
retainAll(Collection<?>) - Method in class com.google.common.collect.AbstractMultiset
 
retainAll(Collection<?>) - Method in class com.google.common.collect.Collections2.FilteredCollection
 
retainAll(Collection<?>) - Method in class com.google.common.collect.FilteredMultimapValues
 
retainAll(Collection<?>) - Method in class com.google.common.collect.ForwardingCollection
 
retainAll(Collection<?>) - Method in class com.google.common.collect.ImmutableCollection
Deprecated.
Unsupported operation.
retainAll(Iterable<?>, Collection<?>) - Static method in class com.google.common.collect.Iterables
Removes, from an iterable, every element that does not belong to the provided collection.
retainAll(Iterator<?>, Collection<?>) - Static method in class com.google.common.collect.Iterators
Traverses an iterator and removes every element that does not belong to the provided collection.
retainAll(Collection<?>) - Method in class com.google.common.collect.MapConstraints.ConstrainedAsMapEntries
 
retainAll(Collection<?>) - Method in class com.google.common.collect.MapConstraints.ConstrainedAsMapValues
 
retainAll(Collection<?>) - Method in class com.google.common.collect.MapConstraints.ConstrainedEntries
 
retainAll(Collection<?>) - Method in class com.google.common.collect.Maps.EntrySet
 
retainAll(Collection<?>) - Method in class com.google.common.collect.Maps.FilteredEntryMap.KeySet
 
retainAll(Collection<?>) - Method in class com.google.common.collect.Maps.FilteredMapValues
 
retainAll(Collection<?>) - Method in class com.google.common.collect.Maps.Values
 
retainAll(Collection<?>) - Method in interface com.google.common.collect.Multiset
retainAll(Collection<?>) - Method in class com.google.common.collect.Multisets.UnmodifiableMultiset
 
retainAll(Collection<?>) - Method in class com.google.common.collect.Sets.ImprovedAbstractSet
 
retainAll(Collection<?>) - Method in class com.google.common.collect.StandardTable.Column.EntrySet
 
retainAll(Collection<?>) - Method in class com.google.common.collect.StandardTable.Column.KeySet
 
retainAll(Collection<?>) - Method in class com.google.common.collect.StandardTable.Column.Values
 
retainAll(Collection<?>) - Method in class com.google.common.collect.StandardTable.ColumnKeySet
 
retainAll(Collection<?>) - Method in class com.google.common.collect.StandardTable.ColumnMap.ColumnMapEntrySet
 
retainAll(Collection<?>) - Method in class com.google.common.collect.StandardTable.ColumnMap.ColumnMapValues
 
retainAll(Collection<?>) - Method in class com.google.common.collect.Synchronized.SynchronizedAsMapEntries
 
retainAll(Collection<?>) - Method in class com.google.common.collect.Synchronized.SynchronizedCollection
 
retainAllImpl(Multiset<?>, Collection<?>) - Static method in class com.google.common.collect.Multisets
retainFrom(CharSequence) - Method in class com.google.common.base.CharMatcher
Returns a string containing all matching characters of a character sequence, in order.
retainOccurrences(Multiset<?>, Multiset<?>) - Static method in class com.google.common.collect.Multisets
Modifies multisetToModify so that its count for an element e is at most multisetToRetain.count(e).
retainOccurrencesImpl(Multiset<E>, Multiset<?>) - Static method in class com.google.common.collect.Multisets
Delegate implementation which cares about the element type.
rethrow(Throwable) - Method in class com.google.common.io.Closer
Stores the given throwable and rethrows it.
rethrow(Throwable, Class<X>) - Method in class com.google.common.io.Closer
Stores the given throwable and rethrows it.
rethrow(Throwable, Class<X1>, Class<X2>) - Method in class com.google.common.io.Closer
Stores the given throwable and rethrows it.
RETRY_AFTER - Static variable in class com.google.common.net.HttpHeaders
The HTTP Retry-After header field name.
retryUpdate(long, int[], boolean) - Method in class com.google.common.cache.Striped64
Handles cases of updates involving initialization, resizing, creating new Cells, and/or contention.
returning(Class<R1>) - Method in class com.google.common.reflect.Invokable
Explicitly specifies the return type of this Invokable.
returning(TypeToken<R1>) - Method in class com.google.common.reflect.Invokable
Explicitly specifies the return type of this Invokable.
returning(T) - Static method in class com.google.common.util.concurrent.Callables
Creates a Callable which immediately returns a preset value each time it is called.
reverse() - Method in class com.google.common.base.Converter.IdentityConverter
 
reverse - Variable in class com.google.common.base.Converter
 
reverse() - Method in class com.google.common.base.Converter
Returns the reversed view of this converter, which converts this.convert(a) back to a value roughly equivalent to a.
reverse() - Method in class com.google.common.base.Converter.ReverseConverter
 
reverse() - Method in class com.google.common.collect.AllEqualOrdering
 
reverse - Variable in class com.google.common.collect.GeneralRange
 
reverse() - Method in class com.google.common.collect.GeneralRange
Returns the same range relative to the reversed comparator.
reverse() - Method in class com.google.common.collect.ImmutableList
Returns a view of this immutable list in reverse order.
reverse() - Method in class com.google.common.collect.ImmutableList.ReverseImmutableList
 
reverse(List<T>) - Static method in class com.google.common.collect.Lists
Returns a reversed view of the specified list.
reverse(Comparator<T>) - Static method in class com.google.common.collect.Maps.DescendingMap
 
reverse() - Method in class com.google.common.collect.NaturalOrdering
 
reverse() - Method in class com.google.common.collect.NullsFirstOrdering
 
reverse() - Method in class com.google.common.collect.NullsLastOrdering
 
reverse() - Method in class com.google.common.collect.Ordering
Returns the reverse of this ordering; the Ordering equivalent to Collections.reverseOrder(Comparator).
reverse() - Method in class com.google.common.collect.ReverseNaturalOrdering
 
reverse() - Method in class com.google.common.collect.ReverseOrdering
 
reverse(Comparator<T>) - Static method in class com.google.common.collect.Sets.DescendingSet
 
reverse() - Method in class com.google.common.collect.SingletonImmutableList
 
reverse(CharSequence) - Static method in class com.google.thirdparty.publicsuffix.TrieParser
Reverses a character sequence.
ReverseConverter(Converter<A, B>) - Constructor for class com.google.common.base.Converter.ReverseConverter
 
ReverseImmutableList(ImmutableList<E>) - Constructor for class com.google.common.collect.ImmutableList.ReverseImmutableList
 
reverseIndex(int) - Method in class com.google.common.collect.ImmutableList.ReverseImmutableList
 
reverseIndex(int) - Method in class com.google.common.collect.Lists.ReverseList
 
ReverseList(List<T>) - Constructor for class com.google.common.collect.Lists.ReverseList
 
ReverseNaturalOrdering - Class in com.google.common.collect
An ordering that uses the reverse of the natural order of the values.
ReverseNaturalOrdering() - Constructor for class com.google.common.collect.ReverseNaturalOrdering
 
reverseOrder() - Static method in class com.google.common.collect.ImmutableSortedMap
Returns a builder that creates immutable sorted maps whose keys are ordered by the reverse of their natural ordering.
reverseOrder() - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns a builder that creates immutable sorted multisets whose elements are ordered by the reverse of their natural ordering.
reverseOrder() - Static method in class com.google.common.collect.ImmutableSortedSet
Returns a builder that creates immutable sorted sets whose elements are ordered by the reverse of their natural ordering.
ReverseOrdering<T> - Class in com.google.common.collect
An ordering that uses the reverse of a given order.
ReverseOrdering(Ordering<? super T>) - Constructor for class com.google.common.collect.ReverseOrdering
 
reversePosition(int) - Method in class com.google.common.collect.ImmutableList.ReverseImmutableList
 
reversePosition(int) - Method in class com.google.common.collect.Lists.ReverseList
 
right - Variable in class com.google.common.collect.Maps.ValueDifferenceImpl
 
right - Variable in class com.google.common.collect.TreeMultiset.AvlNode
 
RIGHT_IS_GREATER - Static variable in class com.google.common.collect.Ordering
 
rightChild(T) - Method in class com.google.common.collect.BinaryTreeTraverser
Returns the right child of the specified node, or Optional.absent() if the specified node has no right child.
rightValue() - Method in interface com.google.common.collect.MapDifference.ValueDifference
Returns the value from the right map (possibly null).
rightValue() - Method in class com.google.common.collect.Maps.ValueDifferenceImpl
 
rng - Static variable in class com.google.common.cache.Striped64
Generator of new random hash codes
root - Variable in class com.google.common.collect.TreeTraverser.PostOrderNode
 
rootReference - Variable in class com.google.common.collect.TreeMultiset
 
rotateLeft() - Method in class com.google.common.collect.TreeMultiset.AvlNode
 
rotateRight() - Method in class com.google.common.collect.TreeMultiset.AvlNode
 
roundIntermediate(double, RoundingMode) - Static method in class com.google.common.math.DoubleMath
 
roundToBigInteger(double, RoundingMode) - Static method in class com.google.common.math.DoubleMath
Returns the BigInteger value that is equal to x rounded with the specified rounding mode, if possible.
roundToInt(double, RoundingMode) - Static method in class com.google.common.math.DoubleMath
Returns the int value that is equal to x rounded with the specified rounding mode, if possible.
roundToLong(double, RoundingMode) - Static method in class com.google.common.math.DoubleMath
Returns the long value that is equal to x rounded with the specified rounding mode, if possible.
row(R) - Method in class com.google.common.collect.ArrayTable
Returns a view of all mappings that have the given row key.
Row(int) - Constructor for class com.google.common.collect.ArrayTable.Row
 
Row(int) - Constructor for class com.google.common.collect.DenseImmutableTable.Row
 
row(R) - Method in class com.google.common.collect.ForwardingTable
 
row(R) - Method in class com.google.common.collect.ImmutableTable
Returns a view of all mappings that have the given row key.
row(R) - Method in class com.google.common.collect.StandardTable
 
Row(R) - Constructor for class com.google.common.collect.StandardTable.Row
 
row(R) - Method in interface com.google.common.collect.Table
Returns a view of all mappings that have the given row key.
row(R) - Method in class com.google.common.collect.Tables.TransformedTable
 
row(C) - Method in class com.google.common.collect.Tables.TransposeTable
 
row(R) - Method in class com.google.common.collect.Tables.UnmodifiableTable
 
row(R) - Method in class com.google.common.collect.TreeBasedTable
Returns a view of all mappings that have the given row key.
rowComparator - Variable in class com.google.common.collect.ImmutableTable.Builder
 
rowComparator() - Method in class com.google.common.collect.TreeBasedTable
Returns the comparator that orders the rows.
rowCounts - Variable in class com.google.common.collect.DenseImmutableTable
 
rowEntry - Variable in class com.google.common.collect.StandardTable.CellIterator
 
RowEntrySet() - Constructor for class com.google.common.collect.StandardTable.Row.RowEntrySet
 
rowIndex - Variable in class com.google.common.collect.ArrayTable.Row
 
rowIndex - Variable in class com.google.common.collect.DenseImmutableTable.Row
 
rowIterator - Variable in class com.google.common.collect.StandardTable.CellIterator
 
rowKey - Variable in class com.google.common.collect.StandardTable.Row
 
rowKey - Variable in class com.google.common.collect.Tables.ImmutableCell
 
rowKeyList() - Method in class com.google.common.collect.ArrayTable
Returns, as an immutable list, the row keys provided when the table was constructed, including those that are mapped to null values only.
rowKeySet() - Method in class com.google.common.collect.AbstractTable
 
rowKeySet() - Method in class com.google.common.collect.ArrayTable
Returns an immutable set of the valid row keys, including those that are associated with null values only.
rowKeySet() - Method in class com.google.common.collect.ForwardingTable
 
rowKeySet() - Method in class com.google.common.collect.ImmutableTable
 
rowKeySet() - Method in interface com.google.common.collect.RowSortedTable
Returns a set of row keys that have one or more values in the table.
rowKeySet() - Method in class com.google.common.collect.StandardRowSortedTable
Returns a set of row keys that have one or more values in the table.
rowKeySet() - Method in class com.google.common.collect.StandardTable
 
rowKeySet() - Method in interface com.google.common.collect.Table
Returns a set of row keys that have one or more values in the table.
rowKeySet() - Method in class com.google.common.collect.Tables.TransformedTable
 
rowKeySet() - Method in class com.google.common.collect.Tables.TransposeTable
 
rowKeySet() - Method in class com.google.common.collect.Tables.UnmodifiableRowSortedMap
 
rowKeySet() - Method in class com.google.common.collect.Tables.UnmodifiableTable
 
rowKeySet() - Method in class com.google.common.collect.TreeBasedTable
 
rowKeyToIndex - Variable in class com.google.common.collect.ArrayTable
 
rowKeyToIndex - Variable in class com.google.common.collect.DenseImmutableTable
 
rowList - Variable in class com.google.common.collect.ArrayTable
 
rowMap - Variable in class com.google.common.collect.ArrayTable
 
rowMap() - Method in class com.google.common.collect.ArrayTable
 
RowMap() - Constructor for class com.google.common.collect.ArrayTable.RowMap
 
rowMap - Variable in class com.google.common.collect.DenseImmutableTable
 
rowMap() - Method in class com.google.common.collect.DenseImmutableTable
 
RowMap() - Constructor for class com.google.common.collect.DenseImmutableTable.RowMap
 
rowMap() - Method in class com.google.common.collect.ForwardingTable
 
rowMap() - Method in class com.google.common.collect.ImmutableTable
Returns a view that associates each row key with the corresponding map from column keys to values.
rowMap() - Method in interface com.google.common.collect.RowSortedTable
Returns a view that associates each row key with the corresponding map from column keys to values.
rowMap() - Method in class com.google.common.collect.SingletonImmutableTable
 
rowMap - Variable in class com.google.common.collect.SparseImmutableTable
 
rowMap() - Method in class com.google.common.collect.SparseImmutableTable
 
rowMap() - Method in class com.google.common.collect.StandardRowSortedTable
Returns a view that associates each row key with the corresponding map from column keys to values.
rowMap - Variable in class com.google.common.collect.StandardTable
 
rowMap() - Method in class com.google.common.collect.StandardTable
 
RowMap() - Constructor for class com.google.common.collect.StandardTable.RowMap
 
rowMap() - Method in interface com.google.common.collect.Table
Returns a view that associates each row key with the corresponding map from column keys to values.
rowMap() - Method in class com.google.common.collect.Tables.TransformedTable
 
rowMap() - Method in class com.google.common.collect.Tables.TransposeTable
 
rowMap() - Method in class com.google.common.collect.Tables.UnmodifiableRowSortedMap
 
rowMap() - Method in class com.google.common.collect.Tables.UnmodifiableTable
 
rowMap() - Method in class com.google.common.collect.TreeBasedTable
 
RowSortedMap() - Constructor for class com.google.common.collect.StandardRowSortedTable.RowSortedMap
 
RowSortedTable<R,C,V> - Interface in com.google.common.collect
Interface that extends Table and whose rows are sorted.
RS - Static variable in class com.google.common.base.Ascii
Record Separator: These four information separators may be used within data in optional fashion, except that their hierarchical relationship shall be: FS is the most inclusive, then GS, then RS, and US is least inclusive.
RTF_UTF_8 - Static variable in class com.google.common.net.MediaType
 
run() - Method in class com.google.common.base.internal.Finalizer
Loops continuously, pulling references off the queue and cleaning them up.
run() - Method in class com.google.common.collect.MapMakerInternalMap.CleanupMapTask
 
run() - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
Run the service.
run() - Method in class com.google.common.util.concurrent.Futures.ChainingListenableFuture
 
run() - Method in class com.google.common.util.concurrent.ListenerCallQueue
 
run() - Method in class com.google.common.util.concurrent.MoreExecutors.ScheduledListeningDecorator.NeverSuccessfulListenableFutureTask
 
run() - Method in class com.google.common.util.concurrent.SerializingExecutor.TaskRunner
 
runCleanup() - Method in class com.google.common.collect.MapMakerInternalMap.Segment
 
runLockedCleanup(long) - Method in class com.google.common.cache.LocalCache.Segment
 
runLockedCleanup() - Method in class com.google.common.collect.MapMakerInternalMap.Segment
 
runnable - Variable in class com.google.common.util.concurrent.ExecutionList.RunnableExecutorPair
 
RunnableExecutorPair(Runnable, Executor, ExecutionList.RunnableExecutorPair) - Constructor for class com.google.common.util.concurrent.ExecutionList.RunnableExecutorPair
 
runnables - Variable in class com.google.common.util.concurrent.ExecutionList
The runnable, executor pairs to execute.
Runnables - Class in com.google.common.util.concurrent
Static utility methods pertaining to the Runnable interface.
Runnables() - Constructor for class com.google.common.util.concurrent.Runnables
 
RUNNING - Static variable in class com.google.common.util.concurrent.AbstractFuture.Sync
 
running() - Method in class com.google.common.util.concurrent.AbstractService
 
running - Variable in class com.google.common.util.concurrent.Futures.FallbackFuture
 
running() - Method in class com.google.common.util.concurrent.Service.Listener
Called when the service transitions from STARTING to RUNNING.
running() - Method in class com.google.common.util.concurrent.ServiceManager.ServiceListener
 
RUNNING_CALLBACK - Static variable in class com.google.common.util.concurrent.AbstractService
 
runningTasks - Variable in class com.google.common.util.concurrent.MoreExecutors.DirectExecutorService
 
runOneIteration() - Method in class com.google.common.util.concurrent.AbstractScheduledService
Run one iteration of the scheduled task.
runtime - Variable in class com.google.common.util.concurrent.UncaughtExceptionHandlers.Exiter
 
runtimeType - Variable in class com.google.common.reflect.TypeToken
 
runUnlockedCleanup() - Method in class com.google.common.cache.LocalCache.Segment
 
runUnlockedCleanup() - Method in class com.google.common.collect.MapMakerInternalMap.Segment
 

S

safeContains(Collection<?>, Object) - Static method in class com.google.common.collect.Collections2
Delegates to Collection.contains(java.lang.Object).
safeContainsKey(Map<?, ?>, Object) - Static method in class com.google.common.collect.Maps
Delegates to Map.containsKey(java.lang.Object).
safeGet(Map<?, V>, Object) - Static method in class com.google.common.collect.Maps
Delegates to Map.get(java.lang.Object).
safeMax - Variable in class com.google.common.escape.ArrayBasedCharEscaper
 
safeMax - Variable in class com.google.common.escape.ArrayBasedUnicodeEscaper
 
safeMax - Variable in class com.google.common.escape.Escapers.Builder
 
safeMaxChar - Variable in class com.google.common.escape.ArrayBasedUnicodeEscaper
 
safeMin - Variable in class com.google.common.escape.ArrayBasedCharEscaper
 
safeMin - Variable in class com.google.common.escape.ArrayBasedUnicodeEscaper
 
safeMin - Variable in class com.google.common.escape.Escapers.Builder
 
safeMinChar - Variable in class com.google.common.escape.ArrayBasedUnicodeEscaper
 
safeOctets - Variable in class com.google.common.net.PercentEscaper
An array of flags where for any char c if safeOctets[c] is true then c should remain unmodified in the output.
safeRemove(Collection<?>, Object) - Static method in class com.google.common.collect.Collections2
Delegates to Collection.remove(java.lang.Object).
safeRemove(Map<?, V>, Object) - Static method in class com.google.common.collect.Maps
Delegates to Map.remove(java.lang.Object).
sameThreadExecutor() - Static method in class com.google.common.util.concurrent.MoreExecutors
Deprecated.
satisfies(K, V) - Method in class com.google.common.collect.FilteredEntryMultimap
 
saturatedCast(long) - Static method in class com.google.common.primitives.Chars
Returns the char nearest in value to value.
saturatedCast(long) - Static method in class com.google.common.primitives.Ints
Returns the int nearest in value to value.
saturatedCast(long) - Static method in class com.google.common.primitives.Shorts
Returns the short nearest in value to value.
saturatedCast(long) - Static method in class com.google.common.primitives.SignedBytes
Returns the byte nearest in value to value.
saturatedCast(long) - Static method in class com.google.common.primitives.UnsignedBytes
Returns the byte value that, when treated as unsigned, is nearest in value to value.
sawReturn - Variable in class com.google.common.io.LineBuffer
Whether a line ending with a CR is pending processing.
scaleNormalize(double) - Static method in class com.google.common.math.DoubleUtils
 
scan(URI, ClassLoader) - Method in class com.google.common.reflect.ClassPath.Scanner
 
scanDirectory(File, ClassLoader) - Method in class com.google.common.reflect.ClassPath.Scanner
 
scanDirectory(File, ClassLoader, String, ImmutableSet<File>) - Method in class com.google.common.reflect.ClassPath.Scanner
 
scanFrom(File, ClassLoader) - Method in class com.google.common.reflect.ClassPath.Scanner
 
scanJar(File, ClassLoader) - Method in class com.google.common.reflect.ClassPath.Scanner
 
scannedUris - Variable in class com.google.common.reflect.ClassPath.Scanner
 
Scanner() - Constructor for class com.google.common.reflect.ClassPath.Scanner
 
schedule(AbstractService, ScheduledExecutorService, Runnable) - Method in class com.google.common.util.concurrent.AbstractScheduledService.CustomScheduler
 
Schedule(long, TimeUnit) - Constructor for class com.google.common.util.concurrent.AbstractScheduledService.CustomScheduler.Schedule
 
schedule(AbstractService, ScheduledExecutorService, Runnable) - Method in class com.google.common.util.concurrent.AbstractScheduledService.Scheduler
Schedules the task to run on the provided executor on behalf of the service.
schedule(Runnable, long, TimeUnit) - Method in interface com.google.common.util.concurrent.ListeningScheduledExecutorService
 
schedule(Callable<V>, long, TimeUnit) - Method in interface com.google.common.util.concurrent.ListeningScheduledExecutorService
 
schedule(Runnable, long, TimeUnit) - Method in class com.google.common.util.concurrent.MoreExecutors.ScheduledListeningDecorator
 
schedule(Callable<V>, long, TimeUnit) - Method in class com.google.common.util.concurrent.MoreExecutors.ScheduledListeningDecorator
 
schedule(Runnable, long, TimeUnit) - Method in class com.google.common.util.concurrent.WrappingScheduledExecutorService
 
schedule(Callable<V>, long, TimeUnit) - Method in class com.google.common.util.concurrent.WrappingScheduledExecutorService
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in interface com.google.common.util.concurrent.ListeningScheduledExecutorService
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class com.google.common.util.concurrent.MoreExecutors.ScheduledListeningDecorator
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class com.google.common.util.concurrent.WrappingScheduledExecutorService
 
scheduledDelegate - Variable in class com.google.common.util.concurrent.MoreExecutors.ScheduledListeningDecorator.ListenableScheduledTask
 
ScheduledListeningDecorator(ScheduledExecutorService) - Constructor for class com.google.common.util.concurrent.MoreExecutors.ScheduledListeningDecorator
 
scheduler() - Method in class com.google.common.util.concurrent.AbstractScheduledService
Returns the AbstractScheduledService.Scheduler object used to configure this service.
Scheduler() - Constructor for class com.google.common.util.concurrent.AbstractScheduledService.Scheduler
 
scheduleRefresh(LocalCache.ReferenceEntry<K, V>, K, int, V, long, CacheLoader<? super K, V>) - Method in class com.google.common.cache.LocalCache.Segment
 
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in interface com.google.common.util.concurrent.ListeningScheduledExecutorService
 
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class com.google.common.util.concurrent.MoreExecutors.ScheduledListeningDecorator
 
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class com.google.common.util.concurrent.WrappingScheduledExecutorService
 
scratch - Variable in class com.google.common.hash.AbstractByteHasher
 
second - Variable in class com.google.common.base.CharMatcher.And
 
second - Variable in class com.google.common.base.CharMatcher.Or
 
second - Variable in class com.google.common.base.Converter.ConverterComposition
 
second - Variable in class com.google.common.collect.Lists.TwoPlusArrayList
 
seed - Variable in class com.google.common.hash.Murmur3_128HashFunction
 
seed - Variable in class com.google.common.hash.Murmur3_32HashFunction
 
seekByKey(Object, int) - Method in class com.google.common.collect.HashBiMap
 
seekByValue(Object, int) - Method in class com.google.common.collect.HashBiMap
 
seen - Variable in class com.google.common.collect.StandardTable.ColumnKeyIterator
 
seenExceptions - Variable in class com.google.common.util.concurrent.Futures.CombinedFuture
 
seenExceptionsLock - Variable in class com.google.common.util.concurrent.Futures.CombinedFuture
 
seenKeys - Variable in class com.google.common.collect.LinkedListMultimap.DistinctKeyIterator
 
Segment(LocalCache<K, V>, int, long, AbstractCache.StatsCounter) - Constructor for class com.google.common.cache.LocalCache.Segment
 
Segment(MapMakerInternalMap<K, V>, int, int) - Constructor for class com.google.common.collect.MapMakerInternalMap.Segment
 
segmentFor(int) - Method in class com.google.common.cache.LocalCache
Returns the segment that should be used for a key with the given hash.
segmentFor(int) - Method in class com.google.common.collect.ComputingConcurrentHashMap
 
segmentFor(int) - Method in class com.google.common.collect.MapMakerInternalMap
Returns the segment that should be used for a key with the given hash.
segmentMask - Variable in class com.google.common.cache.LocalCache
Mask value for indexing into segments.
segmentMask - Variable in class com.google.common.collect.MapMakerInternalMap
Mask value for indexing into segments.
segments - Variable in class com.google.common.cache.LocalCache
The segments, each of which is a specialized hash table.
segments - Variable in class com.google.common.collect.MapMakerInternalMap
The segments, each of which is a specialized hash table.
segmentShift - Variable in class com.google.common.cache.LocalCache
Shift value for indexing within segments.
segmentShift - Variable in class com.google.common.collect.MapMakerInternalMap
Shift value for indexing within segments.
semaphore(int, int) - Static method in class com.google.common.util.concurrent.Striped
Creates a Striped<Semaphore> with eagerly initialized, strongly referenced semaphores, with the specified number of permits.
SeparatedBaseEncoding(BaseEncoding, String, int) - Constructor for class com.google.common.io.BaseEncoding.SeparatedBaseEncoding
 
separatingOutput(GwtWorkarounds.CharOutput, String, int) - Static method in class com.google.common.io.BaseEncoding
 
separator - Variable in class com.google.common.base.Joiner
 
separator - Variable in class com.google.common.io.BaseEncoding.SeparatedBaseEncoding
 
separatorChars - Variable in class com.google.common.io.BaseEncoding.SeparatedBaseEncoding
 
separatorEnd(int) - Method in class com.google.common.base.Splitter.SplittingIterator
Returns the first index in toSplit after separatorPosition that does not contain a separator.
separatorStart(int) - Method in class com.google.common.base.Splitter.SplittingIterator
Returns the first index in toSplit at or after start that contains the separator.
seq - Variable in class com.google.common.io.CharSequenceReader
 
seq - Variable in class com.google.common.io.CharSource.CharSequenceCharSource
 
sequence - Variable in class com.google.common.collect.Lists.CharSequenceAsList
 
sequentialFunnel(Funnel<E>) - Static method in class com.google.common.hash.Funnels
Returns a funnel that processes an Iterable by funneling its elements in iteration order with the specified funnel.
SequentialFunnel(Funnel<E>) - Constructor for class com.google.common.hash.Funnels.SequentialFunnel
 
SerialForm(BloomFilter<T>) - Constructor for class com.google.common.hash.BloomFilter.SerialForm
 
Serialization - Class in com.google.common.collect
Provides static methods for serializing collection classes.
Serialization() - Constructor for class com.google.common.collect.Serialization
 
Serialization.FieldSetter<T> - Class in com.google.common.collect
 
SerializationProxy(MapMakerInternalMap.Strength, MapMakerInternalMap.Strength, Equivalence<Object>, Equivalence<Object>, long, long, int, int, MapMaker.RemovalListener<? super K, ? super V>, ConcurrentMap<K, V>) - Constructor for class com.google.common.collect.MapMakerInternalMap.SerializationProxy
 
SerializedForm(DiscreteDomain<C>) - Constructor for class com.google.common.collect.EmptyContiguousSet.SerializedForm
 
SerializedForm(ImmutableCollection<?>) - Constructor for class com.google.common.collect.ImmutableAsList.SerializedForm
 
SerializedForm(ImmutableBiMap<?, ?>) - Constructor for class com.google.common.collect.ImmutableBiMap.SerializedForm
 
SerializedForm(Object[]) - Constructor for class com.google.common.collect.ImmutableList.SerializedForm
 
SerializedForm(ImmutableMap<?, ?>) - Constructor for class com.google.common.collect.ImmutableMap.SerializedForm
 
SerializedForm(ImmutableMap<?, V>) - Constructor for class com.google.common.collect.ImmutableMapValues.SerializedForm
 
SerializedForm(Multiset<?>) - Constructor for class com.google.common.collect.ImmutableMultiset.SerializedForm
 
SerializedForm(ImmutableList<Range<C>>) - Constructor for class com.google.common.collect.ImmutableRangeSet.SerializedForm
 
SerializedForm(Object[]) - Constructor for class com.google.common.collect.ImmutableSet.SerializedForm
 
SerializedForm(ImmutableSortedMap<?, ?>) - Constructor for class com.google.common.collect.ImmutableSortedMap.SerializedForm
 
SerializedForm(SortedMultiset<E>) - Constructor for class com.google.common.collect.ImmutableSortedMultiset.SerializedForm
 
SerializedForm(Comparator<? super E>, Object[]) - Constructor for class com.google.common.collect.ImmutableSortedSet.SerializedForm
 
SerializedForm(Range<C>, DiscreteDomain<C>) - Constructor for class com.google.common.collect.RegularContiguousSet.SerializedForm
 
SerializedForm(Charset) - Constructor for class com.google.common.hash.Funnels.StringCharsetFunnel.SerializedForm
 
SerializedForm(String, int, String) - Constructor for class com.google.common.hash.MessageDigestHashFunction.SerializedForm
 
SerializingExecutor - Class in com.google.common.util.concurrent
Executor ensuring that all Runnables submitted are executed in order, using the provided Executor, and serially such that no two will ever be running at the same time.
SerializingExecutor(Executor) - Constructor for class com.google.common.util.concurrent.SerializingExecutor
Creates a SerializingExecutor, running tasks using executor.
SerializingExecutor.TaskRunner - Class in com.google.common.util.concurrent
Task that actually runs the Runnables.
serialVersionUID - Static variable in class com.google.common.base.Absent
 
serialVersionUID - Static variable in class com.google.common.base.CaseFormat.StringConverter
 
serialVersionUID - Static variable in class com.google.common.base.Converter.ConverterComposition
 
serialVersionUID - Static variable in class com.google.common.base.Converter.IdentityConverter
 
serialVersionUID - Static variable in class com.google.common.base.Converter.ReverseConverter
 
serialVersionUID - Static variable in class com.google.common.base.Enums.StringConverter
 
serialVersionUID - Static variable in class com.google.common.base.Equivalence.Equals
 
serialVersionUID - Static variable in class com.google.common.base.Equivalence.EquivalentToPredicate
 
serialVersionUID - Static variable in class com.google.common.base.Equivalence.Identity
 
serialVersionUID - Static variable in class com.google.common.base.Equivalence.Wrapper
 
serialVersionUID - Static variable in class com.google.common.base.FunctionalEquivalence
 
serialVersionUID - Static variable in class com.google.common.base.Functions.ConstantFunction
 
serialVersionUID - Static variable in class com.google.common.base.Functions.ForMapWithDefault
 
serialVersionUID - Static variable in class com.google.common.base.Functions.FunctionComposition
 
serialVersionUID - Static variable in class com.google.common.base.Functions.FunctionForMapNoDefault
 
serialVersionUID - Static variable in class com.google.common.base.Functions.PredicateFunction
 
serialVersionUID - Static variable in class com.google.common.base.Functions.SupplierFunction
 
serialVersionUID - Static variable in class com.google.common.base.Optional
 
serialVersionUID - Static variable in class com.google.common.base.PairwiseEquivalence
 
serialVersionUID - Static variable in class com.google.common.base.Predicates.AndPredicate
 
serialVersionUID - Static variable in class com.google.common.base.Predicates.AssignableFromPredicate
 
serialVersionUID - Static variable in class com.google.common.base.Predicates.CompositionPredicate
 
serialVersionUID - Static variable in class com.google.common.base.Predicates.ContainsPatternFromStringPredicate
 
serialVersionUID - Static variable in class com.google.common.base.Predicates.ContainsPatternPredicate
 
serialVersionUID - Static variable in class com.google.common.base.Predicates.InPredicate
 
serialVersionUID - Static variable in class com.google.common.base.Predicates.InstanceOfPredicate
 
serialVersionUID - Static variable in class com.google.common.base.Predicates.IsEqualToPredicate
 
serialVersionUID - Static variable in class com.google.common.base.Predicates.NotPredicate
 
serialVersionUID - Static variable in class com.google.common.base.Predicates.OrPredicate
 
serialVersionUID - Static variable in class com.google.common.base.Present
 
serialVersionUID - Static variable in class com.google.common.base.Suppliers.ExpiringMemoizingSupplier
 
serialVersionUID - Static variable in class com.google.common.base.Suppliers.MemoizingSupplier
 
serialVersionUID - Static variable in class com.google.common.base.Suppliers.SupplierComposition
 
serialVersionUID - Static variable in class com.google.common.base.Suppliers.SupplierOfInstance
 
serialVersionUID - Static variable in class com.google.common.base.Suppliers.ThreadSafeSupplier
 
serialVersionUID - Static variable in class com.google.common.cache.CacheLoader.FunctionToCacheLoader
 
serialVersionUID - Static variable in class com.google.common.cache.CacheLoader.SupplierToCacheLoader
 
serialVersionUID - Static variable in class com.google.common.cache.LocalCache.LoadingSerializationProxy
 
serialVersionUID - Static variable in class com.google.common.cache.LocalCache.LocalLoadingCache
 
serialVersionUID - Static variable in class com.google.common.cache.LocalCache.LocalManualCache
 
serialVersionUID - Static variable in class com.google.common.cache.LocalCache.ManualSerializationProxy
 
serialVersionUID - Static variable in class com.google.common.cache.LongAdder
 
serialVersionUID - Static variable in class com.google.common.cache.RemovalNotification
 
serialVersionUID - Static variable in class com.google.common.collect.AbstractBiMap.Inverse
 
serialVersionUID - Static variable in class com.google.common.collect.AbstractBiMap
 
serialVersionUID - Static variable in class com.google.common.collect.AbstractListMultimap
 
serialVersionUID - Static variable in class com.google.common.collect.AbstractMapBasedMultimap
 
serialVersionUID - Static variable in class com.google.common.collect.AbstractMapBasedMultiset
 
serialVersionUID - Static variable in class com.google.common.collect.AbstractSetMultimap
 
serialVersionUID - Static variable in class com.google.common.collect.AbstractSortedSetMultimap
 
serialVersionUID - Static variable in class com.google.common.collect.AllEqualOrdering
 
serialVersionUID - Static variable in class com.google.common.collect.ArrayListMultimap
 
serialVersionUID - Static variable in class com.google.common.collect.ArrayTable
 
serialVersionUID - Static variable in class com.google.common.collect.ByFunctionOrdering
 
serialVersionUID - Static variable in class com.google.common.collect.ComparatorOrdering
 
serialVersionUID - Static variable in class com.google.common.collect.CompoundOrdering
 
serialVersionUID - Static variable in exception com.google.common.collect.ComputationException
 
serialVersionUID - Static variable in class com.google.common.collect.ComputingConcurrentHashMap.ComputingSerializationProxy
 
serialVersionUID - Static variable in class com.google.common.collect.ComputingConcurrentHashMap
 
serialVersionUID - Static variable in class com.google.common.collect.ConcurrentHashMultiset
 
serialVersionUID - Static variable in class com.google.common.collect.Cut.AboveAll
 
serialVersionUID - Static variable in class com.google.common.collect.Cut.AboveValue
 
serialVersionUID - Static variable in class com.google.common.collect.Cut.BelowAll
 
serialVersionUID - Static variable in class com.google.common.collect.Cut.BelowValue
 
serialVersionUID - Static variable in class com.google.common.collect.Cut
 
serialVersionUID - Static variable in class com.google.common.collect.DiscreteDomain.BigIntegerDomain
 
serialVersionUID - Static variable in class com.google.common.collect.DiscreteDomain.IntegerDomain
 
serialVersionUID - Static variable in class com.google.common.collect.DiscreteDomain.LongDomain
 
serialVersionUID - Static variable in class com.google.common.collect.EmptyContiguousSet.SerializedForm
 
serialVersionUID - Static variable in class com.google.common.collect.EmptyImmutableListMultimap
 
serialVersionUID - Static variable in class com.google.common.collect.EmptyImmutableSet
 
serialVersionUID - Static variable in class com.google.common.collect.EmptyImmutableSetMultimap
 
serialVersionUID - Static variable in class com.google.common.collect.EnumBiMap
 
serialVersionUID - Static variable in class com.google.common.collect.EnumHashBiMap
 
serialVersionUID - Static variable in class com.google.common.collect.EnumMultiset
 
serialVersionUID - Static variable in class com.google.common.collect.EvictingQueue
 
serialVersionUID - Static variable in class com.google.common.collect.ExplicitOrdering
 
serialVersionUID - Static variable in class com.google.common.collect.HashBasedTable.Factory
 
serialVersionUID - Static variable in class com.google.common.collect.HashBasedTable
 
serialVersionUID - Static variable in class com.google.common.collect.HashBiMap
 
serialVersionUID - Static variable in class com.google.common.collect.HashMultimap
 
serialVersionUID - Static variable in class com.google.common.collect.HashMultiset
 
serialVersionUID - Static variable in class com.google.common.collect.ImmutableAsList.SerializedForm
 
serialVersionUID - Static variable in class com.google.common.collect.ImmutableBiMap.SerializedForm
 
serialVersionUID - Static variable in class com.google.common.collect.ImmutableEntry
 
serialVersionUID - Static variable in class com.google.common.collect.ImmutableEnumMap.EnumSerializedForm
 
serialVersionUID - Static variable in class com.google.common.collect.ImmutableEnumSet.EnumSerializedForm
 
serialVersionUID - Static variable in class com.google.common.collect.ImmutableList.SerializedForm
 
serialVersionUID - Static variable in class com.google.common.collect.ImmutableListMultimap
 
serialVersionUID - Static variable in class com.google.common.collect.ImmutableMap.SerializedForm
 
serialVersionUID - Static variable in class com.google.common.collect.ImmutableMapEntrySet.EntrySetSerializedForm
 
serialVersionUID - Static variable in class com.google.common.collect.ImmutableMapKeySet.KeySetSerializedForm
 
serialVersionUID - Static variable in class com.google.common.collect.ImmutableMapValues.SerializedForm
 
serialVersionUID - Static variable in class com.google.common.collect.ImmutableMultimap.BuilderMultimap
 
serialVersionUID - Static variable in class com.google.common.collect.ImmutableMultimap.EntryCollection
 
serialVersionUID - Static variable in class com.google.common.collect.ImmutableMultimap
 
serialVersionUID - Static variable in class com.google.common.collect.ImmutableMultimap.Values
 
serialVersionUID - Static variable in class com.google.common.collect.ImmutableMultiset.EntrySet
 
serialVersionUID - Static variable in class com.google.common.collect.ImmutableMultiset.SerializedForm
 
serialVersionUID - Static variable in class com.google.common.collect.ImmutableSet.SerializedForm
 
serialVersionUID - Static variable in class com.google.common.collect.ImmutableSetMultimap.BuilderMultimap
 
serialVersionUID - Static variable in class com.google.common.collect.ImmutableSetMultimap
 
serialVersionUID - Static variable in class com.google.common.collect.ImmutableSortedMap.SerializedForm
 
serialVersionUID - Static variable in class com.google.common.collect.ImmutableSortedMap
 
serialVersionUID - Static variable in class com.google.common.collect.ImmutableSortedSet.SerializedForm
 
serialVersionUID - Static variable in class com.google.common.collect.LexicographicalOrdering
 
serialVersionUID - Static variable in class com.google.common.collect.LinkedHashMultimap
 
serialVersionUID - Static variable in class com.google.common.collect.LinkedHashMultiset
 
serialVersionUID - Static variable in class com.google.common.collect.LinkedListMultimap
 
serialVersionUID - Static variable in class com.google.common.collect.Lists.OnePlusArrayList
 
serialVersionUID - Static variable in class com.google.common.collect.Lists.TransformingRandomAccessList
 
serialVersionUID - Static variable in class com.google.common.collect.Lists.TransformingSequentialList
 
serialVersionUID - Static variable in class com.google.common.collect.Lists.TwoPlusArrayList
 
serialVersionUID - Static variable in class com.google.common.collect.MapMaker.ComputingMapAdapter
 
serialVersionUID - Static variable in class com.google.common.collect.MapMaker.NullComputingConcurrentMap
 
serialVersionUID - Static variable in class com.google.common.collect.MapMaker.NullConcurrentMap
 
serialVersionUID - Static variable in class com.google.common.collect.MapMaker.RemovalNotification
 
serialVersionUID - Static variable in class com.google.common.collect.MapMakerInternalMap.AbstractSerializationProxy
 
serialVersionUID - Static variable in class com.google.common.collect.MapMakerInternalMap.SerializationProxy
 
serialVersionUID - Static variable in class com.google.common.collect.MapMakerInternalMap
 
serialVersionUID - Static variable in class com.google.common.collect.Maps.BiMapConverter
 
serialVersionUID - Static variable in class com.google.common.collect.Maps.UnmodifiableBiMap
 
serialVersionUID - Static variable in class com.google.common.collect.Multimaps.CustomListMultimap
 
serialVersionUID - Static variable in class com.google.common.collect.Multimaps.CustomMultimap
 
serialVersionUID - Static variable in class com.google.common.collect.Multimaps.CustomSetMultimap
 
serialVersionUID - Static variable in class com.google.common.collect.Multimaps.CustomSortedSetMultimap
 
serialVersionUID - Static variable in class com.google.common.collect.Multimaps.MapMultimap
 
serialVersionUID - Static variable in class com.google.common.collect.Multimaps.UnmodifiableListMultimap
 
serialVersionUID - Static variable in class com.google.common.collect.Multimaps.UnmodifiableMultimap
 
serialVersionUID - Static variable in class com.google.common.collect.Multimaps.UnmodifiableSetMultimap
 
serialVersionUID - Static variable in class com.google.common.collect.Multimaps.UnmodifiableSortedSetMultimap
 
serialVersionUID - Static variable in class com.google.common.collect.Multisets.ImmutableEntry
 
serialVersionUID - Static variable in class com.google.common.collect.Multisets.UnmodifiableMultiset
 
serialVersionUID - Static variable in class com.google.common.collect.MutableClassToInstanceMap
 
serialVersionUID - Static variable in class com.google.common.collect.NaturalOrdering
 
serialVersionUID - Static variable in class com.google.common.collect.NullsFirstOrdering
 
serialVersionUID - Static variable in class com.google.common.collect.NullsLastOrdering
 
serialVersionUID - Static variable in exception com.google.common.collect.Ordering.IncomparableValueException
 
serialVersionUID - Static variable in class com.google.common.collect.Range
 
serialVersionUID - Static variable in class com.google.common.collect.RegularContiguousSet
 
serialVersionUID - Static variable in class com.google.common.collect.RegularImmutableBiMap.InverseSerializedForm
 
serialVersionUID - Static variable in class com.google.common.collect.RegularImmutableMap
 
serialVersionUID - Static variable in class com.google.common.collect.ReverseNaturalOrdering
 
serialVersionUID - Static variable in class com.google.common.collect.ReverseOrdering
 
serialVersionUID - Static variable in class com.google.common.collect.Sets.UnmodifiableNavigableSet
 
serialVersionUID - Static variable in class com.google.common.collect.StandardRowSortedTable
 
serialVersionUID - Static variable in class com.google.common.collect.StandardTable
 
serialVersionUID - Static variable in class com.google.common.collect.Synchronized.SynchronizedAsMap
 
serialVersionUID - Static variable in class com.google.common.collect.Synchronized.SynchronizedAsMapEntries
 
serialVersionUID - Static variable in class com.google.common.collect.Synchronized.SynchronizedAsMapValues
 
serialVersionUID - Static variable in class com.google.common.collect.Synchronized.SynchronizedBiMap
 
serialVersionUID - Static variable in class com.google.common.collect.Synchronized.SynchronizedCollection
 
serialVersionUID - Static variable in class com.google.common.collect.Synchronized.SynchronizedDeque
 
serialVersionUID - Static variable in class com.google.common.collect.Synchronized.SynchronizedEntry
 
serialVersionUID - Static variable in class com.google.common.collect.Synchronized.SynchronizedList
 
serialVersionUID - Static variable in class com.google.common.collect.Synchronized.SynchronizedListMultimap
 
serialVersionUID - Static variable in class com.google.common.collect.Synchronized.SynchronizedMap
 
serialVersionUID - Static variable in class com.google.common.collect.Synchronized.SynchronizedMultimap
 
serialVersionUID - Static variable in class com.google.common.collect.Synchronized.SynchronizedMultiset
 
serialVersionUID - Static variable in class com.google.common.collect.Synchronized.SynchronizedNavigableMap
 
serialVersionUID - Static variable in class com.google.common.collect.Synchronized.SynchronizedNavigableSet
 
serialVersionUID - Static variable in class com.google.common.collect.Synchronized.SynchronizedObject
 
serialVersionUID - Static variable in class com.google.common.collect.Synchronized.SynchronizedQueue
 
serialVersionUID - Static variable in class com.google.common.collect.Synchronized.SynchronizedRandomAccessList
 
serialVersionUID - Static variable in class com.google.common.collect.Synchronized.SynchronizedSet
 
serialVersionUID - Static variable in class com.google.common.collect.Synchronized.SynchronizedSetMultimap
 
serialVersionUID - Static variable in class com.google.common.collect.Synchronized.SynchronizedSortedMap
 
serialVersionUID - Static variable in class com.google.common.collect.Synchronized.SynchronizedSortedSet
 
serialVersionUID - Static variable in class com.google.common.collect.Synchronized.SynchronizedSortedSetMultimap
 
serialVersionUID - Static variable in class com.google.common.collect.Tables.ImmutableCell
 
serialVersionUID - Static variable in class com.google.common.collect.Tables.UnmodifiableRowSortedMap
 
serialVersionUID - Static variable in class com.google.common.collect.Tables.UnmodifiableTable
 
serialVersionUID - Static variable in class com.google.common.collect.TreeBasedTable.Factory
 
serialVersionUID - Static variable in class com.google.common.collect.TreeBasedTable
 
serialVersionUID - Static variable in class com.google.common.collect.TreeMultimap
 
serialVersionUID - Static variable in class com.google.common.collect.TreeMultiset
 
serialVersionUID - Static variable in class com.google.common.collect.UnmodifiableSortedMultiset
 
serialVersionUID - Static variable in class com.google.common.collect.UsingToStringOrdering
 
serialVersionUID - Static variable in class com.google.common.hash.AbstractCompositeHashFunction
 
serialVersionUID - Static variable in class com.google.common.hash.BloomFilter.SerialForm
 
serialVersionUID - Static variable in class com.google.common.hash.ChecksumHashFunction
 
serialVersionUID - Static variable in class com.google.common.hash.Funnels.StringCharsetFunnel.SerializedForm
 
serialVersionUID - Static variable in class com.google.common.hash.HashCode.BytesHashCode
 
serialVersionUID - Static variable in class com.google.common.hash.HashCode.IntHashCode
 
serialVersionUID - Static variable in class com.google.common.hash.HashCode.LongHashCode
 
serialVersionUID - Static variable in class com.google.common.hash.MessageDigestHashFunction.SerializedForm
 
serialVersionUID - Static variable in class com.google.common.hash.Murmur3_128HashFunction
 
serialVersionUID - Static variable in class com.google.common.hash.Murmur3_32HashFunction
 
serialVersionUID - Static variable in class com.google.common.hash.SipHashFunction
 
serialVersionUID - Static variable in class com.google.common.net.HostAndPort
 
serialVersionUID - Static variable in class com.google.common.primitives.Booleans.BooleanArrayAsList
 
serialVersionUID - Static variable in class com.google.common.primitives.Bytes.ByteArrayAsList
 
serialVersionUID - Static variable in class com.google.common.primitives.Chars.CharArrayAsList
 
serialVersionUID - Static variable in class com.google.common.primitives.Doubles.DoubleArrayAsList
 
serialVersionUID - Static variable in class com.google.common.primitives.Doubles.DoubleConverter
 
serialVersionUID - Static variable in class com.google.common.primitives.Floats.FloatArrayAsList
 
serialVersionUID - Static variable in class com.google.common.primitives.Floats.FloatConverter
 
serialVersionUID - Static variable in class com.google.common.primitives.Ints.IntArrayAsList
 
serialVersionUID - Static variable in class com.google.common.primitives.Ints.IntConverter
 
serialVersionUID - Static variable in class com.google.common.primitives.Longs.LongArrayAsList
 
serialVersionUID - Static variable in class com.google.common.primitives.Longs.LongConverter
 
serialVersionUID - Static variable in class com.google.common.primitives.Shorts.ShortArrayAsList
 
serialVersionUID - Static variable in class com.google.common.primitives.Shorts.ShortConverter
 
serialVersionUID - Static variable in class com.google.common.reflect.Types.GenericArrayTypeImpl
 
serialVersionUID - Static variable in class com.google.common.reflect.Types.ParameterizedTypeImpl
 
serialVersionUID - Static variable in class com.google.common.reflect.Types.WildcardTypeImpl
 
serialVersionUID - Static variable in class com.google.common.reflect.TypeToken.ClassSet
 
serialVersionUID - Static variable in class com.google.common.reflect.TypeToken.InterfaceSet
 
serialVersionUID - Static variable in class com.google.common.reflect.TypeToken.SimpleTypeToken
 
serialVersionUID - Static variable in class com.google.common.reflect.TypeToken.TypeSet
 
serialVersionUID - Static variable in class com.google.common.util.concurrent.AbstractFuture.Sync
 
serialVersionUID - Static variable in class com.google.common.util.concurrent.AtomicDouble
 
serialVersionUID - Static variable in class com.google.common.util.concurrent.AtomicDoubleArray
 
serialVersionUID - Static variable in error com.google.common.util.concurrent.ExecutionError
 
serialVersionUID - Static variable in exception com.google.common.util.concurrent.UncheckedExecutionException
 
serialVersionUID - Static variable in exception com.google.common.util.concurrent.UncheckedTimeoutException
 
SERVER - Static variable in class com.google.common.net.HttpHeaders
The HTTP Server header field name.
server - Variable in class com.google.common.net.InetAddresses.TeredoInfo
 
service - Variable in class com.google.common.util.concurrent.AbstractScheduledService.CustomScheduler.ReschedulableCallable
The service that is managing this callable.
Service - Interface in com.google.common.util.concurrent
An object with an operational state, plus asynchronous Service.startAsync() and Service.stopAsync() lifecycle methods to transition between states.
service - Variable in class com.google.common.util.concurrent.ServiceManager.ServiceListener
 
Service.Listener - Class in com.google.common.util.concurrent
A listener for the various state changes that a Service goes through in its lifecycle.
Service.State - Enum in com.google.common.util.concurrent
The lifecycle states of a service.
ServiceListener(Service, WeakReference<ServiceManager.ServiceManagerState>) - Constructor for class com.google.common.util.concurrent.ServiceManager.ServiceListener
 
ServiceManager - Class in com.google.common.util.concurrent
A manager for monitoring and controlling a set of services.
ServiceManager(Iterable<? extends Service>) - Constructor for class com.google.common.util.concurrent.ServiceManager
Constructs a new instance for managing the given services.
ServiceManager.EmptyServiceManagerWarning - Class in com.google.common.util.concurrent
This is never thrown but only used for logging.
ServiceManager.Listener - Class in com.google.common.util.concurrent
A listener for the aggregate state changes of the services that are under management.
ServiceManager.NoOpService - Class in com.google.common.util.concurrent
A Service instance that does nothing.
ServiceManager.ServiceListener - Class in com.google.common.util.concurrent
A Service that wraps another service and times how long it takes for it to start and also calls the ServiceManagerState#transitionService(Service, State, State), to record the state transitions.
ServiceManager.ServiceManagerState - Class in com.google.common.util.concurrent
An encapsulation of all the mutable state of the ServiceManager that needs to be accessed by instances of ServiceManager.ServiceListener.
ServiceManagerState(ImmutableCollection<Service>) - Constructor for class com.google.common.util.concurrent.ServiceManager.ServiceManagerState
It is implicitly assumed that all the services are NEW and that they will all remain NEW until all the Listeners are installed and ServiceManager.ServiceManagerState.markReady() is called.
serviceName() - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
Returns the name of this service.
serviceName() - Method in class com.google.common.util.concurrent.AbstractIdleService
Returns the name of this service.
serviceName() - Method in class com.google.common.util.concurrent.AbstractScheduledService
Returns the name of this service.
services - Variable in class com.google.common.util.concurrent.ServiceManager
 
servicesByState - Variable in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState
 
servicesByState() - Method in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState
 
servicesByState() - Method in class com.google.common.util.concurrent.ServiceManager
Provides a snapshot of the current state of all the services under management.
set(V) - Method in class com.google.common.cache.LocalCache.LoadingValueReference
 
set(int, V) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedList
 
set(V) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedList.WrappedListIterator
 
set(int, int, V) - Method in class com.google.common.collect.ArrayTable
Associates value with the specified row and column indices.
set(int, E) - Method in class com.google.common.collect.Constraints.ConstrainedList
 
set(E) - Method in class com.google.common.collect.Constraints.ConstrainedListIterator
 
set(int) - Method in class com.google.common.collect.Count
 
set(int, E) - Method in class com.google.common.collect.ForwardingList
 
set(E) - Method in class com.google.common.collect.ForwardingListIterator
 
set(int, E) - Method in class com.google.common.collect.ImmutableList
Deprecated.
Unsupported operation.
set(Map.Entry<K, V>) - Method in class com.google.common.collect.LinkedListMultimap.NodeIterator
 
set(V) - Method in class com.google.common.collect.LinkedListMultimap.ValueForKeyIterator
 
set(int, E) - Method in class com.google.common.collect.Lists.AbstractListWrapper
 
set(int, T) - Method in class com.google.common.collect.Lists.ReverseList
 
set - Variable in class com.google.common.collect.Maps.AsMapView
 
set - Variable in class com.google.common.collect.Maps.NavigableAsMapView
 
set(T, Object) - Method in class com.google.common.collect.Serialization.FieldSetter
 
set(T, int) - Method in class com.google.common.collect.Serialization.FieldSetter
 
set(Set<E>, Object) - Static method in class com.google.common.collect.Synchronized
 
set(int, E) - Method in class com.google.common.collect.Synchronized.SynchronizedList
 
set(T) - Method in class com.google.common.collect.TransformedListIterator
 
set(E) - Method in class com.google.common.collect.UnmodifiableListIterator
Deprecated.
Unsupported operation.
set(long) - Method in class com.google.common.hash.BloomFilterStrategies.BitArray
Returns true if the bit changed value.
set(int, Boolean) - Method in class com.google.common.primitives.Booleans.BooleanArrayAsList
 
set(int, Byte) - Method in class com.google.common.primitives.Bytes.ByteArrayAsList
 
set(int, Character) - Method in class com.google.common.primitives.Chars.CharArrayAsList
 
set(int, Double) - Method in class com.google.common.primitives.Doubles.DoubleArrayAsList
 
set(int, Float) - Method in class com.google.common.primitives.Floats.FloatArrayAsList
 
set(int, Integer) - Method in class com.google.common.primitives.Ints.IntArrayAsList
 
set(int, Long) - Method in class com.google.common.primitives.Longs.LongArrayAsList
 
set(int, Short) - Method in class com.google.common.primitives.Shorts.ShortArrayAsList
 
set(V) - Method in class com.google.common.util.concurrent.AbstractFuture
Subclasses should invoke this method to set the result of the computation to value.
set(V) - Method in class com.google.common.util.concurrent.AbstractFuture.Sync
Transition to the COMPLETED state and set the value.
set(double) - Method in class com.google.common.util.concurrent.AtomicDouble
Sets to the given value.
set(int, double) - Method in class com.google.common.util.concurrent.AtomicDoubleArray
Sets the element at position i to the given value.
set(V) - Method in class com.google.common.util.concurrent.SettableFuture
Sets the value of this future.
SET_COOKIE - Static variable in class com.google.common.net.HttpHeaders
The HTTP Set-Cookie header field name.
SET_COOKIE2 - Static variable in class com.google.common.net.HttpHeaders
The HTTP Set-Cookie2 header field name.
setAccessible(boolean) - Method in class com.google.common.reflect.Element
 
setAccessTime(long) - Method in class com.google.common.cache.LocalCache.AbstractReferenceEntry
 
setAccessTime(long) - Method in enum com.google.common.cache.LocalCache.NullEntry
 
setAccessTime(long) - Method in interface com.google.common.cache.LocalCache.ReferenceEntry
Sets the entry access time in ns.
setAccessTime(long) - Method in class com.google.common.cache.LocalCache.StrongAccessEntry
 
setAccessTime(long) - Method in class com.google.common.cache.LocalCache.StrongAccessWriteEntry
 
setAccessTime(long) - Method in class com.google.common.cache.LocalCache.WeakAccessEntry
 
setAccessTime(long) - Method in class com.google.common.cache.LocalCache.WeakAccessWriteEntry
 
setAccessTime(long) - Method in class com.google.common.cache.LocalCache.WeakEntry
 
setBackingMap(Map<E, Count>) - Method in class com.google.common.collect.AbstractMapBasedMultiset
Used during deserialization only.
setBits(BitSet) - Method in class com.google.common.base.CharMatcher.And
 
setBits(BitSet) - Method in class com.google.common.base.CharMatcher.BitSetMatcher
 
setBits(BitSet) - Method in class com.google.common.base.CharMatcher.NegatedMatcher
 
setBits(BitSet) - Method in class com.google.common.base.CharMatcher.Or
 
setBits(BitSet) - Method in class com.google.common.base.CharMatcher
Sets bits in table matched by this matcher.
setBits(BitSet) - Method in class com.google.common.base.SmallCharMatcher
 
setCount(E, int) - Method in class com.google.common.collect.AbstractMapBasedMultiset
 
setCount(E, int) - Method in class com.google.common.collect.AbstractMultiset
 
setCount(E, int, int) - Method in class com.google.common.collect.AbstractMultiset
 
setCount(E, int) - Method in class com.google.common.collect.ConcurrentHashMultiset
Adds or removes occurrences of element such that the ConcurrentHashMultiset.count(java.lang.Object) of the element becomes count.
setCount(E, int, int) - Method in class com.google.common.collect.ConcurrentHashMultiset
Sets the number of occurrences of element to newCount, but only if the count is currently expectedOldCount.
setCount(E, int) - Method in class com.google.common.collect.ForwardingMultiset
 
setCount(E, int, int) - Method in class com.google.common.collect.ForwardingMultiset
 
setCount(E, int) - Method in class com.google.common.collect.ImmutableMultiset.Builder
Adds or removes the necessary occurrences of an element such that the element attains the desired count.
setCount(E, int) - Method in class com.google.common.collect.ImmutableMultiset
Deprecated.
Unsupported operation.
setCount(E, int, int) - Method in class com.google.common.collect.ImmutableMultiset
Deprecated.
Unsupported operation.
setCount(E, int) - Method in class com.google.common.collect.ImmutableSortedMultiset.Builder
Adds or removes the necessary occurrences of an element such that the element attains the desired count.
setCount(E, int) - Method in interface com.google.common.collect.Multiset
Adds or removes the necessary occurrences of an element such that the element attains the desired count.
setCount(E, int, int) - Method in interface com.google.common.collect.Multiset
Conditionally sets the count of an element to a new value, as described in Multiset.setCount(Object, int), provided that the element has the expected current count.
setCount(E, int) - Method in class com.google.common.collect.Multisets.UnmodifiableMultiset
 
setCount(E, int, int) - Method in class com.google.common.collect.Multisets.UnmodifiableMultiset
 
setCount(E, int) - Method in class com.google.common.collect.Synchronized.SynchronizedMultiset
 
setCount(E, int, int) - Method in class com.google.common.collect.Synchronized.SynchronizedMultiset
 
setCount(Comparator<? super E>, E, int, int[]) - Method in class com.google.common.collect.TreeMultiset.AvlNode
 
setCount(Comparator<? super E>, E, int, int, int[]) - Method in class com.google.common.collect.TreeMultiset.AvlNode
 
setCount(E, int) - Method in class com.google.common.collect.TreeMultiset
 
setCount(E, int, int) - Method in class com.google.common.collect.TreeMultiset
 
setCountImpl(Multiset<E>, E, int) - Static method in class com.google.common.collect.Multisets
An implementation of Multiset.setCount(Object, int).
setCountImpl(Multiset<E>, E, int, int) - Static method in class com.google.common.collect.Multisets
setDaemon(boolean) - Method in class com.google.common.util.concurrent.ThreadFactoryBuilder
Sets daemon or not for new threads created with this ThreadFactory.
setDelegates(Map<K, V>, Map<V, K>) - Method in class com.google.common.collect.AbstractBiMap
Specifies the delegate maps going in each direction.
setException(Throwable) - Method in class com.google.common.cache.LocalCache.LoadingValueReference
 
setException(Throwable) - Method in class com.google.common.util.concurrent.AbstractFuture
Subclasses should invoke this method to set the result of the computation to an error, throwable.
setException(Throwable) - Method in class com.google.common.util.concurrent.AbstractFuture.Sync
Transition to the COMPLETED state and set the exception.
setException(Throwable) - Method in class com.google.common.util.concurrent.AsyncSettableFuture
setException(Throwable) - Method in class com.google.common.util.concurrent.Futures.CombinerFuture
 
setException(Throwable) - Method in class com.google.common.util.concurrent.SettableFuture
Sets the future to having failed with the given exception.
setExceptionAndMaybeLog(Throwable) - Method in class com.google.common.util.concurrent.Futures.CombinedFuture
Fails this future with the given Throwable if Futures.CombinedFuture.allMustSucceed is true.
setExpirationTime(long) - Method in class com.google.common.collect.MapMakerInternalMap.AbstractReferenceEntry
 
setExpirationTime(long) - Method in enum com.google.common.collect.MapMakerInternalMap.NullEntry
 
setExpirationTime(long) - Method in interface com.google.common.collect.MapMakerInternalMap.ReferenceEntry
Sets the entry expiration time in ns.
setExpirationTime(long) - Method in class com.google.common.collect.MapMakerInternalMap.SoftEntry
 
setExpirationTime(long) - Method in class com.google.common.collect.MapMakerInternalMap.SoftExpirableEntry
 
setExpirationTime(long) - Method in class com.google.common.collect.MapMakerInternalMap.SoftExpirableEvictableEntry
 
setExpirationTime(long) - Method in class com.google.common.collect.MapMakerInternalMap.StrongEntry
 
setExpirationTime(long) - Method in class com.google.common.collect.MapMakerInternalMap.StrongExpirableEntry
 
setExpirationTime(long) - Method in class com.google.common.collect.MapMakerInternalMap.StrongExpirableEvictableEntry
 
setExpirationTime(long) - Method in class com.google.common.collect.MapMakerInternalMap.WeakEntry
 
setExpirationTime(long) - Method in class com.google.common.collect.MapMakerInternalMap.WeakExpirableEntry
 
setExpirationTime(long) - Method in class com.google.common.collect.MapMakerInternalMap.WeakExpirableEvictableEntry
 
setFuture(ListenableFuture<? extends V>) - Method in class com.google.common.util.concurrent.AsyncSettableFuture.NestedFuture
 
setFuture(ListenableFuture<? extends V>) - Method in class com.google.common.util.concurrent.AsyncSettableFuture
Sets this future to forward to the given future.
setInverse(AbstractBiMap<V, K>) - Method in class com.google.common.collect.AbstractBiMap
 
setKeyStrength(LocalCache.Strength) - Method in class com.google.common.cache.CacheBuilder
 
setKeyStrength(MapMakerInternalMap.Strength) - Method in class com.google.common.collect.MapMaker
 
setMap(Map<K, Collection<V>>) - Method in class com.google.common.collect.AbstractMapBasedMultimap
Used during deserialization only.
SetMultimap<K,V> - Interface in com.google.common.collect
A Multimap that cannot hold duplicate key-value pairs.
setMultimap(SetMultimap<K, V>, Object) - Static method in class com.google.common.collect.Synchronized
 
SetMultimapBuilder() - Constructor for class com.google.common.collect.MultimapBuilder.SetMultimapBuilder
 
setNameFormat(String) - Method in class com.google.common.util.concurrent.ThreadFactoryBuilder
Sets the naming format to use when naming threads (Thread.setName(java.lang.String)) which are created with this ThreadFactory.
setNextEvictable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.AbstractReferenceEntry
 
setNextEvictable(MapMakerInternalMap.ReferenceEntry<Object, Object>) - Method in enum com.google.common.collect.MapMakerInternalMap.NullEntry
 
setNextEvictable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in interface com.google.common.collect.MapMakerInternalMap.ReferenceEntry
Sets the next entry in the recency list.
setNextEvictable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.SoftEntry
 
setNextEvictable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.SoftEvictableEntry
 
setNextEvictable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.SoftExpirableEvictableEntry
 
setNextEvictable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.StrongEntry
 
setNextEvictable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.StrongEvictableEntry
 
setNextEvictable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.StrongExpirableEvictableEntry
 
setNextEvictable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.WeakEntry
 
setNextEvictable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.WeakEvictableEntry
 
setNextEvictable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.WeakExpirableEvictableEntry
 
setNextExpirable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.AbstractReferenceEntry
 
setNextExpirable(MapMakerInternalMap.ReferenceEntry<Object, Object>) - Method in enum com.google.common.collect.MapMakerInternalMap.NullEntry
 
setNextExpirable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in interface com.google.common.collect.MapMakerInternalMap.ReferenceEntry
Sets the next entry in the recency list.
setNextExpirable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.SoftEntry
 
setNextExpirable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.SoftExpirableEntry
 
setNextExpirable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.SoftExpirableEvictableEntry
 
setNextExpirable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.StrongEntry
 
setNextExpirable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.StrongExpirableEntry
 
setNextExpirable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.StrongExpirableEvictableEntry
 
setNextExpirable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.WeakEntry
 
setNextExpirable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.WeakExpirableEntry
 
setNextExpirable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.WeakExpirableEvictableEntry
 
setNextInAccessQueue(LocalCache.ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.AbstractReferenceEntry
 
setNextInAccessQueue(LocalCache.ReferenceEntry<Object, Object>) - Method in enum com.google.common.cache.LocalCache.NullEntry
 
setNextInAccessQueue(LocalCache.ReferenceEntry<K, V>) - Method in interface com.google.common.cache.LocalCache.ReferenceEntry
Sets the next entry in the access queue.
setNextInAccessQueue(LocalCache.ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.StrongAccessEntry
 
setNextInAccessQueue(LocalCache.ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.StrongAccessWriteEntry
 
setNextInAccessQueue(LocalCache.ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.WeakAccessEntry
 
setNextInAccessQueue(LocalCache.ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.WeakAccessWriteEntry
 
setNextInAccessQueue(LocalCache.ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.WeakEntry
 
setNextInWriteQueue(LocalCache.ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.AbstractReferenceEntry
 
setNextInWriteQueue(LocalCache.ReferenceEntry<Object, Object>) - Method in enum com.google.common.cache.LocalCache.NullEntry
 
setNextInWriteQueue(LocalCache.ReferenceEntry<K, V>) - Method in interface com.google.common.cache.LocalCache.ReferenceEntry
Sets the next entry in the write queue.
setNextInWriteQueue(LocalCache.ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.StrongAccessWriteEntry
 
setNextInWriteQueue(LocalCache.ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.StrongWriteEntry
 
setNextInWriteQueue(LocalCache.ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.WeakAccessWriteEntry
 
setNextInWriteQueue(LocalCache.ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.WeakEntry
 
setNextInWriteQueue(LocalCache.ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.WeakWriteEntry
 
setOneValue(int, Future<? extends V>) - Method in class com.google.common.util.concurrent.Futures.CombinedFuture
Sets the value at the given index to that of the given future.
setPredecessorInMultimap(LinkedHashMultimap.ValueEntry<K, V>) - Method in class com.google.common.collect.LinkedHashMultimap.ValueEntry
 
setPredecessorInValueSet(LinkedHashMultimap.ValueSetLink<K, V>) - Method in class com.google.common.collect.LinkedHashMultimap.ValueEntry
 
setPredecessorInValueSet(LinkedHashMultimap.ValueSetLink<K, V>) - Method in class com.google.common.collect.LinkedHashMultimap.ValueSet
 
setPredecessorInValueSet(LinkedHashMultimap.ValueSetLink<K, V>) - Method in interface com.google.common.collect.LinkedHashMultimap.ValueSetLink
 
setPreviousEvictable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.AbstractReferenceEntry
 
setPreviousEvictable(MapMakerInternalMap.ReferenceEntry<Object, Object>) - Method in enum com.google.common.collect.MapMakerInternalMap.NullEntry
 
setPreviousEvictable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in interface com.google.common.collect.MapMakerInternalMap.ReferenceEntry
Sets the previous entry in the recency list.
setPreviousEvictable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.SoftEntry
 
setPreviousEvictable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.SoftEvictableEntry
 
setPreviousEvictable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.SoftExpirableEvictableEntry
 
setPreviousEvictable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.StrongEntry
 
setPreviousEvictable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.StrongEvictableEntry
 
setPreviousEvictable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.StrongExpirableEvictableEntry
 
setPreviousEvictable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.WeakEntry
 
setPreviousEvictable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.WeakEvictableEntry
 
setPreviousEvictable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.WeakExpirableEvictableEntry
 
setPreviousExpirable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.AbstractReferenceEntry
 
setPreviousExpirable(MapMakerInternalMap.ReferenceEntry<Object, Object>) - Method in enum com.google.common.collect.MapMakerInternalMap.NullEntry
 
setPreviousExpirable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in interface com.google.common.collect.MapMakerInternalMap.ReferenceEntry
Sets the previous entry in the recency list.
setPreviousExpirable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.SoftEntry
 
setPreviousExpirable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.SoftExpirableEntry
 
setPreviousExpirable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.SoftExpirableEvictableEntry
 
setPreviousExpirable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.StrongEntry
 
setPreviousExpirable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.StrongExpirableEntry
 
setPreviousExpirable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.StrongExpirableEvictableEntry
 
setPreviousExpirable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.WeakEntry
 
setPreviousExpirable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.WeakExpirableEntry
 
setPreviousExpirable(MapMakerInternalMap.ReferenceEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.WeakExpirableEvictableEntry
 
setPreviousInAccessQueue(LocalCache.ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.AbstractReferenceEntry
 
setPreviousInAccessQueue(LocalCache.ReferenceEntry<Object, Object>) - Method in enum com.google.common.cache.LocalCache.NullEntry
 
setPreviousInAccessQueue(LocalCache.ReferenceEntry<K, V>) - Method in interface com.google.common.cache.LocalCache.ReferenceEntry
Sets the previous entry in the access queue.
setPreviousInAccessQueue(LocalCache.ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.StrongAccessEntry
 
setPreviousInAccessQueue(LocalCache.ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.StrongAccessWriteEntry
 
setPreviousInAccessQueue(LocalCache.ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.WeakAccessEntry
 
setPreviousInAccessQueue(LocalCache.ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.WeakAccessWriteEntry
 
setPreviousInAccessQueue(LocalCache.ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.WeakEntry
 
setPreviousInWriteQueue(LocalCache.ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.AbstractReferenceEntry
 
setPreviousInWriteQueue(LocalCache.ReferenceEntry<Object, Object>) - Method in enum com.google.common.cache.LocalCache.NullEntry
 
setPreviousInWriteQueue(LocalCache.ReferenceEntry<K, V>) - Method in interface com.google.common.cache.LocalCache.ReferenceEntry
Sets the previous entry in the write queue.
setPreviousInWriteQueue(LocalCache.ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.StrongAccessWriteEntry
 
setPreviousInWriteQueue(LocalCache.ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.StrongWriteEntry
 
setPreviousInWriteQueue(LocalCache.ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.WeakAccessWriteEntry
 
setPreviousInWriteQueue(LocalCache.ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.WeakEntry
 
setPreviousInWriteQueue(LocalCache.ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.WeakWriteEntry
 
setPriority(int) - Method in class com.google.common.util.concurrent.ThreadFactoryBuilder
Sets the priority for new threads created with this ThreadFactory.
setRate(double) - Method in class com.google.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.
Sets - Class in com.google.common.collect
Static utility methods pertaining to Set instances.
Sets() - Constructor for class com.google.common.collect.Sets
 
Sets.CartesianSet<E> - Class in com.google.common.collect
 
Sets.DescendingSet<E> - Class in com.google.common.collect
 
Sets.FilteredNavigableSet<E> - Class in com.google.common.collect
 
Sets.FilteredSet<E> - Class in com.google.common.collect
 
Sets.FilteredSortedSet<E> - Class in com.google.common.collect
 
Sets.ImprovedAbstractSet<E> - Class in com.google.common.collect
AbstractSet substitute without the potentially-quadratic removeAll implementation.
Sets.PowerSet<E> - Class in com.google.common.collect
 
Sets.SetView<E> - Class in com.google.common.collect
An unmodifiable view of a set which may be backed by other sets; this view will change as the backing sets do.
Sets.SubSet<E> - Class in com.google.common.collect
 
Sets.UnmodifiableNavigableSet<E> - Class in com.google.common.collect
 
setSafeRange(char, char) - Method in class com.google.common.escape.Escapers.Builder
Sets the safe range of characters for the escaper.
setsFilterSortedSet(SortedSet<E>, Predicate<? super E>) - Static method in class com.google.common.collect.Platform
 
setSuccessorInMultimap(LinkedHashMultimap.ValueEntry<K, V>) - Method in class com.google.common.collect.LinkedHashMultimap.ValueEntry
 
setSuccessorInValueSet(LinkedHashMultimap.ValueSetLink<K, V>) - Method in class com.google.common.collect.LinkedHashMultimap.ValueEntry
 
setSuccessorInValueSet(LinkedHashMultimap.ValueSetLink<K, V>) - Method in class com.google.common.collect.LinkedHashMultimap.ValueSet
 
setSuccessorInValueSet(LinkedHashMultimap.ValueSetLink<K, V>) - Method in interface com.google.common.collect.LinkedHashMultimap.ValueSetLink
 
SettableFuture<V> - Class in com.google.common.util.concurrent
SettableFuture() - Constructor for class com.google.common.util.concurrent.SettableFuture
Explicit private constructor, use the SettableFuture.create() factory method to create instances of SettableFuture.
setThreadFactory(ThreadFactory) - Method in class com.google.common.util.concurrent.ThreadFactoryBuilder
Sets the backing ThreadFactory for new threads created with this ThreadFactory.
setUncaughtExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class com.google.common.util.concurrent.ThreadFactoryBuilder
Sets the Thread.UncaughtExceptionHandler for new threads created with this ThreadFactory.
setUnsafeReplacement(String) - Method in class com.google.common.escape.Escapers.Builder
Sets the replacement string for any characters outside the 'safe' range that have no explicit replacement.
setValue(LocalCache.ReferenceEntry<K, V>, K, V, long) - Method in class com.google.common.cache.LocalCache.Segment
Sets a new value of an entry.
setValue(V) - Method in class com.google.common.cache.LocalCache.WriteThroughEntry
 
setValue(V) - Method in class com.google.common.cache.RemovalNotification
 
setValue(V) - Method in class com.google.common.collect.AbstractMapEntry
 
setValue(int, V) - Method in class com.google.common.collect.ArrayTable.ArrayMap
 
setValue(int, V) - Method in class com.google.common.collect.ArrayTable.Column
 
setValue(int, Map<R, V>) - Method in class com.google.common.collect.ArrayTable.ColumnMap
 
setValue(int, V) - Method in class com.google.common.collect.ArrayTable.Row
 
setValue(int, Map<C, V>) - Method in class com.google.common.collect.ArrayTable.RowMap
 
setValue(V) - Method in class com.google.common.collect.ForwardingMapEntry
 
setValue(V) - Method in class com.google.common.collect.ImmutableEntry
 
setValue(V) - Method in class com.google.common.collect.LinkedListMultimap.Node
 
setValue(V) - Method in class com.google.common.collect.LinkedListMultimap.NodeIterator
 
setValue(MapMakerInternalMap.ReferenceEntry<K, V>, V) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Sets a new value of an entry.
setValue(V) - Method in class com.google.common.collect.MapMakerInternalMap.WriteThroughEntry
 
setValue(V) - Method in class com.google.common.collect.Synchronized.SynchronizedEntry
 
setValue(V) - Method in class com.google.common.reflect.MutableTypeToInstanceMap.UnmodifiableEntry
 
setValue(V) - Method in class com.google.common.util.concurrent.AsyncSettableFuture
setValueReference(LocalCache.ValueReference<K, V>) - Method in class com.google.common.cache.LocalCache.AbstractReferenceEntry
 
setValueReference(LocalCache.ValueReference<Object, Object>) - Method in enum com.google.common.cache.LocalCache.NullEntry
 
setValueReference(LocalCache.ValueReference<K, V>) - Method in interface com.google.common.cache.LocalCache.ReferenceEntry
Sets the value reference for this entry.
setValueReference(LocalCache.ValueReference<K, V>) - Method in class com.google.common.cache.LocalCache.StrongEntry
 
setValueReference(LocalCache.ValueReference<K, V>) - Method in class com.google.common.cache.LocalCache.WeakEntry
 
setValueReference(MapMakerInternalMap.ValueReference<K, V>) - Method in class com.google.common.collect.ComputingConcurrentHashMap.ComputingValueReference
 
setValueReference(MapMakerInternalMap.ValueReference<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.AbstractReferenceEntry
 
setValueReference(MapMakerInternalMap.ValueReference<Object, Object>) - Method in enum com.google.common.collect.MapMakerInternalMap.NullEntry
 
setValueReference(MapMakerInternalMap.ValueReference<K, V>) - Method in interface com.google.common.collect.MapMakerInternalMap.ReferenceEntry
Sets the value reference for this entry.
setValueReference(MapMakerInternalMap.ValueReference<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.SoftEntry
 
setValueReference(MapMakerInternalMap.ValueReference<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.StrongEntry
 
setValueReference(MapMakerInternalMap.ValueReference<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.WeakEntry
 
setValueStrength(LocalCache.Strength) - Method in class com.google.common.cache.CacheBuilder
 
setValueStrength(MapMakerInternalMap.Strength) - Method in class com.google.common.collect.MapMaker
 
SetView() - Constructor for class com.google.common.collect.Sets.SetView
 
setWriteTime(long) - Method in class com.google.common.cache.LocalCache.AbstractReferenceEntry
 
setWriteTime(long) - Method in enum com.google.common.cache.LocalCache.NullEntry
 
setWriteTime(long) - Method in interface com.google.common.cache.LocalCache.ReferenceEntry
Sets the entry write time in ns.
setWriteTime(long) - Method in class com.google.common.cache.LocalCache.StrongAccessWriteEntry
 
setWriteTime(long) - Method in class com.google.common.cache.LocalCache.StrongWriteEntry
 
setWriteTime(long) - Method in class com.google.common.cache.LocalCache.WeakAccessWriteEntry
 
setWriteTime(long) - Method in class com.google.common.cache.LocalCache.WeakEntry
 
setWriteTime(long) - Method in class com.google.common.cache.LocalCache.WeakWriteEntry
 
SFNT - Static variable in class com.google.common.net.MediaType
Media type for SFNT fonts (which includes TrueType and OpenType fonts).
sha1() - Static method in class com.google.common.hash.Hashing
Returns a hash function implementing the SHA-1 algorithm (160 hash bits) by delegating to the SHA-1 MessageDigest.
Sha1Holder() - Constructor for class com.google.common.hash.Hashing.Sha1Holder
 
sha256() - Static method in class com.google.common.hash.Hashing
Returns a hash function implementing the SHA-256 algorithm (256 hash bits) by delegating to the SHA-256 MessageDigest.
Sha256Holder() - Constructor for class com.google.common.hash.Hashing.Sha256Holder
 
sha512() - Static method in class com.google.common.hash.Hashing
Returns a hash function implementing the SHA-512 algorithm (512 hash bits) by delegating to the SHA-512 MessageDigest.
Sha512Holder() - Constructor for class com.google.common.hash.Hashing.Sha512Holder
 
SHA_1 - Static variable in class com.google.common.hash.Hashing.Sha1Holder
 
SHA_256 - Static variable in class com.google.common.hash.Hashing.Sha256Holder
 
SHA_512 - Static variable in class com.google.common.hash.Hashing.Sha512Holder
 
SHOCKWAVE_FLASH - Static variable in class com.google.common.net.MediaType
 
ShortArrayAsList(short[]) - Constructor for class com.google.common.primitives.Shorts.ShortArrayAsList
 
ShortArrayAsList(short[], int, int) - Constructor for class com.google.common.primitives.Shorts.ShortArrayAsList
 
ShortConverter() - Constructor for class com.google.common.primitives.Shorts.ShortConverter
 
Shorts - Class in com.google.common.primitives
Static utility methods pertaining to short primitives, that are not already found in either Short or Arrays.
Shorts() - Constructor for class com.google.common.primitives.Shorts
 
Shorts.LexicographicalComparator - Enum in com.google.common.primitives
 
Shorts.ShortArrayAsList - Class in com.google.common.primitives
 
Shorts.ShortConverter - Class in com.google.common.primitives
 
showCharacter(char) - Static method in class com.google.common.base.CharMatcher
 
shutDown() - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
Stop the service.
shutDown() - Method in class com.google.common.util.concurrent.AbstractIdleService
Stop the service.
shutDown() - Method in class com.google.common.util.concurrent.AbstractScheduledService
Stop the service.
shutdown() - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
shutdown - Variable in class com.google.common.util.concurrent.MoreExecutors.DirectExecutorService
 
shutdown() - Method in class com.google.common.util.concurrent.MoreExecutors.DirectExecutorService
 
shutdown() - Method in class com.google.common.util.concurrent.MoreExecutors.ListeningDecorator
 
shutdown() - Method in class com.google.common.util.concurrent.WrappingExecutorService
 
shutdownAndAwaitTermination(ExecutorService, long, TimeUnit) - Static method in class com.google.common.util.concurrent.MoreExecutors
Shuts down the given executor gradually, first disabling new submissions and later cancelling existing tasks.
shutdownNow() - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
shutdownNow() - Method in class com.google.common.util.concurrent.MoreExecutors.DirectExecutorService
 
shutdownNow() - Method in class com.google.common.util.concurrent.MoreExecutors.ListeningDecorator
 
shutdownNow() - Method in class com.google.common.util.concurrent.WrappingExecutorService
 
shutdownWhenStartupFinishes - Variable in class com.google.common.util.concurrent.AbstractService.StateSnapshot
If true, the user requested a shutdown while the service was still starting up.
SI - Static variable in class com.google.common.base.Ascii
Shift In: A control character indicating that the code combinations which follow shall be interpreted according to the standard code table.
SIGN_MASK - Static variable in class com.google.common.math.DoubleUtils
 
signalAllWaiters() - Method in class com.google.common.util.concurrent.Monitor
Signals all threads waiting on guards.
signalNextWaiter() - Method in class com.google.common.util.concurrent.Monitor
Signals some other thread waiting on a satisfied guard, if one exists.
SignedBytes - Class in com.google.common.primitives
Static utility methods pertaining to byte primitives that interpret values as signed.
SignedBytes() - Constructor for class com.google.common.primitives.SignedBytes
 
SignedBytes.LexicographicalComparator - Enum in com.google.common.primitives
 
SIGNIFICAND_BITS - Static variable in class com.google.common.math.DoubleUtils
 
SIGNIFICAND_MASK - Static variable in class com.google.common.math.DoubleUtils
 
SimpleForwardingCache(Cache<K, V>) - Constructor for class com.google.common.cache.ForwardingCache.SimpleForwardingCache
 
SimpleForwardingCheckedFuture(CheckedFuture<V, X>) - Constructor for class com.google.common.util.concurrent.ForwardingCheckedFuture.SimpleForwardingCheckedFuture
 
SimpleForwardingFuture(Future<V>) - Constructor for class com.google.common.util.concurrent.ForwardingFuture.SimpleForwardingFuture
 
SimpleForwardingListenableFuture(ListenableFuture<V>) - Constructor for class com.google.common.util.concurrent.ForwardingListenableFuture.SimpleForwardingListenableFuture
 
SimpleForwardingLoadingCache(LoadingCache<K, V>) - Constructor for class com.google.common.cache.ForwardingLoadingCache.SimpleForwardingLoadingCache
 
simpleName(Class<?>) - Static method in class com.google.common.base.MoreObjects
Class.getSimpleName() is not GWT compatible yet, so we provide our own implementation.
SimpleStatsCounter() - Constructor for class com.google.common.cache.AbstractCache.SimpleStatsCounter
Constructs an instance with all counts initialized to zero.
SimpleTimeLimiter - Class in com.google.common.util.concurrent
A TimeLimiter that runs method calls in the background using an ExecutorService.
SimpleTimeLimiter(ExecutorService) - Constructor for class com.google.common.util.concurrent.SimpleTimeLimiter
Constructs a TimeLimiter instance using the given executor service to execute proxied method calls.
SimpleTimeLimiter() - Constructor for class com.google.common.util.concurrent.SimpleTimeLimiter
Constructs a TimeLimiter instance using a Executors.newCachedThreadPool() to execute proxied method calls.
SimpleTypeToken(Type) - Constructor for class com.google.common.reflect.TypeToken.SimpleTypeToken
 
simplifyPath(String) - Static method in class com.google.common.io.Files
Returns the lexically cleaned form of the path name, usually (but not always) equivalent to the original.
SINGLE_WIDTH - Static variable in class com.google.common.base.CharMatcher
Determines whether a character is single-width (not double-width).
singleColumnKey - Variable in class com.google.common.collect.SingletonImmutableTable
 
singleKey - Variable in class com.google.common.collect.SingletonImmutableBiMap
 
singleRowKey - Variable in class com.google.common.collect.SingletonImmutableTable
 
singleton(C) - Static method in class com.google.common.collect.Range
Returns a range that contains only the given value.
SingletonImmutableBiMap<K,V> - Class in com.google.common.collect
Implementation of ImmutableMap with exactly one entry.
SingletonImmutableBiMap(K, V) - Constructor for class com.google.common.collect.SingletonImmutableBiMap
 
SingletonImmutableBiMap(K, V, ImmutableBiMap<V, K>) - Constructor for class com.google.common.collect.SingletonImmutableBiMap
 
SingletonImmutableBiMap(Map.Entry<? extends K, ? extends V>) - Constructor for class com.google.common.collect.SingletonImmutableBiMap
 
SingletonImmutableList<E> - Class in com.google.common.collect
Implementation of ImmutableList with exactly one element.
SingletonImmutableList(E) - Constructor for class com.google.common.collect.SingletonImmutableList
 
SingletonImmutableSet<E> - Class in com.google.common.collect
Implementation of ImmutableSet with exactly one element.
SingletonImmutableSet(E) - Constructor for class com.google.common.collect.SingletonImmutableSet
 
SingletonImmutableSet(E, int) - Constructor for class com.google.common.collect.SingletonImmutableSet
 
SingletonImmutableTable<R,C,V> - Class in com.google.common.collect
An implementation of ImmutableTable that holds a single cell.
SingletonImmutableTable(R, C, V) - Constructor for class com.google.common.collect.SingletonImmutableTable
 
SingletonImmutableTable(Table.Cell<R, C, V>) - Constructor for class com.google.common.collect.SingletonImmutableTable
 
singletonIterator(T) - Static method in class com.google.common.collect.Iterators
Returns an iterator containing only value.
singleValue - Variable in class com.google.common.collect.SingletonImmutableBiMap
 
singleValue - Variable in class com.google.common.collect.SingletonImmutableTable
 
sink - Variable in class com.google.common.hash.Funnels.SinkAsStream
 
SinkAsStream(PrimitiveSink) - Constructor for class com.google.common.hash.Funnels.SinkAsStream
 
SIP_HASH_24 - Static variable in class com.google.common.hash.Hashing.SipHash24Holder
 
sipHash24() - Static method in class com.google.common.hash.Hashing
Returns a hash function implementing the 64-bit SipHash-2-4 algorithm using a seed value of k = 00 01 02 ....
sipHash24(long, long) - Static method in class com.google.common.hash.Hashing
Returns a hash function implementing the 64-bit SipHash-2-4 algorithm using the given seed.
SipHash24Holder() - Constructor for class com.google.common.hash.Hashing.SipHash24Holder
 
SipHasher(int, int, long, long) - Constructor for class com.google.common.hash.SipHashFunction.SipHasher
 
SipHashFunction - Class in com.google.common.hash
HashFunction implementation of SipHash-c-d.
SipHashFunction(int, int, long, long) - Constructor for class com.google.common.hash.SipHashFunction
 
SipHashFunction.SipHasher - Class in com.google.common.hash
 
sipRound(int) - Method in class com.google.common.hash.SipHashFunction.SipHasher
 
size() - Method in class com.google.common.cache.AbstractCache
 
size() - Method in interface com.google.common.cache.Cache
Returns the approximate number of entries in this cache.
size() - Method in class com.google.common.cache.ForwardingCache
 
size() - Method in class com.google.common.cache.LocalCache.AbstractCacheSet
 
size() - Method in class com.google.common.cache.LocalCache.AccessQueue
 
size() - Method in class com.google.common.cache.LocalCache.LocalManualCache
 
size() - Method in class com.google.common.cache.LocalCache
 
size() - Method in class com.google.common.cache.LocalCache.Values
 
size() - Method in class com.google.common.cache.LocalCache.WriteQueue
 
size - Variable in class com.google.common.collect.AbstractIndexedListIterator
 
size() - Method in class com.google.common.collect.AbstractMapBasedMultimap.AsMap
 
size() - Method in class com.google.common.collect.AbstractMapBasedMultimap
 
size() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection
 
size - Variable in class com.google.common.collect.AbstractMapBasedMultiset
 
size() - Method in class com.google.common.collect.AbstractMapBasedMultiset
 
size() - Method in class com.google.common.collect.AbstractMultimap.Values
 
size() - Method in class com.google.common.collect.AbstractMultiset.EntrySet
 
size() - Method in class com.google.common.collect.AbstractMultiset
 
size() - Method in class com.google.common.collect.AbstractNavigableMap
 
size() - Method in class com.google.common.collect.AbstractTable.CellSet
 
size() - Method in class com.google.common.collect.AbstractTable.Values
 
size() - Method in class com.google.common.collect.ArrayTable.ArrayMap
 
size() - Method in class com.google.common.collect.ArrayTable
 
size() - Method in class com.google.common.collect.CartesianList
 
size() - Method in class com.google.common.collect.Collections2.FilteredCollection
 
size - Variable in class com.google.common.collect.Collections2.OrderedPermutationCollection
 
size() - Method in class com.google.common.collect.Collections2.OrderedPermutationCollection
 
size() - Method in class com.google.common.collect.Collections2.PermutationCollection
 
size() - Method in class com.google.common.collect.Collections2.TransformedCollection
 
size() - Method in class com.google.common.collect.ConcurrentHashMultiset
size - Variable in class com.google.common.collect.DenseImmutableTable.ImmutableArrayMap
 
size() - Method in class com.google.common.collect.DenseImmutableTable.ImmutableArrayMap
 
size() - Method in class com.google.common.collect.DenseImmutableTable
 
size() - Method in class com.google.common.collect.DescendingImmutableSortedMultiset
 
size() - Method in class com.google.common.collect.DescendingImmutableSortedSet
 
size() - Method in class com.google.common.collect.EmptyContiguousSet
 
size() - Method in class com.google.common.collect.EmptyImmutableBiMap
 
size() - Method in class com.google.common.collect.EmptyImmutableSet
 
size() - Method in class com.google.common.collect.EmptyImmutableSortedMap
 
size() - Method in class com.google.common.collect.EmptyImmutableSortedMultiset
 
size() - Method in class com.google.common.collect.EmptyImmutableSortedSet
 
size() - Method in class com.google.common.collect.FilteredEntryMultimap
 
size() - Method in class com.google.common.collect.FilteredKeyMultimap
 
size() - Method in class com.google.common.collect.FilteredMultimapValues
 
size() - Method in class com.google.common.collect.FluentIterable
Returns the number of elements in this fluent iterable.
size() - Method in class com.google.common.collect.ForwardingCollection
 
size() - Method in class com.google.common.collect.ForwardingMap
 
size() - Method in class com.google.common.collect.ForwardingMultimap
 
size() - Method in class com.google.common.collect.ForwardingTable
 
size() - Method in class com.google.common.collect.HashBiMap.Inverse
 
size - Variable in class com.google.common.collect.HashBiMap
 
size() - Method in class com.google.common.collect.HashBiMap
 
size() - Method in class com.google.common.collect.ImmutableAsList
 
size - Variable in class com.google.common.collect.ImmutableCollection.ArrayBasedBuilder
 
size() - Method in class com.google.common.collect.ImmutableEnumMap
 
size() - Method in class com.google.common.collect.ImmutableEnumSet
 
size() - Method in class com.google.common.collect.ImmutableList.ReverseImmutableList
 
size() - Method in class com.google.common.collect.ImmutableList.SubList
 
size - Variable in class com.google.common.collect.ImmutableMap.Builder
 
size() - Method in class com.google.common.collect.ImmutableMap.MapViewOfValuesAsSingletonSets
 
size() - Method in class com.google.common.collect.ImmutableMapEntrySet
 
size() - Method in class com.google.common.collect.ImmutableMapKeySet
 
size() - Method in class com.google.common.collect.ImmutableMapValues
 
size() - Method in class com.google.common.collect.ImmutableMultimap.EntryCollection
 
size() - Method in class com.google.common.collect.ImmutableMultimap.Keys
 
size - Variable in class com.google.common.collect.ImmutableMultimap
 
size() - Method in class com.google.common.collect.ImmutableMultimap
 
size() - Method in class com.google.common.collect.ImmutableMultimap.Values
 
size() - Method in class com.google.common.collect.ImmutableMultiset.EntrySet
 
size - Variable in class com.google.common.collect.ImmutableRangeSet.AsSet
 
size() - Method in class com.google.common.collect.ImmutableRangeSet.AsSet
 
size - Variable in class com.google.common.collect.ImmutableRangeSet.ComplementRanges
 
size() - Method in class com.google.common.collect.ImmutableRangeSet.ComplementRanges
 
size() - Method in class com.google.common.collect.ImmutableSetMultimap.EntrySet
 
size() - Method in class com.google.common.collect.ImmutableSortedMap
 
size(Iterable<?>) - Static method in class com.google.common.collect.Iterables
Returns the number of elements in iterable.
size(Iterator<?>) - Static method in class com.google.common.collect.Iterators
Returns the number of elements remaining in iterator.
size - Variable in class com.google.common.collect.LinkedHashMultimap.ValueSet
 
size() - Method in class com.google.common.collect.LinkedHashMultimap.ValueSet
 
size - Variable in class com.google.common.collect.LinkedListMultimap
 
size() - Method in class com.google.common.collect.LinkedListMultimap
 
size() - Method in class com.google.common.collect.Lists.AbstractListWrapper
 
size() - Method in class com.google.common.collect.Lists.CharSequenceAsList
 
size() - Method in class com.google.common.collect.Lists.OnePlusArrayList
 
size - Variable in class com.google.common.collect.Lists.Partition
 
size() - Method in class com.google.common.collect.Lists.Partition
 
size() - Method in class com.google.common.collect.Lists.ReverseList
 
size() - Method in class com.google.common.collect.Lists.StringAsImmutableList
 
size() - Method in class com.google.common.collect.Lists.TransformingRandomAccessList
 
size() - Method in class com.google.common.collect.Lists.TransformingSequentialList
 
size() - Method in class com.google.common.collect.Lists.TwoPlusArrayList
 
size() - Method in class com.google.common.collect.MapMakerInternalMap.EntrySet
 
size() - Method in class com.google.common.collect.MapMakerInternalMap.EvictionQueue
 
size() - Method in class com.google.common.collect.MapMakerInternalMap.ExpirationQueue
 
size() - Method in class com.google.common.collect.MapMakerInternalMap.KeySet
 
size() - Method in class com.google.common.collect.MapMakerInternalMap
 
size() - Method in class com.google.common.collect.MapMakerInternalMap.Values
 
size() - Method in class com.google.common.collect.Maps.AsMapView
 
size() - Method in class com.google.common.collect.Maps.EntrySet
 
size() - Method in class com.google.common.collect.Maps.FilteredEntryNavigableMap
 
size() - Method in class com.google.common.collect.Maps.KeySet
 
size() - Method in class com.google.common.collect.Maps.NavigableAsMapView
 
size() - Method in class com.google.common.collect.Maps.TransformedEntriesMap
 
size() - Method in class com.google.common.collect.Maps.Values
 
size - Variable in class com.google.common.collect.MinMaxPriorityQueue
 
size() - Method in class com.google.common.collect.MinMaxPriorityQueue
 
size() - Method in interface com.google.common.collect.Multimap
Returns the number of key-value pairs in this multimap.
size() - Method in class com.google.common.collect.Multimaps.AsMap
 
size() - Method in class com.google.common.collect.Multimaps.Entries
 
size() - Method in class com.google.common.collect.Multimaps.Keys.KeysEntrySet
 
size() - Method in class com.google.common.collect.Multimaps.MapMultimap
 
size() - Method in class com.google.common.collect.Multimaps.TransformedEntriesMultimap
 
size() - Method in class com.google.common.collect.Multisets.ElementSet
 
size() - Method in class com.google.common.collect.RegularContiguousSet
 
size() - Method in class com.google.common.collect.RegularImmutableBiMap.Inverse
 
size() - Method in class com.google.common.collect.RegularImmutableBiMap
 
size - Variable in class com.google.common.collect.RegularImmutableList
 
size() - Method in class com.google.common.collect.RegularImmutableList
 
size() - Method in class com.google.common.collect.RegularImmutableMap
 
size - Variable in class com.google.common.collect.RegularImmutableMultiset
 
size() - Method in class com.google.common.collect.RegularImmutableMultiset
 
size() - Method in class com.google.common.collect.RegularImmutableSet
 
size() - Method in class com.google.common.collect.RegularImmutableSortedMultiset
 
size() - Method in class com.google.common.collect.RegularImmutableSortedSet
 
size() - Method in class com.google.common.collect.RegularImmutableTable.CellSet
 
size() - Method in class com.google.common.collect.RegularImmutableTable.Values
 
size() - Method in class com.google.common.collect.Sets.PowerSet
 
size() - Method in class com.google.common.collect.Sets.SubSet
 
size() - Method in class com.google.common.collect.SingletonImmutableBiMap
 
size() - Method in class com.google.common.collect.SingletonImmutableList
 
size() - Method in class com.google.common.collect.SingletonImmutableSet
 
size() - Method in class com.google.common.collect.SingletonImmutableTable
 
size() - Method in class com.google.common.collect.SparseImmutableTable
 
size() - Method in class com.google.common.collect.StandardTable.Column.EntrySet
 
size() - Method in class com.google.common.collect.StandardTable.ColumnKeySet
 
size() - Method in class com.google.common.collect.StandardTable.ColumnMap.ColumnMapEntrySet
 
size() - Method in class com.google.common.collect.StandardTable.Row.RowEntrySet
 
size() - Method in class com.google.common.collect.StandardTable.RowMap.EntrySet
 
size() - Method in class com.google.common.collect.StandardTable
 
size() - Method in class com.google.common.collect.Synchronized.SynchronizedCollection
 
size() - Method in class com.google.common.collect.Synchronized.SynchronizedMap
 
size() - Method in class com.google.common.collect.Synchronized.SynchronizedMultimap
 
size() - Method in interface com.google.common.collect.Table
Returns the number of row key / column key / value mappings in the table.
size() - Method in class com.google.common.collect.Tables.TransformedTable
 
size() - Method in class com.google.common.collect.Tables.TransposeTable
 
size() - Method in class com.google.common.collect.TreeMultiset
 
size() - Method in class com.google.common.collect.TreeRangeSet.ComplementRangesByLowerBound
 
size() - Method in class com.google.common.collect.TreeRangeSet.RangesByUpperBound
 
size() - Method in class com.google.common.collect.TreeRangeSet.SubRangeSetRangesByLowerBound
 
size() - Method in class com.google.common.io.ByteSource.ByteArrayByteSource
 
size() - Method in class com.google.common.io.ByteSource.ConcatenatedByteSource
 
size() - Method in class com.google.common.io.ByteSource
Returns the size of this source in bytes.
size() - Method in class com.google.common.io.Files.FileByteSource
 
size() - Method in class com.google.common.primitives.Booleans.BooleanArrayAsList
 
size() - Method in class com.google.common.primitives.Bytes.ByteArrayAsList
 
size() - Method in class com.google.common.primitives.Chars.CharArrayAsList
 
size() - Method in class com.google.common.primitives.Doubles.DoubleArrayAsList
 
size() - Method in class com.google.common.primitives.Floats.FloatArrayAsList
 
size() - Method in class com.google.common.primitives.Ints.IntArrayAsList
 
size() - Method in class com.google.common.primitives.Longs.LongArrayAsList
 
size() - Method in class com.google.common.primitives.Shorts.ShortArrayAsList
 
size() - Method in class com.google.common.util.concurrent.AtomicLongMap
Returns the number of key-value mappings in this map.
size() - Method in class com.google.common.util.concurrent.Striped.CompactStriped
 
size - Variable in class com.google.common.util.concurrent.Striped.LargeLazyStriped
 
size() - Method in class com.google.common.util.concurrent.Striped.LargeLazyStriped
 
size() - Method in class com.google.common.util.concurrent.Striped
Returns the total number of stripes in this instance.
size - Variable in class com.google.common.util.concurrent.Striped.SmallLazyStriped
 
size() - Method in class com.google.common.util.concurrent.Striped.SmallLazyStriped
 
SIZE_FIELD_SETTER - Static variable in class com.google.common.collect.ImmutableMultimap.FieldSettersHolder
 
sizeImpl(Multiset<?>) - Static method in class com.google.common.collect.Multisets
An implementation of Collection.size().
SKETCHUP - Static variable in class com.google.common.net.MediaType
 
skip(int) - Method in class com.google.common.collect.FluentIterable
Returns a view of this fluent iterable that skips its first numberToSkip elements.
skip(Iterable<T>, int) - Static method in class com.google.common.collect.Iterables
Returns a view of iterable that skips its first numberToSkip elements.
skip(long) - Method in class com.google.common.io.ByteStreams.LimitedInputStream
 
skip(long) - Method in class com.google.common.io.CharSequenceReader
 
skip(long) - Method in class com.google.common.io.CountingInputStream
 
skip(long) - Method in class com.google.common.io.MultiInputStream
 
skip(long) - Method in class com.google.common.io.MultiReader
 
skipBytes(int) - Method in interface com.google.common.io.ByteArrayDataInput
 
skipBytes(int) - Method in class com.google.common.io.ByteStreams.ByteArrayDataInputStream
 
skipBytes(int) - Method in class com.google.common.io.LittleEndianDataInputStream
 
skipFully(InputStream, long) - Static method in class com.google.common.io.ByteStreams
Discards n bytes of data from the input stream.
skipFully(Reader, long) - Static method in class com.google.common.io.CharStreams
Discards n characters of data from the reader.
skipMe - Variable in class com.google.common.collect.MinMaxPriorityQueue.QueueIterator
 
skipNulls() - Method in class com.google.common.base.Joiner
Returns a joiner with the same behavior as this joiner, except automatically skipping over any provided null elements.
SleepingStopwatch() - Constructor for class com.google.common.util.concurrent.RateLimiter.SleepingStopwatch
 
sleepMicrosUninterruptibly(long) - Method in class com.google.common.util.concurrent.RateLimiter.SleepingStopwatch
 
sleepUninterruptibly(long, TimeUnit) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes unit.sleep(sleepFor) uninterruptibly.
slice(long, long) - Method in class com.google.common.io.ByteSource
Returns a view of a slice of this byte source that is at most length bytes long starting at the given offset.
slice(long, long) - Method in class com.google.common.io.ByteSource.SlicedByteSource
 
SlicedByteSource(long, long) - Constructor for class com.google.common.io.ByteSource.SlicedByteSource
 
sliceStream(InputStream) - Method in class com.google.common.io.ByteSource.SlicedByteSource
 
slope - Variable in class com.google.common.util.concurrent.SmoothRateLimiter.SmoothWarmingUp
The slope of the line from the stable interval (when permits == 0), to the cold interval (when permits == maxPermits)
slowRemoveIfForRemainingElements(List<T>, Predicate<? super T>, int, int) - Static method in class com.google.common.collect.Iterables
 
SmallCharMatcher - Class in com.google.common.base
An immutable version of CharMatcher for smallish sets of characters that uses a hash table with linear probing to check for matches.
SmallCharMatcher(char[], long, boolean, String) - Constructor for class com.google.common.base.SmallCharMatcher
 
SmallLazyStriped(int, Supplier<L>) - Constructor for class com.google.common.util.concurrent.Striped.SmallLazyStriped
 
smear(int) - Static method in class com.google.common.base.SmallCharMatcher
 
smear(int) - Static method in class com.google.common.collect.Hashing
 
smear(int) - Static method in class com.google.common.util.concurrent.Striped
 
smearedHash(Object) - Static method in class com.google.common.collect.Hashing
 
smearedValueHash - Variable in class com.google.common.collect.LinkedHashMultimap.ValueEntry
 
SmoothBursty(RateLimiter.SleepingStopwatch, double) - Constructor for class com.google.common.util.concurrent.SmoothRateLimiter.SmoothBursty
 
SmoothRateLimiter - Class in com.google.common.util.concurrent
 
SmoothRateLimiter(RateLimiter.SleepingStopwatch) - Constructor for class com.google.common.util.concurrent.SmoothRateLimiter
 
SmoothRateLimiter.SmoothBursty - Class in com.google.common.util.concurrent
This implements a "bursty" RateLimiter, where storedPermits are translated to zero throttling.
SmoothRateLimiter.SmoothWarmingUp - Class in com.google.common.util.concurrent
This implements the following function: ^ throttling | 3*stable + / interval | /.
SmoothWarmingUp(RateLimiter.SleepingStopwatch, long, TimeUnit) - Constructor for class com.google.common.util.concurrent.SmoothRateLimiter.SmoothWarmingUp
 
snapshot() - Method in class com.google.common.cache.AbstractCache.SimpleStatsCounter
 
snapshot() - Method in interface com.google.common.cache.AbstractCache.StatsCounter
Returns a snapshot of this counter's values.
snapshot() - Method in class com.google.common.collect.ConcurrentHashMultiset.EntrySet
 
snapshot() - Method in class com.google.common.collect.ConcurrentHashMultiset
 
snapshot - Variable in class com.google.common.util.concurrent.AbstractService
The current state of the service.
SO - Static variable in class com.google.common.base.Ascii
Shift Out: A control character indicating that the code combinations which follow shall be interpreted as outside of the character set of the standard code table until a Shift In character is reached.
SoftEntry(ReferenceQueue<K>, K, int, MapMakerInternalMap.ReferenceEntry<K, V>) - Constructor for class com.google.common.collect.MapMakerInternalMap.SoftEntry
 
SoftEvictableEntry(ReferenceQueue<K>, K, int, MapMakerInternalMap.ReferenceEntry<K, V>) - Constructor for class com.google.common.collect.MapMakerInternalMap.SoftEvictableEntry
 
SoftExpirableEntry(ReferenceQueue<K>, K, int, MapMakerInternalMap.ReferenceEntry<K, V>) - Constructor for class com.google.common.collect.MapMakerInternalMap.SoftExpirableEntry
 
SoftExpirableEvictableEntry(ReferenceQueue<K>, K, int, MapMakerInternalMap.ReferenceEntry<K, V>) - Constructor for class com.google.common.collect.MapMakerInternalMap.SoftExpirableEvictableEntry
 
SoftValueReference(ReferenceQueue<V>, V, LocalCache.ReferenceEntry<K, V>) - Constructor for class com.google.common.cache.LocalCache.SoftValueReference
 
SoftValueReference(ReferenceQueue<V>, V, MapMakerInternalMap.ReferenceEntry<K, V>) - Constructor for class com.google.common.collect.MapMakerInternalMap.SoftValueReference
 
softValues() - Method in class com.google.common.cache.CacheBuilder
Specifies that each value (not key) stored in the cache should be wrapped in a SoftReference (by default, strong references are used).
softValues() - Method in class com.google.common.collect.GenericMapMaker
Deprecated.
Caching functionality in MapMaker has been moved to CacheBuilder, with GenericMapMaker.softValues() being replaced by CacheBuilder.softValues(). Note that CacheBuilder is simply an enhanced API for an implementation which was branched from MapMaker. This method is scheduled for removal in March 2015.
softValues() - Method in class com.google.common.collect.MapMaker
Deprecated.
Caching functionality in MapMaker has been moved to CacheBuilder, with MapMaker.softValues() being replaced by CacheBuilder.softValues(). Note that CacheBuilder is simply an enhanced API for an implementation which was branched from MapMaker. This method is scheduled for removal in March 2015.
SOH - Static variable in class com.google.common.base.Ascii
Start of Heading: A communication control character used at the beginning of a sequence of characters which constitute a machine-sensible address or routing information.
SortedAsMap(SortedMap<K, Collection<V>>) - Constructor for class com.google.common.collect.AbstractMapBasedMultimap.SortedAsMap
 
SortedAsMapView(SortedSet<K>, Function<? super K, V>) - Constructor for class com.google.common.collect.Maps.SortedAsMapView
 
sortedBackingMap() - Method in class com.google.common.collect.StandardRowSortedTable
 
sortedCopy(Iterable<E>) - Method in class com.google.common.collect.AllEqualOrdering
 
sortedCopy(Iterable<E>) - Method in class com.google.common.collect.Ordering
Returns a mutable list containing elements sorted by this ordering; use this only when the resulting list may need further modification, or may contain null.
SortedIterable<T> - Interface in com.google.common.collect
An Iterable whose elements are sorted relative to a Comparator, typically provided at creation time.
SortedIterables - Class in com.google.common.collect
Utilities for dealing with sorted collections of all types.
SortedIterables() - Constructor for class com.google.common.collect.SortedIterables
 
sortedKeySet - Variable in class com.google.common.collect.AbstractMapBasedMultimap.SortedAsMap
 
SortedKeySet(SortedMap<K, Collection<V>>) - Constructor for class com.google.common.collect.AbstractMapBasedMultimap.SortedKeySet
 
SortedKeySet() - Constructor for class com.google.common.collect.Maps.FilteredEntrySortedMap.SortedKeySet
 
SortedKeySet(SortedMap<K, V>) - Constructor for class com.google.common.collect.Maps.SortedKeySet
 
SortedLists - Class in com.google.common.collect
Static methods pertaining to sorted List instances.
SortedLists() - Constructor for class com.google.common.collect.SortedLists
 
SortedLists.KeyAbsentBehavior - Enum in com.google.common.collect
A specification for which index to return if the list contains no elements that compare as equal to the key.
SortedLists.KeyPresentBehavior - Enum in com.google.common.collect
A specification for which index to return if the list contains at least one element that compares as equal to the key.
sortedMap() - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableAsMap
 
sortedMap() - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableKeySet
 
sortedMap() - Method in class com.google.common.collect.AbstractMapBasedMultimap.SortedAsMap
 
sortedMap() - Method in class com.google.common.collect.AbstractMapBasedMultimap.SortedKeySet
 
sortedMap() - Method in class com.google.common.collect.Maps.FilteredEntrySortedMap
 
sortedMap(SortedMap<K, V>, Object) - Static method in class com.google.common.collect.Synchronized
 
SortedMapDifference<K,V> - Interface in com.google.common.collect
An object representing the differences between two sorted maps.
SortedMapDifferenceImpl(SortedMap<K, V>, SortedMap<K, V>, SortedMap<K, V>, SortedMap<K, MapDifference.ValueDifference<V>>) - Constructor for class com.google.common.collect.Maps.SortedMapDifferenceImpl
 
SortedMultiset<E> - Interface in com.google.common.collect
A Multiset which maintains the ordering of its elements, according to either their natural order or an explicit Comparator.
SortedMultisetBridge<E> - Interface in com.google.common.collect
Superinterface of SortedMultiset to introduce a bridge method for elementSet(), to ensure binary compatibility with older Guava versions that specified elementSet() to return SortedSet.
SortedMultisets - Class in com.google.common.collect
Provides static utility methods for creating and working with SortedMultiset instances.
SortedMultisets() - Constructor for class com.google.common.collect.SortedMultisets
 
SortedMultisets.ElementSet<E> - Class in com.google.common.collect
A skeleton implementation for SortedMultiset.elementSet().
SortedMultisets.NavigableElementSet<E> - Class in com.google.common.collect
A skeleton navigable implementation for SortedMultiset.elementSet().
sortedSet(SortedSet<E>, Object) - Static method in class com.google.common.collect.Synchronized
 
SortedSetMultimap<K,V> - Interface in com.google.common.collect
A SetMultimap whose set of values for a given key are kept sorted; that is, they comprise a SortedSet.
sortedSetMultimap(SortedSetMultimap<K, V>, Object) - Static method in class com.google.common.collect.Synchronized
 
SortedSetMultimapBuilder() - Constructor for class com.google.common.collect.MultimapBuilder.SortedSetMultimapBuilder
 
sortEntries(Comparator<? super K>, int, Map.Entry<K, V>[]) - Static method in class com.google.common.collect.ImmutableSortedMap
 
sortKeysByValue(Map<K, V>, Comparator<? super V>) - Static method in class com.google.common.reflect.TypeToken.TypeCollector
 
source - Variable in class com.google.common.eventbus.DeadEvent
 
source - Variable in class com.google.common.io.FileBackedOutputStream
 
sourceFormat - Variable in class com.google.common.base.CaseFormat.StringConverter
 
sources - Variable in class com.google.common.io.ByteSource.ConcatenatedByteSource
 
sources - Variable in class com.google.common.io.CharSource.ConcatenatedCharSource
 
SP - Static variable in class com.google.common.base.Ascii
Space: A normally non-printing graphic character used to separate words.
SPACE - Static variable in class com.google.common.base.Ascii
Alternate name for Ascii.SP.
span() - Method in class com.google.common.collect.ImmutableRangeMap
 
span() - Method in class com.google.common.collect.ImmutableRangeSet
 
span(Range<C>) - Method in class com.google.common.collect.Range
Returns the minimal range that encloses both this range and other.
span() - Method in interface com.google.common.collect.RangeMap
Returns the minimal range enclosing the ranges in this RangeMap.
span() - Method in interface com.google.common.collect.RangeSet
Returns the minimal range which encloses all ranges in this range set.
span() - Method in class com.google.common.collect.TreeRangeMap
 
span() - Method in class com.google.common.collect.TreeRangeMap.SubRangeMap
 
span() - Method in class com.google.common.collect.TreeRangeSet
 
SparseImmutableTable<R,C,V> - Class in com.google.common.collect
A RegularImmutableTable optimized for sparse data.
SparseImmutableTable(ImmutableList<Table.Cell<R, C, V>>, ImmutableSet<R>, ImmutableSet<C>) - Constructor for class com.google.common.collect.SparseImmutableTable
 
specification - Variable in class com.google.common.cache.CacheBuilderSpec
Specification; used for toParseableString().
split(CharSequence) - Method in class com.google.common.base.Splitter.MapSplitter
Splits sequence into substrings, splits each substring into an entry, and returns an unmodifiable map with each of the entries.
split(CharSequence) - Method in class com.google.common.base.Splitter
Splits sequence into string components and makes them available through an Iterator, which may be lazily evaluated.
Splitter - Class in com.google.common.base
Extracts non-overlapping substrings from an input string, typically by recognizing appearances of a separator sequence.
Splitter(Splitter.Strategy) - Constructor for class com.google.common.base.Splitter
 
Splitter(Splitter.Strategy, boolean, CharMatcher, int) - Constructor for class com.google.common.base.Splitter
 
Splitter.MapSplitter - Class in com.google.common.base
An object that splits strings into maps as Splitter splits iterables and lists.
Splitter.SplittingIterator - Class in com.google.common.base
 
Splitter.Strategy - Interface in com.google.common.base
 
splittingIterator(CharSequence) - Method in class com.google.common.base.Splitter
 
SplittingIterator(Splitter, CharSequence) - Constructor for class com.google.common.base.Splitter.SplittingIterator
 
splitToList(CharSequence) - Method in class com.google.common.base.Splitter
Splits sequence into string components and returns them as an immutable list.
sqrt(BigInteger, RoundingMode) - Static method in class com.google.common.math.BigIntegerMath
Returns the square root of x, rounded with the specified rounding mode.
sqrt(int, RoundingMode) - Static method in class com.google.common.math.IntMath
Returns the square root of x, rounded with the specified rounding mode.
sqrt(long, RoundingMode) - Static method in class com.google.common.math.LongMath
Returns the square root of x, rounded with the specified rounding mode.
SQRT2_PRECOMPUTE_THRESHOLD - Static variable in class com.google.common.math.BigIntegerMath
 
SQRT2_PRECOMPUTED_BITS - Static variable in class com.google.common.math.BigIntegerMath
 
sqrtApproxWithDoubles(BigInteger) - Static method in class com.google.common.math.BigIntegerMath
 
sqrtFloor(BigInteger) - Static method in class com.google.common.math.BigIntegerMath
 
sqrtFloor(int) - Static method in class com.google.common.math.IntMath
 
stableIntervalMicros - Variable in class com.google.common.util.concurrent.SmoothRateLimiter
The interval between two unit requests, at our stable rate.
stack - Variable in class com.google.common.collect.BinaryTreeTraverser.InOrderIterator
 
stack - Variable in class com.google.common.collect.BinaryTreeTraverser.PostOrderIterator
 
stack - Variable in class com.google.common.collect.BinaryTreeTraverser.PreOrderIterator
 
stack - Variable in class com.google.common.collect.TreeTraverser.PostOrderIterator
 
stack - Variable in class com.google.common.collect.TreeTraverser.PreOrderIterator
 
stack - Variable in class com.google.common.io.Closer
 
STANDARD_JOINER - Static variable in class com.google.common.collect.Collections2
 
STANDARD_JOINER - Static variable in class com.google.common.collect.Maps
 
standardAdd(E) - Method in class com.google.common.collect.ForwardingList
A sensible default implementation of ForwardingCollection.add(Object), in terms of ForwardingList.add(int, Object).
standardAdd(E) - Method in class com.google.common.collect.ForwardingMultiset
standardAddAll(Collection<? extends E>) - Method in class com.google.common.collect.ForwardingCollection
standardAddAll(int, Iterable<? extends E>) - Method in class com.google.common.collect.ForwardingList
A sensible default implementation of ForwardingList.addAll(int, Collection), in terms of the add method of ForwardingList.listIterator(int).
standardAddAll(Collection<? extends E>) - Method in class com.google.common.collect.ForwardingMultiset
StandardBaseEncoding(String, String, Character) - Constructor for class com.google.common.io.BaseEncoding.StandardBaseEncoding
 
StandardBaseEncoding(BaseEncoding.Alphabet, Character) - Constructor for class com.google.common.io.BaseEncoding.StandardBaseEncoding
 
standardCeiling(E) - Method in class com.google.common.collect.ForwardingNavigableSet
A sensible definition of ForwardingNavigableSet.ceiling(E) in terms of the iterator method of ForwardingNavigableSet.tailSet(Object, boolean).
standardCeilingEntry(K) - Method in class com.google.common.collect.ForwardingNavigableMap
A sensible definition of ForwardingNavigableMap.ceilingEntry(K) in terms of the firstEntry() of ForwardingNavigableMap.tailMap(Object, boolean).
standardCeilingKey(K) - Method in class com.google.common.collect.ForwardingNavigableMap
A sensible definition of ForwardingNavigableMap.ceilingKey(K) in terms of ceilingEntry.
standardClear() - Method in class com.google.common.collect.ForwardingCollection
A sensible definition of ForwardingCollection.clear() in terms of ForwardingCollection.iterator(), using the iterator's remove method.
standardClear() - Method in class com.google.common.collect.ForwardingMap
A sensible definition of ForwardingMap.clear() in terms of the iterator method of ForwardingMap.entrySet().
standardClear() - Method in class com.google.common.collect.ForwardingMultiset
A sensible definition of ForwardingCollection.clear() in terms of the iterator method of ForwardingMultiset.entrySet().
standardContains(Object) - Method in class com.google.common.collect.ForwardingCollection
standardContains(Object) - Method in class com.google.common.collect.ForwardingMultiset
standardContains(Object) - Method in class com.google.common.collect.ForwardingSortedSet
A sensible definition of ForwardingCollection.contains(java.lang.Object) in terms of the first() method of ForwardingSortedSet.tailSet(E).
standardContainsAll(Collection<?>) - Method in class com.google.common.collect.ForwardingCollection
standardContainsKey(Object) - Method in class com.google.common.collect.ForwardingMap
A sensible, albeit inefficient, definition of ForwardingMap.containsKey(java.lang.Object) in terms of the iterator method of ForwardingMap.entrySet().
standardContainsKey(Object) - Method in class com.google.common.collect.ForwardingSortedMap
A sensible definition of ForwardingMap.containsKey(java.lang.Object) in terms of the firstKey() method of ForwardingSortedMap.tailMap(K).
standardContainsValue(Object) - Method in class com.google.common.collect.ForwardingMap
A sensible definition of ForwardingMap.containsValue(java.lang.Object) in terms of the iterator method of ForwardingMap.entrySet().
standardCount(Object) - Method in class com.google.common.collect.ForwardingMultiset
A sensible, albeit inefficient, definition of ForwardingMultiset.count(java.lang.Object) in terms of ForwardingMultiset.entrySet().
standardDescendingKeySet() - Method in class com.google.common.collect.ForwardingNavigableMap
A sensible definition of ForwardingNavigableMap.descendingKeySet() as the navigableKeySet of ForwardingNavigableMap.descendingMap().
StandardDescendingMap() - Constructor for class com.google.common.collect.ForwardingNavigableMap.StandardDescendingMap
Constructor for use by subclasses.
StandardDescendingMultiset() - Constructor for class com.google.common.collect.ForwardingSortedMultiset.StandardDescendingMultiset
Constructor for use by subclasses.
StandardDescendingSet() - Constructor for class com.google.common.collect.ForwardingNavigableSet.StandardDescendingSet
Constructor for use by subclasses.
StandardElementSet() - Constructor for class com.google.common.collect.ForwardingMultiset.StandardElementSet
Constructor for use by subclasses.
StandardElementSet() - Constructor for class com.google.common.collect.ForwardingSortedMultiset.StandardElementSet
Constructor for use by subclasses.
StandardEntrySet() - Constructor for class com.google.common.collect.ForwardingMap.StandardEntrySet
Constructor for use by subclasses.
standardEquals(Object) - Method in class com.google.common.collect.ForwardingList
standardEquals(Object) - Method in class com.google.common.collect.ForwardingMap
A sensible definition of ForwardingMap.equals(java.lang.Object) in terms of the equals method of ForwardingMap.entrySet().
standardEquals(Object) - Method in class com.google.common.collect.ForwardingMapEntry
standardEquals(Object) - Method in class com.google.common.collect.ForwardingMultiset
A sensible, albeit inefficient, definition of ForwardingCollection.size() in terms of entrySet().size() and ForwardingMultiset.count(java.lang.Object).
standardEquals(Object) - Method in class com.google.common.collect.ForwardingSet
standardFirst() - Method in class com.google.common.collect.ForwardingNavigableSet
 
standardFirstEntry() - Method in class com.google.common.collect.ForwardingNavigableMap
A sensible definition of ForwardingNavigableMap.firstEntry() in terms of the iterator() of ForwardingMap.entrySet().
standardFirstEntry() - Method in class com.google.common.collect.ForwardingSortedMultiset
A sensible definition of ForwardingSortedMultiset.firstEntry() in terms of entrySet().iterator().
standardFirstKey() - Method in class com.google.common.collect.ForwardingNavigableMap
A sensible definition of ForwardingSortedMap.firstKey() in terms of firstEntry.
standardFloor(E) - Method in class com.google.common.collect.ForwardingNavigableSet
A sensible definition of ForwardingNavigableSet.floor(E) in terms of the descendingIterator method of ForwardingNavigableSet.headSet(Object, boolean).
standardFloorEntry(K) - Method in class com.google.common.collect.ForwardingNavigableMap
A sensible definition of ForwardingNavigableMap.floorEntry(K) in terms of the lastEntry() of ForwardingNavigableMap.headMap(Object, boolean).
standardFloorKey(K) - Method in class com.google.common.collect.ForwardingNavigableMap
A sensible definition of ForwardingNavigableMap.floorKey(K) in terms of floorEntry.
standardHashCode() - Method in class com.google.common.collect.ForwardingList
A sensible definition of ForwardingList.hashCode() in terms of ForwardingCollection.iterator().
standardHashCode() - Method in class com.google.common.collect.ForwardingMap
A sensible definition of ForwardingMap.hashCode() in terms of the iterator method of ForwardingMap.entrySet().
standardHashCode() - Method in class com.google.common.collect.ForwardingMapEntry
standardHashCode() - Method in class com.google.common.collect.ForwardingMultiset
A sensible definition of ForwardingMultiset.hashCode() as entrySet().hashCode() .
standardHashCode() - Method in class com.google.common.collect.ForwardingSet
A sensible definition of ForwardingSet.hashCode() in terms of ForwardingCollection.iterator().
standardHeadMap(K) - Method in class com.google.common.collect.ForwardingNavigableMap
standardHeadSet(E) - Method in class com.google.common.collect.ForwardingNavigableSet
standardHigher(E) - Method in class com.google.common.collect.ForwardingNavigableSet
A sensible definition of ForwardingNavigableSet.higher(E) in terms of the iterator method of ForwardingNavigableSet.tailSet(Object, boolean).
standardHigherEntry(K) - Method in class com.google.common.collect.ForwardingNavigableMap
A sensible definition of ForwardingNavigableMap.higherEntry(K) in terms of the firstEntry() of ForwardingNavigableMap.tailMap(Object, boolean).
standardHigherKey(K) - Method in class com.google.common.collect.ForwardingNavigableMap
A sensible definition of ForwardingNavigableMap.higherKey(K) in terms of higherEntry.
standardIndexOf(Object) - Method in class com.google.common.collect.ForwardingList
A sensible default implementation of ForwardingList.indexOf(java.lang.Object), in terms of ForwardingList.listIterator().
standardIsEmpty() - Method in class com.google.common.collect.ForwardingCollection
A sensible definition of ForwardingCollection.isEmpty() as !iterator().hasNext.
standardIsEmpty() - Method in class com.google.common.collect.ForwardingMap
A sensible definition of ForwardingMap.isEmpty() in terms of the iterator method of ForwardingMap.entrySet().
standardIterator() - Method in class com.google.common.collect.ForwardingList
A sensible default implementation of ForwardingCollection.iterator(), in terms of ForwardingList.listIterator().
standardIterator() - Method in class com.google.common.collect.ForwardingMultiset
StandardKeySet() - Constructor for class com.google.common.collect.ForwardingMap.StandardKeySet
Constructor for use by subclasses.
StandardKeySet() - Constructor for class com.google.common.collect.ForwardingSortedMap.StandardKeySet
Constructor for use by subclasses.
standardLast() - Method in class com.google.common.collect.ForwardingNavigableSet
 
standardLastEntry() - Method in class com.google.common.collect.ForwardingNavigableMap
A sensible definition of ForwardingNavigableMap.lastEntry() in terms of the iterator() of the ForwardingMap.entrySet() of ForwardingNavigableMap.descendingMap().
standardLastEntry() - Method in class com.google.common.collect.ForwardingSortedMultiset
A sensible definition of ForwardingSortedMultiset.lastEntry() in terms of descendingMultiset().entrySet().iterator().
standardLastIndexOf(Object) - Method in class com.google.common.collect.ForwardingList
A sensible default implementation of ForwardingList.lastIndexOf(java.lang.Object), in terms of ForwardingList.listIterator(int).
standardLastKey() - Method in class com.google.common.collect.ForwardingNavigableMap
A sensible definition of ForwardingSortedMap.lastKey() in terms of lastEntry.
standardListIterator() - Method in class com.google.common.collect.ForwardingList
A sensible default implementation of ForwardingList.listIterator(), in terms of ForwardingList.listIterator(int).
standardListIterator(int) - Method in class com.google.common.collect.ForwardingList
standardLower(E) - Method in class com.google.common.collect.ForwardingNavigableSet
A sensible definition of ForwardingNavigableSet.lower(E) in terms of the descendingIterator method of ForwardingNavigableSet.headSet(Object, boolean).
standardLowerEntry(K) - Method in class com.google.common.collect.ForwardingNavigableMap
A sensible definition of ForwardingNavigableMap.lowerEntry(K) in terms of the lastEntry() of ForwardingNavigableMap.headMap(Object, boolean).
standardLowerKey(K) - Method in class com.google.common.collect.ForwardingNavigableMap
A sensible definition of ForwardingNavigableMap.lowerKey(K) in terms of lowerEntry.
StandardNavigableKeySet() - Constructor for class com.google.common.collect.ForwardingNavigableMap.StandardNavigableKeySet
Constructor for use by subclasses.
standardOffer(E) - Method in class com.google.common.collect.ForwardingQueue
A sensible definition of ForwardingQueue.offer(E) in terms of ForwardingCollection.add(E).
standardPeek() - Method in class com.google.common.collect.ForwardingQueue
A sensible definition of ForwardingQueue.peek() in terms of ForwardingQueue.element().
standardPoll() - Method in class com.google.common.collect.ForwardingQueue
A sensible definition of ForwardingQueue.poll() in terms of ForwardingQueue.remove().
standardPollFirst() - Method in class com.google.common.collect.ForwardingNavigableSet
A sensible definition of ForwardingNavigableSet.pollFirst() in terms of the iterator method.
standardPollFirstEntry() - Method in class com.google.common.collect.ForwardingNavigableMap
A sensible definition of ForwardingNavigableMap.pollFirstEntry() in terms of the iterator of entrySet.
standardPollFirstEntry() - Method in class com.google.common.collect.ForwardingSortedMultiset
A sensible definition of ForwardingSortedMultiset.pollFirstEntry() in terms of entrySet().iterator().
standardPollLast() - Method in class com.google.common.collect.ForwardingNavigableSet
A sensible definition of ForwardingNavigableSet.pollLast() in terms of the descendingIterator method.
standardPollLastEntry() - Method in class com.google.common.collect.ForwardingNavigableMap
A sensible definition of ForwardingNavigableMap.pollFirstEntry() in terms of the iterator of the entrySet of descendingMap.
standardPollLastEntry() - Method in class com.google.common.collect.ForwardingSortedMultiset
A sensible definition of ForwardingSortedMultiset.pollLastEntry() in terms of descendingMultiset().entrySet().iterator().
standardPutAll(Map<? extends K, ? extends V>) - Method in class com.google.common.collect.ForwardingMap
A sensible definition of ForwardingMap.putAll(Map) in terms of ForwardingMap.put(Object, Object).
standardRemove(Object) - Method in class com.google.common.collect.ForwardingCollection
A sensible definition of ForwardingCollection.remove(java.lang.Object) in terms of ForwardingCollection.iterator(), using the iterator's remove method.
standardRemove(Object) - Method in class com.google.common.collect.ForwardingMap
A sensible, albeit inefficient, definition of ForwardingMap.remove(java.lang.Object) in terms of the iterator method of ForwardingMap.entrySet().
standardRemove(Object) - Method in class com.google.common.collect.ForwardingMultiset
standardRemove(Object) - Method in class com.google.common.collect.ForwardingSortedSet
A sensible definition of ForwardingCollection.remove(java.lang.Object) in terms of the iterator() method of ForwardingSortedSet.tailSet(E).
standardRemoveAll(Collection<?>) - Method in class com.google.common.collect.ForwardingCollection
A sensible definition of ForwardingCollection.removeAll(java.util.Collection<?>) in terms of ForwardingCollection.iterator(), using the iterator's remove method.
standardRemoveAll(Collection<?>) - Method in class com.google.common.collect.ForwardingMultiset
A sensible definition of ForwardingCollection.removeAll(java.util.Collection<?>) in terms of the removeAll method of ForwardingMultiset.elementSet().
standardRemoveAll(Collection<?>) - Method in class com.google.common.collect.ForwardingSet
standardRetainAll(Collection<?>) - Method in class com.google.common.collect.ForwardingCollection
A sensible definition of ForwardingCollection.retainAll(java.util.Collection<?>) in terms of ForwardingCollection.iterator(), using the iterator's remove method.
standardRetainAll(Collection<?>) - Method in class com.google.common.collect.ForwardingMultiset
A sensible definition of ForwardingCollection.retainAll(java.util.Collection<?>) in terms of the retainAll method of ForwardingMultiset.elementSet().
StandardRowSortedTable<R,C,V> - Class in com.google.common.collect
Implementation of Table whose iteration ordering across row keys is sorted by their natural ordering or by a supplied comparator.
StandardRowSortedTable(SortedMap<R, Map<C, V>>, Supplier<? extends Map<C, V>>) - Constructor for class com.google.common.collect.StandardRowSortedTable
 
StandardRowSortedTable.RowSortedMap - Class in com.google.common.collect
 
standardSetCount(E, int) - Method in class com.google.common.collect.ForwardingMultiset
standardSetCount(E, int, int) - Method in class com.google.common.collect.ForwardingMultiset
standardSize() - Method in class com.google.common.collect.ForwardingMultiset
A sensible, albeit inefficient, definition of ForwardingCollection.size() in terms of ForwardingMultiset.entrySet().
standardSubList(int, int) - Method in class com.google.common.collect.ForwardingList
A sensible default implementation of ForwardingList.subList(int, int).
standardSubMap(K, K) - Method in class com.google.common.collect.ForwardingNavigableMap
standardSubMap(K, K) - Method in class com.google.common.collect.ForwardingSortedMap
standardSubMultiset(E, BoundType, E, BoundType) - Method in class com.google.common.collect.ForwardingSortedMultiset
standardSubSet(E, boolean, E, boolean) - Method in class com.google.common.collect.ForwardingNavigableSet
A sensible definition of ForwardingNavigableSet.subSet(Object, boolean, Object, boolean) in terms of the headSet and tailSet methods.
standardSubSet(E, E) - Method in class com.google.common.collect.ForwardingNavigableSet
standardSubSet(E, E) - Method in class com.google.common.collect.ForwardingSortedSet
StandardSystemProperty - Enum in com.google.common.base
Represents a standard system property.
StandardSystemProperty(String) - Constructor for enum com.google.common.base.StandardSystemProperty
 
StandardTable<R,C,V> - Class in com.google.common.collect
Table implementation backed by a map that associates row keys with column key / value secondary maps.
StandardTable(Map<R, Map<C, V>>, Supplier<? extends Map<C, V>>) - Constructor for class com.google.common.collect.StandardTable
 
StandardTable.CellIterator - Class in com.google.common.collect
 
StandardTable.Column - Class in com.google.common.collect
 
StandardTable.Column.EntrySet - Class in com.google.common.collect
 
StandardTable.Column.EntrySetIterator - Class in com.google.common.collect
 
StandardTable.Column.KeySet - Class in com.google.common.collect
 
StandardTable.Column.Values - Class in com.google.common.collect
 
StandardTable.ColumnKeyIterator - Class in com.google.common.collect
 
StandardTable.ColumnKeySet - Class in com.google.common.collect
 
StandardTable.ColumnMap - Class in com.google.common.collect
 
StandardTable.ColumnMap.ColumnMapEntrySet - Class in com.google.common.collect
 
StandardTable.ColumnMap.ColumnMapValues - Class in com.google.common.collect
 
StandardTable.Row - Class in com.google.common.collect
 
StandardTable.Row.RowEntrySet - Class in com.google.common.collect
 
StandardTable.RowMap - Class in com.google.common.collect
 
StandardTable.RowMap.EntrySet - Class in com.google.common.collect
 
StandardTable.TableSet<T> - Class in com.google.common.collect
Abstract set whose isEmpty() returns whether the table is empty and whose clear() clears all table mappings.
standardTailMap(K) - Method in class com.google.common.collect.ForwardingNavigableMap
standardTailSet(E) - Method in class com.google.common.collect.ForwardingNavigableSet
standardToArray() - Method in class com.google.common.collect.ForwardingCollection
standardToArray(T[]) - Method in class com.google.common.collect.ForwardingCollection
standardToString() - Method in class com.google.common.collect.ForwardingCollection
A sensible definition of ForwardingObject.toString() in terms of ForwardingCollection.iterator().
standardToString() - Method in class com.google.common.collect.ForwardingMap
A sensible definition of ForwardingObject.toString() in terms of the iterator method of ForwardingMap.entrySet().
standardToString() - Method in class com.google.common.collect.ForwardingMapEntry
standardToString() - Method in class com.google.common.collect.ForwardingMultiset
A sensible definition of ForwardingObject.toString() as entrySet().toString() .
StandardValues() - Constructor for class com.google.common.collect.ForwardingMap.StandardValues
Constructor for use by subclasses.
start() - Method in class com.google.common.base.Stopwatch
Starts the stopwatch.
start() - Static method in class com.google.common.collect.ComparisonChain
Begins a new chained comparison statement.
start - Variable in class com.google.common.primitives.Booleans.BooleanArrayAsList
 
start - Variable in class com.google.common.primitives.Bytes.ByteArrayAsList
 
start - Variable in class com.google.common.primitives.Chars.CharArrayAsList
 
start - Variable in class com.google.common.primitives.Doubles.DoubleArrayAsList
 
start - Variable in class com.google.common.primitives.Floats.FloatArrayAsList
 
start - Variable in class com.google.common.primitives.Ints.IntArrayAsList
 
start - Variable in class com.google.common.primitives.Longs.LongArrayAsList
 
start - Variable in class com.google.common.primitives.Shorts.ShortArrayAsList
 
startAsync() - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
 
startAsync() - Method in class com.google.common.util.concurrent.AbstractIdleService
 
startAsync() - Method in class com.google.common.util.concurrent.AbstractScheduledService
 
startAsync() - Method in class com.google.common.util.concurrent.AbstractService
 
startAsync() - Method in interface com.google.common.util.concurrent.Service
If the service state is Service.State.NEW, this initiates service startup and returns immediately.
startAsync() - Method in class com.google.common.util.concurrent.ServiceManager
Initiates service startup on all the services being managed.
startFinalizer - Static variable in class com.google.common.base.FinalizableReferenceQueue
Reference to Finalizer.startFinalizer().
startFinalizer(Class<?>, ReferenceQueue<Object>, PhantomReference<Object>) - Static method in class com.google.common.base.internal.Finalizer
Starts the Finalizer thread.
starting() - Method in class com.google.common.util.concurrent.AbstractService
 
starting() - Method in class com.google.common.util.concurrent.Service.Listener
Called when the service transitions from NEW to STARTING.
starting() - Method in class com.google.common.util.concurrent.ServiceManager.ServiceListener
 
STARTING_CALLBACK - Static variable in class com.google.common.util.concurrent.AbstractService
 
startTask() - Method in class com.google.common.util.concurrent.MoreExecutors.DirectExecutorService
Checks if the executor has been shut down and increments the running task count.
startTick - Variable in class com.google.common.base.Stopwatch
 
startUp() - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
Start the service.
startUp() - Method in class com.google.common.util.concurrent.AbstractIdleService
Start the service.
startUp() - Method in class com.google.common.util.concurrent.AbstractScheduledService
Start the service.
startupTimers - Variable in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState
 
startupTimes() - Method in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState
 
startupTimes() - Method in class com.google.common.util.concurrent.ServiceManager
Returns the service load times.
state - Variable in class com.google.common.base.AbstractIterator
 
State() - Constructor for enum com.google.common.base.AbstractIterator.State
 
state - Variable in class com.google.common.collect.AbstractIterator
 
State() - Constructor for enum com.google.common.collect.AbstractIterator.State
 
state - Variable in class com.google.common.hash.Hashing.LinearCongruentialGenerator
 
state() - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
 
state() - Method in class com.google.common.util.concurrent.AbstractIdleService
 
state() - Method in class com.google.common.util.concurrent.AbstractScheduledService
 
state() - Method in class com.google.common.util.concurrent.AbstractService
 
state - Variable in class com.google.common.util.concurrent.AbstractService.StateSnapshot
The internal state, which equals external state unless shutdownWhenStartupFinishes is true.
state() - Method in interface com.google.common.util.concurrent.Service
Returns the lifecycle state of the service.
State() - Constructor for enum com.google.common.util.concurrent.Service.State
 
state - Variable in class com.google.common.util.concurrent.ServiceManager.ServiceListener
 
state - Variable in class com.google.common.util.concurrent.ServiceManager
An encapsulation of all of the state that is accessed by the service listeners.
states - Variable in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState
 
StateSnapshot(Service.State) - Constructor for class com.google.common.util.concurrent.AbstractService.StateSnapshot
 
StateSnapshot(Service.State, boolean, Throwable) - Constructor for class com.google.common.util.concurrent.AbstractService.StateSnapshot
 
stats() - Method in class com.google.common.cache.AbstractCache
 
stats() - Method in interface com.google.common.cache.Cache
Returns a current snapshot of this cache's cumulative statistics.
stats() - Method in class com.google.common.cache.ForwardingCache
 
stats() - Method in class com.google.common.cache.LocalCache.LocalManualCache
 
statsCounter - Variable in class com.google.common.cache.LocalCache.Segment
Accumulates cache statistics.
statsCounterSupplier - Variable in class com.google.common.cache.CacheBuilder
 
stop() - Method in class com.google.common.base.Stopwatch
Stops the stopwatch.
stopAsync() - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
 
stopAsync() - Method in class com.google.common.util.concurrent.AbstractIdleService
 
stopAsync() - Method in class com.google.common.util.concurrent.AbstractScheduledService
 
stopAsync() - Method in class com.google.common.util.concurrent.AbstractService
 
stopAsync() - Method in interface com.google.common.util.concurrent.Service
If the service is starting or running, this initiates service shutdown and returns immediately.
stopAsync() - Method in class com.google.common.util.concurrent.ServiceManager
Initiates service shutdown if necessary on all the services being managed.
stopped() - Method in class com.google.common.util.concurrent.ServiceManager.Listener
Called when the all of the component services have reached a terminal state, either terminated or failed.
STOPPED_CALLBACK - Static variable in class com.google.common.util.concurrent.ServiceManager
 
stoppedGuard - Variable in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState
Controls how long to wait for all services to reach a terminal state.
stopping(Service.State) - Method in class com.google.common.util.concurrent.AbstractService
 
stopping(Service.State) - Method in class com.google.common.util.concurrent.Service.Listener
Called when the service transitions to the STOPPING state.
stopping(Service.State) - Method in class com.google.common.util.concurrent.ServiceManager.ServiceListener
 
STOPPING_FROM_RUNNING_CALLBACK - Static variable in class com.google.common.util.concurrent.AbstractService
 
STOPPING_FROM_STARTING_CALLBACK - Static variable in class com.google.common.util.concurrent.AbstractService
 
stoppingCallback(Service.State) - Static method in class com.google.common.util.concurrent.AbstractService
 
Stopwatch - Class in com.google.common.base
An object that measures elapsed time in nanoseconds.
Stopwatch() - Constructor for class com.google.common.base.Stopwatch
Deprecated.
Stopwatch(Ticker) - Constructor for class com.google.common.base.Stopwatch
Deprecated.
stopwatch - Variable in class com.google.common.cache.LocalCache.LoadingValueReference
 
stopwatch - Variable in class com.google.common.util.concurrent.RateLimiter
The underlying timer; used both to measure elapsed time and sleep as necessary.
storedPermits - Variable in class com.google.common.util.concurrent.SmoothRateLimiter
The currently stored permits.
storedPermitsToWaitTime(double, double) - Method in class com.google.common.util.concurrent.SmoothRateLimiter.SmoothBursty
 
storedPermitsToWaitTime(double, double) - Method in class com.google.common.util.concurrent.SmoothRateLimiter.SmoothWarmingUp
 
storedPermitsToWaitTime(double, double) - Method in class com.google.common.util.concurrent.SmoothRateLimiter
Translates a specified portion of our currently stored permits which we want to spend/acquire, into a throttling time.
storeLoadedValue(K, int, LocalCache.LoadingValueReference<K, V>, V) - Method in class com.google.common.cache.LocalCache.Segment
 
strategy - Variable in class com.google.common.base.Splitter
 
strategy - Variable in class com.google.common.hash.BloomFilter.SerialForm
 
strategy - Variable in class com.google.common.hash.BloomFilter
The strategy we employ to map an element T to numHashFunctions bit indexes.
stream - Variable in class com.google.common.hash.AbstractNonStreamingHashFunction.BufferingHasher
 
strength - Variable in class com.google.common.cache.CacheBuilderSpec.KeyStrengthParser
 
strength - Variable in class com.google.common.cache.CacheBuilderSpec.ValueStrengthParser
 
Strength() - Constructor for enum com.google.common.cache.LocalCache.Strength
 
Strength() - Constructor for enum com.google.common.collect.MapMakerInternalMap.Strength
 
STRICT_TRANSPORT_SECURITY - Static variable in class com.google.common.net.HttpHeaders
The HTTP Strict-Transport-Security header field name.
strictParsing - Variable in class com.google.common.cache.CacheBuilder
 
string - Variable in class com.google.common.collect.Lists.StringAsImmutableList
 
StringAsImmutableList(String) - Constructor for class com.google.common.collect.Lists.StringAsImmutableList
 
stringBuilderOutput(int) - Static method in class com.google.common.io.GwtWorkarounds
Returns a CharOutput whose toString() method can be used to get the combined output.
StringCharsetFunnel(Charset) - Constructor for class com.google.common.hash.Funnels.StringCharsetFunnel
 
StringConverter(CaseFormat, CaseFormat) - Constructor for class com.google.common.base.CaseFormat.StringConverter
 
stringConverter(Class<T>) - Static method in class com.google.common.base.Enums
Returns a converter that converts between strings and enum values of type enumClass using Enum.valueOf(Class, String) and Enum.name().
StringConverter(Class<T>) - Constructor for class com.google.common.base.Enums.StringConverter
 
stringConverter() - Static method in class com.google.common.primitives.Doubles
Returns a serializable converter object that converts between strings and doubles using Double.valueOf(java.lang.String) and Double.toString().
stringConverter() - Static method in class com.google.common.primitives.Floats
Returns a serializable converter object that converts between strings and floats using Float.valueOf(java.lang.String) and Float.toString().
stringConverter() - Static method in class com.google.common.primitives.Ints
Returns a serializable converter object that converts between strings and integers using Integer.decode(java.lang.String) and Integer.toString().
stringConverter() - Static method in class com.google.common.primitives.Longs
Returns a serializable converter object that converts between strings and longs using Long.decode(java.lang.String) and Long.toString().
stringConverter() - Static method in class com.google.common.primitives.Shorts
Returns a serializable converter object that converts between strings and shorts using Short.decode(java.lang.String) and Short.toString().
stringFunnel(Charset) - Static method in class com.google.common.hash.Funnels
Returns a funnel that encodes the characters of a CharSequence with the specified Charset.
stringOrNull(char[]) - Static method in class com.google.common.escape.Escapers
 
Strings - Class in com.google.common.base
Static utility methods pertaining to String or CharSequence instances.
Strings() - Constructor for class com.google.common.base.Strings
 
Striped<L> - Class in com.google.common.util.concurrent
A striped Lock/Semaphore/ReadWriteLock.
Striped() - Constructor for class com.google.common.util.concurrent.Striped
 
Striped.CompactStriped<L> - Class in com.google.common.util.concurrent
Implementation of Striped where 2^k stripes are represented as an array of the same length, eagerly initialized.
Striped.LargeLazyStriped<L> - Class in com.google.common.util.concurrent
Implementation of Striped where up to 2^k stripes can be represented, using a ConcurrentMap where the key domain is [0..2^k).
Striped.PaddedLock - Class in com.google.common.util.concurrent
 
Striped.PaddedSemaphore - Class in com.google.common.util.concurrent
 
Striped.PowerOfTwoStriped<L> - Class in com.google.common.util.concurrent
 
Striped.SmallLazyStriped<L> - Class in com.google.common.util.concurrent
Implementation of Striped where up to 2^k stripes can be represented, using an AtomicReferenceArray of size 2^k.
Striped.SmallLazyStriped.ArrayReference<L> - Class in com.google.common.util.concurrent
 
Striped64 - Class in com.google.common.cache
A package-local class holding common representation and mechanics for classes supporting dynamic striping on 64bit values.
Striped64() - Constructor for class com.google.common.cache.Striped64
Package-private default constructor
Striped64.Cell - Class in com.google.common.cache
Padded variant of AtomicLong supporting only raw accesses plus CAS.
StrongAccessEntry(K, int, LocalCache.ReferenceEntry<K, V>) - Constructor for class com.google.common.cache.LocalCache.StrongAccessEntry
 
StrongAccessWriteEntry(K, int, LocalCache.ReferenceEntry<K, V>) - Constructor for class com.google.common.cache.LocalCache.StrongAccessWriteEntry
 
StrongEntry(K, int, LocalCache.ReferenceEntry<K, V>) - Constructor for class com.google.common.cache.LocalCache.StrongEntry
 
StrongEntry(K, int, MapMakerInternalMap.ReferenceEntry<K, V>) - Constructor for class com.google.common.collect.MapMakerInternalMap.StrongEntry
 
StrongEvictableEntry(K, int, MapMakerInternalMap.ReferenceEntry<K, V>) - Constructor for class com.google.common.collect.MapMakerInternalMap.StrongEvictableEntry
 
StrongExpirableEntry(K, int, MapMakerInternalMap.ReferenceEntry<K, V>) - Constructor for class com.google.common.collect.MapMakerInternalMap.StrongExpirableEntry
 
StrongExpirableEvictableEntry(K, int, MapMakerInternalMap.ReferenceEntry<K, V>) - Constructor for class com.google.common.collect.MapMakerInternalMap.StrongExpirableEvictableEntry
 
StrongValueReference(V) - Constructor for class com.google.common.cache.LocalCache.StrongValueReference
 
StrongValueReference(V) - Constructor for class com.google.common.collect.MapMakerInternalMap.StrongValueReference
 
StrongWriteEntry(K, int, LocalCache.ReferenceEntry<K, V>) - Constructor for class com.google.common.cache.LocalCache.StrongWriteEntry
 
STX - Static variable in class com.google.common.base.Ascii
Start of Text: A communication control character which precedes a sequence of characters that is to be treated as an entity and entirely transmitted through to the ultimate destination.
SUB - Static variable in class com.google.common.base.Ascii
Substitute: A character that may be substituted for a character which is determined to be invalid or in error.
subList(int, int) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedList
 
subList(int, int) - Method in class com.google.common.collect.Constraints.ConstrainedList
 
subList(int, int) - Method in class com.google.common.collect.ForwardingList
 
subList(int, int) - Method in class com.google.common.collect.ImmutableList.ReverseImmutableList
 
subList(int, int) - Method in class com.google.common.collect.ImmutableList
Returns an immutable list of the elements between the specified fromIndex, inclusive, and toIndex, exclusive.
SubList(int, int) - Constructor for class com.google.common.collect.ImmutableList.SubList
 
subList(int, int) - Method in class com.google.common.collect.ImmutableList.SubList
 
subList(int, int) - Method in class com.google.common.collect.Lists.ReverseList
 
subList(int, int) - Method in class com.google.common.collect.Lists.StringAsImmutableList
 
subList(int, int) - Method in class com.google.common.collect.SingletonImmutableList
 
subList(int, int) - Method in class com.google.common.collect.Synchronized.SynchronizedList
 
subList(int, int) - Method in class com.google.common.primitives.Booleans.BooleanArrayAsList
 
subList(int, int) - Method in class com.google.common.primitives.Bytes.ByteArrayAsList
 
subList(int, int) - Method in class com.google.common.primitives.Chars.CharArrayAsList
 
subList(int, int) - Method in class com.google.common.primitives.Doubles.DoubleArrayAsList
 
subList(int, int) - Method in class com.google.common.primitives.Floats.FloatArrayAsList
 
subList(int, int) - Method in class com.google.common.primitives.Ints.IntArrayAsList
 
subList(int, int) - Method in class com.google.common.primitives.Longs.LongArrayAsList
 
subList(int, int) - Method in class com.google.common.primitives.Shorts.ShortArrayAsList
 
subListImpl(List<E>, int, int) - Static method in class com.google.common.collect.Lists
An implementation of List.subList(int, int).
subListUnchecked(int, int) - Method in class com.google.common.collect.ImmutableList
Called by the default implementation of ImmutableList.subList(int, int) when toIndex - fromIndex > 1, after index validation has already been performed.
subListUnchecked(int, int) - Method in class com.google.common.collect.ImmutableSortedAsList
 
subListUnchecked(int, int) - Method in class com.google.common.collect.RegularImmutableList
 
submap - Variable in class com.google.common.collect.AbstractMapBasedMultimap.AsMap
Usually the same as map, but smaller for the headMap(), tailMap(), or subMap() of a SortedAsMap.
subMap(K, K) - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableAsMap
 
subMap(K, boolean, K, boolean) - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableAsMap
 
subMap(K, K) - Method in class com.google.common.collect.AbstractMapBasedMultimap.SortedAsMap
 
subMap(K, K) - Method in class com.google.common.collect.AbstractNavigableMap
 
subMap(K, boolean, K, boolean) - Method in class com.google.common.collect.ForwardingNavigableMap
 
subMap(K, K) - Method in class com.google.common.collect.ForwardingSortedMap
 
subMap(K, K) - Method in class com.google.common.collect.ImmutableSortedMap
This method returns a ImmutableSortedMap, consisting of the entries whose keys ranges from fromKey, inclusive, to toKey, exclusive.
subMap(K, boolean, K, boolean) - Method in class com.google.common.collect.ImmutableSortedMap
This method returns a ImmutableSortedMap, consisting of the entries whose keys ranges from fromKey to toKey, inclusive or exclusive as indicated by the boolean flags.
subMap(K, boolean, K, boolean) - Method in class com.google.common.collect.Maps.DescendingMap
 
subMap(K, K) - Method in class com.google.common.collect.Maps.DescendingMap
 
subMap(K, boolean, K, boolean) - Method in class com.google.common.collect.Maps.FilteredEntryNavigableMap
 
subMap(K, K) - Method in class com.google.common.collect.Maps.FilteredEntrySortedMap
 
subMap(K, boolean, K, boolean) - Method in class com.google.common.collect.Maps.NavigableAsMapView
 
subMap(K, K) - Method in class com.google.common.collect.Maps.SortedAsMapView
 
subMap(K, boolean, K, boolean) - Method in class com.google.common.collect.Maps.TransformedEntriesNavigableMap
 
subMap(K, K) - Method in class com.google.common.collect.Maps.TransformedEntriesNavigableMap
 
subMap(K, K) - Method in class com.google.common.collect.Maps.TransformedEntriesSortedMap
 
subMap(K, K) - Method in class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
subMap(K, boolean, K, boolean) - Method in class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
subMap(R, R) - Method in class com.google.common.collect.StandardRowSortedTable.RowSortedMap
 
subMap(K, boolean, K, boolean) - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableMap
 
subMap(K, K) - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableMap
 
subMap(K, K) - Method in class com.google.common.collect.Synchronized.SynchronizedSortedMap
 
subMap(C, C) - Method in class com.google.common.collect.TreeBasedTable.TreeRow
 
subMap(Range<Cut<C>>) - Method in class com.google.common.collect.TreeRangeSet.ComplementRangesByLowerBound
 
subMap(Cut<C>, boolean, Cut<C>, boolean) - Method in class com.google.common.collect.TreeRangeSet.ComplementRangesByLowerBound
 
subMap(Range<Cut<C>>) - Method in class com.google.common.collect.TreeRangeSet.RangesByUpperBound
 
subMap(Cut<C>, boolean, Cut<C>, boolean) - Method in class com.google.common.collect.TreeRangeSet.RangesByUpperBound
 
subMap(Range<Cut<C>>) - Method in class com.google.common.collect.TreeRangeSet.SubRangeSetRangesByLowerBound
 
subMap(Cut<C>, boolean, Cut<C>, boolean) - Method in class com.google.common.collect.TreeRangeSet.SubRangeSetRangesByLowerBound
 
submit(Runnable) - Method in class com.google.common.util.concurrent.AbstractListeningExecutorService
 
submit(Runnable, T) - Method in class com.google.common.util.concurrent.AbstractListeningExecutorService
 
submit(Callable<T>) - Method in class com.google.common.util.concurrent.AbstractListeningExecutorService
 
submit(Callable<T>) - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
submit(Runnable) - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
submit(Runnable, T) - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
submit(Callable<T>) - Method in class com.google.common.util.concurrent.ForwardingListeningExecutorService
 
submit(Runnable) - Method in class com.google.common.util.concurrent.ForwardingListeningExecutorService
 
submit(Runnable, T) - Method in class com.google.common.util.concurrent.ForwardingListeningExecutorService
 
submit(Callable<T>) - Method in interface com.google.common.util.concurrent.ListeningExecutorService
 
submit(Runnable) - Method in interface com.google.common.util.concurrent.ListeningExecutorService
 
submit(Runnable, T) - Method in interface com.google.common.util.concurrent.ListeningExecutorService
 
submit(Callable<T>) - Method in class com.google.common.util.concurrent.WrappingExecutorService
 
submit(Runnable) - Method in class com.google.common.util.concurrent.WrappingExecutorService
 
submit(Runnable, T) - Method in class com.google.common.util.concurrent.WrappingExecutorService
 
submitAndAddQueueListener(ListeningExecutorService, Callable<T>, BlockingQueue<Future<T>>) - Static method in class com.google.common.util.concurrent.MoreExecutors
Submits the task and adds a listener that adds the future to queue when it completes.
subMultiset(E, BoundType, E, BoundType) - Method in class com.google.common.collect.AbstractSortedMultiset
 
subMultiset(E, BoundType, E, BoundType) - Method in class com.google.common.collect.DescendingMultiset
 
subMultiset(E, BoundType, E, BoundType) - Method in class com.google.common.collect.ForwardingSortedMultiset
 
subMultiset(E, BoundType, E, BoundType) - Method in class com.google.common.collect.ImmutableSortedMultiset
 
subMultiset(E, BoundType, E, BoundType) - Method in interface com.google.common.collect.SortedMultiset
Returns a view of this multiset restricted to the range between lowerBound and upperBound.
subMultiset(E, BoundType, E, BoundType) - Method in class com.google.common.collect.UnmodifiableSortedMultiset
 
subRange - Variable in class com.google.common.collect.TreeRangeMap.SubRangeMap
 
subRangeMap(Range<K>) - Method in class com.google.common.collect.ImmutableRangeMap
 
subRangeMap(Range<K>) - Method in interface com.google.common.collect.RangeMap
Returns a view of the part of this range map that intersects with range.
subRangeMap(Range<K>) - Method in class com.google.common.collect.TreeRangeMap
 
SubRangeMap(Range<K>) - Constructor for class com.google.common.collect.TreeRangeMap.SubRangeMap
 
subRangeMap(Range<K>) - Method in class com.google.common.collect.TreeRangeMap.SubRangeMap
 
SubRangeMapAsMap() - Constructor for class com.google.common.collect.TreeRangeMap.SubRangeMap.SubRangeMapAsMap
 
subRangeSet(Range<C>) - Method in class com.google.common.collect.ImmutableRangeSet
Returns a view of the intersection of this range set with the given range.
subRangeSet(Range<C>) - Method in interface com.google.common.collect.RangeSet
Returns a view of the intersection of this RangeSet with the specified range.
subRangeSet(Range<C>) - Method in class com.google.common.collect.TreeRangeSet
 
SubRangeSet(Range<C>) - Constructor for class com.google.common.collect.TreeRangeSet.SubRangeSet
 
subRangeSet(Range<C>) - Method in class com.google.common.collect.TreeRangeSet.SubRangeSet
 
SubRangeSetRangesByLowerBound(Range<Cut<C>>, Range<C>, NavigableMap<Cut<C>, Range<C>>) - Constructor for class com.google.common.collect.TreeRangeSet.SubRangeSetRangesByLowerBound
 
Subscribe - Annotation Type in com.google.common.eventbus
Marks a method as an event subscriber.
subscriber - Variable in class com.google.common.eventbus.EventBus.EventWithSubscriber
 
subscriber - Variable in class com.google.common.eventbus.SubscriberExceptionContext
 
SubscriberExceptionContext - Class in com.google.common.eventbus
Context for an exception thrown by a subscriber.
SubscriberExceptionContext(EventBus, Object, Object, Method) - Constructor for class com.google.common.eventbus.SubscriberExceptionContext
 
subscriberExceptionHandler - Variable in class com.google.common.eventbus.EventBus
 
SubscriberExceptionHandler - Interface in com.google.common.eventbus
Handler for exceptions thrown by event subscribers.
SubscriberFindingStrategy - Interface in com.google.common.eventbus
A method for finding event subscriber methods in objects, for use by EventBus.
subscriberMethod - Variable in class com.google.common.eventbus.SubscriberExceptionContext
 
subscriberMethodsCache - Static variable in class com.google.common.eventbus.AnnotatedSubscriberFinder
A thread-safe cache that contains the mapping from each class to all methods in that class and all super-classes, that are annotated with @Subscribe.
subscribersByType - Variable in class com.google.common.eventbus.EventBus
All registered event subscribers, indexed by event type.
subscribersByTypeLock - Variable in class com.google.common.eventbus.EventBus
 
subSet(K, K) - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableKeySet
 
subSet(K, boolean, K, boolean) - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableKeySet
 
subSet(K, K) - Method in class com.google.common.collect.AbstractMapBasedMultimap.SortedKeySet
 
subSet(V, boolean, V, boolean) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedNavigableSet
 
subSet(V, V) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedSortedSet
 
subSet(E, E) - Method in class com.google.common.collect.Constraints.ConstrainedSortedSet
 
subSet(C, C) - Method in class com.google.common.collect.ContiguousSet
 
subSet(C, boolean, C, boolean) - Method in class com.google.common.collect.ContiguousSet
 
subSet(E, boolean, E, boolean) - Method in class com.google.common.collect.ForwardingNavigableSet
 
subSet(E, E) - Method in class com.google.common.collect.ForwardingSortedSet
 
subSet(Range<C>) - Method in class com.google.common.collect.ImmutableRangeSet.AsSet
 
subSet(E, E) - Method in class com.google.common.collect.ImmutableSortedSet
subSet(E, boolean, E, boolean) - Method in class com.google.common.collect.ImmutableSortedSet
 
subSet(K, K) - Method in class com.google.common.collect.Maps.FilteredEntrySortedMap.SortedKeySet
 
subSet(K, boolean, K, boolean) - Method in class com.google.common.collect.Maps.NavigableKeySet
 
subSet(K, K) - Method in class com.google.common.collect.Maps.NavigableKeySet
 
subSet(K, K) - Method in class com.google.common.collect.Maps.SortedKeySet
 
subSet(E, boolean, E, boolean) - Method in class com.google.common.collect.Sets.DescendingSet
 
subSet(E, E) - Method in class com.google.common.collect.Sets.DescendingSet
 
subSet(E, boolean, E, boolean) - Method in class com.google.common.collect.Sets.FilteredNavigableSet
 
subSet(E, E) - Method in class com.google.common.collect.Sets.FilteredSortedSet
 
SubSet(ImmutableMap<E, Integer>, int) - Constructor for class com.google.common.collect.Sets.SubSet
 
subSet(E, boolean, E, boolean) - Method in class com.google.common.collect.Sets.UnmodifiableNavigableSet
 
subSet(E, E) - Method in class com.google.common.collect.SortedMultisets.ElementSet
 
subSet(E, boolean, E, boolean) - Method in class com.google.common.collect.SortedMultisets.NavigableElementSet
 
subSet(E, boolean, E, boolean) - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableSet
 
subSet(E, E) - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableSet
 
subSet(E, E) - Method in class com.google.common.collect.Synchronized.SynchronizedSortedSet
 
subSetImpl(C, boolean, C, boolean) - Method in class com.google.common.collect.ContiguousSet
 
subSetImpl(E, boolean, E, boolean) - Method in class com.google.common.collect.DescendingImmutableSortedSet
 
subSetImpl(C, boolean, C, boolean) - Method in class com.google.common.collect.EmptyContiguousSet
 
subSetImpl(E, boolean, E, boolean) - Method in class com.google.common.collect.EmptyImmutableSortedSet
 
subSetImpl(C, boolean, C, boolean) - Method in class com.google.common.collect.ImmutableRangeSet.AsSet
 
subSetImpl(E, boolean, E, boolean) - Method in class com.google.common.collect.ImmutableSortedSet
 
subSetImpl(C, boolean, C, boolean) - Method in class com.google.common.collect.RegularContiguousSet
 
subSetImpl(E, boolean, E, boolean) - Method in class com.google.common.collect.RegularImmutableSortedSet
 
subtype - Variable in class com.google.common.net.MediaType
 
subtype() - Method in class com.google.common.net.MediaType
Returns the media subtype.
subtypeBound(Type) - Static method in class com.google.common.reflect.TypeToken
 
subtypeBound(WildcardType) - Static method in class com.google.common.reflect.TypeToken
 
subtypeOf(Type) - Static method in class com.google.common.reflect.Types
Returns a new WildcardType with upperBound.
subtypeOfComponentType(Type[]) - Static method in class com.google.common.reflect.Types
Returns ? extends X if any of bounds is a subtype of X[]; or null otherwise.
succ - Variable in class com.google.common.collect.TreeMultiset.AvlNode
 
succeedsInMultimap(LinkedHashMultimap.ValueEntry<K, V>, LinkedHashMultimap.ValueEntry<K, V>) - Static method in class com.google.common.collect.LinkedHashMultimap
 
succeedsInValueSet(LinkedHashMultimap.ValueSetLink<K, V>, LinkedHashMultimap.ValueSetLink<K, V>) - Static method in class com.google.common.collect.LinkedHashMultimap
 
successfulAsList(ListenableFuture<? extends V>...) - Static method in class com.google.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.google.common.util.concurrent.Futures
Creates a new ListenableFuture whose value is a list containing the values of all its successful input futures.
successor(TreeMultiset.AvlNode<T>, TreeMultiset.AvlNode<T>) - Static method in class com.google.common.collect.TreeMultiset
 
successor(TreeMultiset.AvlNode<T>, TreeMultiset.AvlNode<T>, TreeMultiset.AvlNode<T>) - Static method in class com.google.common.collect.TreeMultiset
 
successorInMultimap - Variable in class com.google.common.collect.LinkedHashMultimap.ValueEntry
 
successorInValueSet - Variable in class com.google.common.collect.LinkedHashMultimap.ValueEntry
 
sum() - Method in interface com.google.common.cache.LongAddable
 
sum() - Method in class com.google.common.cache.LongAddables.PureJavaLongAddable
 
sum() - Method in class com.google.common.cache.LongAdder
Returns the current sum.
sum(Multiset<? extends E>, Multiset<? extends E>) - Static method in class com.google.common.collect.Multisets
Returns an unmodifiable view of the sum of two multisets.
sum() - Method in class com.google.common.util.concurrent.AtomicLongMap
Returns the sum of all values in this map.
sumThenReset() - Method in class com.google.common.cache.LongAdder
Equivalent in effect to LongAdder.sum() followed by LongAdder.reset().
supertypeBound(Type) - Static method in class com.google.common.reflect.TypeToken
 
supertypeBound(WildcardType) - Static method in class com.google.common.reflect.TypeToken
 
supertypeOf(Type) - Static method in class com.google.common.reflect.Types
Returns a new WildcardType with lowerBound.
supplier - Variable in class com.google.common.base.Functions.SupplierFunction
 
Supplier<T> - Interface in com.google.common.base
A class that can supply objects of a single type.
supplier - Variable in class com.google.common.base.Suppliers.SupplierComposition
 
SUPPLIER - Static variable in class com.google.common.cache.LongAddables
 
supplier - Variable in class com.google.common.util.concurrent.Striped.LargeLazyStriped
 
supplier - Variable in class com.google.common.util.concurrent.Striped.SmallLazyStriped
 
SupplierComposition(Function<? super F, T>, Supplier<F>) - Constructor for class com.google.common.base.Suppliers.SupplierComposition
 
SupplierFunction(Supplier<T>) - Constructor for class com.google.common.base.Functions.SupplierFunction
 
supplierFunction() - Static method in class com.google.common.base.Suppliers
Returns a function that accepts a supplier and returns the result of invoking Supplier.get() on that supplier.
SupplierFunctionImpl() - Constructor for enum com.google.common.base.Suppliers.SupplierFunctionImpl
 
SupplierOfInstance(T) - Constructor for class com.google.common.base.Suppliers.SupplierOfInstance
 
Suppliers - Class in com.google.common.base
Useful suppliers.
Suppliers() - Constructor for class com.google.common.base.Suppliers
 
Suppliers.ExpiringMemoizingSupplier<T> - Class in com.google.common.base
 
Suppliers.MemoizingSupplier<T> - Class in com.google.common.base
 
Suppliers.SupplierComposition<F,T> - Class in com.google.common.base
 
Suppliers.SupplierFunction<T> - Interface in com.google.common.base
 
Suppliers.SupplierFunctionImpl - Enum in com.google.common.base
 
Suppliers.SupplierOfInstance<T> - Class in com.google.common.base
 
Suppliers.ThreadSafeSupplier<T> - Class in com.google.common.base
 
SupplierToCacheLoader(Supplier<V>) - Constructor for class com.google.common.cache.CacheLoader.SupplierToCacheLoader
 
supportsClone - Variable in class com.google.common.hash.MessageDigestHashFunction
 
supportsClone() - Method in class com.google.common.hash.MessageDigestHashFunction
 
suppress(Closeable, Throwable, Throwable) - Method in class com.google.common.io.Closer.LoggingSuppressor
 
suppress(Closeable, Throwable, Throwable) - Method in class com.google.common.io.Closer.SuppressingSuppressor
 
suppress(Closeable, Throwable, Throwable) - Method in interface com.google.common.io.Closer.Suppressor
Suppresses the given exception (suppressed) which was thrown when attempting to close the given closeable.
SuppressingSuppressor() - Constructor for class com.google.common.io.Closer.SuppressingSuppressor
 
SUPPRESSOR - Static variable in class com.google.common.io.Closer
The suppressor implementation to use for the current Java version.
suppressor - Variable in class com.google.common.io.Closer
 
SVG_UTF_8 - Static variable in class com.google.common.net.MediaType
 
swap(Object[], int, int) - Static method in class com.google.common.collect.ObjectArrays
Swaps array[i] with array[j].
swap(char[], int, int) - Static method in class com.google.thirdparty.publicsuffix.TrieParser
 
switchDirection() - Method in class com.google.common.collect.Collections2.PermutationIterator
 
symmetricDifference(Set<? extends E>, Set<? extends E>) - Static method in class com.google.common.collect.Sets
Returns an unmodifiable view of the symmetric difference of two sets.
SYN - Static variable in class com.google.common.base.Ascii
Synchronous Idle: A communication control character used by a synchronous transmission system in the absence of any other character to provide a signal from which synchronism may be achieved or retained.
sync - Variable in class com.google.common.util.concurrent.AbstractFuture
Synchronization control for AbstractFutures.
Sync() - Constructor for class com.google.common.util.concurrent.AbstractFuture.Sync
 
Synchronized - Class in com.google.common.collect
Synchronized collection views.
Synchronized() - Constructor for class com.google.common.collect.Synchronized
 
Synchronized.SynchronizedAsMap<K,V> - Class in com.google.common.collect
 
Synchronized.SynchronizedAsMapEntries<K,V> - Class in com.google.common.collect
 
Synchronized.SynchronizedAsMapValues<V> - Class in com.google.common.collect
 
Synchronized.SynchronizedBiMap<K,V> - Class in com.google.common.collect
 
Synchronized.SynchronizedCollection<E> - Class in com.google.common.collect
 
Synchronized.SynchronizedDeque<E> - Class in com.google.common.collect
 
Synchronized.SynchronizedEntry<K,V> - Class in com.google.common.collect
 
Synchronized.SynchronizedList<E> - Class in com.google.common.collect
 
Synchronized.SynchronizedListMultimap<K,V> - Class in com.google.common.collect
 
Synchronized.SynchronizedMap<K,V> - Class in com.google.common.collect
 
Synchronized.SynchronizedMultimap<K,V> - Class in com.google.common.collect
 
Synchronized.SynchronizedMultiset<E> - Class in com.google.common.collect
 
Synchronized.SynchronizedNavigableMap<K,V> - Class in com.google.common.collect
 
Synchronized.SynchronizedNavigableSet<E> - Class in com.google.common.collect
 
Synchronized.SynchronizedObject - Class in com.google.common.collect
 
Synchronized.SynchronizedQueue<E> - Class in com.google.common.collect
 
Synchronized.SynchronizedRandomAccessList<E> - Class in com.google.common.collect
 
Synchronized.SynchronizedSet<E> - Class in com.google.common.collect
 
Synchronized.SynchronizedSetMultimap<K,V> - Class in com.google.common.collect
 
Synchronized.SynchronizedSortedMap<K,V> - Class in com.google.common.collect
 
Synchronized.SynchronizedSortedSet<E> - Class in com.google.common.collect
 
Synchronized.SynchronizedSortedSetMultimap<K,V> - Class in com.google.common.collect
 
SynchronizedAsMap(Map<K, Collection<V>>, Object) - Constructor for class com.google.common.collect.Synchronized.SynchronizedAsMap
 
SynchronizedAsMapEntries(Set<Map.Entry<K, Collection<V>>>, Object) - Constructor for class com.google.common.collect.Synchronized.SynchronizedAsMapEntries
 
SynchronizedAsMapValues(Collection<Collection<V>>, Object) - Constructor for class com.google.common.collect.Synchronized.SynchronizedAsMapValues
 
synchronizedBiMap(BiMap<K, V>) - Static method in class com.google.common.collect.Maps
Returns a synchronized (thread-safe) bimap backed by the specified bimap.
SynchronizedBiMap(BiMap<K, V>, Object, BiMap<V, K>) - Constructor for class com.google.common.collect.Synchronized.SynchronizedBiMap
 
SynchronizedCollection(Collection<E>, Object) - Constructor for class com.google.common.collect.Synchronized.SynchronizedCollection
 
synchronizedDeque(Deque<E>) - Static method in class com.google.common.collect.Queues
Returns a synchronized (thread-safe) deque backed by the specified deque.
SynchronizedDeque(Deque<E>, Object) - Constructor for class com.google.common.collect.Synchronized.SynchronizedDeque
 
SynchronizedEntry(Map.Entry<K, V>, Object) - Constructor for class com.google.common.collect.Synchronized.SynchronizedEntry
 
SynchronizedEventSubscriber - Class in com.google.common.eventbus
Wraps a single-argument subscriber method on a specific object, and ensures that only one thread may enter the method at a time.
SynchronizedEventSubscriber(Object, Method) - Constructor for class com.google.common.eventbus.SynchronizedEventSubscriber
Creates a new SynchronizedEventSubscriber to wrap method on target.
SynchronizedList(List<E>, Object) - Constructor for class com.google.common.collect.Synchronized.SynchronizedList
 
synchronizedListMultimap(ListMultimap<K, V>) - Static method in class com.google.common.collect.Multimaps
Returns a synchronized (thread-safe) ListMultimap backed by the specified multimap.
SynchronizedListMultimap(ListMultimap<K, V>, Object) - Constructor for class com.google.common.collect.Synchronized.SynchronizedListMultimap
 
SynchronizedMap(Map<K, V>, Object) - Constructor for class com.google.common.collect.Synchronized.SynchronizedMap
 
synchronizedMultimap(Multimap<K, V>) - Static method in class com.google.common.collect.Multimaps
Returns a synchronized (thread-safe) multimap backed by the specified multimap.
SynchronizedMultimap(Multimap<K, V>, Object) - Constructor for class com.google.common.collect.Synchronized.SynchronizedMultimap
 
SynchronizedMultiset(Multiset<E>, Object) - Constructor for class com.google.common.collect.Synchronized.SynchronizedMultiset
 
synchronizedNavigableMap(NavigableMap<K, V>) - Static method in class com.google.common.collect.Maps
Returns a synchronized (thread-safe) navigable map backed by the specified navigable map.
SynchronizedNavigableMap(NavigableMap<K, V>, Object) - Constructor for class com.google.common.collect.Synchronized.SynchronizedNavigableMap
 
synchronizedNavigableSet(NavigableSet<E>) - Static method in class com.google.common.collect.Sets
Returns a synchronized (thread-safe) navigable set backed by the specified navigable set.
SynchronizedNavigableSet(NavigableSet<E>, Object) - Constructor for class com.google.common.collect.Synchronized.SynchronizedNavigableSet
 
SynchronizedObject(Object, Object) - Constructor for class com.google.common.collect.Synchronized.SynchronizedObject
 
synchronizedQueue(Queue<E>) - Static method in class com.google.common.collect.Queues
Returns a synchronized (thread-safe) queue backed by the specified queue.
SynchronizedQueue(Queue<E>, Object) - Constructor for class com.google.common.collect.Synchronized.SynchronizedQueue
 
SynchronizedRandomAccessList(List<E>, Object) - Constructor for class com.google.common.collect.Synchronized.SynchronizedRandomAccessList
 
SynchronizedSet(Set<E>, Object) - Constructor for class com.google.common.collect.Synchronized.SynchronizedSet
 
synchronizedSetMultimap(SetMultimap<K, V>) - Static method in class com.google.common.collect.Multimaps
Returns a synchronized (thread-safe) SetMultimap backed by the specified multimap.
SynchronizedSetMultimap(SetMultimap<K, V>, Object) - Constructor for class com.google.common.collect.Synchronized.SynchronizedSetMultimap
 
SynchronizedSortedMap(SortedMap<K, V>, Object) - Constructor for class com.google.common.collect.Synchronized.SynchronizedSortedMap
 
SynchronizedSortedSet(SortedSet<E>, Object) - Constructor for class com.google.common.collect.Synchronized.SynchronizedSortedSet
 
synchronizedSortedSetMultimap(SortedSetMultimap<K, V>) - Static method in class com.google.common.collect.Multimaps
Returns a synchronized (thread-safe) SortedSetMultimap backed by the specified multimap.
SynchronizedSortedSetMultimap(SortedSetMultimap<K, V>, Object) - Constructor for class com.google.common.collect.Synchronized.SynchronizedSortedSetMultimap
 
synchronizedSupplier(Supplier<T>) - Static method in class com.google.common.base.Suppliers
Returns a supplier whose get() method synchronizes on delegate before calling it, making it thread-safe.
SYSTEM_TICKER - Static variable in class com.google.common.base.Ticker
 
systemExit() - Static method in class com.google.common.util.concurrent.UncaughtExceptionHandlers
Returns an exception handler that exits the system.
SystemLoader() - Constructor for class com.google.common.base.FinalizableReferenceQueue.SystemLoader
 
systemNanoTime() - Static method in class com.google.common.base.Platform
Calls System.nanoTime().
systemTicker() - Static method in class com.google.common.base.Ticker
A ticker that reads the current time using System.nanoTime().

T

t - Variable in class com.google.common.collect.ComputingConcurrentHashMap.ComputationExceptionReference
 
table - Variable in class com.google.common.base.CharMatcher.BitSetMatcher
 
table - Variable in class com.google.common.base.SmallCharMatcher
 
table - Variable in class com.google.common.cache.LocalCache.Segment
The per-segment table.
table - Variable in class com.google.common.collect.MapMakerInternalMap.Segment
The per-segment table.
table - Variable in class com.google.common.collect.RegularImmutableMap
 
table - Variable in class com.google.common.collect.RegularImmutableSet
 
Table<R,C,V> - Interface in com.google.common.collect
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> - Interface in com.google.common.collect
Row key / column key / value triplet corresponding to a mapping in a table.
Tables - Class in com.google.common.collect
Provides static methods that involve a Table.
Tables() - Constructor for class com.google.common.collect.Tables
 
Tables.AbstractCell<R,C,V> - Class in com.google.common.collect
 
Tables.ImmutableCell<R,C,V> - Class in com.google.common.collect
 
Tables.TransformedTable<R,C,V1,V2> - Class in com.google.common.collect
 
Tables.TransposeTable<C,R,V> - Class in com.google.common.collect
 
Tables.UnmodifiableRowSortedMap<R,C,V> - Class in com.google.common.collect
 
Tables.UnmodifiableTable<R,C,V> - Class in com.google.common.collect
 
TableSet() - Constructor for class com.google.common.collect.StandardTable.TableSet
 
tail - Variable in class com.google.common.collect.LinkedListMultimap.KeyList
 
tail - Variable in class com.google.common.collect.LinkedListMultimap
 
tailIndex(E, boolean) - Method in class com.google.common.collect.RegularImmutableSortedSet
 
tailMap(K) - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableAsMap
 
tailMap(K, boolean) - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableAsMap
 
tailMap(K) - Method in class com.google.common.collect.AbstractMapBasedMultimap.SortedAsMap
 
tailMap(K) - Method in class com.google.common.collect.AbstractNavigableMap
 
tailMap(K, boolean) - Method in class com.google.common.collect.EmptyImmutableSortedMap
 
tailMap(K, boolean) - Method in class com.google.common.collect.ForwardingNavigableMap
 
tailMap(K) - Method in class com.google.common.collect.ForwardingSortedMap
 
tailMap(K) - Method in class com.google.common.collect.ImmutableSortedMap
This method returns a ImmutableSortedMap, consisting of the entries whose keys are greater than or equals to fromKey.
tailMap(K, boolean) - Method in class com.google.common.collect.ImmutableSortedMap
This method returns a ImmutableSortedMap, consisting of the entries whose keys are greater than (or equal to, if inclusive) fromKey.
tailMap(K, boolean) - Method in class com.google.common.collect.Maps.DescendingMap
 
tailMap(K) - Method in class com.google.common.collect.Maps.DescendingMap
 
tailMap(K, boolean) - Method in class com.google.common.collect.Maps.FilteredEntryNavigableMap
 
tailMap(K) - Method in class com.google.common.collect.Maps.FilteredEntrySortedMap
 
tailMap(K, boolean) - Method in class com.google.common.collect.Maps.NavigableAsMapView
 
tailMap(K) - Method in class com.google.common.collect.Maps.SortedAsMapView
 
tailMap(K) - Method in class com.google.common.collect.Maps.TransformedEntriesNavigableMap
 
tailMap(K, boolean) - Method in class com.google.common.collect.Maps.TransformedEntriesNavigableMap
 
tailMap(K) - Method in class com.google.common.collect.Maps.TransformedEntriesSortedMap
 
tailMap(K) - Method in class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
tailMap(K, boolean) - Method in class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
tailMap(K, boolean) - Method in class com.google.common.collect.RegularImmutableSortedMap
 
tailMap(R) - Method in class com.google.common.collect.StandardRowSortedTable.RowSortedMap
 
tailMap(K, boolean) - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableMap
 
tailMap(K) - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableMap
 
tailMap(K) - Method in class com.google.common.collect.Synchronized.SynchronizedSortedMap
 
tailMap(C) - Method in class com.google.common.collect.TreeBasedTable.TreeRow
 
tailMap(Cut<C>, boolean) - Method in class com.google.common.collect.TreeRangeSet.ComplementRangesByLowerBound
 
tailMap(Cut<C>, boolean) - Method in class com.google.common.collect.TreeRangeSet.RangesByUpperBound
 
tailMap(Cut<C>, boolean) - Method in class com.google.common.collect.TreeRangeSet.SubRangeSetRangesByLowerBound
 
tailMultiset(E, BoundType) - Method in class com.google.common.collect.DescendingImmutableSortedMultiset
 
tailMultiset(E, BoundType) - Method in class com.google.common.collect.DescendingMultiset
 
tailMultiset(E, BoundType) - Method in class com.google.common.collect.EmptyImmutableSortedMultiset
 
tailMultiset(E, BoundType) - Method in class com.google.common.collect.ForwardingSortedMultiset
 
tailMultiset(E, BoundType) - Method in class com.google.common.collect.ImmutableSortedMultiset
 
tailMultiset(E, BoundType) - Method in class com.google.common.collect.RegularImmutableSortedMultiset
 
tailMultiset(E, BoundType) - Method in interface com.google.common.collect.SortedMultiset
Returns a view of this multiset restricted to the elements greater than lowerBound, optionally including lowerBound itself.
tailMultiset(E, BoundType) - Method in class com.google.common.collect.TreeMultiset
 
tailMultiset(E, BoundType) - Method in class com.google.common.collect.UnmodifiableSortedMultiset
 
tailSet(K) - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableKeySet
 
tailSet(K, boolean) - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableKeySet
 
tailSet(K) - Method in class com.google.common.collect.AbstractMapBasedMultimap.SortedKeySet
 
tailSet(V, boolean) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedNavigableSet
 
tailSet(V) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedSortedSet
 
tailSet(E) - Method in class com.google.common.collect.Constraints.ConstrainedSortedSet
 
tailSet(C) - Method in class com.google.common.collect.ContiguousSet
 
tailSet(C, boolean) - Method in class com.google.common.collect.ContiguousSet
 
tailSet(E, boolean) - Method in class com.google.common.collect.ForwardingNavigableSet
 
tailSet(E) - Method in class com.google.common.collect.ForwardingSortedSet
 
tailSet(E) - Method in class com.google.common.collect.ImmutableSortedSet
tailSet(E, boolean) - Method in class com.google.common.collect.ImmutableSortedSet
 
tailSet(K) - Method in class com.google.common.collect.Maps.FilteredEntrySortedMap.SortedKeySet
 
tailSet(K, boolean) - Method in class com.google.common.collect.Maps.NavigableKeySet
 
tailSet(K) - Method in class com.google.common.collect.Maps.NavigableKeySet
 
tailSet(K) - Method in class com.google.common.collect.Maps.SortedKeySet
 
tailSet(E, boolean) - Method in class com.google.common.collect.Sets.DescendingSet
 
tailSet(E) - Method in class com.google.common.collect.Sets.DescendingSet
 
tailSet(E, boolean) - Method in class com.google.common.collect.Sets.FilteredNavigableSet
 
tailSet(E) - Method in class com.google.common.collect.Sets.FilteredSortedSet
 
tailSet(E, boolean) - Method in class com.google.common.collect.Sets.UnmodifiableNavigableSet
 
tailSet(E) - Method in class com.google.common.collect.SortedMultisets.ElementSet
 
tailSet(E, boolean) - Method in class com.google.common.collect.SortedMultisets.NavigableElementSet
 
tailSet(E, boolean) - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableSet
 
tailSet(E) - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableSet
 
tailSet(E) - Method in class com.google.common.collect.Synchronized.SynchronizedSortedSet
 
tailSetImpl(C, boolean) - Method in class com.google.common.collect.ContiguousSet
 
tailSetImpl(E, boolean) - Method in class com.google.common.collect.DescendingImmutableSortedSet
 
tailSetImpl(C, boolean) - Method in class com.google.common.collect.EmptyContiguousSet
 
tailSetImpl(E, boolean) - Method in class com.google.common.collect.EmptyImmutableSortedSet
 
tailSetImpl(C, boolean) - Method in class com.google.common.collect.ImmutableRangeSet.AsSet
 
tailSetImpl(E, boolean) - Method in class com.google.common.collect.ImmutableSortedSet
 
tailSetImpl(C, boolean) - Method in class com.google.common.collect.RegularContiguousSet
 
tailSetImpl(E, boolean) - Method in class com.google.common.collect.RegularImmutableSortedSet
 
take() - Method in class com.google.common.collect.ForwardingBlockingDeque
 
take() - Method in class com.google.common.util.concurrent.ForwardingBlockingQueue
 
takeFirst() - Method in class com.google.common.collect.ForwardingBlockingDeque
 
takeLast() - Method in class com.google.common.collect.ForwardingBlockingDeque
 
takeUninterruptibly(BlockingQueue<E>) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes queue.take() uninterruptibly.
TAR - Static variable in class com.google.common.net.MediaType
 
target - Variable in class com.google.common.base.Equivalence.EquivalentToPredicate
 
target - Variable in class com.google.common.base.Predicates.InPredicate
 
target - Variable in class com.google.common.base.Predicates.IsEqualToPredicate
 
target - Variable in class com.google.common.eventbus.EventSubscriber
Object sporting the subscriber method.
target - Variable in class com.google.common.io.AppendableWriter
 
targetFormat - Variable in class com.google.common.base.CaseFormat.StringConverter
 
taskRunner - Variable in class com.google.common.util.concurrent.SerializingExecutor
The object that actually runs the Runnables submitted, reused.
TaskRunner() - Constructor for class com.google.common.util.concurrent.SerializingExecutor.TaskRunner
 
TE - Static variable in class com.google.common.net.HttpHeaders
The HTTP TE header field name.
TEMP_DIR_ATTEMPTS - Static variable in class com.google.common.io.Files
Maximum loop count when creating temp directories.
TeredoInfo(Inet4Address, Inet4Address, int, int) - Constructor for class com.google.common.net.InetAddresses.TeredoInfo
Constructs a TeredoInfo instance.
TerminalEntry(ImmutableMapEntry<K, V>) - Constructor for class com.google.common.collect.ImmutableMapEntry.TerminalEntry
 
TerminalEntry(K, V) - Constructor for class com.google.common.collect.ImmutableMapEntry.TerminalEntry
 
terminated(Service.State) - Method in class com.google.common.util.concurrent.AbstractService
 
terminated(Service.State) - Method in class com.google.common.util.concurrent.Service.Listener
Called when the service transitions to the TERMINATED state.
terminated(Service.State) - Method in class com.google.common.util.concurrent.ServiceManager.ServiceListener
 
TERMINATED_FROM_NEW_CALLBACK - Static variable in class com.google.common.util.concurrent.AbstractService
 
TERMINATED_FROM_RUNNING_CALLBACK - Static variable in class com.google.common.util.concurrent.AbstractService
 
TERMINATED_FROM_STOPPING_CALLBACK - Static variable in class com.google.common.util.concurrent.AbstractService
 
terminatedCallback(Service.State) - Static method in class com.google.common.util.concurrent.AbstractService
 
termination - Variable in class com.google.common.util.concurrent.MoreExecutors.DirectExecutorService
Signaled after the executor is shutdown and running tasks are done
TEXT_JAVASCRIPT_UTF_8 - Static variable in class com.google.common.net.MediaType
RFC 4329 declares application/javascript to be the correct media type for JavaScript, but this may be necessary in certain situations for compatibility.
TEXT_TYPE - Static variable in class com.google.common.net.MediaType
 
textToNumericFormatV4(String) - Static method in class com.google.common.net.InetAddresses
 
textToNumericFormatV6(String) - Static method in class com.google.common.net.InetAddresses
 
theUnsafe - Static variable in enum com.google.common.primitives.UnsignedBytes.LexicographicalComparatorHolder.UnsafeComparator
 
threadFactory - Static variable in class com.google.common.util.concurrent.JdkFutureAdapters.ListenableFutureAdapter
 
ThreadFactoryBuilder - Class in com.google.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.google.common.util.concurrent.ThreadFactoryBuilder
Creates a new ThreadFactory builder.
threadHashCode - Static variable in class com.google.common.cache.Striped64
ThreadLocal holding a single-slot int array holding hash code.
threadNameSupplier - Variable in class com.google.common.util.concurrent.AbstractIdleService
 
threadRenaming(Callable<T>, Supplier<String>) - Static method in class com.google.common.util.concurrent.Callables
Wraps the given callable such that for the duration of Callable.call() the thread that is running will have the given name.
threadRenaming(Runnable, Supplier<String>) - Static method in class com.google.common.util.concurrent.Callables
Wraps the given runnable such that for the duration of Runnable.run() the thread that is running with have the given name.
ThreadSafeSupplier(Supplier<T>) - Constructor for class com.google.common.base.Suppliers.ThreadSafeSupplier
 
threadStarted - Variable in class com.google.common.base.FinalizableReferenceQueue
Whether or not the background thread started successfully.
threshold - Variable in class com.google.common.cache.LocalCache.Segment
The table is expanded when its size exceeds this threshold.
threshold - Variable in class com.google.common.collect.MapMakerInternalMap.Segment
The table is expanded when its size exceeds this threshold.
Throwables - Class in com.google.common.base
Static utility methods pertaining to instances of Throwable.
Throwables() - Constructor for class com.google.common.base.Throwables
 
throwCause(Exception, boolean) - Static method in class com.google.common.util.concurrent.SimpleTimeLimiter
 
thrown - Variable in class com.google.common.io.Closer
 
thrown - Variable in class com.google.common.util.concurrent.Futures.ImmediateCancelledFuture
 
thrown - Variable in class com.google.common.util.concurrent.Futures.ImmediateFailedCheckedFuture
 
thrown - Variable in class com.google.common.util.concurrent.Futures.ImmediateFailedFuture
 
ticker - Variable in class com.google.common.base.Stopwatch
 
Ticker - Class in com.google.common.base
A time source; returns a time value representing the number of nanoseconds elapsed since some fixed but arbitrary point in time.
Ticker() - Constructor for class com.google.common.base.Ticker
Constructor for use by subclasses.
ticker - Variable in class com.google.common.cache.CacheBuilder
 
ticker(Ticker) - Method in class com.google.common.cache.CacheBuilder
Specifies a nanosecond-precision time source for use in determining when entries should be expired.
ticker - Variable in class com.google.common.cache.LocalCache.ManualSerializationProxy
 
ticker - Variable in class com.google.common.cache.LocalCache
Measures time in a testable way.
ticker - Variable in class com.google.common.collect.MapMaker
 
ticker - Variable in class com.google.common.collect.MapMakerInternalMap
Measures time in a testable way.
TIFF - Static variable in class com.google.common.net.MediaType
 
time - Variable in class com.google.common.collect.MapMakerInternalMap.SoftExpirableEntry
 
time - Variable in class com.google.common.collect.MapMakerInternalMap.SoftExpirableEvictableEntry
 
time - Variable in class com.google.common.collect.MapMakerInternalMap.StrongExpirableEntry
 
time - Variable in class com.google.common.collect.MapMakerInternalMap.StrongExpirableEvictableEntry
 
time - Variable in class com.google.common.collect.MapMakerInternalMap.WeakExpirableEntry
 
time - Variable in class com.google.common.collect.MapMakerInternalMap.WeakExpirableEvictableEntry
 
TimeLimiter - Interface in com.google.common.util.concurrent
Produces proxies that impose a time limit on method calls to the proxied object.
times(UnsignedInteger) - Method in class com.google.common.primitives.UnsignedInteger
Returns the result of multiplying this and val.
times(UnsignedLong) - Method in class com.google.common.primitives.UnsignedLong
Returns the result of multiplying this and val.
TIMING_ALLOW_ORIGIN - Static variable in class com.google.common.net.HttpHeaders
The HTTP Timing-Allow-Origin header field name.
to(CaseFormat, String) - Method in enum com.google.common.base.CaseFormat
Converts the specified String str from this format to the specified format.
toAddrString(InetAddress) - Static method in class com.google.common.net.InetAddresses
Returns the string representation of an InetAddress.
toArray() - Method in class com.google.common.collect.AbstractBiMap.EntrySet
 
toArray(T[]) - Method in class com.google.common.collect.AbstractBiMap.EntrySet
 
toArray() - Method in class com.google.common.collect.AbstractBiMap.ValueSet
 
toArray(T[]) - Method in class com.google.common.collect.AbstractBiMap.ValueSet
 
toArray(Class<V>) - Method in class com.google.common.collect.ArrayTable
Returns a two-dimensional array with the table contents.
toArray() - Method in class com.google.common.collect.Collections2.FilteredCollection
 
toArray(T[]) - Method in class com.google.common.collect.Collections2.FilteredCollection
 
toArray() - Method in class com.google.common.collect.ConcurrentHashMultiset.EntrySet
 
toArray(T[]) - Method in class com.google.common.collect.ConcurrentHashMultiset.EntrySet
 
toArray() - Method in class com.google.common.collect.ConcurrentHashMultiset
 
toArray(T[]) - Method in class com.google.common.collect.ConcurrentHashMultiset
 
toArray() - Method in class com.google.common.collect.DescendingMultiset
 
toArray(T[]) - Method in class com.google.common.collect.DescendingMultiset
 
toArray(Class<E>) - Method in class com.google.common.collect.FluentIterable
Returns an array containing all of the elements from this fluent iterable in iteration order.
toArray() - Method in class com.google.common.collect.ForwardingCollection
 
toArray(T[]) - Method in class com.google.common.collect.ForwardingCollection
 
toArray() - Method in class com.google.common.collect.ImmutableCollection
 
toArray(T[]) - Method in class com.google.common.collect.ImmutableCollection
 
toArray(Iterable<? extends T>, Class<T>) - Static method in class com.google.common.collect.Iterables
Copies an iterable's elements into an array.
toArray(Iterable<?>) - Static method in class com.google.common.collect.Iterables
Copies an iterable's elements into an array.
toArray(Iterator<? extends T>, Class<T>) - Static method in class com.google.common.collect.Iterators
Copies an iterator's elements into an array.
toArray() - Method in class com.google.common.collect.MapConstraints.ConstrainedAsMapEntries
 
toArray(T[]) - Method in class com.google.common.collect.MapConstraints.ConstrainedAsMapEntries
 
toArray() - Method in class com.google.common.collect.MapConstraints.ConstrainedAsMapValues
 
toArray(T[]) - Method in class com.google.common.collect.MapConstraints.ConstrainedAsMapValues
 
toArray() - Method in class com.google.common.collect.MapConstraints.ConstrainedEntries
 
toArray(T[]) - Method in class com.google.common.collect.MapConstraints.ConstrainedEntries
 
toArray() - Method in class com.google.common.collect.Maps.FilteredEntryMap.KeySet
 
toArray(T[]) - Method in class com.google.common.collect.Maps.FilteredEntryMap.KeySet
 
toArray() - Method in class com.google.common.collect.Maps.FilteredMapValues
 
toArray(T[]) - Method in class com.google.common.collect.Maps.FilteredMapValues
 
toArray() - Method in class com.google.common.collect.Maps.UnmodifiableEntries
 
toArray(T[]) - Method in class com.google.common.collect.Maps.UnmodifiableEntries
 
toArray() - Method in class com.google.common.collect.MinMaxPriorityQueue
 
toArray() - Method in class com.google.common.collect.Sets.DescendingSet
 
toArray(T[]) - Method in class com.google.common.collect.Sets.DescendingSet
 
toArray() - Method in class com.google.common.collect.Synchronized.SynchronizedAsMapEntries
 
toArray(T[]) - Method in class com.google.common.collect.Synchronized.SynchronizedAsMapEntries
 
toArray() - Method in class com.google.common.collect.Synchronized.SynchronizedCollection
 
toArray(T[]) - Method in class com.google.common.collect.Synchronized.SynchronizedCollection
 
toArray() - Method in class com.google.common.escape.CharEscaperBuilder
Convert this builder into an array of char[]s where the maximum index is the value of the highest character that has been seen.
toArray(Collection<Boolean>) - Static method in class com.google.common.primitives.Booleans
Copies a collection of Boolean instances into a new array of primitive boolean values.
toArray(Collection<? extends Number>) - Static method in class com.google.common.primitives.Bytes
Returns an array containing each value of collection, converted to a byte value in the manner of Number.byteValue().
toArray(Collection<Character>) - Static method in class com.google.common.primitives.Chars
Copies a collection of Character instances into a new array of primitive char values.
toArray(Collection<? extends Number>) - Static method in class com.google.common.primitives.Doubles
Returns an array containing each value of collection, converted to a double value in the manner of Number.doubleValue().
toArray(Collection<? extends Number>) - Static method in class com.google.common.primitives.Floats
Returns an array containing each value of collection, converted to a float value in the manner of Number.floatValue().
toArray(Collection<? extends Number>) - Static method in class com.google.common.primitives.Ints
Returns an array containing each value of collection, converted to a int value in the manner of Number.intValue().
toArray(Collection<? extends Number>) - Static method in class com.google.common.primitives.Longs
Returns an array containing each value of collection, converted to a long value in the manner of Number.longValue().
toArray(Collection<? extends Number>) - Static method in class com.google.common.primitives.Shorts
Returns an array containing each value of collection, converted to a short value in the manner of Number.shortValue().
toArray(Collection<Type>) - Static method in class com.google.common.reflect.Types
 
toArrayImpl(Collection<?>, T[]) - Static method in class com.google.common.collect.ObjectArrays
Returns an array containing all of the elements in the specified collection; the runtime type of the returned array is that of the specified array.
toArrayImpl(Object[], int, int, T[]) - Static method in class com.google.common.collect.ObjectArrays
Implementation of Collection.toArray(Object[]) for collections backed by an object array.
toArrayImpl(Collection<?>) - Static method in class com.google.common.collect.ObjectArrays
Returns an array containing all of the elements in the specified collection.
toBooleanArray() - Method in class com.google.common.primitives.Booleans.BooleanArrayAsList
 
toByteArray() - Method in interface com.google.common.io.ByteArrayDataOutput
Returns the contents that have been written to this instance, as a byte array.
toByteArray() - Method in class com.google.common.io.ByteStreams.ByteArrayDataOutputStream
 
toByteArray(InputStream) - Static method in class com.google.common.io.ByteStreams
Reads all bytes from an input stream into a byte array.
toByteArray(InputStream, int) - Static method in class com.google.common.io.ByteStreams
Reads all bytes from an input stream into a byte array.
toByteArray(File) - Static method in class com.google.common.io.Files
Reads all bytes from a file into a byte array.
toByteArray(URL) - Static method in class com.google.common.io.Resources
Reads all bytes from a URL into a byte array.
toByteArray() - Method in class com.google.common.primitives.Bytes.ByteArrayAsList
 
toByteArray(char) - Static method in class com.google.common.primitives.Chars
Returns a big-endian representation of value in a 2-element byte array; equivalent to ByteBuffer.allocate(2).putChar(value).array().
toByteArray(int) - Static method in class com.google.common.primitives.Ints
Returns a big-endian representation of value in a 4-element byte array; equivalent to ByteBuffer.allocate(4).putInt(value).array().
toByteArray(long) - Static method in class com.google.common.primitives.Longs
Returns a big-endian representation of value in an 8-element byte array; equivalent to ByteBuffer.allocate(8).putLong(value).array().
toByteArray(short) - Static method in class com.google.common.primitives.Shorts
Returns a big-endian representation of value in a 2-element byte array; equivalent to ByteBuffer.allocate(2).putShort(value).array().
toCacheBuilder() - Method in class com.google.common.cache.CacheBuilderSpec
Returns a CacheBuilder configured according to this instance's specification.
toCharArray() - Method in class com.google.common.primitives.Chars.CharArrayAsList
 
toCollection(Iterable<E>) - Static method in class com.google.common.collect.Iterables
Converts an iterable into a collection.
toDoubleArray() - Method in class com.google.common.primitives.Doubles.DoubleArrayAsList
 
toEscaper() - Method in class com.google.common.escape.CharEscaperBuilder
Convert this builder into a char escaper which is just a decorator around the underlying array of replacement char[]s.
toFloatArray() - Method in class com.google.common.primitives.Floats.FloatArrayAsList
 
toGenericType(Class<T>) - Static method in class com.google.common.reflect.TypeToken
Returns the type token representing the generic type declaration of cls.
toInt(byte) - Static method in class com.google.common.primitives.UnsignedBytes
Returns the value of the given byte as an integer, when treated as unsigned.
toIntArray() - Method in class com.google.common.primitives.Ints.IntArrayAsList
 
toIterator() - Static method in class com.google.common.collect.Iterables
 
TOKEN_MATCHER - Static variable in class com.google.common.net.MediaType
Matcher for type, subtype and attributes.
Tokenizer(String) - Constructor for class com.google.common.net.MediaType.Tokenizer
 
toList() - Method in class com.google.common.collect.FluentIterable
Returns an ImmutableList containing all of the elements from this fluent iterable in proper sequence.
toLong(int) - Static method in class com.google.common.primitives.UnsignedInts
Returns the value of the given int as a long, when treated as unsigned.
toLongArray() - Method in class com.google.common.primitives.Longs.LongArrayAsList
 
toLowerCase(String) - Static method in class com.google.common.base.Ascii
Returns a copy of the input string in which all uppercase ASCII characters have been converted to lowercase.
toLowerCase(CharSequence) - Static method in class com.google.common.base.Ascii
Returns a copy of the input character sequence in which all uppercase ASCII characters have been converted to lowercase.
toLowerCase(char) - Static method in class com.google.common.base.Ascii
If the argument is an uppercase ASCII character returns the lowercase equivalent.
toMap(Function<? super E, V>) - Method in class com.google.common.collect.FluentIterable
Returns an immutable map for which the elements of this FluentIterable are the keys in the same order, mapped to values by the given function.
toMap(Iterable<K>, Function<? super K, V>) - Static method in class com.google.common.collect.Maps
Returns an immutable map whose keys are the distinct elements of keys and whose value for each key was computed by valueFunction.
toMap(Iterator<K>, Function<? super K, V>) - Static method in class com.google.common.collect.Maps
Returns an immutable map whose keys are the distinct elements of keys and whose value for each key was computed by valueFunction.
tooHigh(T) - Method in class com.google.common.collect.GeneralRange
 
tooLow(T) - Method in class com.google.common.collect.GeneralRange
 
toParsableString() - Method in class com.google.common.cache.CacheBuilderSpec
Returns a string that can be used to parse an equivalent CacheBuilderSpec.
topPrivateDomain() - Method in class com.google.common.net.InternetDomainName
Returns the portion of this domain name that is one level beneath the public suffix.
toRemove - Variable in class com.google.common.collect.HashBiMap.Itr
 
toSet() - Method in class com.google.common.collect.FluentIterable
Returns an ImmutableSet containing all of the elements from this fluent iterable with duplicates removed.
toShortArray() - Method in class com.google.common.primitives.Shorts.ShortArrayAsList
 
toSortedList(Comparator<? super E>) - Method in class com.google.common.collect.FluentIterable
Returns an ImmutableList containing all of the elements from this FluentIterable in the order specified by comparator.
toSortedSet(Comparator<? super E>) - Method in class com.google.common.collect.FluentIterable
Returns an ImmutableSortedSet containing all of the elements from this FluentIterable in the order specified by comparator, with duplicates (determined by comparator.compare(x, y) == 0) removed.
toSplit - Variable in class com.google.common.base.Splitter.SplittingIterator
 
toString() - Method in class com.google.common.base.Absent
 
toString() - Method in class com.google.common.base.CaseFormat.StringConverter
 
toString() - Method in class com.google.common.base.CharMatcher
Returns a string representation of this CharMatcher, such as CharMatcher.or(WHITESPACE, JAVA_DIGIT).
toString() - Method in class com.google.common.base.Converter.ConverterComposition
 
toString() - Method in class com.google.common.base.Converter.FunctionBasedConverter
 
toString() - Method in class com.google.common.base.Converter.IdentityConverter
 
toString() - Method in class com.google.common.base.Converter.ReverseConverter
 
toString() - Method in class com.google.common.base.Enums.StringConverter
 
toString() - Method in class com.google.common.base.Equivalence.EquivalentToPredicate
 
toString() - Method in class com.google.common.base.Equivalence.Wrapper
Returns a string representation for this equivalence wrapper.
toString() - Method in class com.google.common.base.FunctionalEquivalence
 
toString() - Method in class com.google.common.base.Functions.ConstantFunction
 
toString() - Method in class com.google.common.base.Functions.ForMapWithDefault
 
toString() - Method in class com.google.common.base.Functions.FunctionComposition
 
toString() - Method in class com.google.common.base.Functions.FunctionForMapNoDefault
 
toString() - Method in enum com.google.common.base.Functions.IdentityFunction
 
toString() - Method in class com.google.common.base.Functions.PredicateFunction
 
toString() - Method in class com.google.common.base.Functions.SupplierFunction
 
toString() - Method in enum com.google.common.base.Functions.ToStringFunction
 
toString(Object) - Method in class com.google.common.base.Joiner
 
toString() - Method in class com.google.common.base.MoreObjects.ToStringHelper
Returns a string in the format specified by MoreObjects.toStringHelper(Object).
toString() - Method in class com.google.common.base.Objects.ToStringHelper
Deprecated.
Returns a string in the format specified by Objects.toStringHelper(Object).
toString() - Method in class com.google.common.base.Optional
Returns a string representation for this instance.
toString() - Method in class com.google.common.base.PairwiseEquivalence
 
toString() - Method in class com.google.common.base.Predicates.AndPredicate
 
toString() - Method in class com.google.common.base.Predicates.AssignableFromPredicate
 
toString() - Method in class com.google.common.base.Predicates.CompositionPredicate
 
toString() - Method in class com.google.common.base.Predicates.ContainsPatternFromStringPredicate
 
toString() - Method in class com.google.common.base.Predicates.ContainsPatternPredicate
 
toString() - Method in class com.google.common.base.Predicates.InPredicate
 
toString() - Method in class com.google.common.base.Predicates.InstanceOfPredicate
 
toString() - Method in class com.google.common.base.Predicates.IsEqualToPredicate
 
toString() - Method in class com.google.common.base.Predicates.NotPredicate
 
toString() - Method in class com.google.common.base.Predicates.OrPredicate
 
toString() - Method in class com.google.common.base.Present
 
toString() - Method in enum com.google.common.base.StandardSystemProperty
Returns a string representation of this system property.
toString() - Method in class com.google.common.base.Stopwatch
Returns a string representation of the current elapsed time.
toString() - Method in class com.google.common.base.Suppliers.ExpiringMemoizingSupplier
 
toString() - Method in class com.google.common.base.Suppliers.MemoizingSupplier
 
toString() - Method in class com.google.common.base.Suppliers.SupplierComposition
 
toString() - Method in enum com.google.common.base.Suppliers.SupplierFunctionImpl
 
toString() - Method in class com.google.common.base.Suppliers.SupplierOfInstance
 
toString() - Method in class com.google.common.base.Suppliers.ThreadSafeSupplier
 
toString() - Method in class com.google.common.cache.CacheBuilder
Returns a string representation for this CacheBuilder instance.
toString() - Method in class com.google.common.cache.CacheBuilderSpec
Returns a string representation for this CacheBuilderSpec instance.
toString() - Method in class com.google.common.cache.CacheStats
 
toString() - Method in class com.google.common.cache.LocalCache.WriteThroughEntry
Returns a string representation of the form {key}={value}.
toString() - Method in class com.google.common.cache.LongAdder
Returns the String representation of the LongAdder.sum().
toString() - Method in class com.google.common.cache.RemovalNotification
Returns a string representation of the form {key}={value}.
toString() - Method in class com.google.common.collect.AbstractBiMap.ValueSet
 
toString() - Method in class com.google.common.collect.AbstractMapBasedMultimap.AsMap
 
toString() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection
 
toString() - Method in class com.google.common.collect.AbstractMapEntry
Returns a string representation of the form {key}={value}.
toString() - Method in class com.google.common.collect.AbstractMultimap
Returns a string representation of the multimap, generated by calling toString on the map returned by Multimap.asMap().
toString() - Method in class com.google.common.collect.AbstractMultiset
toString() - Method in class com.google.common.collect.AbstractRangeSet
 
toString() - Method in class com.google.common.collect.AbstractTable
Returns the string representation rowMap().toString().
toString() - Method in class com.google.common.collect.AllEqualOrdering
 
toString() - Method in class com.google.common.collect.ByFunctionOrdering
 
toString() - Method in class com.google.common.collect.Collections2.OrderedPermutationCollection
 
toString() - Method in class com.google.common.collect.Collections2.PermutationCollection
 
toString() - Method in class com.google.common.collect.ComparatorOrdering
 
toString() - Method in class com.google.common.collect.CompoundOrdering
 
toString() - Method in interface com.google.common.collect.Constraint
Returns a brief human readable description of this constraint, such as "Not null" or "Positive number".
toString() - Method in class com.google.common.collect.ContiguousSet
Returns a short-hand representation of the contents such as "[1..100]".
toString() - Method in class com.google.common.collect.Count
 
toString() - Method in class com.google.common.collect.Cut.AboveAll
 
toString() - Method in class com.google.common.collect.Cut.AboveValue
 
toString() - Method in class com.google.common.collect.Cut.BelowAll
 
toString() - Method in class com.google.common.collect.Cut.BelowValue
 
toString() - Method in class com.google.common.collect.DescendingMultiset
 
toString() - Method in class com.google.common.collect.DiscreteDomain.BigIntegerDomain
 
toString() - Method in class com.google.common.collect.DiscreteDomain.IntegerDomain
 
toString() - Method in class com.google.common.collect.DiscreteDomain.LongDomain
 
toString() - Method in class com.google.common.collect.EmptyContiguousSet
 
toString() - Method in class com.google.common.collect.EmptyImmutableSet
 
toString() - Method in class com.google.common.collect.EmptyImmutableSortedMap
 
toString() - Method in class com.google.common.collect.EmptyImmutableSortedSet
 
toString() - Method in class com.google.common.collect.ExplicitOrdering
 
toString() - Method in class com.google.common.collect.FluentIterable
Returns a string representation of this fluent iterable, with the format [e1, e2, ..., en].
toString() - Method in class com.google.common.collect.ForwardingObject
Returns the string representation generated by the delegate's toString method.
toString() - Method in class com.google.common.collect.GeneralRange
 
toString() - Method in class com.google.common.collect.ImmutableEnumSet
 
toString() - Method in class com.google.common.collect.ImmutableMap
 
toString() - Method in class com.google.common.collect.ImmutableMultiset
 
toString() - Method in class com.google.common.collect.ImmutableRangeMap
 
toString() - Method in class com.google.common.collect.ImmutableRangeSet.AsSet
 
toString(Iterable<?>) - Static method in class com.google.common.collect.Iterables
Returns a string representation of iterable, with the format [e1, e2, ..., en] (that is, identical to Arrays.toString(Iterables.toArray(iterable))).
toString() - Method in class com.google.common.collect.Iterables.UnmodifiableIterable
 
toString(Iterator<?>) - Static method in class com.google.common.collect.Iterators
Returns a string representation of iterator, with the format [e1, e2, ..., en].
toString() - Method in class com.google.common.collect.LexicographicalOrdering
 
toString() - Method in interface com.google.common.collect.MapConstraint
Returns a brief human readable description of this constraint, such as "Not null".
toString() - Method in enum com.google.common.collect.MapConstraints.NotNullMapConstraint
 
toString() - Method in class com.google.common.collect.MapMaker
Returns a string representation for this MapMaker instance.
toString() - Method in class com.google.common.collect.Maps.BiMapConverter
 
toString() - Method in class com.google.common.collect.Maps.DescendingMap
 
toString() - Method in class com.google.common.collect.Maps.MapDifferenceImpl
 
toString() - Method in class com.google.common.collect.Maps.ValueDifferenceImpl
 
toString() - Method in interface com.google.common.collect.Multiset.Entry
Returns the canonical string representation of this entry, defined as follows.
toString() - Method in interface com.google.common.collect.Multiset
toString() - Method in class com.google.common.collect.Multisets.AbstractEntry
Returns a string representation of this multiset entry.
toString() - Method in class com.google.common.collect.NaturalOrdering
 
toString() - Method in class com.google.common.collect.NullsFirstOrdering
 
toString() - Method in class com.google.common.collect.NullsLastOrdering
 
toString() - Method in class com.google.common.collect.Ordering.ArbitraryOrdering
 
toString() - Method in class com.google.common.collect.Range
Returns a string representation of this range, such as "[3..5)" (other examples are listed in the class documentation).
toString(Cut<?>, Cut<?>) - Static method in class com.google.common.collect.Range
 
toString() - Method in interface com.google.common.collect.RangeMap
Returns a readable string representation of this range map.
toString() - Method in interface com.google.common.collect.RangeSet
Returns a readable string representation of this range set.
toString() - Method in class com.google.common.collect.ReverseNaturalOrdering
 
toString() - Method in class com.google.common.collect.ReverseOrdering
 
toString() - Method in class com.google.common.collect.Sets.DescendingSet
 
toString() - Method in class com.google.common.collect.Sets.PowerSet
 
toString() - Method in class com.google.common.collect.SingletonImmutableList
 
toString() - Method in class com.google.common.collect.SingletonImmutableSet
 
toString() - Method in class com.google.common.collect.Synchronized.SynchronizedObject
 
toString() - Method in class com.google.common.collect.Tables.AbstractCell
 
toString() - Method in class com.google.common.collect.TreeMultiset.AvlNode
 
toString() - Method in class com.google.common.collect.TreeRangeMap.SubRangeMap
 
toString() - Method in class com.google.common.collect.TreeRangeMap
 
toString() - Method in class com.google.common.collect.UsingToStringOrdering
 
toString() - Method in class com.google.common.eventbus.EventSubscriber
 
toString - Variable in class com.google.common.hash.ChecksumHashFunction
 
toString() - Method in class com.google.common.hash.ChecksumHashFunction
 
toString() - Method in class com.google.common.hash.Crc32cHashFunction
 
toString() - Method in enum com.google.common.hash.Funnels.ByteArrayFunnel
 
toString() - Method in enum com.google.common.hash.Funnels.IntegerFunnel
 
toString() - Method in enum com.google.common.hash.Funnels.LongFunnel
 
toString() - Method in class com.google.common.hash.Funnels.SequentialFunnel
 
toString() - Method in class com.google.common.hash.Funnels.SinkAsStream
 
toString() - Method in class com.google.common.hash.Funnels.StringCharsetFunnel
 
toString() - Method in enum com.google.common.hash.Funnels.UnencodedCharsFunnel
 
toString() - Method in class com.google.common.hash.HashCode
Returns a string containing each byte of HashCode.asBytes(), in order, as a two-digit unsigned hexadecimal number in lower case.
toString - Variable in class com.google.common.hash.MessageDigestHashFunction.SerializedForm
 
toString - Variable in class com.google.common.hash.MessageDigestHashFunction
 
toString() - Method in class com.google.common.hash.MessageDigestHashFunction
 
toString() - Method in class com.google.common.hash.Murmur3_128HashFunction
 
toString() - Method in class com.google.common.hash.Murmur3_32HashFunction
 
toString() - Method in class com.google.common.hash.SipHashFunction
 
toString() - Method in class com.google.common.io.BaseEncoding.Alphabet
 
toString() - Method in class com.google.common.io.BaseEncoding.SeparatedBaseEncoding
 
toString() - Method in class com.google.common.io.BaseEncoding.StandardBaseEncoding
 
toString() - Method in class com.google.common.io.ByteSink.AsCharSink
 
toString() - Method in class com.google.common.io.ByteSource.AsCharSource
 
toString() - Method in class com.google.common.io.ByteSource.ByteArrayByteSource
 
toString() - Method in class com.google.common.io.ByteSource.ConcatenatedByteSource
 
toString() - Method in class com.google.common.io.ByteSource.EmptyByteSource
 
toString() - Method in class com.google.common.io.ByteSource.SlicedByteSource
 
toString() - Method in class com.google.common.io.CharSource.CharSequenceCharSource
 
toString() - Method in class com.google.common.io.CharSource.ConcatenatedCharSource
 
toString() - Method in class com.google.common.io.CharSource.EmptyCharSource
 
toString() - Method in class com.google.common.io.CharStreams.NullWriter
 
toString(Readable) - Static method in class com.google.common.io.CharStreams
Reads all characters from a Readable object into a String.
toString() - Method in class com.google.common.io.Files.FileByteSink
 
toString() - Method in class com.google.common.io.Files.FileByteSource
 
toString(File, Charset) - Static method in class com.google.common.io.Files
Reads all characters from a file into a String, using the given character set.
toString(URL, Charset) - Static method in class com.google.common.io.Resources
Reads all characters from a URL into a String, using the given character set.
toString() - Method in class com.google.common.io.Resources.UrlByteSource
 
toString() - Method in class com.google.common.net.HostAndPort
Rebuild the host:port string, including brackets if necessary.
toString() - Method in class com.google.common.net.HostSpecifier
Returns a string representation of the host specifier suitable for inclusion in a URI.
toString() - Method in class com.google.common.net.InternetDomainName
Returns the domain name, normalized to all lower case.
toString() - Method in class com.google.common.net.MediaType
Returns the string representation of this media type in the format described in RFC 2045.
toString() - Method in class com.google.common.primitives.Booleans.BooleanArrayAsList
 
toString() - Method in class com.google.common.primitives.Bytes.ByteArrayAsList
 
toString() - Method in class com.google.common.primitives.Chars.CharArrayAsList
 
toString() - Method in class com.google.common.primitives.Doubles.DoubleArrayAsList
 
toString() - Method in class com.google.common.primitives.Doubles.DoubleConverter
 
toString() - Method in class com.google.common.primitives.Floats.FloatArrayAsList
 
toString() - Method in class com.google.common.primitives.Floats.FloatConverter
 
toString() - Method in class com.google.common.primitives.Ints.IntArrayAsList
 
toString() - Method in class com.google.common.primitives.Ints.IntConverter
 
toString() - Method in class com.google.common.primitives.Longs.LongArrayAsList
 
toString() - Method in class com.google.common.primitives.Longs.LongConverter
 
toString() - Method in class com.google.common.primitives.Shorts.ShortArrayAsList
 
toString() - Method in class com.google.common.primitives.Shorts.ShortConverter
 
toString(byte) - Static method in class com.google.common.primitives.UnsignedBytes
Returns a string representation of x, where x is treated as unsigned.
toString(byte, int) - Static method in class com.google.common.primitives.UnsignedBytes
Returns a string representation of x for the given radix, where x is treated as unsigned.
toString() - Method in class com.google.common.primitives.UnsignedInteger
Returns a string representation of the UnsignedInteger value, in base 10.
toString(int) - Method in class com.google.common.primitives.UnsignedInteger
Returns a string representation of the UnsignedInteger value, in base radix.
toString(int) - Static method in class com.google.common.primitives.UnsignedInts
Returns a string representation of x, where x is treated as unsigned.
toString(int, int) - Static method in class com.google.common.primitives.UnsignedInts
Returns a string representation of x for the given radix, where x is treated as unsigned.
toString() - Method in class com.google.common.primitives.UnsignedLong
Returns a string representation of the UnsignedLong value, in base 10.
toString(int) - Method in class com.google.common.primitives.UnsignedLong
Returns a string representation of the UnsignedLong value, in base radix.
toString(long) - Static method in class com.google.common.primitives.UnsignedLongs
Returns a string representation of x, where x is treated as unsigned.
toString(long, int) - Static method in class com.google.common.primitives.UnsignedLongs
Returns a string representation of x for the given radix, where x is treated as unsigned.
toString() - Method in class com.google.common.reflect.AbstractInvocationHandler
By default delegates to Object.toString().
toString() - Method in class com.google.common.reflect.ClassPath.ClassInfo
 
toString() - Method in class com.google.common.reflect.ClassPath.ResourceInfo
 
toString() - Method in class com.google.common.reflect.Element
 
toString() - Method in class com.google.common.reflect.Parameter
 
toString() - Method in class com.google.common.reflect.TypeParameter
 
toString() - Method in class com.google.common.reflect.TypeResolver.TypeVariableKey
 
toString() - Method in class com.google.common.reflect.Types.GenericArrayTypeImpl
 
toString() - Method in class com.google.common.reflect.Types.ParameterizedTypeImpl
 
toString(Type) - Static method in class com.google.common.reflect.Types
Returns human readable string representation of type.
toString() - Method in class com.google.common.reflect.Types.TypeVariableImpl
 
toString() - Method in class com.google.common.reflect.Types.WildcardTypeImpl
 
toString() - Method in class com.google.common.reflect.TypeToken
 
toString() - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
 
toString() - Method in class com.google.common.util.concurrent.AbstractIdleService
 
toString() - Method in class com.google.common.util.concurrent.AbstractScheduledService
 
toString() - Method in class com.google.common.util.concurrent.AbstractService
 
toString() - Method in class com.google.common.util.concurrent.AtomicDouble
Returns the String representation of the current value.
toString() - Method in class com.google.common.util.concurrent.AtomicDoubleArray
Returns the String representation of the current values of array.
toString() - Method in class com.google.common.util.concurrent.AtomicLongMap
 
toString() - Method in class com.google.common.util.concurrent.RateLimiter
 
toString() - Method in class com.google.common.util.concurrent.ServiceManager
 
toStringBuilder(Readable) - Static method in class com.google.common.io.CharStreams
Reads all characters from a Readable object into a new StringBuilder instance.
toStringFunction() - Static method in class com.google.common.base.Functions
Returns a function that calls toString() on its argument.
ToStringFunction() - Constructor for enum com.google.common.base.Functions.ToStringFunction
 
toStringHelper(Object) - Static method in class com.google.common.base.MoreObjects
Creates an instance of MoreObjects.ToStringHelper.
toStringHelper(Class<?>) - Static method in class com.google.common.base.MoreObjects
Creates an instance of MoreObjects.ToStringHelper in the same manner as MoreObjects.toStringHelper(Object), but using the simple name of clazz instead of using an instance's Object.getClass().
toStringHelper(String) - Static method in class com.google.common.base.MoreObjects
Creates an instance of MoreObjects.ToStringHelper in the same manner as MoreObjects.toStringHelper(Object), but using className instead of using an instance's Object.getClass().
ToStringHelper(String) - Constructor for class com.google.common.base.MoreObjects.ToStringHelper
Use MoreObjects.toStringHelper(Object) to create an instance.
toStringHelper(Object) - Static method in class com.google.common.base.Objects
Deprecated.
Use MoreObjects.toStringHelper(Object) instead. This method is scheduled for removal in June 2016.
toStringHelper(Class<?>) - Static method in class com.google.common.base.Objects
Deprecated.
Use MoreObjects.toStringHelper(Class) instead. This method is scheduled for removal in June 2016.
toStringHelper(String) - Static method in class com.google.common.base.Objects
Deprecated.
Use MoreObjects.toStringHelper(String) instead. This method is scheduled for removal in June 2016.
ToStringHelper(String) - Constructor for class com.google.common.base.Objects.ToStringHelper
Deprecated.
Use Objects.toStringHelper(Object) to create an instance.
toStringImpl(Collection<?>) - Static method in class com.google.common.collect.Collections2
An implementation of Collection#toString().
toStringImpl(Map<?, ?>) - Static method in class com.google.common.collect.Maps
An implementation of Map#toString.
totalCount - Variable in class com.google.common.collect.Multisets.MultisetIteratorImpl
Count of all elements equal to current element
totalCount - Variable in class com.google.common.collect.TreeMultiset.AvlNode
 
totalCount(TreeMultiset.AvlNode<?>) - Static method in class com.google.common.collect.TreeMultiset.AvlNode
 
totalLoadTime - Variable in class com.google.common.cache.AbstractCache.SimpleStatsCounter
 
totalLoadTime - Variable in class com.google.common.cache.CacheStats
 
totalLoadTime() - Method in class com.google.common.cache.CacheStats
Returns the total number of nanoseconds the cache has spent loading new values.
totalSize - Variable in class com.google.common.collect.AbstractMapBasedMultimap
 
totalWeight - Variable in class com.google.common.cache.LocalCache.Segment
The weight of the live elements in this segment's region.
toTrickle - Variable in class com.google.common.collect.MinMaxPriorityQueue.MoveDesc
 
touch(File) - Static method in class com.google.common.io.Files
Creates an empty file or updates the last updated timestamp on the same as the unix command of the same name.
toUpperCase(String) - Static method in class com.google.common.base.Ascii
Returns a copy of the input string in which all lowercase ASCII characters have been converted to uppercase.
toUpperCase(CharSequence) - Static method in class com.google.common.base.Ascii
Returns a copy of the input character sequence in which all lowercase ASCII characters have been converted to uppercase.
toUpperCase(char) - Static method in class com.google.common.base.Ascii
If the argument is a lowercase ASCII character returns the uppercase equivalent.
toUriString(InetAddress) - Static method in class com.google.common.net.InetAddresses
Returns the string representation of an InetAddress suitable for inclusion in a URI.
TRAILER - Static variable in class com.google.common.net.HttpHeaders
The HTTP Trailer header field name.
TRANSFER_ENCODING - Static variable in class com.google.common.net.HttpHeaders
The HTTP Transfer-Encoding header field name.
transform(Function<? super T, V>) - Method in class com.google.common.base.Absent
 
transform(Function<? super T, V>) - Method in class com.google.common.base.Optional
If the instance is present, it is transformed with the given Function; otherwise, Optional.absent() is returned.
transform(Function<? super T, V>) - Method in class com.google.common.base.Present
 
transform(Collection<F>, Function<? super F, T>) - Static method in class com.google.common.collect.Collections2
Returns a collection that applies function to each element of fromCollection.
transform(Function<? super E, T>) - Method in class com.google.common.collect.FluentIterable
Returns a fluent iterable that applies function to each element of this fluent iterable.
transform(Iterable<F>, Function<? super F, ? extends T>) - Static method in class com.google.common.collect.Iterables
Returns an iterable that applies function to each element of fromIterable.
transform(Iterator<F>, Function<? super F, ? extends T>) - Static method in class com.google.common.collect.Iterators
Returns an iterator that applies function to each element of fromIterator.
transform(List<F>, Function<? super F, ? extends T>) - Static method in class com.google.common.collect.Lists
Returns a list that applies function to each element of fromList.
transform(K, Collection<V1>) - Method in class com.google.common.collect.Multimaps.TransformedEntriesListMultimap
 
transform(K, Collection<V1>) - Method in class com.google.common.collect.Multimaps.TransformedEntriesMultimap
 
transform(F) - Method in class com.google.common.collect.TransformedIterator
 
transform(ListenableFuture<I>, AsyncFunction<? super I, ? extends O>) - Static method in class com.google.common.util.concurrent.Futures
Returns a new ListenableFuture whose result is asynchronously derived from the result of the given Future.
transform(ListenableFuture<I>, AsyncFunction<? super I, ? extends O>, Executor) - Static method in class com.google.common.util.concurrent.Futures
Returns a new ListenableFuture whose result is asynchronously derived from the result of the given Future.
transform(ListenableFuture<I>, Function<? super I, ? extends O>) - Static method in class com.google.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.google.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.
transformAndConcat(Function<? super E, ? extends Iterable<? extends T>>) - Method in class com.google.common.collect.FluentIterable
Applies function to each element of this fluent iterable and returns a fluent iterable with the concatenated combination of results.
TransformedCollection(Collection<F>, Function<? super F, ? extends T>) - Constructor for class com.google.common.collect.Collections2.TransformedCollection
 
TransformedEntriesListMultimap(ListMultimap<K, V1>, Maps.EntryTransformer<? super K, ? super V1, V2>) - Constructor for class com.google.common.collect.Multimaps.TransformedEntriesListMultimap
 
TransformedEntriesMap(Map<K, V1>, Maps.EntryTransformer<? super K, ? super V1, V2>) - Constructor for class com.google.common.collect.Maps.TransformedEntriesMap
 
TransformedEntriesMultimap(Multimap<K, V1>, Maps.EntryTransformer<? super K, ? super V1, V2>) - Constructor for class com.google.common.collect.Multimaps.TransformedEntriesMultimap
 
TransformedEntriesNavigableMap(NavigableMap<K, V1>, Maps.EntryTransformer<? super K, ? super V1, V2>) - Constructor for class com.google.common.collect.Maps.TransformedEntriesNavigableMap
 
TransformedEntriesSortedMap(SortedMap<K, V1>, Maps.EntryTransformer<? super K, ? super V1, V2>) - Constructor for class com.google.common.collect.Maps.TransformedEntriesSortedMap
 
TransformedIterator<F,T> - Class in com.google.common.collect
An iterator that transforms a backing iterator; for internal use.
TransformedIterator(Iterator<? extends F>) - Constructor for class com.google.common.collect.TransformedIterator
 
TransformedListIterator<F,T> - Class in com.google.common.collect
An iterator that transforms a backing list iterator; for internal use.
TransformedListIterator(ListIterator<? extends F>) - Constructor for class com.google.common.collect.TransformedListIterator
 
TransformedTable(Table<R, C, V1>, Function<? super V1, V2>) - Constructor for class com.google.common.collect.Tables.TransformedTable
 
transformEntries(Map<K, V1>, Maps.EntryTransformer<? super K, ? super V1, V2>) - Static method in class com.google.common.collect.Maps
Returns a view of a map whose values are derived from the original map's entries.
transformEntries(SortedMap<K, V1>, Maps.EntryTransformer<? super K, ? super V1, V2>) - Static method in class com.google.common.collect.Maps
Returns a view of a sorted map whose values are derived from the original sorted map's entries.
transformEntries(NavigableMap<K, V1>, Maps.EntryTransformer<? super K, ? super V1, V2>) - Static method in class com.google.common.collect.Maps
Returns a view of a navigable map whose values are derived from the original navigable map's entries.
transformEntries(Multimap<K, V1>, Maps.EntryTransformer<? super K, ? super V1, V2>) - Static method in class com.google.common.collect.Multimaps
Returns a view of a multimap whose values are derived from the original multimap's entries.
transformEntries(ListMultimap<K, V1>, Maps.EntryTransformer<? super K, ? super V1, V2>) - Static method in class com.google.common.collect.Multimaps
Returns a view of a ListMultimap whose values are derived from the original multimap's entries.
transformEntries(Set<Map.Entry<K, V>>) - Static method in class com.google.common.reflect.MutableTypeToInstanceMap.UnmodifiableEntry
 
transformEntries(Iterator<Map.Entry<K, V>>) - Static method in class com.google.common.reflect.MutableTypeToInstanceMap.UnmodifiableEntry
 
transformEntriesIgnoreNavigable(SortedMap<K, V1>, Maps.EntryTransformer<? super K, ? super V1, V2>) - Static method in class com.google.common.collect.Maps
 
transformEntry(K, V1) - Method in interface com.google.common.collect.Maps.EntryTransformer
Determines an output value based on a key-value pair.
transformEntry(Map.Entry<K, V1>) - Method in class com.google.common.collect.Maps.TransformedEntriesNavigableMap
 
transformEntry(Maps.EntryTransformer<? super K, ? super V1, V2>, Map.Entry<K, V1>) - Static method in class com.google.common.collect.Maps
Returns a view of an entry transformed by the specified transformer.
transformer - Variable in class com.google.common.collect.Maps.TransformedEntriesMap
 
transformer - Variable in class com.google.common.collect.Multimaps.TransformedEntriesMultimap
 
TransformingRandomAccessList(List<F>, Function<? super F, ? extends T>) - Constructor for class com.google.common.collect.Lists.TransformingRandomAccessList
 
TransformingSequentialList(List<F>, Function<? super F, ? extends T>) - Constructor for class com.google.common.collect.Lists.TransformingSequentialList
 
transformValues(Map<K, V1>, Function<? super V1, V2>) - Static method in class com.google.common.collect.Maps
Returns a view of a map where each value is transformed by a function.
transformValues(SortedMap<K, V1>, Function<? super V1, V2>) - Static method in class com.google.common.collect.Maps
Returns a view of a sorted map where each value is transformed by a function.
transformValues(NavigableMap<K, V1>, Function<? super V1, V2>) - Static method in class com.google.common.collect.Maps
Returns a view of a navigable map where each value is transformed by a function.
transformValues(Multimap<K, V1>, Function<? super V1, V2>) - Static method in class com.google.common.collect.Multimaps
Returns a view of a multimap where each value is transformed by a function.
transformValues(ListMultimap<K, V1>, Function<? super V1, V2>) - Static method in class com.google.common.collect.Multimaps
Returns a view of a ListMultimap where each value is transformed by a function.
transformValues(Table<R, C, V1>, Function<? super V1, V2>) - Static method in class com.google.common.collect.Tables
Returns a view of a table where each value is transformed by a function.
transitioned - Variable in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState
 
transitionService(Service, Service.State, Service.State) - Method in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState
Updates the state with the given service transition.
transpose(Table<R, C, V>) - Static method in class com.google.common.collect.Tables
Creates a transposed view of a given table that flips its row and column keys.
TRANSPOSE_CELL - Static variable in class com.google.common.collect.Tables.TransposeTable
 
TransposeTable(Table<R, C, V>) - Constructor for class com.google.common.collect.Tables.TransposeTable
 
treeAggregate(TreeMultiset.AvlNode<?>) - Method in enum com.google.common.collect.TreeMultiset.Aggregate
 
TreeBasedTable<R,C,V> - Class in com.google.common.collect
Implementation of Table whose row keys and column keys are ordered by their natural ordering or by supplied comparators.
TreeBasedTable(Comparator<? super R>, Comparator<? super C>) - Constructor for class com.google.common.collect.TreeBasedTable
 
TreeBasedTable.Factory<C,V> - Class in com.google.common.collect
 
TreeBasedTable.TreeRow - Class in com.google.common.collect
 
treeKeys() - Static method in class com.google.common.collect.MultimapBuilder
Uses a naturally-ordered TreeMap to map keys to value collections.
treeKeys(Comparator<K0>) - Static method in class com.google.common.collect.MultimapBuilder
Uses a TreeMap sorted by the specified comparator to map keys to value collections.
TreeMultimap<K,V> - Class in com.google.common.collect
Implementation of Multimap whose keys and values are ordered by their natural ordering or by supplied comparators.
TreeMultimap(Comparator<? super K>, Comparator<? super V>) - Constructor for class com.google.common.collect.TreeMultimap
 
TreeMultimap(Comparator<? super K>, Comparator<? super V>, Multimap<? extends K, ? extends V>) - Constructor for class com.google.common.collect.TreeMultimap
 
TreeMultiset<E> - Class in com.google.common.collect
A multiset which maintains the ordering of its elements, according to either their natural order or an explicit Comparator.
TreeMultiset(TreeMultiset.Reference<TreeMultiset.AvlNode<E>>, GeneralRange<E>, TreeMultiset.AvlNode<E>) - Constructor for class com.google.common.collect.TreeMultiset
 
TreeMultiset(Comparator<? super E>) - Constructor for class com.google.common.collect.TreeMultiset
 
TreeMultiset.Aggregate - Enum in com.google.common.collect
A function which can be summed across a subtree.
TreeMultiset.AvlNode<E> - Class in com.google.common.collect
 
TreeMultiset.Reference<T> - Class in com.google.common.collect
 
TreeRangeMap<K extends java.lang.Comparable,V> - Class in com.google.common.collect
An implementation of RangeMap based on a TreeMap, supporting all optional operations.
TreeRangeMap() - Constructor for class com.google.common.collect.TreeRangeMap
 
TreeRangeMap.AsMapOfRanges - Class in com.google.common.collect
 
TreeRangeMap.RangeMapEntry<K extends java.lang.Comparable,V> - Class in com.google.common.collect
 
TreeRangeMap.SubRangeMap - Class in com.google.common.collect
 
TreeRangeMap.SubRangeMap.SubRangeMapAsMap - Class in com.google.common.collect
 
TreeRangeSet<C extends java.lang.Comparable<?>> - Class in com.google.common.collect
An implementation of RangeSet backed by a TreeMap.
TreeRangeSet(NavigableMap<Cut<C>, Range<C>>) - Constructor for class com.google.common.collect.TreeRangeSet
 
TreeRangeSet.AsRanges - Class in com.google.common.collect
 
TreeRangeSet.Complement - Class in com.google.common.collect
 
TreeRangeSet.ComplementRangesByLowerBound<C extends java.lang.Comparable<?>> - Class in com.google.common.collect
 
TreeRangeSet.RangesByUpperBound<C extends java.lang.Comparable<?>> - Class in com.google.common.collect
 
TreeRangeSet.SubRangeSet - Class in com.google.common.collect
 
TreeRangeSet.SubRangeSetRangesByLowerBound<C extends java.lang.Comparable<?>> - Class in com.google.common.collect
 
TreeRow(R) - Constructor for class com.google.common.collect.TreeBasedTable.TreeRow
 
TreeRow(R, C, C) - Constructor for class com.google.common.collect.TreeBasedTable.TreeRow
 
TreeSetSupplier(Comparator<? super V>) - Constructor for class com.google.common.collect.MultimapBuilder.TreeSetSupplier
 
treeSetValues() - Method in class com.google.common.collect.MultimapBuilder.MultimapBuilderWithKeys
Uses a naturally-ordered TreeSet to store value collections.
treeSetValues(Comparator<V0>) - Method in class com.google.common.collect.MultimapBuilder.MultimapBuilderWithKeys
Uses a TreeSet ordered by the specified comparator to store value collections.
TreeTraverser<T> - Class in com.google.common.collect
Views elements of a type T as nodes in a tree, and provides methods to traverse the trees induced by this traverser.
TreeTraverser() - Constructor for class com.google.common.collect.TreeTraverser
 
TreeTraverser.BreadthFirstIterator - Class in com.google.common.collect
 
TreeTraverser.PostOrderIterator - Class in com.google.common.collect
 
TreeTraverser.PostOrderNode<T> - Class in com.google.common.collect
 
TreeTraverser.PreOrderIterator - Class in com.google.common.collect
 
TrieParser - Class in com.google.thirdparty.publicsuffix
Parser for a map of reversed domain names stored as a serialized radix tree.
TrieParser() - Constructor for class com.google.thirdparty.publicsuffix.TrieParser
 
triggerShutdown() - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
Invoked to request the service to stop.
trimAndCollapseFrom(CharSequence, char) - Method in class com.google.common.base.CharMatcher
Collapses groups of matching characters exactly as CharMatcher.collapseFrom(java.lang.CharSequence, char) does, except that groups of matching characters at the start or end of the sequence are removed without replacement.
trimFrom(CharSequence) - Method in class com.google.common.base.CharMatcher
Returns a substring of the input character sequence that omits all characters this matcher matches from the beginning and from the end of the string.
trimLeadingFrom(CharSequence) - Method in class com.google.common.base.CharMatcher
Returns a substring of the input character sequence that omits all characters this matcher matches from the beginning of the string.
trimmer - Variable in class com.google.common.base.Splitter.SplittingIterator
 
trimmer - Variable in class com.google.common.base.Splitter
 
trimResults() - Method in class com.google.common.base.Splitter
Returns a splitter that behaves equivalently to this splitter, but automatically removes leading and trailing whitespace from each returned substring; equivalent to trimResults(CharMatcher.WHITESPACE).
trimResults(CharMatcher) - Method in class com.google.common.base.Splitter
Returns a splitter that behaves equivalently to this splitter, but removes all leading or trailing characters matching the given CharMatcher from each returned substring.
trimToSize() - Method in class com.google.common.collect.ArrayListMultimap
Reduces the memory used by this ArrayListMultimap, if feasible.
trimTrailingFrom(CharSequence) - Method in class com.google.common.base.CharMatcher
Returns a substring of the input character sequence that omits all characters this matcher matches from the end of the string.
truncate(CharSequence, int, String) - Static method in class com.google.common.base.Ascii
Truncates the given character sequence to the given maximum length.
trustedGet(TypeToken<T>) - Method in class com.google.common.reflect.ImmutableTypeToInstanceMap
 
trustedGet(TypeToken<T>) - Method in class com.google.common.reflect.MutableTypeToInstanceMap
 
trustedPut(TypeToken<T>, T) - Method in class com.google.common.reflect.MutableTypeToInstanceMap
 
tryAcquire(long, TimeUnit) - Method in class com.google.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.google.common.util.concurrent.RateLimiter
Acquires permits from this RateLimiter if it can be acquired immediately without delay.
tryAcquire() - Method in class com.google.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.google.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.
tryAcquireShared(int) - Method in class com.google.common.util.concurrent.AbstractFuture.Sync
 
tryAcquireUninterruptibly(Semaphore, long, TimeUnit) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes semaphore.tryAcquire(1, timeout, unit) uninterruptibly.
tryAcquireUninterruptibly(Semaphore, int, long, TimeUnit) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes semaphore.tryAcquire(permits, timeout, unit) uninterruptibly.
tryCrossOverAndBubbleUp(int, int, E) - Method in class com.google.common.collect.MinMaxPriorityQueue.Heap
Tries to move toTrickle from a min to a max level and bubble up there.
tryDrainReferenceQueues() - Method in class com.google.common.cache.LocalCache.Segment
Cleanup collected entries when the lock is available.
tryDrainReferenceQueues() - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Cleanup collected entries when the lock is available.
tryEnter() - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor if it is possible to do so immediately.
tryEnterIf(Monitor.Guard) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor if it is possible to do so immediately and the guard is satisfied.
tryExpireEntries(long) - Method in class com.google.common.cache.LocalCache.Segment
Cleanup expired entries when the lock is available.
tryExpireEntries() - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Cleanup expired entries when the lock is available.
tryFind(Iterable<T>, Predicate<? super T>) - Static method in class com.google.common.collect.Iterables
Returns an Optional containing the first element in iterable that satisfies the given predicate, if such an element exists.
tryFind(Iterator<T>, Predicate<? super T>) - Static method in class com.google.common.collect.Iterators
Returns an Optional containing the first element in iterator that satisfies the given predicate, if such an element exists.
tryLock() - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory.CycleDetectingReentrantLock
 
tryLock(long, TimeUnit) - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory.CycleDetectingReentrantLock
 
tryLock() - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory.CycleDetectingReentrantReadLock
 
tryLock(long, TimeUnit) - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory.CycleDetectingReentrantReadLock
 
tryLock() - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory.CycleDetectingReentrantWriteLock
 
tryLock(long, TimeUnit) - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory.CycleDetectingReentrantWriteLock
 
tryParse(String) - Static method in class com.google.common.primitives.Doubles
Parses the specified string as a double-precision floating point value.
tryParse(String) - Static method in class com.google.common.primitives.Floats
Parses the specified string as a single-precision floating point value.
tryParse(String) - Static method in class com.google.common.primitives.Ints
Parses the specified string as a signed decimal integer value.
tryParse(String, int) - Static method in class com.google.common.primitives.Ints
Parses the specified string as a signed integer value using the specified radix.
tryParse(String) - Static method in class com.google.common.primitives.Longs
Parses the specified string as a signed decimal long value.
tryReleaseShared(int) - Method in class com.google.common.util.concurrent.AbstractFuture.Sync
 
trySetName(String, Thread) - Static method in class com.google.common.util.concurrent.Callables
Tries to set name of the given Thread, returns true if successful.
tryStartTiming(Service) - Method in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState
Attempts to start the timer immediately prior to the service being started via Service.startAsync().
tryToComputeNext() - Method in class com.google.common.base.AbstractIterator
 
tryToComputeNext() - Method in class com.google.common.collect.AbstractIterator
 
tryWeakKeys(MapMaker) - Static method in class com.google.common.collect.Platform
Configures the given map maker to use weak keys, if possible; does nothing otherwise (i.e., in GWT).
TSV_UTF_8 - Static variable in class com.google.common.net.MediaType
TwoPlusArrayList(E, E, E[]) - Constructor for class com.google.common.collect.Lists.TwoPlusArrayList
 
type - Variable in class com.google.common.collect.EnumMultiset
 
type - Variable in class com.google.common.net.MediaType
 
type() - Method in class com.google.common.net.MediaType
Returns the top-level media type.
type - Variable in class com.google.common.reflect.Parameter
 
TYPE_NAME - Static variable in class com.google.common.reflect.Types
Class#toString without the "class " and "interface " prefixes
typeAsLowerBound() - Method in class com.google.common.collect.Cut.AboveAll
 
typeAsLowerBound() - Method in class com.google.common.collect.Cut.AboveValue
 
typeAsLowerBound() - Method in class com.google.common.collect.Cut.BelowAll
 
typeAsLowerBound() - Method in class com.google.common.collect.Cut.BelowValue
 
typeAsLowerBound() - Method in class com.google.common.collect.Cut
 
typeAsUpperBound() - Method in class com.google.common.collect.Cut.AboveAll
 
typeAsUpperBound() - Method in class com.google.common.collect.Cut.AboveValue
 
typeAsUpperBound() - Method in class com.google.common.collect.Cut.BelowAll
 
typeAsUpperBound() - Method in class com.google.common.collect.Cut.BelowValue
 
typeAsUpperBound() - Method in class com.google.common.collect.Cut
 
TypeCapture<T> - Class in com.google.common.reflect
Captures the actual type of T.
TypeCapture() - Constructor for class com.google.common.reflect.TypeCapture
 
TypeCollector() - Constructor for class com.google.common.reflect.TypeToken.TypeCollector
 
TypeFilter() - Constructor for enum com.google.common.reflect.TypeToken.TypeFilter
 
TypeMappingIntrospector() - Constructor for class com.google.common.reflect.TypeResolver.TypeMappingIntrospector
 
typeName(Type) - Method in enum com.google.common.reflect.Types.JavaVersion
 
TypeParameter<T> - Class in com.google.common.reflect
TypeParameter() - Constructor for class com.google.common.reflect.TypeParameter
 
typePreservingCollection(Collection<E>, Object) - Static method in class com.google.common.collect.Synchronized
 
typePreservingSet(Set<E>, Object) - Static method in class com.google.common.collect.Synchronized
 
TypeResolver - Class in com.google.common.reflect
An object of this class encapsulates type mappings from type variables.
TypeResolver() - Constructor for class com.google.common.reflect.TypeResolver
 
TypeResolver(TypeResolver.TypeTable) - Constructor for class com.google.common.reflect.TypeResolver
 
typeResolver - Variable in class com.google.common.reflect.TypeToken
Resolver for resolving types with TypeToken.runtimeType as context.
TypeResolver.TypeMappingIntrospector - Class in com.google.common.reflect
 
TypeResolver.TypeTable - Class in com.google.common.reflect
A TypeTable maintains mapping from TypeVariable to types.
TypeResolver.TypeVariableKey - Class in com.google.common.reflect
Wraps around TypeVariable<?> to ensure that any two type variables are equal as long as they are declared by the same GenericDeclaration and have the same name, even if their bounds differ.
TypeResolver.WildcardCapturer - Class in com.google.common.reflect
 
Types - Class in com.google.common.reflect
Utilities for working with Type.
Types() - Constructor for class com.google.common.reflect.Types
 
types - Variable in class com.google.common.reflect.TypeToken.TypeSet
 
Types.ClassOwnership - Enum in com.google.common.reflect
Decides what owner type to use for constructing ParameterizedType from a raw class.
Types.GenericArrayTypeImpl - Class in com.google.common.reflect
 
Types.JavaVersion - Enum in com.google.common.reflect
 
Types.NativeTypeVariableEquals<X> - Class in com.google.common.reflect
Per https://code.google.com/p/guava-libraries/issues/detail?id=1635, In JDK 1.7.0_51-b13, TypeVariableImpl.equals() is changed to no longer be equal to custom TypeVariable implementations.
Types.ParameterizedTypeImpl - Class in com.google.common.reflect
 
Types.TypeVariableImpl<D extends java.lang.reflect.GenericDeclaration> - Class in com.google.common.reflect
 
Types.WildcardTypeImpl - Class in com.google.common.reflect
 
TypeSet() - Constructor for class com.google.common.reflect.TypeToken.TypeSet
 
typeTable - Variable in class com.google.common.reflect.TypeResolver
 
TypeTable() - Constructor for class com.google.common.reflect.TypeResolver.TypeTable
 
TypeTable(ImmutableMap<TypeResolver.TypeVariableKey, Type>) - Constructor for class com.google.common.reflect.TypeResolver.TypeTable
 
TypeToInstanceMap<B> - Interface in com.google.common.reflect
A map, each entry of which maps a TypeToken to an instance of that type.
TypeToken<T> - Class in com.google.common.reflect
A Type with generics.
TypeToken() - Constructor for class com.google.common.reflect.TypeToken
Constructs a new type token of T.
TypeToken(Class<?>) - Constructor for class com.google.common.reflect.TypeToken
Constructs a new type token of T while resolving free type variables in the context of declaringClass.
TypeToken(Type) - Constructor for class com.google.common.reflect.TypeToken
 
TypeToken.ClassSet - Class in com.google.common.reflect
 
TypeToken.InterfaceSet - Class in com.google.common.reflect
 
TypeToken.SimpleTypeToken<T> - Class in com.google.common.reflect
 
TypeToken.TypeCollector<K> - Class in com.google.common.reflect
Collects parent types from a sub type.
TypeToken.TypeCollector.ForwardingTypeCollector<K> - Class in com.google.common.reflect
 
TypeToken.TypeFilter - Enum in com.google.common.reflect
 
TypeToken.TypeSet - Class in com.google.common.reflect
The set of interfaces and classes that T is or is a subtype of.
typeVariable - Variable in class com.google.common.reflect.TypeParameter
 
TypeVariableImpl(D, String, Type[]) - Constructor for class com.google.common.reflect.Types.TypeVariableImpl
 
TypeVariableKey(TypeVariable<?>) - Constructor for class com.google.common.reflect.TypeResolver.TypeVariableKey
 
TypeVisitor - Class in com.google.common.reflect
Based on what a Type is, dispatch it to the corresponding visit* method.
TypeVisitor() - Constructor for class com.google.common.reflect.TypeVisitor
 

U

uids - Variable in class com.google.common.collect.Ordering.ArbitraryOrdering
 
uncaughtException(Thread, Throwable) - Method in class com.google.common.util.concurrent.UncaughtExceptionHandlers.Exiter
 
uncaughtExceptionHandler - Variable in class com.google.common.util.concurrent.ThreadFactoryBuilder
 
UncaughtExceptionHandlers - Class in com.google.common.util.concurrent
Factories for Thread.UncaughtExceptionHandler instances.
UncaughtExceptionHandlers() - Constructor for class com.google.common.util.concurrent.UncaughtExceptionHandlers
 
UncaughtExceptionHandlers.Exiter - Class in com.google.common.util.concurrent
 
UncheckedExecutionException - Exception in com.google.common.util.concurrent
Unchecked variant of ExecutionException.
UncheckedExecutionException() - Constructor for exception com.google.common.util.concurrent.UncheckedExecutionException
Creates a new instance with null as its detail message.
UncheckedExecutionException(String) - Constructor for exception com.google.common.util.concurrent.UncheckedExecutionException
Creates a new instance with the given detail message.
UncheckedExecutionException(String, Throwable) - Constructor for exception com.google.common.util.concurrent.UncheckedExecutionException
Creates a new instance with the given detail message and cause.
UncheckedExecutionException(Throwable) - Constructor for exception com.google.common.util.concurrent.UncheckedExecutionException
Creates a new instance with the given cause.
UncheckedTimeoutException - Exception in com.google.common.util.concurrent
Unchecked version of TimeoutException.
UncheckedTimeoutException() - Constructor for exception com.google.common.util.concurrent.UncheckedTimeoutException
 
UncheckedTimeoutException(String) - Constructor for exception com.google.common.util.concurrent.UncheckedTimeoutException
 
UncheckedTimeoutException(Throwable) - Constructor for exception com.google.common.util.concurrent.UncheckedTimeoutException
 
UncheckedTimeoutException(String, Throwable) - Constructor for exception com.google.common.util.concurrent.UncheckedTimeoutException
 
UNDER - Static variable in class com.google.thirdparty.publicsuffix.PublicSuffixPatterns
If a hostname is not a key in the EXCLUDE map, and if removing its leftmost component results in a name which is a key in this map, it is a public suffix.
unencodedCharsFunnel() - Static method in class com.google.common.hash.Funnels
Returns a funnel that extracts the characters from a CharSequence, a character at a time, without performing any encoding.
UnencodedCharsFunnel() - Constructor for enum com.google.common.hash.Funnels.UnencodedCharsFunnel
 
unfiltered - Variable in class com.google.common.collect.Collections2.FilteredCollection
 
unfiltered - Variable in class com.google.common.collect.FilteredEntryMultimap
 
unfiltered() - Method in class com.google.common.collect.FilteredEntryMultimap
 
unfiltered() - Method in class com.google.common.collect.FilteredEntrySetMultimap
 
unfiltered() - Method in class com.google.common.collect.FilteredKeyListMultimap
 
unfiltered - Variable in class com.google.common.collect.FilteredKeyMultimap
 
unfiltered() - Method in class com.google.common.collect.FilteredKeyMultimap
 
unfiltered() - Method in class com.google.common.collect.FilteredKeySetMultimap
 
unfiltered() - Method in interface com.google.common.collect.FilteredMultimap
 
unfiltered() - Method in interface com.google.common.collect.FilteredSetMultimap
 
unfiltered - Variable in class com.google.common.collect.Maps.AbstractFilteredMap
 
unfiltered() - Method in class com.google.common.collect.Maps.FilteredEntryBiMap
 
unfiltered - Variable in class com.google.common.collect.Maps.FilteredEntryNavigableMap
 
unfiltered - Variable in class com.google.common.collect.Maps.FilteredMapValues
 
unfiltered - Variable in class com.google.common.collect.Multisets.FilteredMultiset
 
unfiltered() - Method in class com.google.common.collect.Sets.FilteredNavigableSet
 
UnicodeEscaper - Class in com.google.common.escape
An Escaper that converts literal text into a format safe for inclusion in a particular context (such as an XML document).
UnicodeEscaper() - Constructor for class com.google.common.escape.UnicodeEscaper
Constructor for use by subclasses.
Uninterruptibles - Class in com.google.common.util.concurrent
Utilities for treating interruptible operations as uninterruptible.
Uninterruptibles() - Constructor for class com.google.common.util.concurrent.Uninterruptibles
 
union(Multiset<? extends E>, Multiset<? extends E>) - Static method in class com.google.common.collect.Multisets
Returns an unmodifiable view of the union of two multisets.
union(Set<? extends E>, Set<? extends E>) - Static method in class com.google.common.collect.Sets
Returns an unmodifiable view of the union of two sets.
uniqueIndex(Function<? super E, K>) - Method in class com.google.common.collect.FluentIterable
Returns an immutable map for which the Map.values() are the elements of this FluentIterable in the given order, and each key is the product of invoking a supplied function on its corresponding value.
uniqueIndex(Iterable<V>, Function<? super V, K>) - Static method in class com.google.common.collect.Maps
Returns an immutable map for which the Map.values() are the given elements in the given order, and each key is the product of invoking a supplied function on its corresponding value.
uniqueIndex(Iterator<V>, Function<? super V, K>) - Static method in class com.google.common.collect.Maps
Returns an immutable map for which the Map.values() are the given elements in the given order, and each key is the product of invoking a supplied function on its corresponding value.
unit - Variable in class com.google.common.util.concurrent.AbstractScheduledService.CustomScheduler.Schedule
 
unlock() - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory.CycleDetectingReentrantLock
 
unlock() - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory.CycleDetectingReentrantReadLock
 
unlock() - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory.CycleDetectingReentrantWriteLock
 
UNMODIFIABLE_WRAPPER - Static variable in class com.google.common.collect.Tables
 
unmodifiableBiMap(BiMap<? extends K, ? extends V>) - Static method in class com.google.common.collect.Maps
Returns an unmodifiable view of the specified bimap.
UnmodifiableBiMap(BiMap<? extends K, ? extends V>, BiMap<V, K>) - Constructor for class com.google.common.collect.Maps.UnmodifiableBiMap
 
unmodifiableCollectionSubclass(Collection<V>) - Method in class com.google.common.collect.AbstractMapBasedMultimap
 
unmodifiableCollectionSubclass(Collection<V>) - Method in class com.google.common.collect.TreeMultimap
 
unmodifiableEmptyCollection() - Method in class com.google.common.collect.FilteredEntryMultimap
 
unmodifiableEmptyCollection() - Method in class com.google.common.collect.FilteredKeyMultimap
 
UnmodifiableEntries(Collection<Map.Entry<K, V>>) - Constructor for class com.google.common.collect.Maps.UnmodifiableEntries
 
unmodifiableEntries(Collection<Map.Entry<K, V>>) - Static method in class com.google.common.collect.Multimaps
Returns an unmodifiable view of the specified collection of entries.
unmodifiableEntry(Map.Entry<? extends K, ? extends V>) - Static method in class com.google.common.collect.Maps
Returns an unmodifiable view of the specified map entry.
UnmodifiableEntry(Map.Entry<K, V>) - Constructor for class com.google.common.reflect.MutableTypeToInstanceMap.UnmodifiableEntry
 
unmodifiableEntrySet(Set<Map.Entry<K, V>>) - Static method in class com.google.common.collect.Maps
Returns an unmodifiable view of the specified set of entries.
UnmodifiableEntrySet(Set<Map.Entry<K, V>>) - Constructor for class com.google.common.collect.Maps.UnmodifiableEntrySet
 
unmodifiableIterable(Iterable<T>) - Static method in class com.google.common.collect.Iterables
Returns an unmodifiable view of iterable.
unmodifiableIterable(ImmutableCollection<E>) - Static method in class com.google.common.collect.Iterables
Deprecated.
no need to use this
UnmodifiableIterable(Iterable<T>) - Constructor for class com.google.common.collect.Iterables.UnmodifiableIterable
 
unmodifiableIterator(Iterator<T>) - Static method in class com.google.common.collect.Iterators
Returns an unmodifiable view of iterator.
unmodifiableIterator(UnmodifiableIterator<T>) - Static method in class com.google.common.collect.Iterators
Deprecated.
no need to use this
UnmodifiableIterator<E> - Class in com.google.common.collect
An iterator that does not support UnmodifiableIterator.remove().
UnmodifiableIterator() - Constructor for class com.google.common.collect.UnmodifiableIterator
Constructor for use by subclasses.
UnmodifiableListIterator<E> - Class in com.google.common.collect
UnmodifiableListIterator() - Constructor for class com.google.common.collect.UnmodifiableListIterator
Constructor for use by subclasses.
unmodifiableListMultimap(ListMultimap<K, V>) - Static method in class com.google.common.collect.Multimaps
Returns an unmodifiable view of the specified ListMultimap.
unmodifiableListMultimap(ImmutableListMultimap<K, V>) - Static method in class com.google.common.collect.Multimaps
Deprecated.
no need to use this
UnmodifiableListMultimap(ListMultimap<K, V>) - Constructor for class com.google.common.collect.Multimaps.UnmodifiableListMultimap
 
unmodifiableMap - Variable in class com.google.common.collect.Maps.UnmodifiableBiMap
 
unmodifiableMap(Map<K, V>) - Static method in class com.google.common.collect.Maps
 
unmodifiableMultimap(Multimap<K, V>) - Static method in class com.google.common.collect.Multimaps
Returns an unmodifiable view of the specified multimap.
unmodifiableMultimap(ImmutableMultimap<K, V>) - Static method in class com.google.common.collect.Multimaps
Deprecated.
no need to use this
UnmodifiableMultimap(Multimap<K, V>) - Constructor for class com.google.common.collect.Multimaps.UnmodifiableMultimap
 
unmodifiableMultiset(Multiset<? extends E>) - Static method in class com.google.common.collect.Multisets
Returns an unmodifiable view of the specified multiset.
unmodifiableMultiset(ImmutableMultiset<E>) - Static method in class com.google.common.collect.Multisets
Deprecated.
no need to use this
UnmodifiableMultiset(Multiset<? extends E>) - Constructor for class com.google.common.collect.Multisets.UnmodifiableMultiset
 
unmodifiableNavigableMap(NavigableMap<K, V>) - Static method in class com.google.common.collect.Maps
Returns an unmodifiable view of the specified navigable map.
UnmodifiableNavigableMap(NavigableMap<K, V>) - Constructor for class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
UnmodifiableNavigableMap(NavigableMap<K, V>, Maps.UnmodifiableNavigableMap<K, V>) - Constructor for class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
unmodifiableNavigableSet(NavigableSet<E>) - Static method in class com.google.common.collect.Sets
Returns an unmodifiable view of the specified navigable set.
UnmodifiableNavigableSet(NavigableSet<E>) - Constructor for class com.google.common.collect.Sets.UnmodifiableNavigableSet
 
unmodifiableOrNull(Map.Entry<K, V>) - Static method in class com.google.common.collect.Maps
 
UnmodifiableRowSortedMap(RowSortedTable<R, ? extends C, ? extends V>) - Constructor for class com.google.common.collect.Tables.UnmodifiableRowSortedMap
 
unmodifiableRowSortedTable(RowSortedTable<R, ? extends C, ? extends V>) - Static method in class com.google.common.collect.Tables
Returns an unmodifiable view of the specified row-sorted table.
unmodifiableSetMultimap(SetMultimap<K, V>) - Static method in class com.google.common.collect.Multimaps
Returns an unmodifiable view of the specified SetMultimap.
unmodifiableSetMultimap(ImmutableSetMultimap<K, V>) - Static method in class com.google.common.collect.Multimaps
Deprecated.
no need to use this
UnmodifiableSetMultimap(SetMultimap<K, V>) - Constructor for class com.google.common.collect.Multimaps.UnmodifiableSetMultimap
 
unmodifiableSortedMultiset(SortedMultiset<E>) - Static method in class com.google.common.collect.Multisets
Returns an unmodifiable view of the specified sorted multiset.
UnmodifiableSortedMultiset<E> - Class in com.google.common.collect
Implementation of Multisets.unmodifiableSortedMultiset(SortedMultiset), split out into its own file so it can be GWT emulated (to deal with the differing elementSet() types in GWT and non-GWT).
UnmodifiableSortedMultiset(SortedMultiset<E>) - Constructor for class com.google.common.collect.UnmodifiableSortedMultiset
 
unmodifiableSortedSetMultimap(SortedSetMultimap<K, V>) - Static method in class com.google.common.collect.Multimaps
Returns an unmodifiable view of the specified SortedSetMultimap.
UnmodifiableSortedSetMultimap(SortedSetMultimap<K, V>) - Constructor for class com.google.common.collect.Multimaps.UnmodifiableSortedSetMultimap
 
unmodifiableTable(Table<? extends R, ? extends C, ? extends V>) - Static method in class com.google.common.collect.Tables
Returns an unmodifiable view of the specified table.
UnmodifiableTable(Table<? extends R, ? extends C, ? extends V>) - Constructor for class com.google.common.collect.Tables.UnmodifiableTable
 
unmodifiableValueCollection(Collection<V>) - Static method in class com.google.common.collect.Multimaps
Returns an unmodifiable view of the specified collection, preserving the interface for instances of SortedSet, Set, List and Collection, in that order of preference.
unmodifiableWrapper() - Static method in class com.google.common.collect.Tables
 
unregister(Object) - Method in class com.google.common.eventbus.EventBus
Unregisters all subscriber methods on a registered object.
UNSAFE - Static variable in class com.google.common.cache.Striped64.Cell
 
UNSAFE - Static variable in class com.google.common.cache.Striped64
 
UNSAFE_COMPARATOR_NAME - Static variable in class com.google.common.primitives.UnsignedBytes.LexicographicalComparatorHolder
 
unsafeBinarySearch(Object) - Method in class com.google.common.collect.RegularImmutableSortedSet
 
unsafeComparator() - Method in class com.google.common.collect.RegularImmutableSortedSet
 
UnsafeComparator() - Constructor for enum com.google.common.primitives.UnsignedBytes.LexicographicalComparatorHolder.UnsafeComparator
 
unsafeCompare(Object, Object) - Method in class com.google.common.collect.ForwardingSortedMap
 
unsafeCompare(Object, Object) - Method in class com.google.common.collect.ForwardingSortedSet
 
unsafeCompare(Object, Object) - Method in class com.google.common.collect.ImmutableSortedSet
 
unsafeCompare(Comparator<?>, Object, Object) - Static method in class com.google.common.collect.ImmutableSortedSet
 
unsafeReplacement - Variable in class com.google.common.escape.Escapers.Builder
 
UNSET - Static variable in class com.google.common.cache.LocalCache
Placeholder.
unset() - Static method in class com.google.common.cache.LocalCache
Singleton placeholder that indicates a value is being loaded.
UNSET - Static variable in class com.google.common.collect.MapMakerInternalMap
Placeholder.
unset() - Static method in class com.google.common.collect.MapMakerInternalMap
Singleton placeholder that indicates a value is being computed.
UNSET_EXPECTED_SIZE - Static variable in class com.google.common.collect.MinMaxPriorityQueue.Builder
 
UNSET_INT - Static variable in class com.google.common.cache.CacheBuilder
 
UNSET_INT - Static variable in class com.google.common.collect.MapMaker
 
UNSIGNED_MASK - Static variable in class com.google.common.primitives.UnsignedBytes
 
UNSIGNED_MASK - Static variable in class com.google.common.primitives.UnsignedLong
 
UnsignedBytes - Class in com.google.common.primitives
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).
UnsignedBytes() - Constructor for class com.google.common.primitives.UnsignedBytes
 
UnsignedBytes.LexicographicalComparatorHolder - Class in com.google.common.primitives
Provides a lexicographical comparator implementation; either a Java implementation or a faster implementation based on Unsafe.
UnsignedBytes.LexicographicalComparatorHolder.PureJavaComparator - Enum in com.google.common.primitives
 
UnsignedBytes.LexicographicalComparatorHolder.UnsafeComparator - Enum in com.google.common.primitives
 
UnsignedInteger - Class in com.google.common.primitives
A wrapper class for unsigned int values, supporting arithmetic operations.
UnsignedInteger(int) - Constructor for class com.google.common.primitives.UnsignedInteger
 
UnsignedInts - Class in com.google.common.primitives
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).
UnsignedInts() - Constructor for class com.google.common.primitives.UnsignedInts
 
UnsignedInts.LexicographicalComparator - Enum in com.google.common.primitives
 
UnsignedLong - Class in com.google.common.primitives
A wrapper class for unsigned long values, supporting arithmetic operations.
UnsignedLong(long) - Constructor for class com.google.common.primitives.UnsignedLong
 
UnsignedLongs - Class in com.google.common.primitives
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).
UnsignedLongs() - Constructor for class com.google.common.primitives.UnsignedLongs
 
UnsignedLongs.LexicographicalComparator - Enum in com.google.common.primitives
 
UnsupportedLoadingOperationException() - Constructor for exception com.google.common.cache.CacheLoader.UnsupportedLoadingOperationException
 
unwrap(Class<T>) - Static method in class com.google.common.primitives.Primitives
Returns the corresponding primitive type of type if it is a wrapper type; otherwise returns type itself.
unwrap() - Method in class com.google.common.reflect.TypeToken
Returns the corresponding primitive type if this is a wrapper type; otherwise returns this itself.
update(byte) - Method in class com.google.common.hash.AbstractByteHasher
Updates this hasher with the given byte.
update(byte[]) - Method in class com.google.common.hash.AbstractByteHasher
Updates this hasher with the given bytes.
update(byte[], int, int) - Method in class com.google.common.hash.AbstractByteHasher
Updates this hasher with len bytes starting at off in the given buffer.
update(int) - Method in class com.google.common.hash.AbstractByteHasher
Updates the sink with the given number of bytes from the buffer.
update(byte) - Method in class com.google.common.hash.ChecksumHashFunction.ChecksumHasher
 
update(byte[], int, int) - Method in class com.google.common.hash.ChecksumHashFunction.ChecksumHasher
 
update(byte) - Method in class com.google.common.hash.Crc32cHashFunction.Crc32cHasher
 
update(byte) - Method in class com.google.common.hash.MessageDigestHashFunction.MessageDigestHasher
 
update(byte[]) - Method in class com.google.common.hash.MessageDigestHashFunction.MessageDigestHasher
 
update(byte[], int, int) - Method in class com.google.common.hash.MessageDigestHashFunction.MessageDigestHasher
 
update(int) - Method in class com.google.common.io.FileBackedOutputStream
Checks if writing len bytes would go over threshold, and switches to file buffering if so.
updateInverseMap(K, boolean, V, V) - Method in class com.google.common.collect.AbstractBiMap
 
updater - Static variable in class com.google.common.util.concurrent.AtomicDouble
 
UPGRADE - Static variable in class com.google.common.net.HttpHeaders
The HTTP Upgrade header field name.
UPPER_BOUND_FN - Static variable in class com.google.common.collect.Range
 
UPPER_HEX_DIGITS - Static variable in class com.google.common.net.PercentEscaper
 
upperBound - Variable in class com.google.common.collect.Range
 
upperBound - Variable in class com.google.common.collect.TreeBasedTable.TreeRow
 
upperBoundFn() - Static method in class com.google.common.collect.Range
 
upperBounds - Variable in class com.google.common.reflect.Types.WildcardTypeImpl
 
upperBoundType - Variable in class com.google.common.collect.GeneralRange
 
upperBoundType() - Method in class com.google.common.collect.Range
Returns the type of this range's upper bound: BoundType.CLOSED if the range includes its upper endpoint, BoundType.OPEN if it does not.
upperBoundWindow - Variable in class com.google.common.collect.TreeRangeSet.RangesByUpperBound
upperBoundWindow represents the headMap/subMap/tailMap view of the entire "ranges by upper bound" map; it's a constraint on the *keys*, and does not affect the values.
upperCase() - Method in class com.google.common.io.BaseEncoding.Alphabet
 
upperCase() - Method in class com.google.common.io.BaseEncoding.SeparatedBaseEncoding
 
upperCase - Variable in class com.google.common.io.BaseEncoding.StandardBaseEncoding
 
upperCase() - Method in class com.google.common.io.BaseEncoding.StandardBaseEncoding
 
upperCase() - Method in class com.google.common.io.BaseEncoding
Returns an encoding that behaves equivalently to this encoding, but encodes and decodes with uppercase letters.
upperEndpoint - Variable in class com.google.common.collect.GeneralRange
 
upperEndpoint() - Method in class com.google.common.collect.Range
Returns the upper endpoint of this range.
upTo(Comparator<? super T>, T, BoundType) - Static method in class com.google.common.collect.GeneralRange
Returns everything below the endpoint relative to the specified comparator, with the specified endpoint behavior.
upTo(C, BoundType) - Static method in class com.google.common.collect.Range
Returns a range with no lower bound up to the given endpoint, which may be either inclusive (closed) or exclusive (open).
url - Variable in class com.google.common.io.Resources.UrlByteSource
 
url() - Method in class com.google.common.reflect.ClassPath.ResourceInfo
Returns the url identifying the resource.
URL_FORM_PARAMETER_ESCAPER - Static variable in class com.google.common.net.UrlEscapers
 
URL_FORM_PARAMETER_OTHER_SAFE_CHARS - Static variable in class com.google.common.net.UrlEscapers
 
URL_FRAGMENT_ESCAPER - Static variable in class com.google.common.net.UrlEscapers
 
URL_PATH_OTHER_SAFE_CHARS_LACKING_PLUS - Static variable in class com.google.common.net.UrlEscapers
 
URL_PATH_SEGMENT_ESCAPER - Static variable in class com.google.common.net.UrlEscapers
 
UrlByteSource(URL) - Constructor for class com.google.common.io.Resources.UrlByteSource
 
UrlEscapers - Class in com.google.common.net
Escaper instances suitable for strings to be included in particular sections of URLs.
UrlEscapers() - Constructor for class com.google.common.net.UrlEscapers
 
urlFormParameterEscaper() - Static method in class com.google.common.net.UrlEscapers
Returns an Escaper instance that escapes strings so they can be safely included in URL form parameter names and values.
urlFragmentEscaper() - Static method in class com.google.common.net.UrlEscapers
Returns an Escaper instance that escapes strings so they can be safely included in a URL fragment.
urlPathSegmentEscaper() - Static method in class com.google.common.net.UrlEscapers
Returns an Escaper instance that escapes strings so they can be safely included in URL path segments.
US - Static variable in class com.google.common.base.Ascii
Unit Separator: These four information separators may be used within data in optional fashion, except that their hierarchical relationship shall be: FS is the most inclusive, then GS, then RS, and US is least inclusive.
US_ASCII - Static variable in class com.google.common.base.Charsets
US-ASCII: seven-bit ASCII, the Basic Latin block of the Unicode character set (ISO646-US).
useCustomMap - Variable in class com.google.common.collect.MapMaker
 
useDaemonThreadFactory(ThreadPoolExecutor) - Static method in class com.google.common.util.concurrent.MoreExecutors
 
usedInGenericType(Type) - Method in enum com.google.common.reflect.Types.JavaVersion
 
usedInGenericType(Type[]) - Method in enum com.google.common.reflect.Types.JavaVersion
 
useForNull(String) - Method in class com.google.common.base.Joiner.MapJoiner
Returns a map joiner with the same behavior as this one, except automatically substituting nullText for any provided null keys or values.
useForNull(String) - Method in class com.google.common.base.Joiner
Returns a joiner with the same behavior as this one, except automatically substituting nullText for any provided null elements.
USER_AGENT - Static variable in class com.google.common.net.HttpHeaders
The HTTP User-Agent header field name.
usesAccessEntries() - Method in class com.google.common.cache.LocalCache
 
usesAccessQueue() - Method in class com.google.common.cache.LocalCache
 
usesKeyReferences() - Method in class com.google.common.cache.LocalCache
 
usesKeyReferences() - Method in class com.google.common.collect.MapMakerInternalMap
 
usesValueReferences() - Method in class com.google.common.cache.LocalCache
 
usesValueReferences() - Method in class com.google.common.collect.MapMakerInternalMap
 
usesWriteEntries() - Method in class com.google.common.cache.LocalCache
 
usesWriteQueue() - Method in class com.google.common.cache.LocalCache
 
usingToString() - Static method in class com.google.common.collect.Ordering
Returns an ordering that compares objects by the natural ordering of their string representations as returned by toString().
UsingToStringOrdering - Class in com.google.common.collect
An ordering that uses the natural order of the string representation of the values.
UsingToStringOrdering() - Constructor for class com.google.common.collect.UsingToStringOrdering
 
Utf8 - Class in com.google.common.base
Low-level, high-performance utility methods related to the UTF-8 character encoding.
Utf8() - Constructor for class com.google.common.base.Utf8
 
UTF_16 - Static variable in class com.google.common.base.Charsets
UTF-16: sixteen-bit UCS Transformation Format, byte order identified by an optional byte-order mark.
UTF_16BE - Static variable in class com.google.common.base.Charsets
UTF-16BE: sixteen-bit UCS Transformation Format, big-endian byte order.
UTF_16LE - Static variable in class com.google.common.base.Charsets
UTF-16LE: sixteen-bit UCS Transformation Format, little-endian byte order.
UTF_8 - Static variable in class com.google.common.base.Charsets
UTF-8: eight-bit UCS Transformation Format.
UTF_8_CONSTANT_PARAMETERS - Static variable in class com.google.common.net.MediaType
 

V

v0 - Variable in class com.google.common.hash.SipHashFunction.SipHasher
 
v1 - Variable in class com.google.common.hash.SipHashFunction.SipHasher
 
v2 - Variable in class com.google.common.hash.SipHashFunction.SipHasher
 
v3 - Variable in class com.google.common.hash.SipHashFunction.SipHasher
 
validateEntries(int, Map.Entry<K, V>[], Comparator<? super K>) - Static method in class com.google.common.collect.ImmutableSortedMap
 
validateIterator() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection.WrappedIterator
If the delegate changed since the iterator was created, the iterator is no longer valid.
validatePart(String, boolean) - Static method in class com.google.common.net.InternetDomainName
validateSyntax(List<String>) - Static method in class com.google.common.net.InternetDomainName
Validation method used by to ensure that the domain name is syntactically valid according to RFC 1035.
validPadding - Variable in class com.google.common.io.BaseEncoding.Alphabet
 
validSurrogatePairAt(CharSequence, int) - Static method in class com.google.common.base.Strings
True when a valid surrogate pair starts at the given index in the given string.
value - Variable in class com.google.common.base.Functions.ConstantFunction
 
value - Variable in class com.google.common.base.MoreObjects.ToStringHelper.ValueHolder
 
value - Variable in class com.google.common.base.Objects.ToStringHelper.ValueHolder
Deprecated.
 
value() - Method in enum com.google.common.base.StandardSystemProperty
Returns the current value for this system property by delegating to System.getProperty(String).
value - Variable in class com.google.common.base.Suppliers.ExpiringMemoizingSupplier
 
value - Variable in class com.google.common.base.Suppliers.MemoizingSupplier
 
value - Variable in class com.google.common.cache.LocalCache.WriteThroughEntry
 
value - Variable in class com.google.common.cache.RemovalNotification
 
value - Variable in class com.google.common.cache.Striped64.Cell
 
value - Variable in class com.google.common.collect.ComputingConcurrentHashMap.ComputedReference
 
value - Variable in class com.google.common.collect.Count
 
value - Variable in class com.google.common.collect.ImmutableEntry
 
value - Variable in class com.google.common.collect.LinkedListMultimap.Node
 
value - Variable in class com.google.common.collect.MapMakerInternalMap.WriteThroughEntry
 
value - Variable in exception com.google.common.collect.Ordering.IncomparableValueException
 
value - Variable in class com.google.common.collect.Tables.ImmutableCell
 
value - Variable in class com.google.common.collect.TreeMultiset.Reference
 
value - Variable in class com.google.common.collect.TreeRangeMap.RangeMapEntry
 
value - Variable in class com.google.common.primitives.UnsignedInteger
 
value - Variable in class com.google.common.primitives.UnsignedLong
 
value - Variable in class com.google.common.util.concurrent.AbstractFuture.Sync
 
value - Variable in class com.google.common.util.concurrent.AtomicDouble
 
value - Variable in class com.google.common.util.concurrent.Futures.ImmediateSuccessfulCheckedFuture
 
value - Variable in class com.google.common.util.concurrent.Futures.ImmediateSuccessfulFuture
 
VALUE_CAN_BE_CAST_TO_KEY - Static variable in class com.google.common.collect.MutableClassToInstanceMap
 
VALUE_PARSERS - Static variable in class com.google.common.cache.CacheBuilderSpec
Map of names to ValueParser.
VALUE_SET_LOAD_FACTOR - Static variable in class com.google.common.collect.LinkedHashMultimap
 
valueComparator() - Method in class com.google.common.collect.ForwardingSortedSetMultimap
 
valueComparator - Variable in class com.google.common.collect.ImmutableMultimap.Builder
 
valueComparator() - Method in class com.google.common.collect.ImmutableSetMultimap
 
valueComparator() - Method in class com.google.common.collect.MapConstraints.ConstrainedSortedSetMultimap
 
valueComparator - Variable in class com.google.common.collect.Multimaps.CustomSortedSetMultimap
 
valueComparator() - Method in class com.google.common.collect.Multimaps.CustomSortedSetMultimap
 
valueComparator() - Method in class com.google.common.collect.Multimaps.UnmodifiableSortedSetMultimap
 
valueComparator() - Method in interface com.google.common.collect.SortedSetMultimap
Returns the comparator that orders the multimap values, with null indicating that natural ordering is used.
valueComparator() - Method in class com.google.common.collect.Synchronized.SynchronizedSortedSetMultimap
 
valueComparator - Variable in class com.google.common.collect.TreeMultimap
 
valueComparator() - Method in class com.google.common.collect.TreeMultimap
 
ValueDifferenceImpl(V, V) - Constructor for class com.google.common.collect.Maps.ValueDifferenceImpl
 
ValueEntry(K, V, int, LinkedHashMultimap.ValueEntry<K, V>) - Constructor for class com.google.common.collect.LinkedHashMultimap.ValueEntry
 
valueEquivalence - Variable in class com.google.common.cache.CacheBuilder
 
valueEquivalence(Equivalence<Object>) - Method in class com.google.common.cache.CacheBuilder
Sets a custom Equivalence strategy for comparing values.
valueEquivalence - Variable in class com.google.common.cache.LocalCache.ManualSerializationProxy
 
valueEquivalence - Variable in class com.google.common.cache.LocalCache
Strategy for comparing values.
valueEquivalence - Variable in class com.google.common.collect.MapMakerInternalMap.AbstractSerializationProxy
 
valueEquivalence - Variable in class com.google.common.collect.MapMakerInternalMap
Strategy for comparing values.
ValueForKeyIterator(Object) - Constructor for class com.google.common.collect.LinkedListMultimap.ValueForKeyIterator
Constructs a new iterator over all values for the specified key.
ValueForKeyIterator(Object, int) - Constructor for class com.google.common.collect.LinkedListMultimap.ValueForKeyIterator
Constructs a new iterator over all values for the specified key starting at the specified index.
valueFunction() - Static method in class com.google.common.collect.Maps
 
valueHash - Variable in class com.google.common.collect.HashBiMap.BiEntry
 
ValueHolder() - Constructor for class com.google.common.base.MoreObjects.ToStringHelper.ValueHolder
 
ValueHolder() - Constructor for class com.google.common.base.Objects.ToStringHelper.ValueHolder
Deprecated.
 
ValueIterator() - Constructor for class com.google.common.cache.LocalCache.ValueIterator
 
valueIterator - Variable in class com.google.common.collect.AbstractMapBasedMultimap.Itr
 
valueIterator() - Method in class com.google.common.collect.AbstractMapBasedMultimap
 
valueIterator() - Method in class com.google.common.collect.AbstractMultimap
 
valueIterator - Variable in class com.google.common.collect.ImmutableMultimap.Itr
 
valueIterator() - Method in class com.google.common.collect.ImmutableMultimap
 
valueIterator() - Method in class com.google.common.collect.LinkedHashMultimap
 
ValueIterator() - Constructor for class com.google.common.collect.MapMakerInternalMap.ValueIterator
 
valueIterator(Iterator<Map.Entry<K, V>>) - Static method in class com.google.common.collect.Maps
 
valueIterator(UnmodifiableIterator<Map.Entry<K, V>>) - Static method in class com.google.common.collect.Maps
 
valueList - Variable in class com.google.common.collect.RegularImmutableSortedMap
 
valueOf(String) - Static method in enum com.google.common.base.AbstractIterator.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.base.CaseFormat
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.base.Functions.IdentityFunction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.base.Functions.ToStringFunction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.base.Predicates.ObjectPredicate
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.base.StandardSystemProperty
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.base.Suppliers.SupplierFunctionImpl
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.cache.CacheBuilder.NullListener
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.cache.CacheBuilder.OneWeigher
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.cache.LocalCache.EntryFactory
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.cache.LocalCache.NullEntry
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.cache.LocalCache.Strength
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.cache.RemovalCause
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.collect.AbstractIterator.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.collect.BoundType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.collect.GenericMapMaker.NullListener
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.collect.Interners.WeakInterner.Dummy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.collect.MapConstraints.NotNullMapConstraint
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.collect.MapMaker.RemovalCause
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.collect.MapMakerInternalMap.EntryFactory
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.collect.MapMakerInternalMap.NullEntry
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.collect.MapMakerInternalMap.Strength
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.collect.Maps.EntryFunction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.collect.MultimapBuilder.LinkedListSupplier
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.collect.SortedLists.KeyAbsentBehavior
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.collect.SortedLists.KeyPresentBehavior
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.collect.TreeMultiset.Aggregate
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.hash.BloomFilterStrategies
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.hash.Funnels.ByteArrayFunnel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.hash.Funnels.IntegerFunnel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.hash.Funnels.LongFunnel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.hash.Funnels.UnencodedCharsFunnel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.hash.Hashing.ChecksumType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.io.Files.FilePredicate
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.io.FileWriteMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.primitives.Booleans.LexicographicalComparator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.primitives.Chars.LexicographicalComparator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.primitives.Doubles.LexicographicalComparator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.primitives.Floats.LexicographicalComparator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.primitives.Ints.LexicographicalComparator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.primitives.Longs.LexicographicalComparator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.primitives.Shorts.LexicographicalComparator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.primitives.SignedBytes.LexicographicalComparator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.primitives.UnsignedBytes.LexicographicalComparatorHolder.PureJavaComparator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.primitives.UnsignedBytes.LexicographicalComparatorHolder.UnsafeComparator
Returns the enum constant of this type with the specified name.
valueOf(long) - Static method in class com.google.common.primitives.UnsignedInteger
Returns an UnsignedInteger that is equal to value, if possible.
valueOf(BigInteger) - Static method in class com.google.common.primitives.UnsignedInteger
Returns a UnsignedInteger representing the same value as the specified BigInteger.
valueOf(String) - Static method in class com.google.common.primitives.UnsignedInteger
Returns an UnsignedInteger holding the value of the specified String, parsed as an unsigned int value.
valueOf(String, int) - Static method in class com.google.common.primitives.UnsignedInteger
Returns an UnsignedInteger holding the value of the specified String, parsed as an unsigned int value in the specified radix.
valueOf(String) - Static method in enum com.google.common.primitives.UnsignedInts.LexicographicalComparator
Returns the enum constant of this type with the specified name.
valueOf(long) - Static method in class com.google.common.primitives.UnsignedLong
Returns an UnsignedLong representing the same value as the specified long.
valueOf(BigInteger) - Static method in class com.google.common.primitives.UnsignedLong
Returns a UnsignedLong representing the same value as the specified BigInteger.
valueOf(String) - Static method in class com.google.common.primitives.UnsignedLong
Returns an UnsignedLong holding the value of the specified String, parsed as an unsigned long value.
valueOf(String, int) - Static method in class com.google.common.primitives.UnsignedLong
Returns an UnsignedLong holding the value of the specified String, parsed as an unsigned long value in the specified radix.
valueOf(String) - Static method in enum com.google.common.primitives.UnsignedLongs.LexicographicalComparator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.reflect.Types.ClassOwnership
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.reflect.Types.JavaVersion
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.reflect.TypeToken.TypeFilter
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.util.concurrent.CycleDetectingLockFactory.Policies
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.util.concurrent.MoreExecutors.DirectExecutor
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.util.concurrent.Service.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.thirdparty.publicsuffix.PublicSuffixType
Returns the enum constant of this type with the specified name.
valueOffset - Static variable in class com.google.common.cache.Striped64.Cell
 
valueOrNull(Map.Entry<?, V>) - Static method in class com.google.common.collect.Maps
 
ValuePredicate(K) - Constructor for class com.google.common.collect.FilteredEntryMultimap.ValuePredicate
 
valuePredicateOnEntries(Predicate<? super V>) - Static method in class com.google.common.collect.Maps
 
valueReference - Variable in class com.google.common.cache.LocalCache.StrongEntry
 
valueReference - Variable in class com.google.common.cache.LocalCache.WeakEntry
 
valueReference - Variable in class com.google.common.collect.MapMakerInternalMap.SoftEntry
 
valueReference - Variable in class com.google.common.collect.MapMakerInternalMap.StrongEntry
 
valueReference - Variable in class com.google.common.collect.MapMakerInternalMap.WeakEntry
 
valueReferenceQueue - Variable in class com.google.common.cache.LocalCache.Segment
The value reference queue contains value references whose values have been garbage collected, and which need to be cleaned up internally.
valueReferenceQueue - Variable in class com.google.common.collect.MapMakerInternalMap.Segment
The value reference queue contains value references whose values have been garbage collected, and which need to be cleaned up internally.
values() - Static method in enum com.google.common.base.AbstractIterator.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.base.CaseFormat
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.base.Functions.IdentityFunction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.base.Functions.ToStringFunction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.base.Predicates.ObjectPredicate
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.base.StandardSystemProperty
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.base.Suppliers.SupplierFunctionImpl
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.cache.CacheBuilder.NullListener
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.cache.CacheBuilder.OneWeigher
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.cache.LocalCache.EntryFactory
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.cache.LocalCache.NullEntry
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.cache.LocalCache.Strength
Returns an array containing the constants of this enum type, in the order they are declared.
values - Variable in class com.google.common.cache.LocalCache
 
values() - Method in class com.google.common.cache.LocalCache
 
Values(ConcurrentMap<?, ?>) - Constructor for class com.google.common.cache.LocalCache.Values
 
values() - Static method in enum com.google.common.cache.RemovalCause
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class com.google.common.collect.AbstractBiMap
 
values() - Static method in enum com.google.common.collect.AbstractIterator.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class com.google.common.collect.AbstractMapBasedMultimap
Returns a view collection containing the value from each key-value pair contained in this multimap, without collapsing duplicates (so values().size() == size()).
values - Variable in class com.google.common.collect.AbstractMultimap
 
values() - Method in class com.google.common.collect.AbstractMultimap
 
Values() - Constructor for class com.google.common.collect.AbstractMultimap.Values
 
values() - Method in class com.google.common.collect.AbstractSortedSetMultimap
Returns a view collection containing the value from each key-value pair contained in this multimap, without collapsing duplicates (so values().size() == size()).
values - Variable in class com.google.common.collect.AbstractTable
 
values() - Method in class com.google.common.collect.AbstractTable
 
Values() - Constructor for class com.google.common.collect.AbstractTable.Values
 
values() - Method in class com.google.common.collect.ArrayTable
Returns an unmodifiable collection of all values, which may contain duplicates.
values() - Method in interface com.google.common.collect.BiMap
values() - Static method in enum com.google.common.collect.BoundType
Returns an array containing the constants of this enum type, in the order they are declared.
values - Variable in class com.google.common.collect.DenseImmutableTable
 
values() - Method in class com.google.common.collect.EmptyImmutableSortedMap
 
values() - Method in class com.google.common.collect.ForwardingMap
 
values() - Method in class com.google.common.collect.ForwardingMultimap
 
values() - Method in class com.google.common.collect.ForwardingTable
 
values() - Static method in enum com.google.common.collect.GenericMapMaker.NullListener
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class com.google.common.collect.HashBiMap.Inverse
 
values() - Method in class com.google.common.collect.HashBiMap
 
values() - Method in class com.google.common.collect.ImmutableBiMap
Returns an immutable set of the values in this map.
values - Variable in class com.google.common.collect.ImmutableMap.SerializedForm
 
values - Variable in class com.google.common.collect.ImmutableMap
 
values() - Method in class com.google.common.collect.ImmutableMap
Returns an immutable collection of the values in this map.
values() - Method in class com.google.common.collect.ImmutableMultimap
Returns an immutable collection of the values in this multimap.
Values(ImmutableMultimap<K, V>) - Constructor for class com.google.common.collect.ImmutableMultimap.Values
 
values - Variable in class com.google.common.collect.ImmutableRangeMap
 
values() - Method in class com.google.common.collect.ImmutableSortedMap
Returns an immutable collection of the values in this map, sorted by the ordering of the corresponding keys.
values() - Method in class com.google.common.collect.ImmutableTable
 
values() - Static method in enum com.google.common.collect.Interners.WeakInterner.Dummy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class com.google.common.collect.LinkedHashMultimap
Returns a collection of all values in the multimap.
values() - Method in class com.google.common.collect.LinkedListMultimap
Returns a view collection containing the value from each key-value pair contained in this multimap, without collapsing duplicates (so values().size() == size()).
values() - Method in class com.google.common.collect.MapConstraints.ConstrainedBiMap
 
values() - Static method in enum com.google.common.collect.MapConstraints.NotNullMapConstraint
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.collect.MapMaker.RemovalCause
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.collect.MapMakerInternalMap.EntryFactory
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.collect.MapMakerInternalMap.NullEntry
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.collect.MapMakerInternalMap.Strength
Returns an array containing the constants of this enum type, in the order they are declared.
values - Variable in class com.google.common.collect.MapMakerInternalMap
 
values() - Method in class com.google.common.collect.MapMakerInternalMap
 
Values() - Constructor for class com.google.common.collect.MapMakerInternalMap.Values
 
values() - Method in class com.google.common.collect.Maps.DescendingMap
 
values() - Static method in enum com.google.common.collect.Maps.EntryFunction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class com.google.common.collect.Maps.FilteredEntryBiMap
 
values() - Method in class com.google.common.collect.Maps.FilteredEntryNavigableMap
 
values - Variable in class com.google.common.collect.Maps.ImprovedAbstractMap
 
values() - Method in class com.google.common.collect.Maps.ImprovedAbstractMap
 
values - Variable in class com.google.common.collect.Maps.UnmodifiableBiMap
 
values() - Method in class com.google.common.collect.Maps.UnmodifiableBiMap
 
Values(Map<K, V>) - Constructor for class com.google.common.collect.Maps.Values
 
values() - Method in interface com.google.common.collect.Multimap
Returns a view collection containing the value from each key-value pair contained in this multimap, without collapsing duplicates (so values().size() == size()).
values() - Static method in enum com.google.common.collect.MultimapBuilder.LinkedListSupplier
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class com.google.common.collect.Multimaps.MapMultimap
 
values - Variable in class com.google.common.collect.Multimaps.UnmodifiableMultimap
 
values() - Method in class com.google.common.collect.Multimaps.UnmodifiableMultimap
 
values() - Method in class com.google.common.collect.RegularImmutableSortedMap
 
Values() - Constructor for class com.google.common.collect.RegularImmutableTable.Values
 
values() - Static method in enum com.google.common.collect.SortedLists.KeyAbsentBehavior
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.collect.SortedLists.KeyPresentBehavior
Returns an array containing the constants of this enum type, in the order they are declared.
Values() - Constructor for class com.google.common.collect.StandardTable.Column.Values
 
values() - Method in class com.google.common.collect.StandardTable
Returns a collection of all values, which may contain duplicates.
values() - Method in class com.google.common.collect.Synchronized.SynchronizedAsMap
 
values() - Method in class com.google.common.collect.Synchronized.SynchronizedBiMap
 
values - Variable in class com.google.common.collect.Synchronized.SynchronizedMap
 
values() - Method in class com.google.common.collect.Synchronized.SynchronizedMap
 
values() - Method in class com.google.common.collect.Synchronized.SynchronizedMultimap
 
values() - Method in interface com.google.common.collect.Table
Returns a collection of all values, which may contain duplicates.
values() - Method in class com.google.common.collect.Tables.TransposeTable
 
values() - Method in class com.google.common.collect.Tables.UnmodifiableTable
 
values() - Static method in enum com.google.common.collect.TreeMultiset.Aggregate
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class com.google.common.collect.TreeRangeMap.SubRangeMap.SubRangeMapAsMap
 
values() - Static method in enum com.google.common.hash.BloomFilterStrategies
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.hash.Funnels.ByteArrayFunnel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.hash.Funnels.IntegerFunnel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.hash.Funnels.LongFunnel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.hash.Funnels.UnencodedCharsFunnel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.hash.Hashing.ChecksumType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.io.Files.FilePredicate
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.io.FileWriteMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.primitives.Booleans.LexicographicalComparator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.primitives.Chars.LexicographicalComparator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.primitives.Doubles.LexicographicalComparator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.primitives.Floats.LexicographicalComparator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.primitives.Ints.LexicographicalComparator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.primitives.Longs.LexicographicalComparator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.primitives.Shorts.LexicographicalComparator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.primitives.SignedBytes.LexicographicalComparator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.primitives.UnsignedBytes.LexicographicalComparatorHolder.PureJavaComparator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.primitives.UnsignedBytes.LexicographicalComparatorHolder.UnsafeComparator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.primitives.UnsignedInts.LexicographicalComparator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.primitives.UnsignedLongs.LexicographicalComparator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.reflect.Types.ClassOwnership
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.reflect.Types.JavaVersion
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.reflect.TypeToken.TypeFilter
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.util.concurrent.CycleDetectingLockFactory.Policies
Returns an array containing the constants of this enum type, in the order they are declared.
values - Variable in class com.google.common.util.concurrent.Futures.CombinedFuture
 
values() - Static method in enum com.google.common.util.concurrent.MoreExecutors.DirectExecutor
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.util.concurrent.Service.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.thirdparty.publicsuffix.PublicSuffixType
Returns an array containing the constants of this enum type, in the order they are declared.
valuesCollection - Variable in class com.google.common.collect.Synchronized.SynchronizedMultimap
 
valuesDelegate - Variable in class com.google.common.collect.AbstractBiMap.ValueSet
 
valueSet - Variable in class com.google.common.collect.AbstractBiMap
 
ValueSet() - Constructor for class com.google.common.collect.AbstractBiMap.ValueSet
 
valueSet(Comparator<? super V>, Collection<? extends V>) - Static method in class com.google.common.collect.ImmutableSetMultimap
 
ValueSet(K, int) - Constructor for class com.google.common.collect.LinkedHashMultimap.ValueSet
 
valueSet - Variable in class com.google.common.collect.Synchronized.SynchronizedBiMap
 
valueSetCapacity - Variable in class com.google.common.collect.LinkedHashMultimap
 
valuesIterator() - Method in class com.google.common.collect.AbstractTable
 
valuesIterator() - Method in class com.google.common.collect.ImmutableTable
 
valueStrength - Variable in class com.google.common.cache.CacheBuilder
 
valueStrength - Variable in class com.google.common.cache.CacheBuilderSpec
 
valueStrength - Variable in class com.google.common.cache.LocalCache.ManualSerializationProxy
 
valueStrength - Variable in class com.google.common.cache.LocalCache
Strategy for referencing values.
valueStrength - Variable in class com.google.common.collect.MapMaker
 
valueStrength - Variable in class com.google.common.collect.MapMakerInternalMap.AbstractSerializationProxy
 
valueStrength - Variable in class com.google.common.collect.MapMakerInternalMap
Strategy for referencing values.
ValueStrengthParser(LocalCache.Strength) - Constructor for class com.google.common.cache.CacheBuilderSpec.ValueStrengthParser
 
valueTable - Variable in class com.google.common.collect.RegularImmutableBiMap
 
valueType - Variable in class com.google.common.collect.EnumBiMap
 
valueType() - Method in class com.google.common.collect.EnumBiMap
Returns the associated value type.
var - Variable in class com.google.common.reflect.TypeResolver.TypeVariableKey
 
VARY - Static variable in class com.google.common.net.HttpHeaders
The HTTP Vary header field name.
VCARD_UTF_8 - Static variable in class com.google.common.net.MediaType
 
Verify - Class in com.google.common.base
Static convenience methods that serve the same purpose as Java language assertions, except that they are always enabled.
Verify() - Constructor for class com.google.common.base.Verify
 
verify(boolean) - Static method in class com.google.common.base.Verify
Ensures that expression is true, throwing a VerifyException with no message otherwise.
verify(boolean, String, Object...) - Static method in class com.google.common.base.Verify
Ensures that expression is true, throwing a VerifyException with a custom message otherwise.
VerifyException - Exception in com.google.common.base
Exception thrown upon the failure of a verification check, including those performed by the convenience methods of the Verify class.
VerifyException() - Constructor for exception com.google.common.base.VerifyException
Constructs a VerifyException with no message.
VerifyException(String) - Constructor for exception com.google.common.base.VerifyException
Constructs a VerifyException with the message message.
verifyIndex(int) - Method in class com.google.common.collect.MinMaxPriorityQueue.Heap
 
verifyNotNull(T) - Static method in class com.google.common.base.Verify
Ensures that reference is non-null, throwing a VerifyException with a default message otherwise.
verifyNotNull(T, String, Object...) - Static method in class com.google.common.base.Verify
Ensures that reference is non-null, throwing a VerifyException with a custom message otherwise.
VIA - Static variable in class com.google.common.net.HttpHeaders
The HTTP Via header field name.
VIDEO_TYPE - Static variable in class com.google.common.net.MediaType
 
viewMapValuesAsSingletonSets() - Method in class com.google.common.collect.ImmutableMap
 
VisibleForTesting - Annotation Type in com.google.common.annotations
Annotates a program element that exists, or is more widely visible than otherwise necessary, only for use in test code.
visit(Type...) - Method in class com.google.common.reflect.TypeVisitor
Visits the given types.
visitClass(Class<?>) - Method in class com.google.common.reflect.TypeResolver.TypeMappingIntrospector
 
visitClass(Class<?>) - Method in class com.google.common.reflect.TypeVisitor
 
visited - Variable in class com.google.common.reflect.TypeVisitor
 
visitGenericArrayType(GenericArrayType) - Method in class com.google.common.reflect.TypeVisitor
 
visitParameterizedType(ParameterizedType) - Method in class com.google.common.reflect.TypeResolver.TypeMappingIntrospector
 
visitParameterizedType(ParameterizedType) - Method in class com.google.common.reflect.TypeVisitor
 
visitTypeVariable(TypeVariable<?>) - Method in class com.google.common.reflect.TypeResolver.TypeMappingIntrospector
 
visitTypeVariable(TypeVariable<?>) - Method in class com.google.common.reflect.TypeVisitor
 
visitWildcardType(WildcardType) - Method in class com.google.common.reflect.TypeResolver.TypeMappingIntrospector
 
visitWildcardType(WildcardType) - Method in class com.google.common.reflect.TypeVisitor
 
VT - Static variable in class com.google.common.base.Ascii
Vertical Tabulation ('\v'): A format effector which controls the movement of the printing position to the next in a series of predetermined printing lines.

W

waiterCount - Variable in class com.google.common.util.concurrent.Monitor.Guard
 
waitFor(Monitor.Guard) - Method in class com.google.common.util.concurrent.Monitor
Waits for the guard to be satisfied.
waitFor(Monitor.Guard, long, TimeUnit) - Method in class com.google.common.util.concurrent.Monitor
Waits for the guard to be satisfied.
waitForLoadingValue(LocalCache.ReferenceEntry<K, V>, K, LocalCache.ValueReference<K, V>) - Method in class com.google.common.cache.LocalCache.Segment
 
waitForUninterruptibly(Monitor.Guard) - Method in class com.google.common.util.concurrent.Monitor
Waits for the guard to be satisfied.
waitForUninterruptibly(Monitor.Guard, long, TimeUnit) - Method in class com.google.common.util.concurrent.Monitor
Waits for the guard to be satisfied.
waitForValue() - Method in class com.google.common.cache.LocalCache.LoadingValueReference
 
waitForValue() - Method in class com.google.common.cache.LocalCache.SoftValueReference
 
waitForValue() - Method in class com.google.common.cache.LocalCache.StrongValueReference
 
waitForValue() - Method in interface com.google.common.cache.LocalCache.ValueReference
Waits for a value that may still be loading.
waitForValue() - Method in class com.google.common.cache.LocalCache.WeakValueReference
 
waitForValue() - Method in class com.google.common.collect.ComputingConcurrentHashMap.ComputationExceptionReference
 
waitForValue() - Method in class com.google.common.collect.ComputingConcurrentHashMap.ComputedReference
 
waitForValue() - Method in class com.google.common.collect.ComputingConcurrentHashMap.ComputingValueReference
Waits for a computation to complete.
waitForValue() - Method in class com.google.common.collect.MapMakerInternalMap.SoftValueReference
 
waitForValue() - Method in class com.google.common.collect.MapMakerInternalMap.StrongValueReference
 
waitForValue() - Method in interface com.google.common.collect.MapMakerInternalMap.ValueReference
Waits for a value that may still be computing.
waitForValue() - Method in class com.google.common.collect.MapMakerInternalMap.WeakValueReference
 
waitQueue - Variable in class com.google.common.util.concurrent.ListenerCallQueue
 
waitQueue - Variable in class com.google.common.util.concurrent.SerializingExecutor
A list of Runnables to be run in order.
warmupPeriodMicros - Variable in class com.google.common.util.concurrent.SmoothRateLimiter.SmoothWarmingUp
 
WARNING - Static variable in class com.google.common.net.HttpHeaders
The HTTP Warning header field name.
wasEvicted() - Method in enum com.google.common.cache.RemovalCause
Returns true if there was an automatic removal due to eviction (the cause is neither RemovalCause.EXPLICIT nor RemovalCause.REPLACED).
wasEvicted() - Method in class com.google.common.cache.RemovalNotification
Returns true if there was an automatic removal due to eviction (the cause is neither RemovalCause.EXPLICIT nor RemovalCause.REPLACED).
wasEvicted() - Method in enum com.google.common.collect.MapMaker.RemovalCause
Returns true if there was an automatic removal due to eviction (the cause is neither MapMaker.RemovalCause.EXPLICIT nor MapMaker.RemovalCause.REPLACED).
wasEvicted() - Method in class com.google.common.collect.MapMaker.RemovalNotification
Returns true if there was an automatic removal due to eviction (the cause is neither MapMaker.RemovalCause.EXPLICIT nor MapMaker.RemovalCause.REPLACED).
wasInterrupted() - Method in class com.google.common.util.concurrent.AbstractFuture.Sync
Checks if the state is AbstractFuture.Sync.INTERRUPTED.
wasInterrupted() - Method in class com.google.common.util.concurrent.AbstractFuture
Returns true if this future was cancelled with mayInterruptIfRunning set to true.
WEAK_MASK - Static variable in enum com.google.common.cache.LocalCache.EntryFactory
 
WeakAccessEntry(ReferenceQueue<K>, K, int, LocalCache.ReferenceEntry<K, V>) - Constructor for class com.google.common.cache.LocalCache.WeakAccessEntry
 
WeakAccessWriteEntry(ReferenceQueue<K>, K, int, LocalCache.ReferenceEntry<K, V>) - Constructor for class com.google.common.cache.LocalCache.WeakAccessWriteEntry
 
weakCompareAndSet(double, double) - Method in class com.google.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.google.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.
WeakEntry(ReferenceQueue<K>, K, int, LocalCache.ReferenceEntry<K, V>) - Constructor for class com.google.common.cache.LocalCache.WeakEntry
 
WeakEntry(ReferenceQueue<K>, K, int, MapMakerInternalMap.ReferenceEntry<K, V>) - Constructor for class com.google.common.collect.MapMakerInternalMap.WeakEntry
 
WeakEvictableEntry(ReferenceQueue<K>, K, int, MapMakerInternalMap.ReferenceEntry<K, V>) - Constructor for class com.google.common.collect.MapMakerInternalMap.WeakEvictableEntry
 
WeakExpirableEntry(ReferenceQueue<K>, K, int, MapMakerInternalMap.ReferenceEntry<K, V>) - Constructor for class com.google.common.collect.MapMakerInternalMap.WeakExpirableEntry
 
WeakExpirableEvictableEntry(ReferenceQueue<K>, K, int, MapMakerInternalMap.ReferenceEntry<K, V>) - Constructor for class com.google.common.collect.MapMakerInternalMap.WeakExpirableEvictableEntry
 
WeakInterner() - Constructor for class com.google.common.collect.Interners.WeakInterner
 
weakKeys() - Method in class com.google.common.cache.CacheBuilder
Specifies that each key (not value) stored in the cache should be wrapped in a WeakReference (by default, strong references are used).
weakKeys() - Method in class com.google.common.collect.GenericMapMaker
Deprecated.
weakKeys() - Method in class com.google.common.collect.MapMaker
Specifies that each key (not value) stored in the map should be wrapped in a WeakReference (by default, strong references are used).
WeakValueReference(ReferenceQueue<V>, V, LocalCache.ReferenceEntry<K, V>) - Constructor for class com.google.common.cache.LocalCache.WeakValueReference
 
WeakValueReference(ReferenceQueue<V>, V, MapMakerInternalMap.ReferenceEntry<K, V>) - Constructor for class com.google.common.collect.MapMakerInternalMap.WeakValueReference
 
weakValues() - Method in class com.google.common.cache.CacheBuilder
Specifies that each value (not key) stored in the cache should be wrapped in a WeakReference (by default, strong references are used).
weakValues() - Method in class com.google.common.collect.GenericMapMaker
Deprecated.
weakValues() - Method in class com.google.common.collect.MapMaker
Specifies that each value (not key) stored in the map should be wrapped in a WeakReference (by default, strong references are used).
WeakWriteEntry(ReferenceQueue<K>, K, int, LocalCache.ReferenceEntry<K, V>) - Constructor for class com.google.common.cache.LocalCache.WeakWriteEntry
 
WEBM_AUDIO - Static variable in class com.google.common.net.MediaType
 
WEBM_VIDEO - Static variable in class com.google.common.net.MediaType
 
WEBP - Static variable in class com.google.common.net.MediaType
 
weigh(Object, Object) - Method in enum com.google.common.cache.CacheBuilder.OneWeigher
 
weigh(K, V) - Method in interface com.google.common.cache.Weigher
Returns the weight of a cache entry.
weigher - Variable in class com.google.common.cache.CacheBuilder
 
weigher(Weigher<? super K1, ? super V1>) - Method in class com.google.common.cache.CacheBuilder
Specifies the weigher to use in determining the weight of entries.
weigher - Variable in class com.google.common.cache.LocalCache.ManualSerializationProxy
 
weigher - Variable in class com.google.common.cache.LocalCache
Weigher to weigh cache entries.
Weigher<K,V> - Interface in com.google.common.cache
Calculates the weights of cache entries.
weight - Variable in class com.google.common.cache.LocalCache.WeightedSoftValueReference
 
weight - Variable in class com.google.common.cache.LocalCache.WeightedStrongValueReference
 
weight - Variable in class com.google.common.cache.LocalCache.WeightedWeakValueReference
 
WeightedSoftValueReference(ReferenceQueue<V>, V, LocalCache.ReferenceEntry<K, V>, int) - Constructor for class com.google.common.cache.LocalCache.WeightedSoftValueReference
 
WeightedStrongValueReference(V, int) - Constructor for class com.google.common.cache.LocalCache.WeightedStrongValueReference
 
WeightedWeakValueReference(ReferenceQueue<V>, V, LocalCache.ReferenceEntry<K, V>, int) - Constructor for class com.google.common.cache.LocalCache.WeightedWeakValueReference
 
WellBehavedMap<K,V> - Class in com.google.common.collect
Workaround for EnumMap bug.
WellBehavedMap(Map<K, V>) - Constructor for class com.google.common.collect.WellBehavedMap
 
WellBehavedMap.EntrySet - Class in com.google.common.collect
 
where(Map<TypeResolver.TypeVariableKey, ? extends Type>) - Method in class com.google.common.reflect.TypeResolver.TypeTable
Returns a new TypeResolver with variable mapping to type.
where(Type, Type) - Method in class com.google.common.reflect.TypeResolver
Returns a new TypeResolver with type variables in formal mapping to types in actual.
where(Map<TypeResolver.TypeVariableKey, ? extends Type>) - Method in class com.google.common.reflect.TypeResolver
Returns a new TypeResolver with variable mapping to type.
where(TypeParameter<X>, TypeToken<X>) - Method in class com.google.common.reflect.TypeToken
Returns a new TypeToken where type variables represented by typeParam are substituted by typeArg.
where(TypeParameter<X>, Class<X>) - Method in class com.google.common.reflect.TypeToken
Returns a new TypeToken where type variables represented by typeParam are substituted by typeArg.
WHITESPACE - Static variable in class com.google.common.base.CharMatcher
Determines whether a character is whitespace according to the latest Unicode standard, as illustrated here.
WHITESPACE_MULTIPLIER - Static variable in class com.google.common.base.CharMatcher
 
WHITESPACE_SHIFT - Static variable in class com.google.common.base.CharMatcher
 
WHITESPACE_TABLE - Static variable in class com.google.common.base.CharMatcher
 
wholeRow - Variable in class com.google.common.collect.TreeBasedTable.TreeRow
 
wholeRow() - Method in class com.google.common.collect.TreeBasedTable.TreeRow
 
WILDCARD - Static variable in class com.google.common.net.MediaType
 
wildcardCapturer - Static variable in class com.google.common.reflect.TypeResolver.TypeMappingIntrospector
 
WildcardCapturer() - Constructor for class com.google.common.reflect.TypeResolver.WildcardCapturer
 
WildcardTypeImpl(Type[], Type[]) - Constructor for class com.google.common.reflect.Types.WildcardTypeImpl
 
WITH_STRING_PARAM_FIRST - Static variable in class com.google.common.util.concurrent.Futures
 
withCharset(Charset) - Method in class com.google.common.net.MediaType
Returns a new instance with the same type and subtype as this instance, with the charset parameter set to the name of the given charset.
withDefaultPort(int) - Method in class com.google.common.net.HostAndPort
Provide a default port if the parsed string contained only a host.
WithExplicitOrdering(CycleDetectingLockFactory.Policy, Map<E, CycleDetectingLockFactory.LockGraphNode>) - Constructor for class com.google.common.util.concurrent.CycleDetectingLockFactory.WithExplicitOrdering
 
withFallback(ListenableFuture<? extends V>, FutureFallback<? extends V>) - Static method in class com.google.common.util.concurrent.Futures
Returns a Future whose result is taken from the given primary input or, if the primary input fails, from the Future provided by the fallback.
withFallback(ListenableFuture<? extends V>, FutureFallback<? extends V>, Executor) - Static method in class com.google.common.util.concurrent.Futures
Returns a Future whose result is taken from the given primary input or, if the primary input fails, from the Future provided by the fallback.
withKeyValueSeparator(String) - Method in class com.google.common.base.Joiner
Returns a MapJoiner using the given key-value separator, and the same configuration as this Joiner otherwise.
withKeyValueSeparator(String) - Method in class com.google.common.base.Splitter
Returns a MapSplitter which splits entries based on this splitter, and splits entries into keys and values using the specified separator.
withKeyValueSeparator(char) - Method in class com.google.common.base.Splitter
Returns a MapSplitter which splits entries based on this splitter, and splits entries into keys and values using the specified separator.
withKeyValueSeparator(Splitter) - Method in class com.google.common.base.Splitter
Returns a MapSplitter which splits entries based on this splitter, and splits entries into keys and values using the specified key-value splitter.
withLowerBoundType(BoundType, DiscreteDomain<Comparable<?>>) - Method in class com.google.common.collect.Cut.AboveAll
 
withLowerBoundType(BoundType, DiscreteDomain<C>) - Method in class com.google.common.collect.Cut.AboveValue
 
withLowerBoundType(BoundType, DiscreteDomain<Comparable<?>>) - Method in class com.google.common.collect.Cut.BelowAll
 
withLowerBoundType(BoundType, DiscreteDomain<C>) - Method in class com.google.common.collect.Cut.BelowValue
 
withLowerBoundType(BoundType, DiscreteDomain<C>) - Method in class com.google.common.collect.Cut
 
withNarrowedType() - Method in enum com.google.common.base.Predicates.ObjectPredicate
 
withoutParameters() - Method in class com.google.common.net.MediaType
Returns a new instance with the same type and subtype as this instance, but without any parameters.
withPadChar(char) - Method in class com.google.common.io.BaseEncoding.SeparatedBaseEncoding
 
withPadChar(char) - Method in class com.google.common.io.BaseEncoding.StandardBaseEncoding
 
withPadChar(char) - Method in class com.google.common.io.BaseEncoding
Returns an encoding that behaves equivalently to this encoding, but uses an alternate character for padding.
withParameter(String, String) - Method in class com.google.common.net.MediaType
Replaces all parameters with the given attribute with a single parameter with the given value.
withParameters(Multimap<String, String>) - Method in class com.google.common.net.MediaType
Replaces all parameters with the given parameters.
withSeparator(String, int) - Method in class com.google.common.io.BaseEncoding.SeparatedBaseEncoding
 
withSeparator(String, int) - Method in class com.google.common.io.BaseEncoding.StandardBaseEncoding
 
withSeparator(String, int) - Method in class com.google.common.io.BaseEncoding
Returns an encoding that behaves equivalently to this encoding, but adds a separator string after every n characters.
withToString(String) - Method in class com.google.common.base.CharMatcher.And
 
withToString(String) - Method in class com.google.common.base.CharMatcher.NegatedFastMatcher
 
withToString(String) - Method in class com.google.common.base.CharMatcher.NegatedMatcher
 
withToString(String) - Method in class com.google.common.base.CharMatcher.Or
 
withToString(String) - Method in class com.google.common.base.CharMatcher
Subclasses should provide a new CharMatcher with the same characteristics as this, but with their toString method overridden with the new description.
withType() - Static method in class com.google.common.base.Absent
 
withUpperBoundType(BoundType, DiscreteDomain<Comparable<?>>) - Method in class com.google.common.collect.Cut.AboveAll
 
withUpperBoundType(BoundType, DiscreteDomain<C>) - Method in class com.google.common.collect.Cut.AboveValue
 
withUpperBoundType(BoundType, DiscreteDomain<Comparable<?>>) - Method in class com.google.common.collect.Cut.BelowAll
 
withUpperBoundType(BoundType, DiscreteDomain<C>) - Method in class com.google.common.collect.Cut.BelowValue
 
withUpperBoundType(BoundType, DiscreteDomain<C>) - Method in class com.google.common.collect.Cut
 
WML_UTF_8 - Static variable in class com.google.common.net.MediaType
 
WMV - Static variable in class com.google.common.net.MediaType
 
WOFF - Static variable in class com.google.common.net.MediaType
Media type for the Web Open Font Format (WOFF) defined by the W3C.
wordBoundary - Variable in enum com.google.common.base.CaseFormat
 
wordSeparator - Variable in enum com.google.common.base.CaseFormat
 
wrap(S) - Method in class com.google.common.base.Equivalence
Returns a wrapper of reference that implements Object.equals() such that wrap(a).equals(wrap(b)) if and only if equivalent(a, b).
wrap(NavigableSet<V>) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedNavigableSet
 
wrap(Map<K, V>) - Static method in class com.google.common.collect.WellBehavedMap
Wraps the given map into a WellBehavedEntriesMap, which intercepts its entrySet() method by taking the Set<K> keySet() and transforming it to Set<Entry<K, V>>.
wrap(CharEscaper) - Static method in class com.google.common.escape.Escapers
Private helper to wrap a CharEscaper as a UnicodeEscaper.
wrap(byte[]) - Static method in class com.google.common.io.ByteSource
Returns a view of the given byte array as a ByteSource.
wrap(CharSequence) - Static method in class com.google.common.io.CharSource
Returns a view of the given character sequence as a CharSource.
wrap(Class<T>) - Static method in class com.google.common.primitives.Primitives
Returns the corresponding wrapper type of type if it is a primitive type; otherwise returns type itself.
wrap() - Method in class com.google.common.reflect.TypeToken
Returns the corresponding wrapper type if this is a primitive type; otherwise returns this itself.
wrapAndThrowExceptionOrError(Throwable, Class<X>) - Static method in class com.google.common.util.concurrent.Futures
 
wrapAndThrowUnchecked(Throwable) - Static method in class com.google.common.util.concurrent.Futures
 
wrapCollection(K, Collection<V>) - Method in class com.google.common.collect.AbstractMapBasedMultimap
Generates a decorated collection that remains consistent with the values in the multimap for the provided key.
wrapCollection(K, Collection<V>) - Method in class com.google.common.collect.TreeMultimap
 
wrapEntry(Map.Entry<K, Collection<V>>) - Method in class com.google.common.collect.AbstractMapBasedMultimap.AsMap
 
wrapEntry(TreeMultiset.AvlNode<E>) - Method in class com.google.common.collect.TreeMultiset
 
wrapList(K, List<V>, AbstractMapBasedMultimap<K, V>.WrappedCollection) - Method in class com.google.common.collect.AbstractMapBasedMultimap
 
WrappedCollection(K, Collection<V>, AbstractMapBasedMultimap<K, V>.WrappedCollection) - Constructor for class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection
 
WrappedCombiner(Callable<T>) - Constructor for class com.google.common.util.concurrent.Futures.WrappedCombiner
 
WrappedIterator() - Constructor for class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection.WrappedIterator
 
WrappedIterator(Iterator<V>) - Constructor for class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection.WrappedIterator
 
WrappedList(K, List<V>, AbstractMapBasedMultimap<K, V>.WrappedCollection) - Constructor for class com.google.common.collect.AbstractMapBasedMultimap.WrappedList
 
WrappedListIterator() - Constructor for class com.google.common.collect.AbstractMapBasedMultimap.WrappedList.WrappedListIterator
 
WrappedListIterator(int) - Constructor for class com.google.common.collect.AbstractMapBasedMultimap.WrappedList.WrappedListIterator
 
WrappedNavigableSet(K, NavigableSet<V>, AbstractMapBasedMultimap<K, V>.WrappedCollection) - Constructor for class com.google.common.collect.AbstractMapBasedMultimap.WrappedNavigableSet
 
wrappedRunnable - Variable in class com.google.common.util.concurrent.AbstractScheduledService.CustomScheduler.ReschedulableCallable
The underlying task.
WrappedSet(K, Set<V>) - Constructor for class com.google.common.collect.AbstractMapBasedMultimap.WrappedSet
 
WrappedSortedSet(K, SortedSet<V>, AbstractMapBasedMultimap<K, V>.WrappedCollection) - Constructor for class com.google.common.collect.AbstractMapBasedMultimap.WrappedSortedSet
 
Wrapper(Equivalence<? super T>, T) - Constructor for class com.google.common.base.Equivalence.Wrapper
 
WRAPPER_TO_PRIMITIVE_TYPE - Static variable in class com.google.common.primitives.Primitives
A map from wrapper types to their corresponding primitive types.
WrappingExecutorService - Class in com.google.common.util.concurrent
An abstract ExecutorService that allows subclasses to wrap tasks before they are submitted to the underlying executor.
WrappingExecutorService(ExecutorService) - Constructor for class com.google.common.util.concurrent.WrappingExecutorService
 
WrappingScheduledExecutorService - Class in com.google.common.util.concurrent
An abstract ScheduledExecutorService that allows subclasses to wrap tasks before they are submitted to the underlying executor.
WrappingScheduledExecutorService(ScheduledExecutorService) - Constructor for class com.google.common.util.concurrent.WrappingScheduledExecutorService
 
wrapTask(Callable<T>) - Method in class com.google.common.util.concurrent.WrappingExecutorService
Wraps a Callable for submission to the underlying executor.
wrapTask(Runnable) - Method in class com.google.common.util.concurrent.WrappingExecutorService
Wraps a Runnable for submission to the underlying executor.
wrapTasks(Collection<? extends Callable<T>>) - Method in class com.google.common.util.concurrent.WrappingExecutorService
Wraps a collection of tasks.
write(int) - Method in class com.google.common.hash.Funnels.SinkAsStream
 
write(byte[]) - Method in class com.google.common.hash.Funnels.SinkAsStream
 
write(byte[], int, int) - Method in class com.google.common.hash.Funnels.SinkAsStream
 
write(int) - Method in class com.google.common.hash.HashingOutputStream
 
write(byte[], int, int) - Method in class com.google.common.hash.HashingOutputStream
 
write(char[], int, int) - Method in class com.google.common.io.AppendableWriter
 
write(int) - Method in class com.google.common.io.AppendableWriter
 
write(String) - Method in class com.google.common.io.AppendableWriter
 
write(String, int, int) - Method in class com.google.common.io.AppendableWriter
 
write(int) - Method in interface com.google.common.io.ByteArrayDataOutput
 
write(byte[]) - Method in interface com.google.common.io.ByteArrayDataOutput
 
write(byte[], int, int) - Method in interface com.google.common.io.ByteArrayDataOutput
 
write(byte[]) - Method in class com.google.common.io.ByteSink
Writes all the given bytes to this sink.
write(int) - Method in class com.google.common.io.ByteStreams.ByteArrayDataOutputStream
 
write(byte[]) - Method in class com.google.common.io.ByteStreams.ByteArrayDataOutputStream
 
write(byte[], int, int) - Method in class com.google.common.io.ByteStreams.ByteArrayDataOutputStream
 
write(CharSequence) - Method in class com.google.common.io.CharSink
Writes the given character sequence to this sink.
write(int) - Method in class com.google.common.io.CharStreams.NullWriter
 
write(char[]) - Method in class com.google.common.io.CharStreams.NullWriter
 
write(char[], int, int) - Method in class com.google.common.io.CharStreams.NullWriter
 
write(String) - Method in class com.google.common.io.CharStreams.NullWriter
 
write(String, int, int) - Method in class com.google.common.io.CharStreams.NullWriter
 
write(byte[], int, int) - Method in class com.google.common.io.CountingOutputStream
 
write(int) - Method in class com.google.common.io.CountingOutputStream
 
write(int) - Method in class com.google.common.io.FileBackedOutputStream
 
write(byte[]) - Method in class com.google.common.io.FileBackedOutputStream
 
write(byte[], int, int) - Method in class com.google.common.io.FileBackedOutputStream
 
write(byte[], File) - Static method in class com.google.common.io.Files
Overwrites a file with the contents of a byte array.
write(CharSequence, File, Charset) - Static method in class com.google.common.io.Files
Writes a character sequence (such as a string) to a file using the given character set.
write(CharSequence, File, Charset, boolean) - Static method in class com.google.common.io.Files
Private helper method.
write(byte) - Method in interface com.google.common.io.GwtWorkarounds.ByteOutput
 
write(char) - Method in interface com.google.common.io.GwtWorkarounds.CharOutput
 
write(byte[], int, int) - Method in class com.google.common.io.LittleEndianDataOutputStream
 
WRITE_MASK - Static variable in enum com.google.common.cache.LocalCache.EntryFactory
 
writeBoolean(boolean) - Method in interface com.google.common.io.ByteArrayDataOutput
 
writeBoolean(boolean) - Method in class com.google.common.io.ByteStreams.ByteArrayDataOutputStream
 
writeBoolean(boolean) - Method in class com.google.common.io.LittleEndianDataOutputStream
 
writeByte(int) - Method in interface com.google.common.io.ByteArrayDataOutput
 
writeByte(int) - Method in class com.google.common.io.ByteStreams.ByteArrayDataOutputStream
 
writeByte(int) - Method in class com.google.common.io.LittleEndianDataOutputStream
 
writeBytes(String) - Method in interface com.google.common.io.ByteArrayDataOutput
Deprecated.
This method is dangerous as it discards the high byte of every character. For UTF-8, use write(s.getBytes(Charsets.UTF_8)).
writeBytes(String) - Method in class com.google.common.io.ByteStreams.ByteArrayDataOutputStream
 
writeBytes(String) - Method in class com.google.common.io.LittleEndianDataOutputStream
Deprecated.
The semantics of writeBytes(String s) are considered dangerous. Please use LittleEndianDataOutputStream.writeUTF(String s), LittleEndianDataOutputStream.writeChars(String s) or another write method instead.
writeBytesTo(byte[], int, int) - Method in class com.google.common.hash.HashCode
Copies bytes from this hash code into dest.
writeBytesToImpl(byte[], int, int) - Method in class com.google.common.hash.HashCode.BytesHashCode
 
writeBytesToImpl(byte[], int, int) - Method in class com.google.common.hash.HashCode.IntHashCode
 
writeBytesToImpl(byte[], int, int) - Method in class com.google.common.hash.HashCode.LongHashCode
 
writeBytesToImpl(byte[], int, int) - Method in class com.google.common.hash.HashCode
 
writeChar(int) - Method in interface com.google.common.io.ByteArrayDataOutput
 
writeChar(int) - Method in class com.google.common.io.ByteStreams.ByteArrayDataOutputStream
 
writeChar(int) - Method in class com.google.common.io.LittleEndianDataOutputStream
Writes a char as specified by DataOutputStream.writeChar(int), except using little-endian byte order.
writeChars(String) - Method in interface com.google.common.io.ByteArrayDataOutput
 
writeChars(String) - Method in class com.google.common.io.ByteStreams.ByteArrayDataOutputStream
 
writeChars(String) - Method in class com.google.common.io.LittleEndianDataOutputStream
Writes a String as specified by DataOutputStream.writeChars(String), except each character is written using little-endian byte order.
writeDouble(double) - Method in interface com.google.common.io.ByteArrayDataOutput
 
writeDouble(double) - Method in class com.google.common.io.ByteStreams.ByteArrayDataOutputStream
 
writeDouble(double) - Method in class com.google.common.io.LittleEndianDataOutputStream
Writes a double as specified by DataOutputStream.writeDouble(double), except using little-endian byte order.
WriteDurationParser() - Constructor for class com.google.common.cache.CacheBuilderSpec.WriteDurationParser
 
writeExpirationDuration - Variable in class com.google.common.cache.CacheBuilderSpec
 
writeExpirationTimeUnit - Variable in class com.google.common.cache.CacheBuilderSpec
 
writeFloat(float) - Method in interface com.google.common.io.ByteArrayDataOutput
 
writeFloat(float) - Method in class com.google.common.io.ByteStreams.ByteArrayDataOutputStream
 
writeFloat(float) - Method in class com.google.common.io.LittleEndianDataOutputStream
Writes a float as specified by DataOutputStream.writeFloat(float), except using little-endian byte order.
writeFrom(InputStream) - Method in class com.google.common.io.ByteSink
Writes all the bytes from the given InputStream to this sink.
writeFrom(Readable) - Method in class com.google.common.io.CharSink
Writes all the text from the given Readable (such as a Reader) to this sink.
writeInt(int) - Method in interface com.google.common.io.ByteArrayDataOutput
 
writeInt(int) - Method in class com.google.common.io.ByteStreams.ByteArrayDataOutputStream
 
writeInt(int) - Method in class com.google.common.io.LittleEndianDataOutputStream
Writes an int as specified by DataOutputStream.writeInt(int), except using little-endian byte order.
writeLines(Iterable<? extends CharSequence>) - Method in class com.google.common.io.CharSink
Writes the given lines of text to this sink with each line (including the last) terminated with the operating system's default line separator.
writeLines(Iterable<? extends CharSequence>, String) - Method in class com.google.common.io.CharSink
Writes the given lines of text to this sink with each line (including the last) terminated with the given line separator.
writeLock - Variable in class com.google.common.util.concurrent.CycleDetectingLockFactory.CycleDetectingReentrantReadWriteLock
 
writeLock() - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory.CycleDetectingReentrantReadWriteLock
 
writeLong(long) - Method in interface com.google.common.io.ByteArrayDataOutput
 
writeLong(long) - Method in class com.google.common.io.ByteStreams.ByteArrayDataOutputStream
 
writeLong(long) - Method in class com.google.common.io.LittleEndianDataOutputStream
Writes a long as specified by DataOutputStream.writeLong(long), except using little-endian byte order.
writeMap(Map<K, V>, ObjectOutputStream) - Static method in class com.google.common.collect.Serialization
Stores the contents of a map in an output stream, as part of serialization.
writeMapTo(ObjectOutputStream) - Method in class com.google.common.collect.MapMakerInternalMap.AbstractSerializationProxy
 
writeMultimap(Multimap<K, V>, ObjectOutputStream) - Static method in class com.google.common.collect.Serialization
Stores the contents of a multimap in an output stream, as part of serialization.
writeMultiset(Multiset<E>, ObjectOutputStream) - Static method in class com.google.common.collect.Serialization
Stores the contents of a multiset in an output stream, as part of serialization.
writeObject(ObjectOutputStream) - Method in class com.google.common.cache.LongAdder
 
writeObject(ObjectOutputStream) - Method in class com.google.common.collect.AbstractBiMap.Inverse
 
writeObject(ObjectOutputStream) - Method in class com.google.common.collect.ArrayListMultimap
 
writeObject(ObjectOutputStream) - Method in class com.google.common.collect.ComputingConcurrentHashMap.ComputingSerializationProxy
 
writeObject(ObjectOutputStream) - Method in class com.google.common.collect.ConcurrentHashMultiset
 
writeObject(ObjectOutputStream) - Method in class com.google.common.collect.EnumBiMap
 
writeObject(ObjectOutputStream) - Method in class com.google.common.collect.EnumHashBiMap
 
writeObject(ObjectOutputStream) - Method in class com.google.common.collect.EnumMultiset
 
writeObject(ObjectOutputStream) - Method in class com.google.common.collect.HashBiMap
 
writeObject(ObjectOutputStream) - Method in class com.google.common.collect.HashMultimap
 
writeObject(ObjectOutputStream) - Method in class com.google.common.collect.HashMultiset
 
writeObject(ObjectOutputStream) - Method in class com.google.common.collect.ImmutableListMultimap
 
writeObject(ObjectOutputStream) - Method in class com.google.common.collect.ImmutableSetMultimap
 
writeObject(ObjectOutputStream) - Method in class com.google.common.collect.LinkedHashMultimap
 
writeObject(ObjectOutputStream) - Method in class com.google.common.collect.LinkedHashMultiset
 
writeObject(ObjectOutputStream) - Method in class com.google.common.collect.LinkedListMultimap
 
writeObject(ObjectOutputStream) - Method in class com.google.common.collect.MapMakerInternalMap.SerializationProxy
 
writeObject(ObjectOutputStream) - Method in class com.google.common.collect.Multimaps.CustomListMultimap
 
writeObject(ObjectOutputStream) - Method in class com.google.common.collect.Multimaps.CustomMultimap
 
writeObject(ObjectOutputStream) - Method in class com.google.common.collect.Multimaps.CustomSetMultimap
 
writeObject(ObjectOutputStream) - Method in class com.google.common.collect.Multimaps.CustomSortedSetMultimap
 
writeObject(ObjectOutputStream) - Method in class com.google.common.collect.Synchronized.SynchronizedObject
 
writeObject(ObjectOutputStream) - Method in class com.google.common.collect.TreeMultimap
 
writeObject(ObjectOutputStream) - Method in class com.google.common.collect.TreeMultiset
 
writeObject(ObjectOutputStream) - Method in class com.google.common.util.concurrent.AtomicDouble
Saves the state to a stream (that is, serializes it).
writeObject(ObjectOutputStream) - Method in class com.google.common.util.concurrent.AtomicDoubleArray
Saves the state to a stream (that is, serializes it).
writeQueue - Variable in class com.google.common.cache.LocalCache.Segment
A queue of elements currently in the map, ordered by write time.
WriteQueue() - Constructor for class com.google.common.cache.LocalCache.WriteQueue
 
writeReplace() - Method in class com.google.common.cache.LocalCache.LocalLoadingCache
 
writeReplace() - Method in class com.google.common.cache.LocalCache.LocalManualCache
 
writeReplace() - Method in class com.google.common.collect.ComputingConcurrentHashMap
 
writeReplace() - Method in class com.google.common.collect.EmptyContiguousSet
 
writeReplace() - Method in class com.google.common.collect.HashBiMap.Inverse
 
writeReplace() - Method in class com.google.common.collect.ImmutableAsList
 
writeReplace() - Method in class com.google.common.collect.ImmutableBiMap
 
writeReplace() - Method in class com.google.common.collect.ImmutableCollection
 
writeReplace() - Method in class com.google.common.collect.ImmutableEnumMap
 
writeReplace() - Method in class com.google.common.collect.ImmutableEnumSet
 
writeReplace() - Method in class com.google.common.collect.ImmutableList
 
writeReplace() - Method in class com.google.common.collect.ImmutableMap
 
writeReplace() - Method in class com.google.common.collect.ImmutableMapEntrySet
 
writeReplace() - Method in class com.google.common.collect.ImmutableMapKeySet
 
writeReplace() - Method in class com.google.common.collect.ImmutableMapValues
 
writeReplace() - Method in class com.google.common.collect.ImmutableMultiset.EntrySet
 
writeReplace() - Method in class com.google.common.collect.ImmutableMultiset
 
writeReplace() - Method in class com.google.common.collect.ImmutableRangeSet.AsSet
 
writeReplace() - Method in class com.google.common.collect.ImmutableRangeSet
 
writeReplace() - Method in class com.google.common.collect.ImmutableSet
 
writeReplace() - Method in class com.google.common.collect.ImmutableSortedMap
 
writeReplace() - Method in class com.google.common.collect.ImmutableSortedMultiset
 
writeReplace() - Method in class com.google.common.collect.ImmutableSortedSet
 
writeReplace() - Method in class com.google.common.collect.MapMakerInternalMap
 
writeReplace() - Method in class com.google.common.collect.RegularContiguousSet
 
writeReplace() - Method in class com.google.common.collect.RegularImmutableBiMap.Inverse
 
writeReplace() - Method in class com.google.common.hash.BloomFilter
 
writeReplace() - Method in class com.google.common.hash.Funnels.StringCharsetFunnel
 
writeReplace() - Method in class com.google.common.hash.MessageDigestHashFunction
 
writeReplace() - Method in class com.google.common.reflect.TypeToken
Implemented to support serialization of subclasses.
writeShort(int) - Method in interface com.google.common.io.ByteArrayDataOutput
 
writeShort(int) - Method in class com.google.common.io.ByteStreams.ByteArrayDataOutputStream
 
writeShort(int) - Method in class com.google.common.io.LittleEndianDataOutputStream
Writes a short as specified by DataOutputStream.writeShort(int), except using little-endian byte order.
WriteThroughEntry(K, V) - Constructor for class com.google.common.cache.LocalCache.WriteThroughEntry
 
WriteThroughEntry(K, V) - Constructor for class com.google.common.collect.MapMakerInternalMap.WriteThroughEntry
 
writeTime - Variable in class com.google.common.cache.LocalCache.StrongAccessWriteEntry
 
writeTime - Variable in class com.google.common.cache.LocalCache.StrongWriteEntry
 
writeTime - Variable in class com.google.common.cache.LocalCache.WeakAccessWriteEntry
 
writeTime - Variable in class com.google.common.cache.LocalCache.WeakWriteEntry
 
writeTo(OutputStream) - Method in class com.google.common.hash.BloomFilter
Writes this BloomFilter to an output stream, with a custom format (not Java serialization).
writeTo(byte[], int) - Method in class com.google.common.io.ByteStreams.FastByteArrayOutputStream
Writes the contents of the internal buffer to the given array starting at the given offset.
writeUTF(String) - Method in interface com.google.common.io.ByteArrayDataOutput
 
writeUTF(String) - Method in class com.google.common.io.ByteStreams.ByteArrayDataOutputStream
 
writeUTF(String) - Method in class com.google.common.io.LittleEndianDataOutputStream
 
WWW_AUTHENTICATE - Static variable in class com.google.common.net.HttpHeaders
The HTTP WWW-Authenticate header field name.

X

X_CONTENT_TYPE_OPTIONS - Static variable in class com.google.common.net.HttpHeaders
The HTTP X-Content-Type-Options header field name.
X_DO_NOT_TRACK - Static variable in class com.google.common.net.HttpHeaders
The HTTP X-Do-Not-Track header field name.
X_FORWARDED_FOR - Static variable in class com.google.common.net.HttpHeaders
The HTTP X-Forwarded-For header field name.
X_FORWARDED_PROTO - Static variable in class com.google.common.net.HttpHeaders
The HTTP X-Forwarded-Proto header field name.
X_FRAME_OPTIONS - Static variable in class com.google.common.net.HttpHeaders
The HTTP X-Frame-Options header field name.
X_POWERED_BY - Static variable in class com.google.common.net.HttpHeaders
The HTTP X-Powered-By header field name.
X_REQUESTED_WITH - Static variable in class com.google.common.net.HttpHeaders
The HTTP X-Requested-With header field name.
X_USER_IP - Static variable in class com.google.common.net.HttpHeaders
The HTTP X-User-IP header field name.
X_XSS_PROTECTION - Static variable in class com.google.common.net.HttpHeaders
The HTTP X-XSS-Protection header field name.
XHTML_UTF_8 - Static variable in class com.google.common.net.MediaType
 
XML_ATTRIBUTE_ESCAPER - Static variable in class com.google.common.xml.XmlEscapers
 
XML_CONTENT_ESCAPER - Static variable in class com.google.common.xml.XmlEscapers
 
XML_ESCAPER - Static variable in class com.google.common.xml.XmlEscapers
 
XML_UTF_8 - Static variable in class com.google.common.net.MediaType
As described in RFC 3023, this constant (text/xml) is used for XML documents that are "readable by casual users." MediaType.APPLICATION_XML_UTF_8 is provided for documents that are intended for applications.
xmlAttributeEscaper() - Static method in class com.google.common.xml.XmlEscapers
Returns an Escaper instance that escapes special characters in a string so it can safely be included in XML document as an attribute value.
xmlContentEscaper() - Static method in class com.google.common.xml.XmlEscapers
Returns an Escaper instance that escapes special characters in a string so it can safely be included in an XML document as element content.
XmlEscapers - Class in com.google.common.xml
Escaper instances suitable for strings to be included in XML attribute values and elements' text contents.
XmlEscapers() - Constructor for class com.google.common.xml.XmlEscapers
 
XOFF - Static variable in class com.google.common.base.Ascii
Transmission off.
XON - Static variable in class com.google.common.base.Ascii
Transmission On: Although originally defined as DC1, this ASCII control character is now better known as the XON code used for software flow control in serial communications.
XRD_UTF_8 - Static variable in class com.google.common.net.MediaType
Media type for Extensible Resource Descriptors.

Z

ZERO - Static variable in class com.google.common.primitives.UnsignedInteger
 
ZERO - Static variable in class com.google.common.primitives.UnsignedLong
 
ZEROES - Static variable in class com.google.common.base.CharMatcher
 
ZIP - Static variable in class com.google.common.net.MediaType
 
A B C D E F G H I J K L M N O P Q R S T U V W X Z