Index

A B C D E F G H I J K L M N O P Q R S T U V W X Y Z 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form

A

a - Variable in class com.google.common.collect.Streams.TemporaryPair
 
a - Variable in class com.google.common.collect.testing.google.MultisetNavigationTester
 
a - Variable in class com.google.common.collect.testing.testers.NavigableMapNavigationTester
 
a - Variable in class com.google.common.collect.testing.testers.NavigableSetNavigationTester
 
a - Variable in class com.google.common.collect.testing.testers.SortedMapNavigationTester
 
a - Variable in class com.google.common.collect.testing.testers.SortedSetNavigationTester
 
A - Enum constant in enum class com.google.common.collect.testing.AnEnum
 
AAC_AUDIO - Static variable in class com.google.common.net.MediaType
Advanced Audio Coding.
abbreviate(TimeUnit) - Static method in class com.google.common.base.Stopwatch
 
About all Immutable- collections - Search tag in class com.google.common.collect.ImmutableCollection
Section
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
 
aboveSamplesGreater() - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.MapSortedKeySetGenerator
 
aboveSamplesGreater() - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.SortedMapSubmapTestMapGenerator
 
aboveSamplesGreater() - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.SortedSetSubsetTestSetGenerator
 
aboveSamplesGreater() - Method in class com.google.common.collect.testing.NavigableMapTestSuiteBuilder.DescendingTestMapGenerator
 
aboveSamplesGreater() - Method in interface com.google.common.collect.testing.TestSortedMapGenerator
Returns an entry with a key greater than the keys of the TestContainerGenerator.samples() and greater than the key of TestSortedMapGenerator.aboveSamplesLesser().
aboveSamplesGreater() - Method in interface com.google.common.collect.testing.TestSortedSetGenerator
Returns an element greater than the TestContainerGenerator.samples() and greater than TestSortedSetGenerator.aboveSamplesLesser().
aboveSamplesGreater() - Method in class com.google.common.collect.testing.TestStringSortedMapGenerator
 
aboveSamplesGreater() - Method in class com.google.common.collect.testing.TestStringSortedSetGenerator
 
aboveSamplesLesser() - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.MapSortedKeySetGenerator
 
aboveSamplesLesser() - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.SortedMapSubmapTestMapGenerator
 
aboveSamplesLesser() - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.SortedSetSubsetTestSetGenerator
 
aboveSamplesLesser() - Method in class com.google.common.collect.testing.NavigableMapTestSuiteBuilder.DescendingTestMapGenerator
 
aboveSamplesLesser() - Method in interface com.google.common.collect.testing.TestSortedMapGenerator
Returns an entry with a key greater than the keys of the TestContainerGenerator.samples() but less than the key of TestSortedMapGenerator.aboveSamplesGreater().
aboveSamplesLesser() - Method in interface com.google.common.collect.testing.TestSortedSetGenerator
Returns an element greater than the TestContainerGenerator.samples() but less than TestSortedSetGenerator.aboveSamplesGreater().
aboveSamplesLesser() - Method in class com.google.common.collect.testing.TestStringSortedMapGenerator
 
aboveSamplesLesser() - Method in class com.google.common.collect.testing.TestStringSortedSetGenerator
 
aboveValue(C) - Static method in class com.google.common.collect.Cut
 
AboveValue(C) - Constructor for class com.google.common.collect.Cut.AboveValue
 
absent() - Static method in class com.google.common.base.Optional
Returns an Optional instance with no contained reference.
absent() - Element in annotation interface com.google.common.collect.testing.features.CollectionFeature.Require
 
absent() - Element in annotation interface com.google.common.collect.testing.features.CollectionSize.Require
 
absent() - Element in annotation interface com.google.common.collect.testing.features.ListFeature.Require
 
absent() - Element in annotation interface com.google.common.collect.testing.features.MapFeature.Require
 
absent() - Element in annotation interface com.google.common.collect.testing.features.SetFeature.Require
 
absent() - Element in annotation interface com.google.common.collect.testing.google.MultimapFeature.Require
 
absent() - Element in annotation interface com.google.common.collect.testing.google.MultisetFeature.Require
 
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
 
absentFeatures - Variable in class com.google.common.collect.testing.features.TesterRequirements
 
ABSTRACT_HASH_FUNCTION - Enum constant in enum class com.google.common.hash.Hashing.Crc32CSupplier
 
AbstractBaseGraph<N> - Class in com.google.common.graph
This class provides a skeletal implementation of BaseGraph.
AbstractBaseGraph() - Constructor for class com.google.common.graph.AbstractBaseGraph
 
AbstractBiMap<K,V> - Class in com.google.common.collect
A general-purpose bimap implementation using any two backing Map instances.
AbstractBiMap(Map<K, V>, AbstractBiMap<V, K>) - Constructor for class com.google.common.collect.AbstractBiMap
Private constructor for inverse bimap.
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.BiMapEntry - Class in com.google.common.collect
 
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
 
AbstractBiMapTester<K,V> - Class in com.google.common.collect.testing.google
Skeleton for a tester of a BiMap.
AbstractBiMapTester() - Constructor for class com.google.common.collect.testing.google.AbstractBiMapTester
 
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() - Constructor for class com.google.common.cache.LocalCache.AbstractCacheSet
 
AbstractCatchingFuture<V,X,F,T> - Class in com.google.common.util.concurrent
Implementations of Futures.catching*.
AbstractCatchingFuture(ListenableFuture<? extends V>, Class<X>, F) - Constructor for class com.google.common.util.concurrent.AbstractCatchingFuture
 
AbstractCatchingFuture.AsyncCatchingFuture<V,X> - Class in com.google.common.util.concurrent
AbstractCatchingFuture.CatchingFuture<V,X> - Class in com.google.common.util.concurrent
AbstractCell() - Constructor for class com.google.common.collect.Tables.AbstractCell
 
AbstractCollectionTester<E> - Class in com.google.common.collect.testing
Base class for collection testers.
AbstractCollectionTester() - Constructor for class com.google.common.collect.testing.AbstractCollectionTester
 
AbstractCollectionTestSuiteBuilder<B,E> - Class in com.google.common.collect.testing
Abstract superclass of all test-suite builders for collection interfaces.
AbstractCollectionTestSuiteBuilder() - Constructor for class com.google.common.collect.testing.AbstractCollectionTestSuiteBuilder
 
AbstractCompositeHashFunction - Class in com.google.common.hash
An abstract composition of multiple hash functions.
AbstractCompositeHashFunction(HashFunction...) - Constructor for class com.google.common.hash.AbstractCompositeHashFunction
 
AbstractContainerTester<C,E> - Class in com.google.common.collect.testing
Base class for testers of classes (including Collection and Map) that contain elements.
AbstractContainerTester() - Constructor for class com.google.common.collect.testing.AbstractContainerTester
 
AbstractContainerTester.ArrayWithDuplicate<E> - Class in com.google.common.collect.testing
 
AbstractContiguousSetGenerator() - Constructor for class com.google.common.collect.testing.google.SetGenerators.AbstractContiguousSetGenerator
 
AbstractDirectedNetworkConnections<N,E> - Class in com.google.common.graph
A base implementation of NetworkConnections for directed networks.
AbstractDirectedNetworkConnections(Map<E, N>, Map<E, N>, int) - Constructor for class com.google.common.graph.AbstractDirectedNetworkConnections
 
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 ListenableFuture, intended for advanced users only.
AbstractFuture() - Constructor for class com.google.common.util.concurrent.AbstractFuture
Constructor for use by subclasses.
AbstractFuture.AtomicHelper - Class in com.google.common.util.concurrent
 
AbstractFuture.Cancellation - Class in com.google.common.util.concurrent
A special value to represent cancellation and the 'wasInterrupted' bit.
AbstractFuture.Failure - Class in com.google.common.util.concurrent
A special value to represent failure, when AbstractFuture.setException(java.lang.Throwable) is called successfully.
AbstractFuture.Listener - Class in com.google.common.util.concurrent
Listeners also form a stack through the AbstractFuture.listeners field.
AbstractFuture.SafeAtomicHelper - Class in com.google.common.util.concurrent
AbstractFuture.SetFuture<V> - Class in com.google.common.util.concurrent
A special value that encodes the 'setFuture' state.
AbstractFuture.SynchronizedHelper - Class in com.google.common.util.concurrent
AbstractFuture.AtomicHelper based on synchronized and volatile writes.
AbstractFuture.Trusted<V> - Interface in com.google.common.util.concurrent
Tag interface marking trusted subclasses.
AbstractFuture.TrustedFuture<V> - Class in com.google.common.util.concurrent
A less abstract subclass of AbstractFuture.
AbstractFuture.UnsafeAtomicHelper - Class in com.google.common.util.concurrent
AbstractFuture.Waiter - Class in com.google.common.util.concurrent
Waiter links form a Treiber stack, in the AbstractFuture.waiters field.
AbstractGraph<N> - Class in com.google.common.graph
This class provides a skeletal implementation of Graph.
AbstractGraph() - Constructor for class com.google.common.graph.AbstractGraph
 
AbstractGraphBuilder<N> - Class in com.google.common.graph
A base class for builders that construct graphs with user-defined properties.
AbstractGraphBuilder(boolean) - Constructor for class com.google.common.graph.AbstractGraphBuilder
Creates a new instance with the specified edge directionality.
AbstractHasher - Class in com.google.common.hash
An abstract implementation of Hasher, which only requires subtypes to implement Hasher.putByte(byte).
AbstractHasher() - Constructor for class com.google.common.hash.AbstractHasher
 
AbstractHashFunction - Class in com.google.common.hash
Skeleton implementation of HashFunction in terms of HashFunction.newHasher().
AbstractHashFunction() - Constructor for class com.google.common.hash.AbstractHashFunction
 
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.
AbstractIdleService.DelegateService - Class in com.google.common.util.concurrent
 
AbstractIdleService.ThreadNameSupplier - Class in com.google.common.util.concurrent
 
Abstract implementations - Search tag in package com.google.common.collect
Section
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
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<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.base.AbstractIterator
 
AbstractIterator() - Constructor for class com.google.common.collect.AbstractIterator
Constructor for use by subclasses.
AbstractIterator.State - Enum Class in com.google.common.base
 
AbstractIterator.State - Enum Class in com.google.common.collect
 
AbstractIteratorTester<E,I> - Class in com.google.common.collect.testing
Most of the logic for IteratorTester and ListIteratorTester.
AbstractIteratorTester(int, Iterable<E>, Iterable<? extends IteratorFeature>, Iterable<E>, AbstractIteratorTester.KnownOrder, int) - Constructor for class com.google.common.collect.testing.AbstractIteratorTester
 
AbstractIteratorTester.IteratorOperation - Interface in com.google.common.collect.testing
 
AbstractIteratorTester.KnownOrder - Enum Class in com.google.common.collect.testing
 
AbstractIteratorTester.MultiExceptionListIterator - Class in com.google.common.collect.testing
Quasi-implementation of ListIterator that works from a list of elements and a set of features to support (from the enclosing AbstractIteratorTester instance).
AbstractIteratorTester.PermittedMetaException - Exception Class in com.google.common.collect.testing
Meta-exception thrown by AbstractIteratorTester.MultiExceptionListIterator instead of throwing any particular exception type.
AbstractIteratorTester.Stimulus<E,T> - Class in com.google.common.collect.testing
 
AbstractIteratorTester.UnknownElementException - Exception Class in com.google.common.collect.testing
 
AbstractListenableFutureTest - Class in com.google.common.util.concurrent.testing
Abstract test case parent for anything implementing ListenableFuture.
AbstractListenableFutureTest() - Constructor for class com.google.common.util.concurrent.testing.AbstractListenableFutureTest
 
AbstractListeningExecutorService - Class in com.google.common.util.concurrent
Abstract ListeningExecutorService implementation that creates ListenableFuture instances for each Runnable and Callable submitted to it.
AbstractListeningExecutorService() - Constructor for class com.google.common.util.concurrent.AbstractListeningExecutorService
 
AbstractListIndexOfTester<E> - Class in com.google.common.collect.testing.testers
Common parent class for ListIndexOfTester and ListLastIndexOfTester.
AbstractListIndexOfTester() - Constructor for class com.google.common.collect.testing.testers.AbstractListIndexOfTester
 
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.
AbstractListMultimapTester<K,V> - Class in com.google.common.collect.testing.google
Superclass for all ListMultimap testers.
AbstractListMultimapTester() - Constructor for class com.google.common.collect.testing.google.AbstractListMultimapTester
 
AbstractListTester<E> - Class in com.google.common.collect.testing.testers
Base class for list testers.
AbstractListTester() - Constructor for class com.google.common.collect.testing.testers.AbstractListTester
 
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
 
AbstractMapTester<K,V> - Class in com.google.common.collect.testing
Base class for map testers.
AbstractMapTester() - Constructor for class com.google.common.collect.testing.AbstractMapTester
 
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
 
AbstractMultimapTester<K,V,M> - Class in com.google.common.collect.testing.google
Superclass for all Multimap testers.
AbstractMultimapTester() - Constructor for class com.google.common.collect.testing.google.AbstractMultimapTester
 
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
 
AbstractMultisetSetCountTester<E> - Class in com.google.common.collect.testing.google
AbstractMultisetSetCountTester() - Constructor for class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
 
AbstractMultisetTester<E> - Class in com.google.common.collect.testing.google
Base class for multiset collection tests.
AbstractMultisetTester() - Constructor for class com.google.common.collect.testing.google.AbstractMultisetTester
 
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
 
AbstractNetwork<N,E> - Class in com.google.common.graph
This class provides a skeletal implementation of Network.
AbstractNetwork() - Constructor for class com.google.common.graph.AbstractNetwork
 
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
 
AbstractPackageSanityTests - Class in com.google.common.testing
Automatically runs sanity checks against top level classes in the same package of the test that extends AbstractPackageSanityTests.
AbstractPackageSanityTests() - Constructor for class com.google.common.testing.AbstractPackageSanityTests
 
AbstractPackageSanityTests.Chopper - Class in com.google.common.testing
 
AbstractQueueTester<E> - Class in com.google.common.collect.testing.testers
Base class for queue collection tests.
AbstractQueueTester() - Constructor for class com.google.common.collect.testing.testers.AbstractQueueTester
 
AbstractRangeSet<C> - 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
 
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.Cancellable - Interface in com.google.common.util.concurrent
 
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.CustomScheduler.SupplantableFuture - Class in com.google.common.util.concurrent
Contains the most recently submitted Future, which may be cancelled or updated, always under a lock.
AbstractScheduledService.FutureAsCancellable - Class in com.google.common.util.concurrent
 
AbstractScheduledService.Scheduler - Class in com.google.common.util.concurrent
A scheduler defines the policy for how the AbstractScheduledService should run its task.
AbstractScheduledService.ServiceDelegate - Class in com.google.common.util.concurrent
 
AbstractScheduledService.ServiceDelegate.Task - Class in com.google.common.util.concurrent
 
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>, int, 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.HasReachedRunningGuard - Class in com.google.common.util.concurrent
 
AbstractService.IsStartableGuard - Class in com.google.common.util.concurrent
 
AbstractService.IsStoppableGuard - Class in com.google.common.util.concurrent
 
AbstractService.IsStoppedGuard - Class in com.google.common.util.concurrent
 
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.
AbstractSetTester<E> - Class in com.google.common.collect.testing.testers
 
AbstractSetTester() - Constructor for class com.google.common.collect.testing.testers.AbstractSetTester
 
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 - 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.
AbstractStreamingHasher(int) - Constructor for class com.google.common.hash.AbstractStreamingHasher
Constructor for use by subclasses.
AbstractStreamingHasher(int, int) - Constructor for class com.google.common.hash.AbstractStreamingHasher
Constructor for use by subclasses.
AbstractStrongKeyEntry(K, int) - Constructor for class com.google.common.collect.MapMakerInternalMap.AbstractStrongKeyEntry
 
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
 
AbstractTester<G> - Class in com.google.common.collect.testing
This abstract base class for testers allows the framework to inject needed information after JUnit constructs the instances.
AbstractTester() - Constructor for class com.google.common.collect.testing.AbstractTester
 
AbstractTransformFuture<I,O,F,T> - Class in com.google.common.util.concurrent
Implementations of Futures.transform*.
AbstractTransformFuture(ListenableFuture<? extends I>, F) - Constructor for class com.google.common.util.concurrent.AbstractTransformFuture
 
AbstractTransformFuture.AsyncTransformFuture<I,O> - Class in com.google.common.util.concurrent
AbstractTransformFuture.TransformFuture<I,O> - Class in com.google.common.util.concurrent
AbstractUndirectedNetworkConnections<N,E> - Class in com.google.common.graph
A base implementation of NetworkConnections for undirected networks.
AbstractUndirectedNetworkConnections(Map<E, N>) - Constructor for class com.google.common.graph.AbstractUndirectedNetworkConnections
 
AbstractValueGraph<N,V> - Class in com.google.common.graph
This class provides a skeletal implementation of ValueGraph.
AbstractValueGraph() - Constructor for class com.google.common.graph.AbstractValueGraph
 
AbstractWeakKeyEntry(ReferenceQueue<K>, K, int) - Constructor for class com.google.common.collect.MapMakerInternalMap.AbstractWeakKeyEntry
 
accept(ClosingFuture.ValueAndCloser<V>) - Method in interface com.google.common.util.concurrent.ClosingFuture.ValueAndCloserConsumer
Accepts a ClosingFuture.ValueAndCloser for the last step in a ClosingFuture pipeline.
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_CH - Static variable in class com.google.common.net.HttpHeaders
The HTTP Accept-CH 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_ALLOW_PRIVATE_NETWORK - Static variable in class com.google.common.net.HttpHeaders
The HTTP Access-Control-Allow-Private-Network 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 class com.google.common.cache.LocalCache.EntryFactory
 
AccessDurationParser() - Constructor for class com.google.common.cache.CacheBuilderSpec.AccessDurationParser
 
accessEntry(int) - Method in class com.google.common.collect.CompactHashMap
Mark an access of the specified entry.
accessEntry(int) - Method in class com.google.common.collect.CompactLinkedHashMap
 
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.Invokable
 
accessOrder - Variable in class com.google.common.collect.CompactLinkedHashMap
 
accessQueue - Variable in class com.google.common.cache.LocalCache.Segment
A queue of elements currently in the map, ordered by access time.
AccessQueue() - Constructor for class com.google.common.cache.LocalCache.AccessQueue
 
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
 
accumulateAndGet(double, DoubleBinaryOperator) - Method in class com.google.common.util.concurrent.AtomicDouble
Atomically updates the current value with the results of applying the given function to the current and given values.
accumulateAndGet(int, double, DoubleBinaryOperator) - Method in class com.google.common.util.concurrent.AtomicDoubleArray
Atomically updates the element at index i with the results of applying the given function to the current and given values.
accumulateAndGet(K, long, LongBinaryOperator) - Method in class com.google.common.util.concurrent.AtomicLongMap
Updates the value currently associated with key by combining it with x via the specified accumulator function, returning the new value.
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).
Acquiring - Search tag in class com.google.common.collect.Ordering
Section
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).
actualContents() - Method in class com.google.common.collect.testing.AbstractCollectionTester
 
actualContents() - Method in class com.google.common.collect.testing.AbstractContainerTester
 
actualContents() - Method in class com.google.common.collect.testing.AbstractMapTester
 
actualContents() - Method in class com.google.common.collect.testing.google.AbstractMultimapTester
 
AD_AUCTION_ALLOWED - Static variable in class com.google.common.net.HttpHeaders
The HTTP Ad-Auction-Allowed header field name.
AD_AUCTION_SIGNALS - Static variable in class com.google.common.net.HttpHeaders
The HTTP Ad-Auction-Signals header field name.
adapterExecutor - Variable in class com.google.common.util.concurrent.JdkFutureAdapters.ListenableFutureAdapter
 
add - Variable in class com.google.common.collect.testing.AbstractIteratorTester
 
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.StatsAccumulator
Adds the given value to the dataset.
add(double) - Method in class com.google.common.primitives.ImmutableDoubleArray.Builder
Appends value to the end of the values the built ImmutableDoubleArray will contain.
add(double, double) - Method in class com.google.common.math.PairedStatsAccumulator
Adds the given pair of values to the dataset.
add(int) - Method in class com.google.common.collect.Count
 
add(int) - Method in class com.google.common.primitives.ImmutableIntArray.Builder
Appends value to the end of the values the built ImmutableIntArray will contain.
add(int, E) - Method in class com.google.common.collect.ForwardingList
 
add(int, E) - Method in class com.google.common.collect.ImmutableList
Deprecated.
Unsupported operation.
add(int, E) - Method in class com.google.common.collect.Lists.AbstractListWrapper
 
add(int, E) - Method in class com.google.common.collect.Synchronized.SynchronizedList
 
add(int, T) - Method in class com.google.common.collect.Lists.ReverseList
 
add(int, V) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedList
 
add(int, V) - Method in class com.google.common.collect.FilteredKeyMultimap.AddRejectingList
 
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(long) - Method in interface com.google.common.hash.LongAddable
 
add(long) - Method in class com.google.common.hash.LongAddables.PureJavaLongAddable
 
add(long) - Method in class com.google.common.hash.LongAdder
Adds the given value.
add(long) - Method in class com.google.common.primitives.ImmutableLongArray.Builder
Appends value to the end of the values the built ImmutableLongArray will contain.
add(Range<C>) - Method in class com.google.common.collect.AbstractRangeSet
 
add(Range<C>) - Method in class com.google.common.collect.ImmutableRangeSet
Deprecated.
Unsupported operation.
add(Range<C>) - Method in class com.google.common.collect.ImmutableRangeSet.Builder
Add the specified range to this builder.
add(Range<C>) - Method in interface com.google.common.collect.RangeSet
Adds the specified range to this RangeSet (optional operation).
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(ListenerCallQueue.Event<L>, Object) - Method in class com.google.common.util.concurrent.ListenerCallQueue.PerListenerQueue
Enqueues an event to be run.
add(E) - Method in class com.google.common.collect.AbstractMultiset
 
add(E) - Method in class com.google.common.collect.CollectCollectors.EnumSetAccumulator
 
add(E) - Method in class com.google.common.collect.Collections2.FilteredCollection
 
add(E) - Method in class com.google.common.collect.CompactHashSet
 
add(E) - Method in class com.google.common.collect.EvictingQueue
Adds the given element to this queue.
add(E) - Method in class com.google.common.collect.ForwardingCollection
 
add(E) - Method in class com.google.common.collect.ForwardingListIterator
 
add(E) - Method in class com.google.common.collect.ImmutableCollection
Deprecated.
Unsupported operation.
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.ImmutableList.Builder
Adds element to the ImmutableList.
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.ImmutableSet.Builder
 
add(E) - Method in class com.google.common.collect.ImmutableSet.EmptySetBuilderImpl
 
add(E) - Method in class com.google.common.collect.ImmutableSet.JdkBackedSetBuilderImpl
 
add(E) - Method in class com.google.common.collect.ImmutableSet.RegularSetBuilderImpl
 
add(E) - Method in class com.google.common.collect.ImmutableSet.SetBuilderImpl
Adds e to this SetBuilderImpl, returning the updated result.
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.ImmutableSortedSet.Builder
Adds element to the ImmutableSortedSet.
add(E) - Method in class com.google.common.collect.MinMaxPriorityQueue
Adds the given element to this queue.
add(E) - Method in interface com.google.common.collect.Multiset
Adds a single occurrence of the specified element to this multiset.
add(E) - Method in class com.google.common.collect.Multisets.UnmodifiableMultiset
 
add(E) - Method in class com.google.common.collect.Sets.SetView
Deprecated.
Unsupported operation.
add(E) - Method in class com.google.common.collect.Synchronized.SynchronizedCollection
 
add(E) - Method in class com.google.common.collect.testing.AbstractIteratorTester.MultiExceptionListIterator
 
add(E) - Method in class com.google.common.collect.testing.SafeTreeSet
 
add(E) - Method in class com.google.common.collect.UnmodifiableListIterator
Deprecated.
Unsupported operation.
add(E...) - Method in class com.google.common.collect.ImmutableCollection.Builder
Adds each element of elements to the ImmutableCollection being built.
add(E...) - Method in class com.google.common.collect.ImmutableList.Builder
Adds each element of elements to the ImmutableList.
add(E...) - Method in class com.google.common.collect.ImmutableMultiset.Builder
Adds each element of elements to the ImmutableMultiset.
add(E...) - Method in class com.google.common.collect.ImmutableSet.Builder
 
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 each element of elements to the ImmutableSortedSet, ignoring duplicate elements (only the first duplicate element is added).
add(E, int) - Method in class com.google.common.collect.AbstractMapBasedMultiset
Adds a number of occurrences of an element to this multiset.
add(E, int) - Method in class com.google.common.collect.AbstractMultiset
 
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, int) - Method in class com.google.common.collect.EnumMultiset
 
add(E, int) - Method in class com.google.common.collect.ForwardingMultiset
 
add(E, int) - Method in class com.google.common.collect.ImmutableMultiset
Deprecated.
Unsupported operation.
add(E, int) - Method in interface com.google.common.collect.Multiset
Adds a number of occurrences of an element to this multiset.
add(E, int) - Method in class com.google.common.collect.Multisets.FilteredMultiset
 
add(E, int) - Method in class com.google.common.collect.Multisets.UnmodifiableMultiset
 
add(E, int) - Method in class com.google.common.collect.Synchronized.SynchronizedMultiset
 
add(E, int) - Method in class com.google.common.collect.TreeMultiset
 
add(AutoCloseable, Executor) - Method in class com.google.common.util.concurrent.ClosingFuture.CloseableList
 
add(Object) - Method in class com.google.common.collect.MoreCollectors.ToOptionalState
 
add(Object[], int) - Method in class com.google.common.collect.ImmutableList.Builder
 
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(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.MoreObjects.ToStringHelper
Adds a name/value pair to the formatted output in name=value format.
add(Comparator<? super E>, E, int, int[]) - Method in class com.google.common.collect.TreeMultiset.AvlNode
 
add(Map.Entry<K, V>) - Method in class com.google.common.collect.LinkedListMultimap.NodeIterator
 
add(Map<Class<?>, Class<?>>, Map<Class<?>, Class<?>>, Class<?>, Class<?>) - Static method in class com.google.common.primitives.Primitives
 
add(T) - Method in class com.google.common.collect.TransformedListIterator
 
add(V) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection
 
add(V) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedList.WrappedListIterator
 
add(V) - Method in class com.google.common.collect.FilteredKeyMultimap.AddRejectingList
 
add(V) - Method in class com.google.common.collect.FilteredKeyMultimap.AddRejectingSet
 
add(V) - Method in class com.google.common.collect.LinkedHashMultimap.ValueSet
 
add(V) - Method in class com.google.common.collect.LinkedListMultimap.ValueForKeyIterator
 
addAll(double...) - Method in class com.google.common.math.StatsAccumulator
Adds the given values to the dataset.
addAll(double[]) - Method in class com.google.common.primitives.ImmutableDoubleArray.Builder
Appends values, in order, to the end of the values the built ImmutableDoubleArray will contain.
addAll(int...) - Method in class com.google.common.math.StatsAccumulator
Adds the given values to the dataset.
addAll(int[]) - Method in class com.google.common.primitives.ImmutableIntArray.Builder
Appends values, in order, to the end of the values the built ImmutableIntArray will contain.
addAll(int, Collection<? extends E>) - Method in class com.google.common.collect.ForwardingList
 
addAll(int, Collection<? extends E>) - Method in class com.google.common.collect.ImmutableList
Deprecated.
Unsupported operation.
addAll(int, Collection<? extends E>) - Method in class com.google.common.collect.Lists.AbstractListWrapper
 
addAll(int, Collection<? extends E>) - Method in class com.google.common.collect.Synchronized.SynchronizedList
 
addAll(int, Collection<? extends V>) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedList
 
addAll(int, Collection<? extends V>) - Method in class com.google.common.collect.FilteredKeyMultimap.AddRejectingList
 
addAll(long...) - Method in class com.google.common.math.StatsAccumulator
Adds the given values to the dataset.
addAll(long[]) - Method in class com.google.common.primitives.ImmutableLongArray.Builder
Appends values, in order, to the end of the values the built ImmutableLongArray will contain.
addAll(RangeSet<C>) - Method in class com.google.common.collect.AbstractRangeSet
 
addAll(RangeSet<C>) - Method in class com.google.common.collect.ImmutableRangeSet
Deprecated.
Unsupported operation.
addAll(RangeSet<C>) - Method in class com.google.common.collect.ImmutableRangeSet.Builder
Add all ranges from the specified range set to this builder.
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(PairedStats) - Method in class com.google.common.math.PairedStatsAccumulator
Adds the given statistics to the dataset, as if the individual values used to compute the statistics had been added directly.
addAll(Stats) - Method in class com.google.common.math.StatsAccumulator
Adds the given statistics to the dataset, as if the individual values used to compute the statistics had been added directly.
addAll(StatsAccumulator) - Method in class com.google.common.math.StatsAccumulator
Adds the given statistics to the dataset, as if the individual values used to compute the statistics had been added directly.
addAll(ImmutableDoubleArray) - Method in class com.google.common.primitives.ImmutableDoubleArray.Builder
Appends values, in order, to the end of the values the built ImmutableDoubleArray will contain.
addAll(ImmutableIntArray) - Method in class com.google.common.primitives.ImmutableIntArray.Builder
Appends values, in order, to the end of the values the built ImmutableIntArray will contain.
addAll(ImmutableLongArray) - Method in class com.google.common.primitives.ImmutableLongArray.Builder
Appends values, in order, to the end of the values the built ImmutableLongArray will contain.
addAll(Iterable<? extends E>) - Method in class com.google.common.collect.ImmutableCollection.Builder
Adds each element of elements to the ImmutableCollection being built.
addAll(Iterable<? 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(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(Iterable<? 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(Iterable<? extends Number>) - Method in class com.google.common.math.StatsAccumulator
Adds the given values to the dataset.
addAll(Iterable<Range<C>>) - Method in class com.google.common.collect.ImmutableRangeSet
Deprecated.
Unsupported operation.
addAll(Iterable<Range<C>>) - Method in class com.google.common.collect.ImmutableRangeSet.Builder
Add all of the specified ranges to this builder.
addAll(Iterable<Range<C>>) - Method in interface com.google.common.collect.RangeSet
Adds all of the specified ranges to this range set (optional operation).
addAll(Iterable<Double>) - Method in class com.google.common.primitives.ImmutableDoubleArray.Builder
Appends values, in order, to the end of the values the built ImmutableDoubleArray will contain.
addAll(Iterable<Integer>) - Method in class com.google.common.primitives.ImmutableIntArray.Builder
Appends values, in order, to the end of the values the built ImmutableIntArray will contain.
addAll(Iterable<Long>) - Method in class com.google.common.primitives.ImmutableLongArray.Builder
Appends values, in order, to the end of the values the built ImmutableLongArray will contain.
addAll(Collection<? extends E>) - Method in class com.google.common.collect.AbstractMultiset
addAll(Collection<? extends E>) - Method in class com.google.common.collect.Collections2.FilteredCollection
 
addAll(Collection<? extends E>) - Method in class com.google.common.collect.EvictingQueue
 
addAll(Collection<? extends E>) - Method in class com.google.common.collect.ForwardingCollection
 
addAll(Collection<? extends E>) - Method in class com.google.common.collect.ImmutableCollection
Deprecated.
Unsupported operation.
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(Collection<? extends E>) - Method in class com.google.common.collect.Sets.SetView
Deprecated.
Unsupported operation.
addAll(Collection<? extends E>) - Method in class com.google.common.collect.Synchronized.SynchronizedCollection
 
addAll(Collection<? extends E>) - Method in class com.google.common.collect.testing.MinimalCollection
 
addAll(Collection<? extends E>) - Method in class com.google.common.collect.testing.SafeTreeSet
 
addAll(Collection<? extends V>) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection
 
addAll(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<E>, Iterable<? extends E>) - Static method in class com.google.common.collect.testing.Helpers
 
addAll(Collection<Double>) - Method in class com.google.common.primitives.ImmutableDoubleArray.Builder
Appends values, in order, to the end of the values the built ImmutableDoubleArray will contain.
addAll(Collection<Integer>) - Method in class com.google.common.primitives.ImmutableIntArray.Builder
Appends values, in order, to the end of the values the built ImmutableIntArray will contain.
addAll(Collection<Long>) - Method in class com.google.common.primitives.ImmutableLongArray.Builder
Appends values, in order, to the end of the values the built ImmutableLongArray will contain.
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(Iterator<? 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.ImmutableList.Builder
Adds each element of elements to the ImmutableList.
addAll(Iterator<? 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.ImmutableSet.Builder
 
addAll(Iterator<? 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.ImmutableSortedSet.Builder
Adds each element of elements to the ImmutableSortedSet, ignoring duplicate elements (only the first duplicate element is added).
addAll(Iterator<? extends Number>) - Method in class com.google.common.math.StatsAccumulator
Adds the given values to the dataset.
addAll(DoubleStream) - Method in class com.google.common.math.StatsAccumulator
Adds the given values to the dataset.
addAll(DoubleStream) - Method in class com.google.common.primitives.ImmutableDoubleArray.Builder
Appends all values from stream, in order, to the end of the values the built ImmutableDoubleArray will contain.
addAll(IntStream) - Method in class com.google.common.math.StatsAccumulator
Adds the given values to the dataset.
addAll(IntStream) - Method in class com.google.common.primitives.ImmutableIntArray.Builder
Appends all values from stream, in order, to the end of the values the built ImmutableIntArray will contain.
addAll(LongStream) - Method in class com.google.common.math.StatsAccumulator
Adds the given values to the dataset.
addAll(LongStream) - Method in class com.google.common.primitives.ImmutableLongArray.Builder
Appends all values from stream, in order, to the end of the values the built ImmutableLongArray will contain.
addAllImpl(Multiset<E>, Multiset<? extends E>) - Static method in class com.google.common.collect.Multisets
A specialization of addAllImpl for when elements is itself a Multiset.
addAllImpl(Multiset<E>, Collection<? extends E>) - Static method in class com.google.common.collect.Multisets
addAllImpl(List<E>, int, Iterable<? extends E>) - Static method in class com.google.common.collect.Lists
An implementation of List.addAll(int, Collection).
addAndGet(double) - Method in class com.google.common.util.concurrent.AtomicDouble
Atomically adds the given value to the current value.
addAndGet(int) - Method in class com.google.common.collect.Count
 
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(FutureCallback<? super V>, Executor) - Method in class com.google.common.util.concurrent.FluentFuture
Registers separate success and failure callbacks to be run when this 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.
addCausalChain(Set<Throwable>, Throwable) - Static method in class com.google.common.util.concurrent.AggregateFuture
Adds the chain to the seen set, and returns whether all the chain was new to us.
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.
addDedupedElement(E) - Method in class com.google.common.collect.ImmutableSet.SetBuilderImpl
Adds e to the insertion-order array of deduplicated elements.
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
 
addDelayedShutdownHook(ExecutorService, Duration) - Static method in class com.google.common.util.concurrent.MoreExecutors
Add a shutdown hook to wait for thread completion in the given service.
addDoneString(StringBuilder) - Method in class com.google.common.util.concurrent.AbstractFuture
 
addEdge(EndpointPair<N>, E) - Method in class com.google.common.graph.ImmutableNetwork.Builder
Adds edge connecting endpoints.
addEdge(EndpointPair<N>, E) - Method in interface com.google.common.graph.MutableNetwork
Adds edge connecting endpoints.
addEdge(EndpointPair<N>, E) - Method in class com.google.common.graph.StandardMutableNetwork
 
addEdge(N, N, E) - Method in class com.google.common.graph.ImmutableNetwork.Builder
Adds edge connecting nodeU to nodeV.
addEdge(N, N, E) - Method in interface com.google.common.graph.MutableNetwork
Adds edge connecting nodeU to nodeV.
addEdge(N, N, E) - Method in class com.google.common.graph.StandardMutableNetwork
 
addEqualityGroup(Object...) - Method in class com.google.common.testing.EqualsTester
Adds equalityGroup with objects that are supposed to be equal to each other and not equal to any other equality groups added to this tester.
addEquivalenceGroup(Iterable<T>) - Method in class com.google.common.testing.EquivalenceTester
 
addEquivalenceGroup(T, T...) - Method in class com.google.common.testing.EquivalenceTester
Adds a group of objects that are supposed to be equivalent to each other and not equivalent to objects in any other equivalence group added to this tester.
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.
addException(Collection<IOException>, IOException) - Static method in class com.google.common.io.MoreFiles
Adds the given exception to the given collection, creating the collection if it's null.
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
 
addImpliedFeatures(Set<Feature<?>>) - Static method in class com.google.common.collect.testing.features.FeatureUtil
Given a set of features, add to it all the features directly or indirectly implied by any of them, and return it.
addInEdge(E, N, boolean) - Method in class com.google.common.graph.AbstractDirectedNetworkConnections
 
addInEdge(E, N, boolean) - Method in class com.google.common.graph.AbstractUndirectedNetworkConnections
 
addInEdge(E, N, boolean) - Method in class com.google.common.graph.DirectedMultiNetworkConnections
 
addInEdge(E, N, boolean) - Method in interface com.google.common.graph.NetworkConnections
Add edge to the set of incoming edges.
addInEdge(E, N, boolean) - Method in class com.google.common.graph.UndirectedMultiNetworkConnections
 
addInitialException(Set<Throwable>) - Method in class com.google.common.util.concurrent.AggregateFuture
 
addInitialException(Set<Throwable>) - Method in class com.google.common.util.concurrent.AggregateFutureState
Populates seen with the exception that was passed to setException.
Additional documentation - Search tag in interface com.google.common.graph.Graph
Section
Additional documentation - Search tag in interface com.google.common.graph.Network
Section
Additional documentation - Search tag in interface com.google.common.graph.PredecessorsFunction
Section
Additional documentation - Search tag in interface com.google.common.graph.SuccessorsFunction
Section
Additional documentation - Search tag in interface com.google.common.graph.ValueGraph
Section
Additional notes - Search tag in class com.google.common.collect.Ordering
Section
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(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(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, Executor) - Method in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState
 
addListener(Runnable, Executor) - Method in class com.google.common.util.concurrent.AbstractFuture
Registers a listener to be run on the given executor.
addListener(Runnable, Executor) - Method in class com.google.common.util.concurrent.AbstractFuture.TrustedFuture
 
addListener(Runnable, Executor) - Method in class com.google.common.util.concurrent.FluentFuture.TrustedFuture
 
addListener(Runnable, Executor) - Method in class com.google.common.util.concurrent.ForwardingFluentFuture
 
addListener(Runnable, Executor) - Method in class com.google.common.util.concurrent.ForwardingListenableFuture
 
addListener(Runnable, Executor) - Method in class com.google.common.util.concurrent.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(L, Executor) - Method in class com.google.common.util.concurrent.ListenerCallQueue
Adds a listener that will be called using the given executor when events are later enqueued and dispatched.
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.
addNode(N) - Method in class com.google.common.graph.ImmutableGraph.Builder
Adds node if it is not already present.
addNode(N) - Method in class com.google.common.graph.ImmutableNetwork.Builder
Adds node if it is not already present.
addNode(N) - Method in class com.google.common.graph.ImmutableValueGraph.Builder
Adds node if it is not already present.
addNode(N) - Method in interface com.google.common.graph.MutableGraph
Adds node if it is not already present.
addNode(N) - Method in interface com.google.common.graph.MutableNetwork
Adds node if it is not already present.
addNode(N) - Method in interface com.google.common.graph.MutableValueGraph
Adds node if it is not already present.
addNode(N) - Method in class com.google.common.graph.StandardMutableGraph
 
addNode(N) - Method in class com.google.common.graph.StandardMutableNetwork
 
addNode(N) - Method in class com.google.common.graph.StandardMutableValueGraph
 
addNodeInternal(N) - Method in class com.google.common.graph.StandardMutableNetwork
Adds node to the graph and returns the associated NetworkConnections.
addNodeInternal(N) - Method in class com.google.common.graph.StandardMutableValueGraph
Adds node to the graph and returns the associated GraphConnections.
addOutEdge(E, N) - Method in class com.google.common.graph.AbstractDirectedNetworkConnections
 
addOutEdge(E, N) - Method in class com.google.common.graph.AbstractUndirectedNetworkConnections
 
addOutEdge(E, N) - Method in class com.google.common.graph.DirectedMultiNetworkConnections
 
addOutEdge(E, N) - Method in interface com.google.common.graph.NetworkConnections
Add edge to the set of outgoing edges.
addOutEdge(E, N) - Method in class com.google.common.graph.UndirectedMultiNetworkConnections
 
addPendingString(StringBuilder) - Method in class com.google.common.util.concurrent.AbstractFuture
 
addPredecessor(N, V) - Method in class com.google.common.graph.DirectedGraphConnections
 
addPredecessor(N, V) - Method in interface com.google.common.graph.GraphConnections
Add node as a predecessor to the origin node.
addPredecessor(N, V) - Method in class com.google.common.graph.UndirectedGraphConnections
 
AddRejectingList(K) - Constructor for class com.google.common.collect.FilteredKeyMultimap.AddRejectingList
 
AddRejectingSet(K) - Constructor for class com.google.common.collect.FilteredKeyMultimap.AddRejectingSet
 
addRelatedGroup(Iterable<? extends T>) - Method in class com.google.common.testing.RelationshipTester
 
addRightChild(E, int) - Method in class com.google.common.collect.TreeMultiset.AvlNode
 
addSampleInstances(Class<T>, Iterable<? extends T>) - Method in class com.google.common.testing.FreshValueGenerator
 
addShutdownHook(Thread) - Method in class com.google.common.util.concurrent.MoreExecutors.Application
 
addSuccessor(N, V) - Method in class com.google.common.graph.DirectedGraphConnections
 
addSuccessor(N, V) - Method in interface com.google.common.graph.GraphConnections
Add node as a successor to the origin node.
addSuccessor(N, V) - Method in class com.google.common.graph.UndirectedGraphConnections
 
addTearDown(TearDown) - Method in interface com.google.common.testing.TearDownAccepter
Registers a TearDown implementor which will be run after the test proper.
addTearDown(TearDown) - Method in class com.google.common.testing.TearDownStack
 
addToCache(MapRetrievalCache.CacheEntry<K, V>) - Method in class com.google.common.graph.MapRetrievalCache
 
addToCache(K, V) - Method in class com.google.common.graph.MapRetrievalCache
 
addToMap() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection
Add the delegate to the map.
addUnconditionalHolder() - Method in class com.google.common.base.MoreObjects.ToStringHelper
 
addUnconditionalHolder(Object) - Method in class com.google.common.base.MoreObjects.ToStringHelper
 
addUnconditionalHolder(String, Object) - Method in class com.google.common.base.MoreObjects.ToStringHelper
 
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.MoreObjects.ToStringHelper
Adds an unnamed value to the formatted output.
adjacentEdges(E) - Method in class com.google.common.graph.AbstractNetwork
 
adjacentEdges(E) - Method in class com.google.common.graph.ForwardingNetwork
 
adjacentEdges(E) - Method in interface com.google.common.graph.Network
Returns a live view of the edges which have an incident node in common with edge.
adjacentNode(E) - Method in class com.google.common.graph.AbstractDirectedNetworkConnections
 
adjacentNode(E) - Method in class com.google.common.graph.AbstractUndirectedNetworkConnections
 
adjacentNode(E) - Method in interface com.google.common.graph.NetworkConnections
Returns the node that is adjacent to the origin node along edge.
adjacentNode(N) - Method in class com.google.common.graph.EndpointPair
Returns the node that is adjacent to node along the origin edge.
adjacentNodeFn(Network<N, E>, N) - Static method in class com.google.common.graph.ImmutableNetwork
 
adjacentNodes() - Method in class com.google.common.graph.AbstractDirectedNetworkConnections
 
adjacentNodes() - Method in class com.google.common.graph.DirectedGraphConnections
 
adjacentNodes() - Method in interface com.google.common.graph.GraphConnections
 
adjacentNodes() - Method in interface com.google.common.graph.NetworkConnections
 
adjacentNodes() - Method in class com.google.common.graph.UndirectedGraphConnections
 
adjacentNodes() - Method in class com.google.common.graph.UndirectedMultiNetworkConnections
 
adjacentNodes() - Method in class com.google.common.graph.UndirectedNetworkConnections
 
adjacentNodes(N) - Method in interface com.google.common.graph.BaseGraph
Returns a live view of the nodes which have an incident edge in common with node in this graph.
adjacentNodes(N) - Method in class com.google.common.graph.ForwardingGraph
 
adjacentNodes(N) - Method in class com.google.common.graph.ForwardingNetwork
 
adjacentNodes(N) - Method in class com.google.common.graph.ForwardingValueGraph
 
adjacentNodes(N) - Method in interface com.google.common.graph.Graph
Returns a live view of the nodes which have an incident edge in common with node in this graph.
adjacentNodes(N) - Method in interface com.google.common.graph.Network
Returns a live view of the nodes which have an incident edge in common with node in this graph.
adjacentNodes(N) - Method in class com.google.common.graph.StandardNetwork
 
adjacentNodes(N) - Method in class com.google.common.graph.StandardValueGraph
 
adjacentNodes(N) - Method in interface com.google.common.graph.ValueGraph
Returns a live view of the nodes which have an incident edge in common with node in this graph.
adjacentNodesMultiset() - Method in class com.google.common.graph.UndirectedMultiNetworkConnections
 
adjacentNodesReference - Variable in class com.google.common.graph.UndirectedMultiNetworkConnections
 
adjacentNodeValues - Variable in class com.google.common.graph.DirectedGraphConnections
 
adjacentNodeValues - Variable in class com.google.common.graph.UndirectedGraphConnections
 
adjustAfterRemove(int, int) - Method in class com.google.common.collect.CompactHashMap
Updates the index an iterator is pointing to after a call to remove: returns the index of the entry that should be looked at after a removal on indexRemoved, with indexBeforeRemove as the index that *was* the next entry that would be looked at.
adjustAfterRemove(int, int) - Method in class com.google.common.collect.CompactHashSet
Updates the index an iterator is pointing to after a call to remove: returns the index of the entry that should be looked at after a removal on indexRemoved, with indexBeforeRemove as the index that *was* the next entry that would be looked at.
adjustAfterRemove(int, int) - Method in class com.google.common.collect.CompactLinkedHashMap
 
adjustAfterRemove(int, int) - Method in class com.google.common.collect.CompactLinkedHashSet
 
ADLER_32 - Enum constant in enum class com.google.common.hash.Hashing.ChecksumType
 
adler32() - Static method in class com.google.common.hash.Hashing
Returns a hash function implementing the Adler-32 checksum algorithm (32 hash bits).
advance() - Method in class com.google.common.cache.LocalCache.HashIterator
 
advance() - Method in class com.google.common.collect.MapMakerInternalMap.HashIterator
 
advance() - Method in class com.google.common.graph.EndpointPairIterator
Called after EndpointPairIterator.successorIterator is exhausted.
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.
advance(long) - Method in class com.google.common.testing.FakeTicker
Advances the ticker value by nanoseconds.
advance(long, TimeUnit) - Method in class com.google.common.testing.FakeTicker
Advances the ticker value by time in timeUnit.
advance(Duration) - Method in class com.google.common.testing.FakeTicker
Advances the ticker value by duration.
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.
advanceTo(ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.HashIterator
Advances to the given entry.
advanceTo(E) - Method in class com.google.common.collect.MapMakerInternalMap.HashIterator
Advances to the given entry.
AFTER_LAST - Static variable in class com.google.common.collect.testing.SampleElements.Strings
 
AFTER_LAST_2 - Static variable in class com.google.common.collect.testing.SampleElements.Strings
 
afterDone() - Method in class com.google.common.util.concurrent.AbstractCatchingFuture
 
afterDone() - Method in class com.google.common.util.concurrent.AbstractFuture
Callback method that is called exactly once after the future is completed.
afterDone() - Method in class com.google.common.util.concurrent.AbstractTransformFuture
 
afterDone() - Method in class com.google.common.util.concurrent.AggregateFuture
 
afterDone() - Method in class com.google.common.util.concurrent.Futures.InCompletionOrderFuture
 
afterDone() - Method in class com.google.common.util.concurrent.Futures.NonCancellationPropagatingFuture
 
afterDone() - Method in class com.google.common.util.concurrent.TimeoutFuture
 
afterDone() - Method in class com.google.common.util.concurrent.TrustedListenableFutureTask
 
afterEveryChars - Variable in class com.google.common.io.BaseEncoding.SeparatedBaseEncoding
 
afterRanInterruptiblyFailure(Throwable) - Method in class com.google.common.util.concurrent.CombinedFuture.CombinedFutureInterruptibleTask
 
afterRanInterruptiblyFailure(Throwable) - Method in class com.google.common.util.concurrent.InterruptibleTask
Any interruption that happens as a result of calling interruptTask will arrive before this method is called.
afterRanInterruptiblyFailure(Throwable) - Method in class com.google.common.util.concurrent.TrustedListenableFutureTask.TrustedFutureInterruptibleAsyncTask
 
afterRanInterruptiblyFailure(Throwable) - Method in class com.google.common.util.concurrent.TrustedListenableFutureTask.TrustedFutureInterruptibleTask
 
afterRanInterruptiblySuccess(ListenableFuture<V>) - Method in class com.google.common.util.concurrent.TrustedListenableFutureTask.TrustedFutureInterruptibleAsyncTask
 
afterRanInterruptiblySuccess(T) - Method in class com.google.common.util.concurrent.CombinedFuture.CombinedFutureInterruptibleTask
 
afterRanInterruptiblySuccess(T) - Method in class com.google.common.util.concurrent.InterruptibleTask
Any interruption that happens as a result of calling interruptTask will arrive before this method is called.
afterRanInterruptiblySuccess(V) - Method in class com.google.common.util.concurrent.TrustedListenableFutureTask.TrustedFutureInterruptibleTask
 
AGE - Static variable in class com.google.common.net.HttpHeaders
The HTTP Age header field name.
Aggregate() - Constructor for enum class 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
 
AggregateFuture<InputT,OutputT> - Class in com.google.common.util.concurrent
A future whose value is derived from a collection of input futures.
AggregateFuture(ImmutableCollection<? extends ListenableFuture<? extends InputT>>, boolean, boolean) - Constructor for class com.google.common.util.concurrent.AggregateFuture
 
AggregateFuture.ReleaseResourcesReason - Enum Class in com.google.common.util.concurrent
 
AggregateFutureState<OutputT> - Class in com.google.common.util.concurrent
A helper which does some thread-safe operations for aggregate futures, which must be implemented differently in GWT.
AggregateFutureState(int) - Constructor for class com.google.common.util.concurrent.AggregateFutureState
 
AggregateFutureState.AtomicHelper - Class in com.google.common.util.concurrent
 
AggregateFutureState.SafeAtomicHelper - Class in com.google.common.util.concurrent
 
AggregateFutureState.SynchronizedAtomicHelper - Class in com.google.common.util.concurrent
 
algorithmName - Variable in class com.google.common.hash.MessageDigestHashFunction.SerializedForm
 
all() - Static method in class com.google.common.collect.ImmutableRangeSet
Returns an immutable range set containing the single range Range.all().
all() - Static method in class com.google.common.collect.Range
Returns a range that contains every value of type C.
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(Comparator<? super T>) - Static method in class com.google.common.collect.GeneralRange
Returns the whole range relative to the specified comparator.
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.ImmutableRangeSet
 
ALL - Static variable in class com.google.common.collect.Range
 
ALL_INPUT_FUTURES_PROCESSED - Enum constant in enum class com.google.common.util.concurrent.AggregateFuture.ReleaseResourcesReason
 
ALL_SET - Static variable in class com.google.common.util.concurrent.Striped
A bit mask were all bits are set.
ALL_STRATEGIES - Static variable in enum class com.google.common.collect.testing.SpliteratorTester.SpliteratorDecompositionStrategy
 
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.AggregateFuture
 
allMustSucceed - Variable in class com.google.common.util.concurrent.ClosingFuture.Combiner
 
allMustSucceed - Variable in class com.google.common.util.concurrent.Futures.FutureCombiner
 
allocArrays() - Method in class com.google.common.collect.CompactHashMap
Handle lazy allocation of arrays.
allocArrays() - Method in class com.google.common.collect.CompactHashSet
Handle lazy allocation of arrays.
allocArrays() - Method in class com.google.common.collect.CompactLinkedHashMap
 
allocArrays() - Method in class com.google.common.collect.CompactLinkedHashSet
 
ALLOW - Static variable in class com.google.common.net.HttpHeaders
The HTTP Allow header field name.
ALLOW_INSECURE - Enum constant in enum class com.google.common.io.RecursiveDeleteOption
Specifies that the recursive delete should not throw an exception when it can't be guaranteed that it can be done securely, without vulnerability to race conditions (i.e.
AllowConcurrentEvents - Annotation Interface 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.
allowNulls - Variable in class com.google.common.collect.testing.MinimalCollection
 
ALLOWS_ANY_NULL_QUERIES - Enum constant in enum class com.google.common.collect.testing.features.MapFeature
The map does not throw NullPointerException on any null queries.
ALLOWS_NULL_ENTRY_QUERIES - Enum constant in enum class com.google.common.collect.testing.features.MapFeature
The map does not throw NullPointerException on calls such as entrySet().contains(null) or entrySet().remove(null)
ALLOWS_NULL_KEY_QUERIES - Enum constant in enum class com.google.common.collect.testing.features.MapFeature
The map does not throw NullPointerException on calls such as containsKey(null), get(null), keySet().contains(null) or remove(null).
ALLOWS_NULL_KEYS - Enum constant in enum class com.google.common.collect.testing.features.MapFeature
 
ALLOWS_NULL_QUERIES - Enum constant in enum class com.google.common.collect.testing.features.CollectionFeature
The collection must not throw NullPointerException on calls such as contains(null) or remove(null), but instead must return a simple false.
ALLOWS_NULL_VALUE_QUERIES - Enum constant in enum class com.google.common.collect.testing.features.MapFeature
The map does not throw NullPointerException on calls such as containsValue(null), values().contains(null) or values().remove(null).
ALLOWS_NULL_VALUES - Enum constant in enum class com.google.common.collect.testing.features.CollectionFeature
 
ALLOWS_NULL_VALUES - Enum constant in enum class com.google.common.collect.testing.features.MapFeature
 
allowsNullKeys - Variable in class com.google.common.collect.testing.MapInterfaceTest
 
allowsNullValues - Variable in class com.google.common.collect.testing.MapInterfaceTest
 
allowsParallelEdges - Variable in class com.google.common.graph.NetworkBuilder
 
allowsParallelEdges - Variable in class com.google.common.graph.StandardNetwork
 
allowsParallelEdges() - Method in class com.google.common.graph.ForwardingNetwork
 
allowsParallelEdges() - Method in interface com.google.common.graph.Network
Returns true if this network allows parallel edges.
allowsParallelEdges() - Method in class com.google.common.graph.StandardNetwork
 
allowsParallelEdges(boolean) - Method in class com.google.common.graph.NetworkBuilder
Specifies whether the network will allow parallel edges.
allowsSelfLoops - Variable in class com.google.common.graph.AbstractGraphBuilder
 
allowsSelfLoops - Variable in class com.google.common.graph.StandardNetwork
 
allowsSelfLoops - Variable in class com.google.common.graph.StandardValueGraph
 
allowsSelfLoops() - Method in interface com.google.common.graph.BaseGraph
Returns true if this graph allows self-loops (edges that connect a node to itself).
allowsSelfLoops() - Method in class com.google.common.graph.ForwardingGraph
 
allowsSelfLoops() - Method in class com.google.common.graph.ForwardingNetwork
 
allowsSelfLoops() - Method in class com.google.common.graph.ForwardingValueGraph
 
allowsSelfLoops() - Method in interface com.google.common.graph.Graph
Returns true if this graph allows self-loops (edges that connect a node to itself).
allowsSelfLoops() - Method in interface com.google.common.graph.Network
Returns true if this network allows self-loops (edges that connect a node to itself).
allowsSelfLoops() - Method in class com.google.common.graph.StandardNetwork
 
allowsSelfLoops() - Method in class com.google.common.graph.StandardValueGraph
 
allowsSelfLoops() - Method in interface com.google.common.graph.ValueGraph
Returns true if this graph allows self-loops (edges that connect a node to itself).
allowsSelfLoops(boolean) - Method in class com.google.common.graph.GraphBuilder
Specifies whether the graph will allow self-loops (edges that connect a node to itself).
allowsSelfLoops(boolean) - Method in class com.google.common.graph.NetworkBuilder
Specifies whether the network will allow self-loops (edges that connect a node to itself).
allowsSelfLoops(boolean) - Method in class com.google.common.graph.ValueGraphBuilder
Specifies whether the graph will allow self-loops (edges that connect a node to itself).
allPrimitiveTypes() - Static method in class com.google.common.primitives.Primitives
Returns an immutable set of all nine primitive types (including void).
allTests() - Method in class com.google.common.collect.testing.TestsForListsInJavaUtil
 
allTests() - Method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
allTests() - Method in class com.google.common.collect.testing.TestsForQueuesInJavaUtil
 
allTests() - Method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
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 - Variable in class com.google.common.io.BaseEncoding.StandardBaseEncoding
 
Alphabet(String, char[]) - Constructor for class com.google.common.io.BaseEncoding.Alphabet
 
Alphabet(String, char[], byte[], boolean) - Constructor for class com.google.common.io.BaseEncoding.Alphabet
 
ALTERNATE_ADVANCE_AND_SPLIT - Enum constant in enum class com.google.common.collect.testing.SpliteratorTester.SpliteratorDecompositionStrategy
 
Alternatives - Search tag in class com.google.common.util.concurrent.FluentFuture
Section
ALWAYS_FALSE - Enum constant in enum class com.google.common.base.Predicates.ObjectPredicate
 
ALWAYS_TRUE - Enum constant in enum class com.google.common.base.Predicates.ObjectPredicate
 
AlwaysEqual() - Constructor for class com.google.common.testing.ArbitraryInstances.AlwaysEqual
 
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(double, double) - Method in class com.google.common.math.LinearTransformation.LinearTransformationBuilder
Finish building an instance which also maps x = x2 to y = y2.
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) - Method in class com.google.common.base.CharMatcher.Any
 
and(CharMatcher) - Method in class com.google.common.base.CharMatcher.Is
 
and(CharMatcher) - Method in class com.google.common.base.CharMatcher.IsNot
 
and(CharMatcher) - Method in class com.google.common.base.CharMatcher.None
 
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.
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(CharMatcher, CharMatcher) - Constructor for class com.google.common.base.CharMatcher.And
 
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.
AnEnum - Enum Class in com.google.common.collect.testing
A sample enumerated type we use for testing.
AnEnum() - Constructor for enum class com.google.common.collect.testing.AnEnum
 
ANNOTATED_TYPE_EXISTS - Static variable in class com.google.common.reflect.Invokable
 
annotatedType - Variable in class com.google.common.reflect.Parameter
An AnnotatedType instance, or null under Android VMs (possible only when using the Android flavor of Guava).
annotatedTypeExists() - Static method in class com.google.common.testing.NullPointerTester
 
annotationCache - Static variable in class com.google.common.collect.testing.features.FeatureUtil
A cache of annotated objects (typically a Class or Method) to its set of annotations.
annotations - Variable in class com.google.common.reflect.Parameter
 
any() - Static method 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(Type[]) - Static method in class com.google.common.reflect.TypeToken
 
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.
Any() - Constructor for class com.google.common.base.CharMatcher.Any
 
ANY - Enum constant in enum class com.google.common.collect.testing.features.CollectionSize
 
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_FONT_TYPE - Static variable in class com.google.common.net.MediaType
Wildcard matching any "font" top-level media type.
ANY_IMAGE_TYPE - Static variable in class com.google.common.net.MediaType
 
ANY_PRESENT - Enum constant in enum class com.google.common.collect.SortedLists.KeyPresentBehavior
Return the index of any list element that compares as equal to the key.
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
 
ANY4 - Static variable in class com.google.common.net.InetAddresses
 
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 BMP character present in the given character sequence.
AnyOf(CharSequence) - Constructor for class com.google.common.base.CharMatcher.AnyOf
 
append(char) - Method in class com.google.common.io.AppendableWriter
 
append(char) - Method in class com.google.common.io.CharStreams.NullWriter
 
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(CharSequence) - 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.AppendableWriter
 
append(CharSequence, int, int) - Method in class com.google.common.io.CharStreams.NullWriter
 
append(CharSequence, File, Charset) - Static method in class com.google.common.io.Files
Deprecated.
Prefer asCharSink(to, charset, FileWriteMode.APPEND).write(from). This method is scheduled to be removed in October 2019.
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 - Enum constant in enum class com.google.common.io.FileWriteMode
Specifies that writes to the opened file should append to the end of the file.
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.
appendResultObject(StringBuilder, Object) - Method in class com.google.common.util.concurrent.AbstractFuture
Any object can be the result of a Future, and not every object has a reasonable toString() implementation.
appendTo(A, Iterable<? extends 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, 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, 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(A, Iterator<? extends 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, 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(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, Iterable<? extends 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, 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, 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(StringBuilder, Iterator<? extends 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, 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.
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.
appendUserObject(StringBuilder, Object) - Method in class com.google.common.util.concurrent.AbstractFuture
Helper for printing user supplied objects into our toString method.
APPLE_MOBILE_CONFIG - Static variable in class com.google.common.net.MediaType
APPLE_PASSBOOK - 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(double, long) - Method in interface com.google.common.collect.Streams.DoubleFunctionWithIndex
Applies this function to the given argument and its index within a stream.
apply(int, long) - Method in interface com.google.common.collect.Streams.IntFunctionWithIndex
Applies this function to the given argument and its index within a stream.
apply(long, long) - Method in interface com.google.common.collect.Streams.LongFunctionWithIndex
Applies this function to the given argument and its index within a stream.
apply(A) - Method in class com.google.common.base.Converter
Deprecated.
Provided to satisfy the Function interface; use Converter.convert(A) instead.
apply(A) - Method in class com.google.common.base.Functions.FunctionComposition
 
apply(A) - Method in class com.google.common.base.Predicates.CompositionPredicate
 
apply(C) - Method in class com.google.common.collect.Range
Deprecated.
Provided only to satisfy the Predicate interface; use Range.contains(C) instead.
apply(Supplier<Object>) - Method in enum class com.google.common.base.Suppliers.SupplierFunctionImpl
 
apply(ClosingFuture.DeferredCloser, T) - Method in interface com.google.common.util.concurrent.ClosingFuture.AsyncClosingFunction
Applies this function to an input, or throws an exception if unable to do so.
apply(ClosingFuture.DeferredCloser, T) - Method in interface com.google.common.util.concurrent.ClosingFuture.ClosingFunction
Applies this function to an input, or throws an exception if unable to do so.
apply(ClosingFuture.DeferredCloser, V1, V2) - Method in interface com.google.common.util.concurrent.ClosingFuture.Combiner2.AsyncClosingFunction2
Applies this function to two inputs, or throws an exception if unable to do so.
apply(ClosingFuture.DeferredCloser, V1, V2) - Method in interface com.google.common.util.concurrent.ClosingFuture.Combiner2.ClosingFunction2
Applies this function to two inputs, or throws an exception if unable to do so.
apply(ClosingFuture.DeferredCloser, V1, V2, V3) - Method in interface com.google.common.util.concurrent.ClosingFuture.Combiner3.AsyncClosingFunction3
Applies this function to three inputs, or throws an exception if unable to do so.
apply(ClosingFuture.DeferredCloser, V1, V2, V3) - Method in interface com.google.common.util.concurrent.ClosingFuture.Combiner3.ClosingFunction3
Applies this function to three inputs, or throws an exception if unable to do so.
apply(ClosingFuture.DeferredCloser, V1, V2, V3, V4) - Method in interface com.google.common.util.concurrent.ClosingFuture.Combiner4.AsyncClosingFunction4
Applies this function to four inputs, or throws an exception if unable to do so.
apply(ClosingFuture.DeferredCloser, V1, V2, V3, V4) - Method in interface com.google.common.util.concurrent.ClosingFuture.Combiner4.ClosingFunction4
Applies this function to four inputs, or throws an exception if unable to do so.
apply(ClosingFuture.DeferredCloser, V1, V2, V3, V4, V5) - Method in interface com.google.common.util.concurrent.ClosingFuture.Combiner5.AsyncClosingFunction5
Applies this function to five inputs, or throws an exception if unable to do so.
apply(ClosingFuture.DeferredCloser, V1, V2, V3, V4, V5) - Method in interface com.google.common.util.concurrent.ClosingFuture.Combiner5.ClosingFunction5
Applies this function to five inputs, or throws an exception if unable to do so.
apply(E) - Method in class com.google.common.collect.Interners.InternerFunction
 
apply(F) - Method in interface com.google.common.base.Function
 
apply(F) - Method in class com.google.common.base.Functions.SupplierFunction
 
apply(I) - Method in interface com.google.common.util.concurrent.AsyncFunction
Returns an output Future to use in place of the given input.
apply(Character) - Method in class com.google.common.base.CharMatcher
Deprecated.
Provided only to satisfy the Predicate interface; use CharMatcher.matches(char) instead.
apply(Character) - Method in class com.google.common.base.CharMatcher.ForPredicate
 
apply(CharSequence) - Method in class com.google.common.base.Predicates.ContainsPatternPredicate
 
apply(Class<?>) - Method in class com.google.common.base.Predicates.SubtypeOfPredicate
 
apply(Iterable<E>) - Method in class com.google.common.collect.FluentIterable.FromIterableFunction
 
apply(Object) - Method in class com.google.common.base.Functions.ConstantFunction
 
apply(Object) - Method in enum class com.google.common.base.Functions.IdentityFunction
 
apply(Object) - Method in enum class com.google.common.base.Functions.ToStringFunction
 
apply(Object) - Method in class com.google.common.base.Predicates.IsEqualToPredicate
 
apply(Object, V) - Method in class com.google.common.collect.Maps.AbstractFilteredMap
 
apply(K) - Method in class com.google.common.base.Functions.ForMapWithDefault
 
apply(K) - Method in class com.google.common.base.Functions.FunctionForMapNoDefault
 
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(T) - Method in class com.google.common.base.Equivalence.EquivalentToPredicate
 
apply(T) - Method in class com.google.common.base.Functions.PredicateFunction
 
apply(T) - Method in interface com.google.common.base.Predicate
Returns the result of applying this predicate to input (Java 8+ users, see notes in the class documentation above).
apply(T) - Method in class com.google.common.base.Predicates.AndPredicate
 
apply(T) - Method in class com.google.common.base.Predicates.InPredicate
 
apply(T) - Method in class com.google.common.base.Predicates.InstanceOfPredicate
 
apply(T) - Method in class com.google.common.base.Predicates.NotPredicate
 
apply(T) - Method in class com.google.common.base.Predicates.OrPredicate
 
apply(T) - Method in class com.google.common.hash.BloomFilter
Deprecated.
Provided only to satisfy the Predicate interface; use BloomFilter.mightContain(T) instead.
apply(T, long) - Method in interface com.google.common.collect.Streams.FunctionWithIndex
Applies this function to the given argument and its index within a stream.
apply(V) - Method in class com.google.common.collect.FilteredEntryMultimap.ValuePredicate
 
applyAsyncClosingFunction(ClosingFuture.AsyncClosingFunction<V, U>, V) - Method in class com.google.common.util.concurrent.ClosingFuture.CloseableList
 
applyClosingFunction(ClosingFuture.ClosingFunction<? super V, U>, V) - Method in class com.google.common.util.concurrent.ClosingFuture.CloseableList
 
approximateElementCount() - Method in class com.google.common.hash.BloomFilter
Returns an estimate for the total number of distinct elements that have been added to this Bloom filter.
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
 
arbitraryConstantInstanceOrNull(Class<T>) - Static method in class com.google.common.testing.ArbitraryInstances
 
ArbitraryInstances - Class in com.google.common.testing
Supplies an arbitrary "default" instance for a wide range of types, often useful in testing utilities.
ArbitraryInstances() - Constructor for class com.google.common.testing.ArbitraryInstances
 
ArbitraryInstances.AlwaysEqual - Class in com.google.common.testing
 
ArbitraryInstances.ByToString - Class in com.google.common.testing
 
ArbitraryInstances.Dummies - Class in com.google.common.testing
 
ArbitraryInstances.Dummies.DeterministicRandom - Class in com.google.common.testing
 
ArbitraryInstances.Dummies.DummyCountDownLatch - Class in com.google.common.testing
 
ArbitraryInstances.Dummies.DummyExecutor - Class in com.google.common.testing
 
ArbitraryInstances.Dummies.DummyRunnable - Class in com.google.common.testing
 
ArbitraryInstances.Dummies.DummyScheduledThreadPoolExecutor - Class in com.google.common.testing
 
ArbitraryInstances.Dummies.DummyThreadFactory - Class in com.google.common.testing
 
ArbitraryInstances.Dummies.InMemoryPrintStream - Class in com.google.common.testing
 
ArbitraryInstances.Dummies.InMemoryPrintWriter - Class in com.google.common.testing
 
ArbitraryInstances.NullByteSink - Class in com.google.common.testing
 
arbitraryNullFriendlyComparator() - Static method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
arbitraryNullFriendlyComparator() - Static method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
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
 
areEqual(double, double) - Static method in class com.google.common.primitives.ImmutableDoubleArray
 
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.Iterators.ArrayItr
 
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.ImmutableDoubleArray
 
array - Variable in class com.google.common.primitives.ImmutableDoubleArray.Builder
 
array - Variable in class com.google.common.primitives.ImmutableIntArray
 
array - Variable in class com.google.common.primitives.ImmutableIntArray.Builder
 
array - Variable in class com.google.common.primitives.ImmutableLongArray
 
array - Variable in class com.google.common.primitives.ImmutableLongArray.Builder
 
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.
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(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.
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.
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(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.
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.
ArrayItr(T[], int) - Constructor for class com.google.common.collect.Iterators.ArrayItr
 
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
 
ArrayListMultimapGwtSerializationDependencies<K,V> - Class in com.google.common.collect
A dummy superclass to support GWT serialization of the element types of an ArrayListMultimap.
ArrayListMultimapGwtSerializationDependencies(Map<K, Collection<V>>) - Constructor for class com.google.common.collect.ArrayListMultimapGwtSerializationDependencies
 
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
 
ArrayTable<R,C,V> - Class in com.google.common.collect
Fixed-size Table implementation backed by a two-dimensional array.
ArrayTable(ArrayTable<R, C, V>) - Constructor for class com.google.common.collect.ArrayTable
 
ArrayTable(Table<R, C, ? extends V>) - Constructor for class com.google.common.collect.ArrayTable
 
ArrayTable(Iterable<? extends R>, Iterable<? extends C>) - 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
 
ArrayWithDuplicate(E[], E) - Constructor for class com.google.common.collect.testing.AbstractContainerTester.ArrayWithDuplicate
 
asAsyncCallable(Callable<T>, ListeningExecutorService) - Static method in class com.google.common.util.concurrent.Callables
Creates an AsyncCallable from a Callable.
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.
asByteSink(Path, OpenOption...) - Static method in class com.google.common.io.MoreFiles
Returns a view of the given path as a ByteSink.
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() - Method in class com.google.common.reflect.ClassPath.ResourceInfo
Returns a ByteSource view of the resource from which its bytes can be read.
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.
asByteSource(Charset) - Method in class com.google.common.io.ByteSource.AsCharSource
 
asByteSource(Charset) - Method in class com.google.common.io.CharSource
Returns a ByteSource view of this char source that encodes chars read from this source as bytes using the given Charset.
asByteSource(Path, OpenOption...) - Static method in class com.google.common.io.MoreFiles
Returns a view of the given path as a ByteSource.
AsByteSource(Charset) - Constructor for class com.google.common.io.CharSource.AsByteSource
 
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.
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(Path, Charset, OpenOption...) - Static method in class com.google.common.io.MoreFiles
Returns a view of the given path as a CharSink using the given charset.
AsCharSink(Charset) - Constructor for class com.google.common.io.ByteSink.AsCharSink
 
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.
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) - Method in class com.google.common.io.ByteSource.EmptyByteSource
 
asCharSource(Charset) - Method in class com.google.common.io.CharSource.AsByteSource
 
asCharSource(Charset) - Method in class com.google.common.io.MoreFiles.PathByteSource
 
asCharSource(Charset) - Method in class com.google.common.reflect.ClassPath.ResourceInfo
Returns a CharSource view of the resource from which its bytes can be read as characters decoded with the given charset.
asCharSource(Path, Charset, OpenOption...) - Static method in class com.google.common.io.MoreFiles
Returns a view of the given path as a CharSource using the given charset.
AsCharSource(Charset) - Constructor for class com.google.common.io.ByteSource.AsCharSource
 
ascii() - Static method in class com.google.common.base.CharMatcher
Determines whether a character is ASCII, meaning that its code point is less than 128.
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() - Constructor for class com.google.common.base.CharMatcher.Ascii
 
asciiDigits - Static variable in class com.google.common.primitives.Longs.AsciiDigits
 
AsciiDigits() - Constructor for class com.google.common.primitives.Longs.AsciiDigits
 
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().
asDescendingMapOfRanges() - Method in class com.google.common.collect.ImmutableRangeMap
 
asDescendingMapOfRanges() - Method in interface com.google.common.collect.RangeMap
Returns a view of this range map as an unmodifiable Map<Range<K>, V>.
asDescendingMapOfRanges() - Method in class com.google.common.collect.TreeRangeMap
 
asDescendingMapOfRanges() - Method in class com.google.common.collect.TreeRangeMap.SubRangeMap
 
asDescendingSetOfRanges - Variable in class com.google.common.collect.TreeRangeSet
 
asDescendingSetOfRanges() - Method in class com.google.common.collect.ImmutableRangeSet
 
asDescendingSetOfRanges() - Method in interface com.google.common.collect.RangeSet
Returns a descending view of the disconnected ranges that make up this range set.
asDescendingSetOfRanges() - Method in class com.google.common.collect.TreeRangeSet
 
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 - 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.
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.
asGraph() - Method in class com.google.common.graph.AbstractNetwork
 
asGraph() - Method in class com.google.common.graph.AbstractValueGraph
 
asGraph() - Method in class com.google.common.graph.ImmutableNetwork
 
asGraph() - Method in class com.google.common.graph.ImmutableValueGraph
 
asGraph() - Method in interface com.google.common.graph.Network
Returns a live view of this network as a Graph.
asGraph() - Method in interface com.google.common.graph.ValueGraph
Returns a live view of this graph as a Graph.
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.
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 - Variable in class com.google.common.collect.ImmutableMultiset
 
asList - Variable in class com.google.common.collect.ImmutableSet.CachingAsList
 
asList() - Method in class com.google.common.collect.EmptyContiguousSet
 
asList() - Method in class com.google.common.collect.ImmutableCollection
Returns an ImmutableList containing the same elements, in the same order, as this collection.
asList() - Method in class com.google.common.collect.ImmutableList
Deprecated.
There is no reason to use this; it always returns this.
asList() - Method in class com.google.common.collect.ImmutableMapValues
 
asList() - Method in class com.google.common.collect.ImmutableMultiset
 
asList() - Method in class com.google.common.collect.ImmutableSet.CachingAsList
 
asList() - Method in class com.google.common.collect.SingletonImmutableSet
 
asList() - Method in class com.google.common.collect.testing.SampleElements
 
asList() - Method in class com.google.common.primitives.ImmutableDoubleArray
Returns an immutable view of this array's values as a List; note that double values are boxed into Double instances on demand, which can be very expensive.
asList() - Method in class com.google.common.primitives.ImmutableIntArray
Returns an immutable view of this array's values as a List; note that int values are boxed into Integer instances on demand, which can be very expensive.
asList() - Method in class com.google.common.primitives.ImmutableLongArray
Returns an immutable view of this array's values as a List; note that long values are boxed into Long instances on demand, which can be very expensive.
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[]).
asList(Predicate<? super T>, Predicate<? super T>) - Static method in class com.google.common.base.Predicates
 
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(ImmutableDoubleArray) - Constructor for class com.google.common.primitives.ImmutableDoubleArray.AsList
 
AsList(ImmutableIntArray) - Constructor for class com.google.common.primitives.ImmutableIntArray.AsList
 
AsList(ImmutableLongArray) - Constructor for class com.google.common.primitives.ImmutableLongArray.AsList
 
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 - Variable in class com.google.common.collect.AbstractMultimap
 
asMap - Variable in class com.google.common.collect.Synchronized.SynchronizedMultimap
 
asMap - Variable in class com.google.common.util.concurrent.AtomicLongMap
 
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() - 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() - Method in class com.google.common.collect.EmptyImmutableListMultimap
 
asMap() - Method in class com.google.common.collect.EmptyImmutableSetMultimap
 
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() - 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() - 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() - 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() - Method in class com.google.common.util.concurrent.AtomicLongMap
Returns a live, read-only view of the map backing this AtomicLongMap.
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(Multimap<K, V>) - Static method in class com.google.common.collect.Multimaps
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(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(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() - Constructor for class com.google.common.collect.FilteredEntryMultimap.AsMap
 
AsMap(Multimap<K, V>) - Constructor for class com.google.common.collect.Multimaps.AsMap
 
AsMap(Map<K, Collection<V>>) - Constructor for class com.google.common.collect.AbstractMapBasedMultimap.AsMap
 
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
 
AsMapGenerator(OneSizeTestContainerGenerator<M, Map.Entry<K, V>>) - Constructor for class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.AsMapGenerator
 
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() - Method in class com.google.common.collect.TreeRangeMap.SubRangeMap
 
AsMapOfRanges(Iterable<TreeRangeMap.RangeMapEntry<K, V>>) - Constructor for class com.google.common.collect.TreeRangeMap.AsMapOfRanges
 
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.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.
asRanges - Variable in class com.google.common.collect.TreeRangeSet
 
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() - Method in class com.google.common.collect.TreeRangeSet
 
AsRanges(Collection<Range<C>>) - Constructor for class com.google.common.collect.TreeRangeSet.AsRanges
 
assertArrayEquals(String, Object[], Object[]) - Static method in class com.google.common.collect.testing.testers.ListToArrayTester
 
assertBasic(Escaper) - Static method in class com.google.common.escape.testing.EscaperAsserts
Asserts that an escaper behaves correctly with respect to null inputs.
assertCleared() - Method in class com.google.common.collect.testing.google.MultimapClearTester
 
assertCollectionIsUnmodifiable(Collection<E>, E) - Static method in class com.google.common.collect.testing.google.UnmodifiableCollectionTests
Verifies that a collection is immutable.
assertCollectionsAreEquivalent(Collection<E>, Collection<E>) - Static method in class com.google.common.collect.testing.google.UnmodifiableCollectionTests
 
assertContains(Iterable<?>, Object) - Static method in class com.google.common.collect.testing.Helpers
 
assertContainsAllOf(Iterable<?>, Object...) - Static method in class com.google.common.collect.testing.Helpers
 
assertContentsAnyOrder(Iterable<?>, Object...) - Static method in class com.google.common.collect.testing.Helpers
 
assertContentsInOrder(Iterable<?>, Object...) - Static method in class com.google.common.collect.testing.Helpers
 
assertEmpty(Multimap<?, ?>) - Static method in class com.google.common.collect.testing.google.GoogleHelpers
 
assertEmpty(Iterable<?>) - Static method in class com.google.common.collect.testing.Helpers
 
assertEmpty(Map<?, ?>) - Static method in class com.google.common.collect.testing.Helpers
 
assertEntrySetNotContainsString(Set<Map.Entry<K, V>>) - Method in class com.google.common.collect.testing.MapInterfaceTest
 
assertEqualIgnoringOrder(Iterable<?>, Iterable<?>) - Static method in class com.google.common.collect.testing.Helpers
 
assertEqualInOrder(Iterable<?>, Iterable<?>) - Static method in class com.google.common.collect.testing.Helpers
 
assertEquivalent(R, R) - Method in class com.google.common.testing.CollectorTester
 
assertEscaping(CharEscaper, String, char) - Static method in class com.google.common.escape.testing.EscaperAsserts
Asserts that an escaper escapes the given character into the expected string.
assertEscaping(UnicodeEscaper, String, int) - Static method in class com.google.common.escape.testing.EscaperAsserts
Asserts that a Unicode escaper escapes the given code point into the expected string.
assertException(Throwable) - Method in class com.google.common.util.concurrent.testing.MockFutureListener
Verify that the listener completes in a reasonable amount of time, and Asserts that the future throws an ExecutableException and that the cause of the ExecutableException is expectedCause.
assertGet(K, Collection<? extends V>) - Method in class com.google.common.collect.testing.google.AbstractListMultimapTester
 
assertGet(K, Collection<? extends V>) - Method in class com.google.common.collect.testing.google.AbstractMultimapTester
 
assertGet(K, V...) - Method in class com.google.common.collect.testing.google.AbstractListMultimapTester
 
assertGet(K, V...) - Method in class com.google.common.collect.testing.google.AbstractMultimapTester
 
assertInvariants(Map<K, V>) - Method in class com.google.common.collect.testing.MapInterfaceTest
Checks all the properties that should always hold of a map.
assertIteratorIsUnmodifiable(Iterator<?>) - Static method in class com.google.common.collect.testing.google.UnmodifiableCollectionTests
Verifies that an Iterator is unmodifiable.
assertIteratorsInOrder(Iterator<?>, Iterator<?>) - Static method in class com.google.common.collect.testing.google.UnmodifiableCollectionTests
Asserts that two iterators contain elements in tandem.
assertMapEntryIsUnmodifiable(Map.Entry<?, ?>) - Static method in class com.google.common.collect.testing.google.UnmodifiableCollectionTests
 
assertMoreInvariants(Map<K, V>) - Method in class com.google.common.collect.testing.MapInterfaceTest
Override this to check invariants which should hold true for a particular implementation, but which are not generally applicable to every instance of Map.
assertMultimapIsUnmodifiable(Multimap<K, V>, K, V) - Static method in class com.google.common.collect.testing.google.UnmodifiableCollectionTests
Verifies that a multimap is immutable.
assertMultimapRemainsUnmodified(Multimap<K, V>, List<Map.Entry<K, V>>) - Static method in class com.google.common.collect.testing.google.UnmodifiableCollectionTests
 
assertMultisetIsUnmodifiable(Multiset<E>, E) - Static method in class com.google.common.collect.testing.google.UnmodifiableCollectionTests
Verifies that a multiset is immutable.
assertOneToOne() - Method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
 
assertPermitted(Exception) - Method in exception class com.google.common.collect.testing.AbstractIteratorTester.PermittedMetaException
 
assertRelated(int, int, int) - Method in class com.google.common.testing.RelationshipTester
 
assertSetCount(E, int) - Method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
 
assertSetCountDecreasingFailure(E, int) - Method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
 
assertSetCountIncreasingFailure(E, int) - Method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
 
assertSetCountNegativeOldCount() - Method in class com.google.common.collect.testing.google.MultisetSetCountConditionallyTester
 
assertSetIsUnmodifiable(Set<E>, E) - Static method in class com.google.common.collect.testing.google.UnmodifiableCollectionTests
Verifies that a set is immutable.
assertSuccess(Object) - Method in class com.google.common.util.concurrent.testing.MockFutureListener
Verify that the listener completes in a reasonable amount of time, and Asserts that the future returns the expected data.
assertThreeToThree() - Method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
 
assertTimeout() - Method in class com.google.common.util.concurrent.testing.MockFutureListener
 
assertUnescaped(CharEscaper, char) - Static method in class com.google.common.escape.testing.EscaperAsserts
Asserts that an escaper does not escape the given character.
assertUnescaped(UnicodeEscaper, int) - Static method in class com.google.common.escape.testing.EscaperAsserts
Asserts that a Unicode escaper does not escape the given character.
assertUnicodeEscaping(UnicodeEscaper, String, char, char) - Static method in class com.google.common.escape.testing.EscaperAsserts
Asserts that a Unicode escaper escapes the given hi/lo surrogate pair into the expected string.
assertUnrelated(int, int, int, int) - Method in class com.google.common.testing.RelationshipTester
 
assertWithTemplate(String, RelationshipTester.Item<T>, RelationshipTester.Item<T>, boolean) - Method in class com.google.common.testing.RelationshipTester
 
assertZeroToZero() - Method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
 
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
 
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.
AsyncCallable<V> - Interface in com.google.common.util.concurrent
Computes a value, possibly asynchronously.
AsyncCallableInterruptibleTask(AsyncCallable<V>, Executor) - Constructor for class com.google.common.util.concurrent.CombinedFuture.AsyncCallableInterruptibleTask
 
AsyncCatchingFuture(ListenableFuture<? extends V>, Class<X>, AsyncFunction<? super X, ? extends V>) - Constructor for class com.google.common.util.concurrent.AbstractCatchingFuture.AsyncCatchingFuture
 
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) - 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.
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.
AsyncTransformFuture(ListenableFuture<? extends I>, AsyncFunction<? super I, ? extends O>) - Constructor for class com.google.common.util.concurrent.AbstractTransformFuture.AsyncTransformFuture
 
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
 
ATOMIC_HELPER - Static variable in class com.google.common.util.concurrent.AbstractFuture
 
ATOMIC_HELPER - Static variable in class com.google.common.util.concurrent.AggregateFutureState
 
AtomicDouble - Class in com.google.common.util.concurrent
A double value that may be updated atomically.
AtomicDouble() - Constructor for class com.google.common.util.concurrent.AtomicDouble
Creates a new AtomicDouble with initial value 0.0.
AtomicDouble(double) - Constructor for class com.google.common.util.concurrent.AtomicDouble
Creates a new AtomicDouble with the given initial value.
AtomicDoubleArray - Class in com.google.common.util.concurrent
A double array in which elements may be updated atomically.
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.
AtomicDoubleArray(int) - Constructor for class com.google.common.util.concurrent.AtomicDoubleArray
Creates a new AtomicDoubleArray of the given length, with all elements initially zero.
AtomicHelper() - Constructor for class com.google.common.util.concurrent.AbstractFuture.AtomicHelper
 
AtomicHelper() - Constructor for class com.google.common.util.concurrent.AggregateFutureState.AtomicHelper
 
AtomicLongMap<K> - Class in com.google.common.util.concurrent
A map containing long values that can be atomically updated.
AtomicLongMap(ConcurrentHashMap<K, Long>) - 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
 
autoIncrementStepNanos - Variable in class com.google.common.testing.FakeTicker
 
Automatically closing - Search tag in class com.google.common.util.concurrent.ClosingFuture
Section
available() - Method in class com.google.common.io.ByteStreams.LimitedInputStream
 
available() - Method in class com.google.common.io.MultiInputStream
 
availableCapacity(Buffer) - Static method in class com.google.common.io.ReaderInputStream
Returns the number of elements between the limit and capacity.
aValidIndex() - Method in class com.google.common.collect.testing.testers.ListSetTester
 
averageLoadPenalty() - Method in class com.google.common.cache.CacheStats
Returns the average time spent loading new values.
AvlNode() - Constructor for class com.google.common.collect.TreeMultiset.AvlNode
Constructor for the header node.
AvlNode(E, int) - Constructor for class com.google.common.collect.TreeMultiset.AvlNode
 
Avoid EventBus - Search tag in class com.google.common.eventbus.EventBus
Section
await() - Method in class com.google.common.util.concurrent.ForwardingCondition
 
await(long, TimeUnit) - Method in class com.google.common.util.concurrent.ForwardingCondition
 
await(Monitor.Guard, boolean) - Method in class com.google.common.util.concurrent.Monitor
 
await(CountDownLatch) - Static method in class com.google.common.testing.GcFinalization
Waits until the given latch has counted down to zero, invoking the garbage collector as necessary to try to ensure that this will happen.
awaitClear(WeakReference<?>) - Static method in class com.google.common.testing.GcFinalization
Waits until the given weak reference is cleared, invoking the garbage collector as necessary to try to ensure that this will happen.
awaitDone(GcFinalization.FinalizationPredicate) - Static method in class com.google.common.testing.GcFinalization
Waits until the given predicate returns true, invoking the garbage collector as necessary to try to ensure that this will happen.
awaitDone(Future<?>) - Static method in class com.google.common.testing.GcFinalization
Waits until the given future is done, invoking the garbage collector as necessary to try to ensure that this will happen.
awaitFullGc() - Static method in class com.google.common.testing.GcFinalization
Tries to perform a "full" garbage collection cycle (including processing of weak references and invocation of finalize methods) and waits for it to complete.
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.
AwaitHealthGuard() - Constructor for class com.google.common.util.concurrent.ServiceManager.ServiceManagerState.AwaitHealthGuard
 
awaitHealthy() - Method in class com.google.common.util.concurrent.ServiceManager
Waits for the ServiceManager to become healthy.
awaitHealthy() - Method in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState
 
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(long, TimeUnit) - Method in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState
 
awaitHealthy(Duration) - Method in class com.google.common.util.concurrent.ServiceManager
Waits for the ServiceManager to become healthy for no more than the given time.
awaitNanos(long) - Method in class com.google.common.util.concurrent.ForwardingCondition
 
awaitNanos(Monitor.Guard, long, boolean) - Method in class com.google.common.util.concurrent.Monitor
Caller should check before calling that guard is not satisfied.
awaitRunning() - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
 
awaitRunning() - Method in class com.google.common.util.concurrent.AbstractIdleService
 
awaitRunning() - Method in class com.google.common.util.concurrent.AbstractScheduledService
 
awaitRunning() - 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 class com.google.common.util.concurrent.AbstractExecutionThreadService
 
awaitRunning(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractIdleService
 
awaitRunning(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractScheduledService
 
awaitRunning(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractService
 
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.
awaitRunning(Duration) - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
 
awaitRunning(Duration) - Method in class com.google.common.util.concurrent.AbstractIdleService
 
awaitRunning(Duration) - Method in class com.google.common.util.concurrent.AbstractScheduledService
 
awaitRunning(Duration) - Method in class com.google.common.util.concurrent.AbstractService
 
awaitRunning(Duration) - 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() - Method in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState
 
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(long, TimeUnit) - Method in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState
 
awaitStopped(Duration) - 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.
awaitTerminated() - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
 
awaitTerminated() - Method in class com.google.common.util.concurrent.AbstractIdleService
 
awaitTerminated() - Method in class com.google.common.util.concurrent.AbstractScheduledService
 
awaitTerminated() - 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 class com.google.common.util.concurrent.AbstractExecutionThreadService
 
awaitTerminated(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractIdleService
 
awaitTerminated(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractScheduledService
 
awaitTerminated(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractService
 
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.
awaitTerminated(Duration) - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
 
awaitTerminated(Duration) - Method in class com.google.common.util.concurrent.AbstractIdleService
 
awaitTerminated(Duration) - Method in class com.google.common.util.concurrent.AbstractScheduledService
 
awaitTerminated(Duration) - Method in class com.google.common.util.concurrent.AbstractService
 
awaitTerminated(Duration) - 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.DirectExecutorService
 
awaitTermination(long, TimeUnit) - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
awaitTermination(long, TimeUnit) - Method in class com.google.common.util.concurrent.MoreExecutors.ListeningDecorator
 
awaitTermination(long, TimeUnit) - Method in class com.google.common.util.concurrent.testing.SameThreadScheduledExecutorService
 
awaitTermination(long, TimeUnit) - Method in class com.google.common.util.concurrent.testing.TestingExecutors.NoOpScheduledExecutorService
 
awaitTermination(long, TimeUnit) - Method in class com.google.common.util.concurrent.WrappingExecutorService
 
awaitTermination(Duration) - Method in interface com.google.common.util.concurrent.ListeningExecutorService
awaitTerminationUninterruptibly(ExecutorService) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes executor.awaitTermination(long, TimeUnit) uninterruptibly with no timeout.
awaitTerminationUninterruptibly(ExecutorService, long, TimeUnit) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes executor.awaitTermination(long, TimeUnit) uninterruptibly.
awaitTerminationUninterruptibly(ExecutorService, Duration) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes executor.awaitTermination(long, TimeUnit) uninterruptibly.
awaitUninterruptibly() - Method in class com.google.common.util.concurrent.ForwardingCondition
 
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.
awaitUninterruptibly(CountDownLatch, Duration) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes latch.await(timeout, unit) uninterruptibly.
awaitUninterruptibly(Condition, long, TimeUnit) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes condition.await(timeout, unit) uninterruptibly.
awaitUninterruptibly(Condition, Duration) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes condition.await(timeout, unit) uninterruptibly.
awaitUntil(Date) - Method in class com.google.common.util.concurrent.ForwardingCondition
 
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.collect.Streams.TemporaryPair
 
b - Variable in class com.google.common.collect.testing.google.MultisetNavigationTester
 
b - Variable in class com.google.common.collect.testing.testers.NavigableMapNavigationTester
 
b - Variable in class com.google.common.collect.testing.testers.NavigableSetNavigationTester
 
b - Variable in class com.google.common.collect.testing.testers.SortedSetNavigationTester
 
b - Variable in class com.google.common.hash.SipHashFunction.SipHasher
 
B - Enum constant in enum class com.google.common.collect.testing.AnEnum
 
BACK - Enum constant in enum class com.google.common.graph.Traverser.InsertionOrder
 
backingGraph - Variable in class com.google.common.graph.ImmutableGraph
 
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 - Variable in class com.google.common.collect.AbstractMapBasedMultiset
 
backingMap - Variable in class com.google.common.collect.MutableClassToInstanceMap.SerializedForm
 
backingMap - Variable in class com.google.common.collect.StandardTable
 
backingMap - Variable in class com.google.common.graph.MapIteratorCache
 
backingMap - Variable in class com.google.common.reflect.MutableTypeToInstanceMap
 
backingMap() - Method in class com.google.common.collect.AbstractMapBasedMultimap
 
backingMap() - Method in class com.google.common.collect.AbstractSortedKeySortedSetMultimap
 
backingRowMap - Variable in class com.google.common.collect.StandardTable.Row
 
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
 
backingValueGraph - Variable in class com.google.common.graph.StandardMutableGraph
 
backward - Variable in class com.google.common.collect.testing.google.BiMapInverseTester.BiMapPair
 
backwardDelegate - Variable in class com.google.common.collect.JdkBackedImmutableBiMap
 
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.
base - Variable in class com.google.common.hash.Striped64
Base value, used mainly when there is no contention, but also as a fallback during table initialization races.
base16() - Static method in class com.google.common.io.BaseEncoding
The "base16" encoding specified by RFC 4648 section 8, Base 16 Encoding.
BASE16 - Static variable in class com.google.common.io.BaseEncoding
 
Base16Encoding(BaseEncoding.Alphabet) - Constructor for class com.google.common.io.BaseEncoding.Base16Encoding
 
Base16Encoding(String, String) - Constructor for class com.google.common.io.BaseEncoding.Base16Encoding
 
base32() - Static method in class com.google.common.io.BaseEncoding
The "base32" encoding specified by RFC 4648 section 6, Base 32 Encoding.
BASE32 - Static variable in class com.google.common.io.BaseEncoding
 
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 method in class com.google.common.io.BaseEncoding
The "base64" base encoding specified by RFC 4648 section 4, Base 64 Encoding.
BASE64 - Static variable in class com.google.common.io.BaseEncoding
 
BASE64_URL - Static variable in class com.google.common.io.BaseEncoding
 
Base64Encoding(BaseEncoding.Alphabet, Character) - Constructor for class com.google.common.io.BaseEncoding.Base64Encoding
 
Base64Encoding(String, String, Character) - Constructor for class com.google.common.io.BaseEncoding.Base64Encoding
 
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.)
BaseComparable - Class in com.google.common.collect.testing
Simple base class to verify that we handle generics correctly.
BaseComparable(String) - Constructor for class com.google.common.collect.testing.BaseComparable
 
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.Base16Encoding - Class in com.google.common.io
 
BaseEncoding.Base64Encoding - Class in com.google.common.io
 
BaseEncoding.DecodingException - Exception Class 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
 
BaseGraph<N> - Interface in com.google.common.graph
A non-public interface for the methods shared between Graph and ValueGraph.
BaseImmutableMultimap<K,V> - Class in com.google.common.collect
A dummy superclass of ImmutableMultimap that can be instanceof'd without ProGuard retaining additional implementation details of ImmutableMultimap.
BaseImmutableMultimap() - Constructor for class com.google.common.collect.BaseImmutableMultimap
 
baseOffset - Static variable in class com.google.common.cache.Striped64
 
baseOffset - Static variable in class com.google.common.hash.Striped64
 
BASIC_AUDIO - Static variable in class com.google.common.net.MediaType
Basic Audio, as defined by RFC 2046.
becomeSubsumedInto(ClosingFuture.CloseableList) - Method in class com.google.common.util.concurrent.ClosingFuture
 
BEFORE_FIRST - Static variable in class com.google.common.collect.testing.SampleElements.Strings
 
BEFORE_FIRST_2 - Static variable in class com.google.common.collect.testing.SampleElements.Strings
 
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.
beingCalled - Variable in class com.google.common.util.concurrent.ClosingFuture.Peeker
 
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
 
belowSamplesGreater() - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.MapSortedKeySetGenerator
 
belowSamplesGreater() - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.SortedMapSubmapTestMapGenerator
 
belowSamplesGreater() - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.SortedSetSubsetTestSetGenerator
 
belowSamplesGreater() - Method in class com.google.common.collect.testing.NavigableMapTestSuiteBuilder.DescendingTestMapGenerator
 
belowSamplesGreater() - Method in interface com.google.common.collect.testing.TestSortedMapGenerator
Returns an entry with a key less than the keys of the TestContainerGenerator.samples() but greater than the key of TestSortedMapGenerator.belowSamplesLesser().
belowSamplesGreater() - Method in interface com.google.common.collect.testing.TestSortedSetGenerator
Returns an element less than the TestContainerGenerator.samples() but greater than TestSortedSetGenerator.belowSamplesLesser().
belowSamplesGreater() - Method in class com.google.common.collect.testing.TestStringSortedMapGenerator
 
belowSamplesGreater() - Method in class com.google.common.collect.testing.TestStringSortedSetGenerator
 
belowSamplesLesser() - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.MapSortedKeySetGenerator
 
belowSamplesLesser() - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.SortedMapSubmapTestMapGenerator
 
belowSamplesLesser() - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.SortedSetSubsetTestSetGenerator
 
belowSamplesLesser() - Method in class com.google.common.collect.testing.NavigableMapTestSuiteBuilder.DescendingTestMapGenerator
 
belowSamplesLesser() - Method in interface com.google.common.collect.testing.TestSortedMapGenerator
Returns an entry with a key less than the keys of the TestContainerGenerator.samples() and less than the key of TestSortedMapGenerator.belowSamplesGreater().
belowSamplesLesser() - Method in interface com.google.common.collect.testing.TestSortedSetGenerator
belowSamplesLesser() - Method in class com.google.common.collect.testing.TestStringSortedMapGenerator
 
belowSamplesLesser() - Method in class com.google.common.collect.testing.TestStringSortedSetGenerator
 
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
 
BEST_VALIDATOR - Static variable in class com.google.common.util.concurrent.FuturesGetChecked.GetCheckedTypeValidatorHolder
 
bestGetCheckedTypeValidator() - Static method in class com.google.common.util.concurrent.FuturesGetChecked
 
Beta - Annotation Interface 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 class com.google.common.primitives.UnsignedBytes.LexicographicalComparatorHolder.UnsafeComparator
 
BigDecimalMath - Class in com.google.common.math
A class for arithmetic on BigDecimal that is not covered by its built-in methods.
BigDecimalMath() - Constructor for class com.google.common.math.BigDecimalMath
 
BigDecimalMath.BigDecimalToDoubleRounder - Class in com.google.common.math
 
BigDecimalToDoubleRounder() - Constructor for class com.google.common.math.BigDecimalMath.BigDecimalToDoubleRounder
 
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
 
BigIntegerMath.BigIntegerToDoubleRounder - Class in com.google.common.math
 
bigIntegers() - Static method in class com.google.common.collect.DiscreteDomain
Returns the discrete domain for values of type BigInteger.
BigIntegerToDoubleRounder() - Constructor for class com.google.common.math.BigIntegerMath.BigIntegerToDoubleRounder
 
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.
bigThreadConstructor - Static variable in class com.google.common.base.internal.Finalizer
 
bigToDouble(BigInteger) - Static method in class com.google.common.math.DoubleUtils
 
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
 
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.
BiMapClearTester<K,V> - Class in com.google.common.collect.testing.google
Tester for BiMap.clear.
BiMapClearTester() - Constructor for class com.google.common.collect.testing.google.BiMapClearTester
 
BiMapConverter(BiMap<A, B>) - Constructor for class com.google.common.collect.Maps.BiMapConverter
 
BiMapEntry(Map.Entry<K, V>) - Constructor for class com.google.common.collect.AbstractBiMap.BiMapEntry
 
BiMapEntrySetTester<K,V> - Class in com.google.common.collect.testing.google
Tester for BiMap.entrySet and methods on the entries in the set.
BiMapEntrySetTester() - Constructor for class com.google.common.collect.testing.google.BiMapEntrySetTester
 
BiMapGenerators - Class in com.google.common.collect.testing.google
Generators of various BiMaps and derived collections.
BiMapGenerators() - Constructor for class com.google.common.collect.testing.google.BiMapGenerators
 
BiMapGenerators.ImmutableBiMapCopyOfEntriesGenerator - Class in com.google.common.collect.testing.google
 
BiMapGenerators.ImmutableBiMapCopyOfGenerator - Class in com.google.common.collect.testing.google
 
BiMapGenerators.ImmutableBiMapGenerator - Class in com.google.common.collect.testing.google
 
BiMapInverseTester<K,V> - Class in com.google.common.collect.testing.google
Tests for the inverse view of a BiMap.
BiMapInverseTester() - Constructor for class com.google.common.collect.testing.google.BiMapInverseTester
 
BiMapInverseTester.BiMapPair<K,V> - Class in com.google.common.collect.testing.google
 
BiMapPair(BiMap<K, V>) - Constructor for class com.google.common.collect.testing.google.BiMapInverseTester.BiMapPair
 
BiMapPutTester<K,V> - Class in com.google.common.collect.testing.google
Tester for BiMap.put and BiMap.forcePut.
BiMapPutTester() - Constructor for class com.google.common.collect.testing.google.BiMapPutTester
 
BiMapRemoveTester<K,V> - Class in com.google.common.collect.testing.google
Tester for BiMap.remove.
BiMapRemoveTester() - Constructor for class com.google.common.collect.testing.google.BiMapRemoveTester
 
BiMapTestSuiteBuilder<K,V> - Class in com.google.common.collect.testing.google
Creates, based on your criteria, a JUnit test suite that exhaustively tests a BiMap implementation.
BiMapTestSuiteBuilder() - Constructor for class com.google.common.collect.testing.google.BiMapTestSuiteBuilder
 
BiMapTestSuiteBuilder.NoRecurse - Enum Class in com.google.common.collect.testing.google
 
BiMapValueSetGenerator(OneSizeTestContainerGenerator<BiMap<K, V>, Map.Entry<K, V>>) - Constructor for class com.google.common.collect.testing.google.DerivedGoogleCollectionGenerators.BiMapValueSetGenerator
 
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<? 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.
binarySearch(List<? extends T>, T) - Method in class com.google.common.collect.Ordering
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.
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.
bitCount - Variable in class com.google.common.hash.BloomFilterStrategies.LockFreeBitArray
 
bitCount() - Method in class com.google.common.hash.BloomFilterStrategies.LockFreeBitArray
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 - Variable in class com.google.common.hash.MacHashFunction
 
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.FarmHashFingerprint64
 
bits() - Method in class com.google.common.hash.Fingerprint2011
 
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() - Method in class com.google.common.hash.Hashing.ConcatenatedHashFunction
 
bits() - Method in class com.google.common.hash.MacHashFunction
 
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.LockFreeBitArray
Number of bits
bitsPerChar - Variable in class com.google.common.io.BaseEncoding.Alphabet
 
Blocker(InterruptibleTask<?>) - Constructor for class com.google.common.util.concurrent.InterruptibleTask.Blocker
 
BloomFilter<T> - Class in com.google.common.hash
A Bloom filter for instances of T.
BloomFilter(BloomFilterStrategies.LockFreeBitArray, 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 Class 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 class com.google.common.hash.BloomFilterStrategies
 
BloomFilterStrategies.LockFreeBitArray - Class in com.google.common.hash
Models a lock-free array of bits.
bmix64(long, long) - Method in class com.google.common.hash.Murmur3_128HashFunction.Murmur3_128Hasher
 
BMP - Static variable in class com.google.common.net.MediaType
Bitmap file format (bmp files).
BooleanArrayAsList(boolean[]) - Constructor for class com.google.common.primitives.Booleans.BooleanArrayAsList
 
BooleanArrayAsList(boolean[], int, int) - Constructor for class com.google.common.primitives.Booleans.BooleanArrayAsList
 
BooleanComparator(int, String) - Constructor for enum class com.google.common.primitives.Booleans.BooleanComparator
 
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.BooleanComparator - Enum Class in com.google.common.primitives
Comparators for Boolean values.
Booleans.LexicographicalComparator - Enum Class in com.google.common.primitives
 
Bound() - Constructor for enum class com.google.common.collect.testing.DerivedCollectionGenerators.Bound
 
Bound() - Constructor for enum class com.google.common.collect.testing.google.SortedMultisetTestSuiteBuilder.Bound
 
boundAsSuperclass(Type) - Method in class com.google.common.reflect.TypeToken
 
bounds - Variable in class com.google.common.reflect.Types.TypeVariableImpl
 
bounds - Variable in class com.google.common.reflect.TypeToken.Bounds
 
Bounds(Type[], boolean) - Constructor for class com.google.common.reflect.TypeToken.Bounds
 
boundsAsInterfaces(Type[]) - Method in class com.google.common.reflect.TypeToken
 
BoundType - Enum Class in com.google.common.collect
Indicates whether an endpoint of some range is contained in the range itself ("closed") or not ("open").
BoundType(boolean) - Constructor for enum class com.google.common.collect.BoundType
 
breadthFirst(Iterable<? extends N>) - Method in class com.google.common.graph.Traverser
Returns an unmodifiable Iterable over the nodes reachable from any of the startNodes, in the order of a breadth-first traversal.
breadthFirst(Iterator<? extends N>) - Method in class com.google.common.graph.Traverser.Traversal
 
breadthFirst(N) - Method in class com.google.common.graph.Traverser
Returns an unmodifiable Iterable over the nodes reachable from startNode, in the order of a breadth-first traversal.
BreadthFirstIterator(T) - Constructor for class com.google.common.collect.TreeTraverser.BreadthFirstIterator
Deprecated.
 
breadthFirstTraversal(T) - Method in class com.google.common.collect.TreeTraverser
Deprecated.
Use Traverser.breadthFirst(N) instead, which has the same behavior.
breakingWhitespace() - Static method 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).
BreakingWhitespace() - Constructor for class com.google.common.base.CharMatcher.BreakingWhitespace
 
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.
BucketOverflowException() - Constructor for exception class com.google.common.collect.RegularImmutableMap.BucketOverflowException
 
buf - Variable in class com.google.common.io.LineReader
 
buffer - Variable in class com.google.common.collect.TopKSelector
 
buffer - Variable in class com.google.common.hash.AbstractStreamingHasher
Buffer via which we pass data to the hash algorithm (the implementor)
buffer - Variable in class com.google.common.hash.Murmur3_32HashFunction.Murmur3_32Hasher
 
BUFFER_SIZE - Static variable in class com.google.common.io.ByteStreams
 
BufferingHasher(int) - Constructor for class com.google.common.hash.AbstractNonStreamingHashFunction.BufferingHasher
 
bufferSize - Variable in class com.google.common.collect.TopKSelector
 
bufferSize - Variable in class com.google.common.hash.AbstractStreamingHasher
Number of bytes to be filled before process() invocation(s).
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
 
build() - Method in class com.google.common.collect.ImmutableSet.EmptySetBuilderImpl
 
build() - Method in class com.google.common.collect.ImmutableSet.JdkBackedSetBuilderImpl
 
build() - Method in class com.google.common.collect.ImmutableSet.RegularSetBuilderImpl
 
build() - Method in class com.google.common.collect.ImmutableSet.SetBuilderImpl
 
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.Interners.InternerBuilder
 
build() - Method in class com.google.common.collect.MultimapBuilder
Returns a new, empty Multimap with the specified implementation.
build() - Method in class com.google.common.collect.MultimapBuilder.ListMultimapBuilder
 
build() - Method in class com.google.common.collect.MultimapBuilder.SetMultimapBuilder
 
build() - 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.graph.GraphBuilder
Returns an empty MutableGraph with the properties of this GraphBuilder.
build() - Method in class com.google.common.graph.ImmutableGraph.Builder
Returns a newly-created ImmutableGraph based on the contents of this Builder.
build() - Method in class com.google.common.graph.ImmutableNetwork.Builder
Returns a newly-created ImmutableNetwork based on the contents of this Builder.
build() - Method in class com.google.common.graph.ImmutableValueGraph.Builder
Returns a newly-created ImmutableValueGraph based on the contents of this Builder.
build() - Method in class com.google.common.graph.NetworkBuilder
Returns an empty MutableNetwork with the properties of this NetworkBuilder.
build() - Method in class com.google.common.graph.ValueGraphBuilder
Returns an empty MutableValueGraph with the properties of this ValueGraphBuilder.
build() - Method in class com.google.common.primitives.ImmutableDoubleArray.Builder
Returns a new immutable array.
build() - Method in class com.google.common.primitives.ImmutableIntArray.Builder
Returns a new immutable array.
build() - Method in class com.google.common.primitives.ImmutableLongArray.Builder
Returns a new immutable array.
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(boolean) - Method in class com.google.common.collect.ImmutableMap.Builder
 
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(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(Multimap<? extends K, ? extends V>) - Method in class com.google.common.collect.MultimapBuilder.ListMultimapBuilder
 
build(Multimap<? extends K, ? extends V>) - Method in class com.google.common.collect.MultimapBuilder.SetMultimapBuilder
 
build(Multimap<? extends K, ? extends V>) - Method in class com.google.common.collect.MultimapBuilder.SortedSetMultimapBuilder
 
buildDeclaredTesterRequirements(AnnotatedElement) - Static method in class com.google.common.collect.testing.features.FeatureUtil
Construct the set of requirements specified by annotations directly on a tester class or method.
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() - Static method in class com.google.common.collect.ImmutableClassToInstanceMap
Returns a new builder.
builder() - Static method in class com.google.common.collect.ImmutableList
Returns a new builder.
builder() - Static method in class com.google.common.collect.ImmutableListMultimap
Returns a new builder.
builder() - Static method in class com.google.common.collect.ImmutableMap
Returns a new builder.
builder() - Static method in class com.google.common.collect.ImmutableMultimap
Returns a new builder.
builder() - Static method in class com.google.common.collect.ImmutableMultiset
Returns a new builder.
builder() - Static method in class com.google.common.collect.ImmutableRangeMap
Returns a new builder for an immutable range map.
builder() - Static method in class com.google.common.collect.ImmutableRangeSet
Returns a new builder for an immutable range set.
builder() - Static method in class com.google.common.collect.ImmutableSet
Returns a new builder.
builder() - Static method in class com.google.common.collect.ImmutableSetMultimap
builder() - Static method in class com.google.common.collect.ImmutableSortedMap
Deprecated.
Use ImmutableSortedMap.naturalOrder(), which offers better type-safety.
builder() - Static method in class com.google.common.collect.ImmutableSortedMultiset
Deprecated.
Use ImmutableSortedMultiset.naturalOrder(), which offers better type-safety.
builder() - Static method in class com.google.common.collect.ImmutableSortedSet
Deprecated.
Use ImmutableSortedSet.naturalOrder(), which offers better type-safety.
builder() - Static method in class com.google.common.collect.ImmutableTable
Returns a new builder.
builder() - Static method in class com.google.common.escape.Escapers
Returns a builder for creating simple, fast escapers.
builder() - Static method in class com.google.common.primitives.ImmutableDoubleArray
Returns a new, empty builder for ImmutableDoubleArray instances, with a default initial capacity.
builder() - Static method in class com.google.common.primitives.ImmutableIntArray
Returns a new, empty builder for ImmutableIntArray instances, with a default initial capacity.
builder() - Static method in class com.google.common.primitives.ImmutableLongArray
Returns a new, empty builder for ImmutableLongArray instances, with a default initial capacity.
builder() - Static method in class com.google.common.reflect.ImmutableTypeToInstanceMap
Returns a new builder.
builder(int) - Static method in class com.google.common.primitives.ImmutableDoubleArray
Returns a new, empty builder for ImmutableDoubleArray instances, sized to hold up to initialCapacity values without resizing.
builder(int) - Static method in class com.google.common.primitives.ImmutableIntArray
Returns a new, empty builder for ImmutableIntArray instances, sized to hold up to initialCapacity values without resizing.
builder(int) - Static method in class com.google.common.primitives.ImmutableLongArray
Returns a new, empty builder for ImmutableLongArray instances, sized to hold up to initialCapacity values without resizing.
Builder() - Constructor for class com.google.common.collect.ImmutableBiMap.Builder
Creates a new builder.
Builder() - Constructor for class com.google.common.collect.ImmutableClassToInstanceMap.Builder
 
Builder() - Constructor for class com.google.common.collect.ImmutableCollection.Builder
 
Builder() - Constructor for class com.google.common.collect.ImmutableList.Builder
Creates a new builder.
Builder() - Constructor for class com.google.common.collect.ImmutableListMultimap.Builder
Creates a new builder.
Builder() - Constructor for class com.google.common.collect.ImmutableMap.Builder
Creates a new builder.
Builder() - Constructor for class com.google.common.collect.ImmutableMultimap.Builder
Creates a new builder.
Builder() - Constructor for class com.google.common.collect.ImmutableMultiset.Builder
Creates a new builder.
Builder() - Constructor for class com.google.common.collect.ImmutableRangeMap.Builder
 
Builder() - Constructor for class com.google.common.collect.ImmutableRangeSet.Builder
 
Builder() - Constructor for class com.google.common.collect.ImmutableSet.Builder
 
Builder() - Constructor for class com.google.common.collect.ImmutableSetMultimap.Builder
Creates a new builder.
Builder() - Constructor for class com.google.common.collect.ImmutableTable.Builder
Creates a new builder.
Builder() - Constructor for class com.google.common.escape.Escapers.Builder
 
Builder() - Constructor for class com.google.common.reflect.ImmutableTypeToInstanceMap.Builder
 
Builder(boolean) - Constructor for class com.google.common.collect.ImmutableSet.Builder
 
Builder(int) - Constructor for class com.google.common.collect.ImmutableBiMap.Builder
 
Builder(int) - Constructor for class com.google.common.collect.ImmutableList.Builder
 
Builder(int) - Constructor for class com.google.common.collect.ImmutableListMultimap.Builder
Creates a new builder with a hint for the number of distinct keys.
Builder(int) - Constructor for class com.google.common.collect.ImmutableMap.Builder
 
Builder(int) - Constructor for class com.google.common.collect.ImmutableMultimap.Builder
Creates a new builder with a hint for the number of distinct keys.
Builder(int) - Constructor for class com.google.common.collect.ImmutableSet.Builder
 
Builder(int) - Constructor for class com.google.common.collect.ImmutableSetMultimap.Builder
 
Builder(int) - Constructor for class com.google.common.primitives.ImmutableDoubleArray.Builder
 
Builder(int) - Constructor for class com.google.common.primitives.ImmutableIntArray.Builder
 
Builder(int) - Constructor for class com.google.common.primitives.ImmutableLongArray.Builder
 
Builder(Multiset<E>) - Constructor for class com.google.common.collect.ImmutableMultiset.Builder
 
Builder(GraphBuilder<N>) - Constructor for class com.google.common.graph.ImmutableGraph.Builder
 
Builder(NetworkBuilder<N, E>) - Constructor for class com.google.common.graph.ImmutableNetwork.Builder
 
Builder(ValueGraphBuilder<N, V>) - Constructor for class com.google.common.graph.ImmutableValueGraph.Builder
 
Builder(Comparator<? super E>) - Constructor for class com.google.common.collect.ImmutableSortedMultiset.Builder
Creates a new builder.
Builder(Comparator<? super E>) - Constructor for class com.google.common.collect.ImmutableSortedSet.Builder
Creates a new builder.
Builder(Comparator<? super E>, int) - Constructor for class com.google.common.collect.ImmutableSortedSet.Builder
Creates a new builder with an expected size.
Builder(Comparator<? super K>) - Constructor for class com.google.common.collect.ImmutableSortedMap.Builder
Creates a new builder.
Builder(Comparator<B>) - Constructor for class com.google.common.collect.MinMaxPriorityQueue.Builder
 
BuilderAddAllListGenerator() - Constructor for class com.google.common.collect.testing.google.ListGenerators.BuilderAddAllListGenerator
 
BuilderAddListGenerator() - Constructor for class com.google.common.collect.testing.google.ListGenerators.BuilderAddListGenerator
 
builderMap - Variable in class com.google.common.collect.ImmutableMultimap.Builder
 
BuilderReversedListGenerator() - Constructor for class com.google.common.collect.testing.google.ListGenerators.BuilderReversedListGenerator
 
builderWithExpectedKeys(int) - Static method in class com.google.common.collect.ImmutableListMultimap
Returns a new builder with a hint for how many distinct keys are expected to be added.
builderWithExpectedKeys(int) - Static method in class com.google.common.collect.ImmutableMultimap
Returns a new builder with a hint for how many distinct keys are expected to be added.
builderWithExpectedKeys(int) - Static method in class com.google.common.collect.ImmutableSetMultimap
Returns a new builder with a hint for how many distinct keys are expected to be added.
builderWithExpectedSize(int) - Static method in class com.google.common.collect.ImmutableBiMap
Returns a new builder, expecting the specified number of entries to be added.
builderWithExpectedSize(int) - Static method in class com.google.common.collect.ImmutableList
Returns a new builder, expecting the specified number of elements to be added.
builderWithExpectedSize(int) - Static method in class com.google.common.collect.ImmutableMap
Returns a new builder, expecting the specified number of entries to be added.
builderWithExpectedSize(int) - Static method in class com.google.common.collect.ImmutableSet
Returns a new builder, expecting the specified number of distinct elements to be added.
builderWithExpectedSize(int) - Static method in class com.google.common.collect.ImmutableSortedMap
Deprecated.
Not supported for ImmutableSortedMap.
builderWithExpectedSize(int) - Static method in class com.google.common.collect.ImmutableSortedSet
Deprecated.
Not supported by ImmutableSortedSet.
Building a Graph - Search tag in interface com.google.common.graph.Graph
Section
Building a Network - Search tag in interface com.google.common.graph.Network
Section
Building a ValueGraph - Search tag in interface com.google.common.graph.ValueGraph
Section
buildJdkBacked() - Method in class com.google.common.collect.ImmutableBiMap.Builder
 
buildJdkBacked() - Method in class com.google.common.collect.ImmutableMap.Builder
 
buildJdkBacked() - Method in class com.google.common.collect.ImmutableMultiset.Builder
 
buildKeepingLast() - Method in class com.google.common.collect.ImmutableBiMap.Builder
Deprecated.
This method does not make sense for bimaps and should not be called.
buildKeepingLast() - Method in class com.google.common.collect.ImmutableMap.Builder
Returns a newly-created immutable map, using the last value for any key that was added more than once.
buildKeepingLast() - Method in class com.google.common.collect.ImmutableSortedMap.Builder
Deprecated.
This method is not currently implemented, and may never be.
buildOrThrow() - Method in class com.google.common.collect.ImmutableBiMap.Builder
Returns a newly-created immutable bimap, or throws an exception if any key or value was added more than once.
buildOrThrow() - Method in class com.google.common.collect.ImmutableMap.Builder
Returns a newly-created immutable map, or throws an exception if any key was added more than once.
buildOrThrow() - Method in class com.google.common.collect.ImmutableSortedMap.Builder
Returns a newly-created immutable sorted map, or throws an exception if any two keys are equal.
buildOrThrow() - Method in class com.google.common.collect.ImmutableTable.Builder
Returns a newly-created immutable table, or throws an exception if duplicate key pairs were added.
buildParamList(Invokable<?, ?>, int) - Method in class com.google.common.testing.NullPointerTester
 
buildSorted(Comparator<? super E>) - Method in class com.google.common.collect.ImmutableList.Builder
Returns a newly-created ImmutableList based on the contents of the Builder, sorted according to the specified comparator.
buildTesterRequirements(Annotation) - Static method in class com.google.common.collect.testing.features.FeatureUtil
Find all the constraints explicitly or implicitly specified by a single tester annotation.
buildTesterRequirements(Class<?>) - Static method in class com.google.common.collect.testing.features.FeatureUtil
Construct the full set of requirements for a tester class.
buildTesterRequirements(Method) - Static method in class com.google.common.collect.testing.features.FeatureUtil
Construct the full set of requirements for a tester method.
bulkGet(Iterable<? extends Object>) - 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.
bus - Variable in class com.google.common.eventbus.Subscriber
The event bus this subscriber belongs to.
bus - Variable in class com.google.common.eventbus.SubscriberRegistry
The event bus this registry belongs to.
busy - Variable in class com.google.common.cache.Striped64
Spinlock (locked via CAS) used when resizing and/or creating Cells.
busy - Variable in class com.google.common.hash.Striped64
Spinlock (locked via CAS) used when resizing and/or creating Cells.
busyOffset - Static variable in class com.google.common.cache.Striped64
 
busyOffset - Static variable in class com.google.common.hash.Striped64
 
BY_FIELD_NAME - Static variable in class com.google.common.testing.ArbitraryInstances
 
BY_METHOD_NAME - Static variable in class com.google.common.testing.ClassSanityTester
 
BY_NUMBER_OF_PARAMETERS - Static variable in class com.google.common.testing.ClassSanityTester
 
BY_PARAMETERS - Static variable in class com.google.common.testing.ClassSanityTester
 
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 class com.google.common.hash.LittleEndianByteArray.UnsafeByteArray
 
BYTE_ARRAY_BASE_OFFSET - Static variable in enum class com.google.common.primitives.UnsignedBytes.LexicographicalComparatorHolder.UnsafeComparator
The offset to the first element in a byte array.
BYTE_MASK - Static variable in class com.google.common.collect.CompactHashing
 
BYTE_MAX_SIZE - Static variable in class com.google.common.collect.CompactHashing
 
BYTE_TABLE - Static variable in class com.google.common.hash.Crc32cHashFunction.Crc32cHasher
 
byteArray - Static variable in class com.google.common.hash.LittleEndianByteArray
The instance that actually does the work; delegates to Unsafe or a pure-Java fallback.
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
 
ByteArrayByteSource(byte[], int, int) - 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 class com.google.common.hash.Funnels.ByteArrayFunnel
 
byteArrayOutputStream - Variable in class com.google.common.io.ByteStreams.ByteArrayDataOutputStream
 
byteBuffer - Variable in class com.google.common.io.ReaderInputStream
byteBuffer holds encoded characters that have not yet been sent to the caller of the input stream.
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.math.PairedStats
The size of byte array representation in bytes.
BYTES - Static variable in class com.google.common.math.Stats
The size of byte array representation in 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[], String) - 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.LimitedInputStream - Class in com.google.common.io
 
ByToString() - Constructor for class com.google.common.testing.ArbitraryInstances.ByToString
 
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.collect.testing.google.MultisetNavigationTester
 
c - Variable in class com.google.common.collect.testing.testers.NavigableMapNavigationTester
 
c - Variable in class com.google.common.collect.testing.testers.NavigableSetNavigationTester
 
c - Variable in class com.google.common.collect.testing.testers.SortedMapNavigationTester
 
c - Variable in class com.google.common.collect.testing.testers.SortedSetNavigationTester
 
c - Variable in class com.google.common.hash.SipHashFunction
 
c - Variable in class com.google.common.hash.SipHashFunction.SipHasher
 
C - Enum constant in enum class com.google.common.collect.testing.AnEnum
 
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.
CacheBuilder() - Constructor for class com.google.common.cache.CacheBuilder
 
CacheBuilder.LoggerHolder - Class in com.google.common.cache
 
CacheBuilder.NullListener - Enum Class in com.google.common.cache
 
CacheBuilder.OneWeigher - Enum Class 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
cacheEntry - Variable in class com.google.common.graph.MapIteratorCache
 
CacheEntry(K, V) - Constructor for class com.google.common.graph.MapRetrievalCache.CacheEntry
 
cacheEntry1 - Variable in class com.google.common.graph.MapRetrievalCache
 
cacheEntry2 - Variable in class com.google.common.graph.MapRetrievalCache
 
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 Class 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 Class in com.google.common.cache
Exception thrown by loadAll() to indicate that it is not supported.
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.
CachingAsList() - Constructor for class com.google.common.collect.ImmutableSet.CachingAsList
 
calculateNewCapacity() - Method in class com.google.common.collect.MinMaxPriorityQueue
Returns ~2x the old capacity if small; ~1.5x otherwise.
calculateNewMeanNonFinite(double, double) - Static method in class com.google.common.math.StatsAccumulator
Calculates the new value for the accumulated mean when a value is added, in the case where at least one of the previous mean and the value is non-finite.
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).
call() - Method in class com.google.common.util.concurrent.AbstractScheduledService.CustomScheduler.ReschedulableCallable
 
call() - Method in interface com.google.common.util.concurrent.AsyncCallable
Computes a result Future.
call(ClosingFuture.Combiner.CombiningCallable<V>, ClosingFuture.CloseableList) - Method in class com.google.common.util.concurrent.ClosingFuture.Peeker
 
call(ClosingFuture.Combiner.CombiningCallable<V>, Executor) - Method in class com.google.common.util.concurrent.ClosingFuture.Combiner
Returns a new ClosingFuture pipeline step derived from the inputs by applying a combining function to their values.
call(ClosingFuture.Combiner2.ClosingFunction2<V1, V2, U>, Executor) - Method in class com.google.common.util.concurrent.ClosingFuture.Combiner2
Returns a new ClosingFuture pipeline step derived from the inputs by applying a combining function to their values.
call(ClosingFuture.Combiner3.ClosingFunction3<V1, V2, V3, U>, Executor) - Method in class com.google.common.util.concurrent.ClosingFuture.Combiner3
Returns a new ClosingFuture pipeline step derived from the inputs by applying a combining function to their values.
call(ClosingFuture.Combiner4.ClosingFunction4<V1, V2, V3, V4, U>, Executor) - Method in class com.google.common.util.concurrent.ClosingFuture.Combiner4
Returns a new ClosingFuture pipeline step derived from the inputs by applying a combining function to their values.
call(ClosingFuture.Combiner5.ClosingFunction5<V1, V2, V3, V4, V5, U>, Executor) - Method in class com.google.common.util.concurrent.ClosingFuture.Combiner5
Returns a new ClosingFuture pipeline step derived from the inputs by applying a combining function to their values.
call(ClosingFuture.DeferredCloser) - Method in interface com.google.common.util.concurrent.ClosingFuture.AsyncClosingCallable
Computes a result, or throws an exception if unable to do so.
call(ClosingFuture.DeferredCloser) - Method in interface com.google.common.util.concurrent.ClosingFuture.ClosingCallable
Computes a result, or throws an exception if unable to do so.
call(ClosingFuture.DeferredCloser, ClosingFuture.Peeker) - Method in interface com.google.common.util.concurrent.ClosingFuture.Combiner.AsyncCombiningCallable
Computes a ClosingFuture result, or throws an exception if unable to do so.
call(ClosingFuture.DeferredCloser, ClosingFuture.Peeker) - Method in interface com.google.common.util.concurrent.ClosingFuture.Combiner.CombiningCallable
Computes a result, or throws an exception if unable to do so.
call(Callable<C>, Executor) - Method in class com.google.common.util.concurrent.Futures.FutureCombiner
Creates the ListenableFuture which will return the result of calling Callable.call() in combiner when all futures complete, using the specified executor.
call(L) - Method in interface com.google.common.util.concurrent.ListenerCallQueue.Event
Call a method on the listener.
callable - Variable in class com.google.common.util.concurrent.CombinedFuture.AsyncCallableInterruptibleTask
 
callable - Variable in class com.google.common.util.concurrent.CombinedFuture.CallableInterruptibleTask
 
callable - Variable in class com.google.common.util.concurrent.TrustedListenableFutureTask.TrustedFutureInterruptibleAsyncTask
 
callable - Variable in class com.google.common.util.concurrent.TrustedListenableFutureTask.TrustedFutureInterruptibleTask
 
CallableInterruptibleTask(Callable<V>, Executor) - Constructor for class com.google.common.util.concurrent.CombinedFuture.CallableInterruptibleTask
 
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
 
callAsync(AsyncCallable<C>, Executor) - Method in class com.google.common.util.concurrent.Futures.FutureCombiner
Creates the ListenableFuture which will return the result of calling AsyncCallable.call() in combiner when all futures complete, using the specified executor.
callAsync(ClosingFuture.Combiner.AsyncCombiningCallable<V>, ClosingFuture.CloseableList) - Method in class com.google.common.util.concurrent.ClosingFuture.Peeker
 
callAsync(ClosingFuture.Combiner.AsyncCombiningCallable<V>, Executor) - Method in class com.google.common.util.concurrent.ClosingFuture.Combiner
Returns a new ClosingFuture pipeline step derived from the inputs by applying a ClosingFuture-returning function to their values.
callAsync(ClosingFuture.Combiner2.AsyncClosingFunction2<V1, V2, U>, Executor) - Method in class com.google.common.util.concurrent.ClosingFuture.Combiner2
Returns a new ClosingFuture pipeline step derived from the inputs by applying a ClosingFuture-returning function to their values.
callAsync(ClosingFuture.Combiner3.AsyncClosingFunction3<V1, V2, V3, U>, Executor) - Method in class com.google.common.util.concurrent.ClosingFuture.Combiner3
Returns a new ClosingFuture pipeline step derived from the inputs by applying a ClosingFuture-returning function to their values.
callAsync(ClosingFuture.Combiner4.AsyncClosingFunction4<V1, V2, V3, V4, U>, Executor) - Method in class com.google.common.util.concurrent.ClosingFuture.Combiner4
Returns a new ClosingFuture pipeline step derived from the inputs by applying a ClosingFuture-returning function to their values.
callAsync(ClosingFuture.Combiner5.AsyncClosingFunction5<V1, V2, V3, V4, V5, U>, Executor) - Method in class com.google.common.util.concurrent.ClosingFuture.Combiner5
Returns a new ClosingFuture pipeline step derived from the inputs by applying a ClosingFuture-returning function to their values.
callback - Variable in class com.google.common.util.concurrent.Futures.CallbackListener
 
CallbackListener(Future<V>, FutureCallback<? super V>) - Constructor for class com.google.common.util.concurrent.Futures.CallbackListener
 
called - Variable in class com.google.common.testing.ForwardingWrapperTester.InteractionTester
 
callUninterruptiblyWithTimeout(Callable<T>, long, TimeUnit) - Method in class com.google.common.util.concurrent.FakeTimeLimiter
 
callUninterruptiblyWithTimeout(Callable<T>, long, TimeUnit) - Method in class com.google.common.util.concurrent.SimpleTimeLimiter
 
callUninterruptiblyWithTimeout(Callable<T>, long, TimeUnit) - Method in interface com.google.common.util.concurrent.TimeLimiter
Invokes a specified Callable, timing out after the specified time limit.
callUninterruptiblyWithTimeout(Callable<T>, Duration) - Method in interface com.google.common.util.concurrent.TimeLimiter
Invokes a specified Callable, timing out after the specified time limit.
callWithTimeout(Callable<T>, long, TimeUnit) - Method in class com.google.common.util.concurrent.FakeTimeLimiter
 
callWithTimeout(Callable<T>, long, TimeUnit) - Method in class com.google.common.util.concurrent.SimpleTimeLimiter
 
callWithTimeout(Callable<T>, long, TimeUnit) - Method in interface com.google.common.util.concurrent.TimeLimiter
Invokes a specified Callable, timing out after the specified time limit.
callWithTimeout(Callable<T>, long, TimeUnit, boolean) - Method in class com.google.common.util.concurrent.SimpleTimeLimiter
 
callWithTimeout(Callable<T>, Duration) - 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.TrustedFuture
 
cancel(boolean) - Method in interface com.google.common.util.concurrent.AbstractScheduledService.Cancellable
 
cancel(boolean) - Method in class com.google.common.util.concurrent.AbstractScheduledService.CustomScheduler.SupplantableFuture
 
cancel(boolean) - Method in class com.google.common.util.concurrent.AbstractScheduledService.FutureAsCancellable
 
cancel(boolean) - Method in class com.google.common.util.concurrent.ClosingFuture
Attempts to cancel execution of this step.
cancel(boolean) - Method in class com.google.common.util.concurrent.FluentFuture.TrustedFuture
 
cancel(boolean) - Method in class com.google.common.util.concurrent.ForwardingFluentFuture
 
cancel(boolean) - Method in class com.google.common.util.concurrent.ForwardingFuture
 
cancel(boolean) - Method in class com.google.common.util.concurrent.Futures.InCompletionOrderFuture
 
cancel(boolean) - Method in class com.google.common.util.concurrent.ImmediateFuture
 
cancel(boolean) - Method in class com.google.common.util.concurrent.MoreExecutors.ScheduledListeningDecorator.ListenableScheduledTask
 
Cancellation(boolean, Throwable) - Constructor for class com.google.common.util.concurrent.AbstractFuture.Cancellation
 
cancellationDelegate - Variable in class com.google.common.util.concurrent.AbstractScheduledService.CustomScheduler.ReschedulableCallable
The future that represents the next execution of this task.
cancellationExceptionWithCause(String, Throwable) - Static method in class com.google.common.util.concurrent.AbstractFuture
 
CANCELLED - Enum constant in enum class com.google.common.util.concurrent.ExecutionSequencer.RunningState
 
Cancelling - Search tag in class com.google.common.util.concurrent.ClosingFuture
Section
canDecode(char) - Method in class com.google.common.io.BaseEncoding.Alphabet
 
canDecode(CharSequence) - Method in class com.google.common.io.BaseEncoding
Determines whether the specified character sequence is a valid encoded string according to this encoding.
canDecode(CharSequence) - Method in class com.google.common.io.BaseEncoding.SeparatedBaseEncoding
 
canDecode(CharSequence) - Method in class com.google.common.io.BaseEncoding.StandardBaseEncoding
 
canonical(DiscreteDomain<C>) - Method in class com.google.common.collect.Cut.AboveValue
 
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.
canonical(DiscreteDomain<Comparable<?>>) - Method in class com.google.common.collect.Cut.BelowAll
 
canonicalForm - Variable in class com.google.common.net.HostSpecifier
 
canonicalizeTypeArg(TypeVariable<?>, Type) - Static method in class com.google.common.reflect.TypeToken
In reflection, Foo<?>.getUpperBounds()[0] is always Object.class, even when Foo is defined as Foo<T extends String>.
canonicalizeWildcardsInParameterizedType(ParameterizedType) - Static method in class com.google.common.reflect.TypeToken
 
canonicalizeWildcardsInType(Type) - Static method in class com.google.common.reflect.TypeToken
 
canonicalizeWildcardType(TypeVariable<?>, WildcardType) - Static method in class com.google.common.reflect.TypeToken
 
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
 
canTraverseWithoutReusingEdge(Graph<?>, Object, Object) - Static method in class com.google.common.graph.Graphs
Determines whether an edge has already been used during traversal.
Capabilities - Search tag in interface com.google.common.graph.Graph
Section
Capabilities - Search tag in interface com.google.common.graph.Network
Section
Capabilities - Search tag in interface com.google.common.graph.ValueGraph
Section
capacity() - Method in class com.google.common.collect.MinMaxPriorityQueue
 
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).
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
 
captureAsTypeVariable(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 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 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
 
cas(long, long) - Method in class com.google.common.hash.Striped64.Cell
 
casBase(long, long) - Method in class com.google.common.cache.Striped64
CASes the base field.
casBase(long, long) - Method in class com.google.common.hash.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.
casBusy() - Method in class com.google.common.hash.Striped64
CASes the busy field from 0 to 1 to acquire lock.
CASE_MASK - Static variable in class com.google.common.base.Ascii
A bit mask which selects the bit encoding ASCII character case.
CaseFormat - Enum Class in com.google.common.base
Utility class for converting between various ASCII case formats.
CaseFormat(CharMatcher, String) - Constructor for enum class com.google.common.base.CaseFormat
 
CaseFormat.StringConverter - Class in com.google.common.base
 
casListeners(AbstractFuture<?>, AbstractFuture.Listener, AbstractFuture.Listener) - Method in class com.google.common.util.concurrent.AbstractFuture.AtomicHelper
Performs a CAS operation on the AbstractFuture.listeners field.
casListeners(AbstractFuture<?>, AbstractFuture.Listener, AbstractFuture.Listener) - Method in class com.google.common.util.concurrent.AbstractFuture.SafeAtomicHelper
 
casListeners(AbstractFuture<?>, AbstractFuture.Listener, AbstractFuture.Listener) - Method in class com.google.common.util.concurrent.AbstractFuture.SynchronizedHelper
 
casListeners(AbstractFuture<?>, AbstractFuture.Listener, AbstractFuture.Listener) - Method in class com.google.common.util.concurrent.AbstractFuture.UnsafeAtomicHelper
Performs a CAS operation on the AbstractFuture.listeners field.
cast() - Method in class com.google.common.graph.ElementOrder
 
cast() - Method in class com.google.common.graph.GraphBuilder
 
cast() - Method in class com.google.common.graph.NetworkBuilder
 
cast() - Method in class com.google.common.graph.ValueGraphBuilder
 
cast(Multiset<T>) - Static method in class com.google.common.collect.testing.google.MultisetNavigationTester
Used to avoid http://bugs.sun.com/view_bug.do?bug_id=6558557
cast(Class<T>, Object) - Static method in class com.google.common.collect.ImmutableClassToInstanceMap.Builder
 
cast(Class<T>, Object) - Static method in class com.google.common.collect.MutableClassToInstanceMap
 
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
castForTesting(MapMakerInternalMap.InternalEntry<K, MapMaker.Dummy, ?>) - Method in class com.google.common.collect.MapMakerInternalMap.StrongKeyDummyValueSegment
 
castForTesting(MapMakerInternalMap.InternalEntry<K, MapMaker.Dummy, ?>) - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyDummyValueSegment
 
castForTesting(MapMakerInternalMap.InternalEntry<K, V, ?>) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Unsafe cast of the given entry to E, the type of the specific MapMakerInternalMap.InternalEntry implementation type.
castForTesting(MapMakerInternalMap.InternalEntry<K, V, ?>) - Method in class com.google.common.collect.MapMakerInternalMap.StrongKeyStrongValueSegment
 
castForTesting(MapMakerInternalMap.InternalEntry<K, V, ?>) - Method in class com.google.common.collect.MapMakerInternalMap.StrongKeyWeakValueSegment
 
castForTesting(MapMakerInternalMap.InternalEntry<K, V, ?>) - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyStrongValueSegment
 
castForTesting(MapMakerInternalMap.InternalEntry<K, V, ?>) - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyWeakValueSegment
 
castOrCopyToCollection(Iterable<E>) - Static method in class com.google.common.collect.Iterables
Converts an iterable into a collection.
castOrCopyToList(Iterable<E>) - Static method in class com.google.common.collect.testing.Helpers
 
casValue(AbstractFuture<?>, Object, Object) - Method in class com.google.common.util.concurrent.AbstractFuture.AtomicHelper
Performs a CAS operation on the AbstractFuture.value field.
casValue(AbstractFuture<?>, Object, Object) - Method in class com.google.common.util.concurrent.AbstractFuture.SafeAtomicHelper
 
casValue(AbstractFuture<?>, Object, Object) - Method in class com.google.common.util.concurrent.AbstractFuture.SynchronizedHelper
 
casValue(AbstractFuture<?>, Object, Object) - Method in class com.google.common.util.concurrent.AbstractFuture.UnsafeAtomicHelper
Performs a CAS operation on the AbstractFuture.value field.
casWaiters(AbstractFuture<?>, AbstractFuture.Waiter, AbstractFuture.Waiter) - Method in class com.google.common.util.concurrent.AbstractFuture.AtomicHelper
Performs a CAS operation on the AbstractFuture.waiters field.
casWaiters(AbstractFuture<?>, AbstractFuture.Waiter, AbstractFuture.Waiter) - Method in class com.google.common.util.concurrent.AbstractFuture.SafeAtomicHelper
 
casWaiters(AbstractFuture<?>, AbstractFuture.Waiter, AbstractFuture.Waiter) - Method in class com.google.common.util.concurrent.AbstractFuture.SynchronizedHelper
 
casWaiters(AbstractFuture<?>, AbstractFuture.Waiter, AbstractFuture.Waiter) - Method in class com.google.common.util.concurrent.AbstractFuture.UnsafeAtomicHelper
Performs a CAS operation on the AbstractFuture.waiters field.
catching(ListenableFuture<? extends V>, Class<X>, Function<? super X, ? 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 with the given exceptionType, from the result provided by the fallback.
catching(Class<X>, Function<? super X, ? extends V>, Executor) - Method in class com.google.common.util.concurrent.FluentFuture
Returns a Future whose result is taken from this Future or, if this Future fails with the given exceptionType, from the result provided by the fallback.
catching(Class<X>, ClosingFuture.ClosingFunction<? super X, ? extends V>, Executor) - Method in class com.google.common.util.concurrent.ClosingFuture
Returns a new ClosingFuture pipeline step derived from this one by applying a function to its exception if it is an instance of a given exception type.
Catching - Search tag in class com.google.common.util.concurrent.ClosingFuture
Section
catchingAsync(ListenableFuture<? extends V>, Class<X>, AsyncFunction<? super X, ? 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 with the given exceptionType, from the result provided by the fallback.
catchingAsync(Class<X>, AsyncFunction<? super X, ? extends V>, Executor) - Method in class com.google.common.util.concurrent.FluentFuture
Returns a Future whose result is taken from this Future or, if this Future fails with the given exceptionType, from the result provided by the fallback.
catchingAsync(Class<X>, ClosingFuture.AsyncClosingFunction<? super X, ? extends V>, Executor) - Method in class com.google.common.util.concurrent.ClosingFuture
Returns a new ClosingFuture pipeline step derived from this one by applying a function that returns a ClosingFuture to its exception if it is an instance of a given exception type.
catchingAsyncMoreGeneric(Class<X>, ClosingFuture.AsyncClosingFunction<? super X, W>, Executor) - Method in class com.google.common.util.concurrent.ClosingFuture
 
CatchingFuture(ListenableFuture<? extends V>, Class<X>, Function<? super X, ? extends V>) - Constructor for class com.google.common.util.concurrent.AbstractCatchingFuture.CatchingFuture
 
catchingMoreGeneric(Class<X>, ClosingFuture.ClosingFunction<? super X, W>, Executor) - Method in class com.google.common.util.concurrent.ClosingFuture
 
cause - Variable in class com.google.common.cache.RemovalNotification
 
cause - Variable in class com.google.common.util.concurrent.AbstractFuture.Cancellation
 
CAUSELESS_CANCELLED - Static variable in class com.google.common.util.concurrent.AbstractFuture.Cancellation
 
CAUSELESS_INTERRUPTED - Static variable in class com.google.common.util.concurrent.AbstractFuture.Cancellation
 
cbuf - Variable in class com.google.common.io.LineReader
 
CDN_LOOP - Static variable in class com.google.common.net.HttpHeaders
The HTTP CDN-Loop header field name.
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(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(E) - Method in class com.google.common.collect.testing.SafeTreeSet
 
ceiling(Comparator<? super E>, E) - Method in class com.google.common.collect.TreeMultiset.AvlNode
 
ceiling(K) - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableKeySet
 
ceiling(K) - Method in class com.google.common.collect.Maps.NavigableKeySet
 
ceiling(V) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedNavigableSet
 
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
 
ceilingEntry(K) - Method in class com.google.common.collect.testing.SafeTreeMap
 
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
 
ceilingKey(K) - Method in class com.google.common.collect.testing.SafeTreeMap
 
ceilingPowerOfTwo(int) - Static method in class com.google.common.math.IntMath
Returns the smallest power of two greater than or equal to x.
ceilingPowerOfTwo(long) - Static method in class com.google.common.math.LongMath
Returns the smallest power of two greater than or equal to x.
ceilingPowerOfTwo(BigInteger) - Static method in class com.google.common.math.BigIntegerMath
Returns the smallest power of two greater than or equal to x.
ceilToPowerOfTwo(int) - Static method in class com.google.common.util.concurrent.Striped
 
Cell(long) - Constructor for class com.google.common.cache.Striped64.Cell
 
Cell(long) - Constructor for class com.google.common.hash.Striped64.Cell
 
cellColumnIndices - Variable in class com.google.common.collect.DenseImmutableTable
 
cellColumnIndices - Variable in class com.google.common.collect.ImmutableTable.SerializedForm
 
cellColumnInRowIndices - Variable in class com.google.common.collect.SparseImmutableTable
 
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() - Method in class com.google.common.collect.Tables.TransformedTable
 
cellIterator() - Method in class com.google.common.collect.Tables.TransposeTable
 
CellIterator() - Constructor for class com.google.common.collect.StandardTable.CellIterator
 
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.
cellRowIndices - Variable in class com.google.common.collect.DenseImmutableTable
 
cellRowIndices - Variable in class com.google.common.collect.ImmutableTable.SerializedForm
 
cellRowIndices - Variable in class com.google.common.collect.SparseImmutableTable
 
cells - Variable in class com.google.common.cache.Striped64
Table of cells.
cells - Variable in class com.google.common.collect.ImmutableTable.Builder
 
cells - Variable in class com.google.common.hash.Striped64
Table of cells.
cellSet - Variable in class com.google.common.collect.AbstractTable
 
cellSet() - Method in class com.google.common.collect.AbstractTable
 
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() - Method in class com.google.common.collect.StandardTable
Returns a set of all row key / column key / value triplets.
cellSet() - Method in class com.google.common.collect.Synchronized.SynchronizedTable
 
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
 
CellSet() - Constructor for class com.google.common.collect.AbstractTable.CellSet
 
CellSet() - Constructor for class com.google.common.collect.RegularImmutableTable.CellSet
 
cellSpliterator() - Method in class com.google.common.collect.AbstractTable
 
cellSpliterator() - Method in class com.google.common.collect.ArrayTable
 
cellSpliterator() - Method in class com.google.common.collect.ImmutableTable
 
cellSpliterator() - Method in class com.google.common.collect.StandardTable
 
cellSpliterator() - Method in class com.google.common.collect.Tables.TransformedTable
 
cellSpliterator() - Method in class com.google.common.collect.Tables.TransposeTable
 
cellValues - Variable in class com.google.common.collect.ImmutableTable.SerializedForm
 
Chaining - Search tag in class com.google.common.collect.Ordering
Section
characteristics - Variable in class com.google.common.collect.CollectSpliterators.FlatMapSpliterator
 
characteristics() - Method in class com.google.common.collect.CollectSpliterators.FlatMapSpliterator
 
characteristics() - Method in class com.google.common.collect.Streams.MapWithIndexSpliterator
 
characteristics() - Method in class com.google.common.collect.testing.SpliteratorTester.GeneralSpliterator
 
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.
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.
CharactersOfCharSequenceGenerator() - Constructor for class com.google.common.collect.testing.google.ListGenerators.CharactersOfCharSequenceGenerator
 
CharactersOfStringGenerator() - Constructor for class com.google.common.collect.testing.google.ListGenerators.CharactersOfStringGenerator
 
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
 
charBuffer - Variable in class com.google.common.io.ReaderInputStream
charBuffer holds characters that have been read from the Reader but not encoded yet.
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() - Constructor for class com.google.common.base.CharMatcher
Constructor for use by subclasses.
CharMatcher.And - Class in com.google.common.base
Implementation of CharMatcher.and(CharMatcher).
CharMatcher.Any - Class in com.google.common.base
Implementation of CharMatcher.any().
CharMatcher.AnyOf - Class in com.google.common.base
Implementation of CharMatcher.anyOf(CharSequence) for three or more characters.
CharMatcher.Ascii - Class in com.google.common.base
Implementation of CharMatcher.ascii().
CharMatcher.BitSetMatcher - Class in com.google.common.base
Fast matcher using a BitSet table of matching characters.
CharMatcher.BreakingWhitespace - Class in com.google.common.base
CharMatcher.Digit - Class in com.google.common.base
Implementation of CharMatcher.digit().
CharMatcher.FastMatcher - Class in com.google.common.base
A matcher for which precomputation will not yield any significant benefit.
CharMatcher.ForPredicate - Class in com.google.common.base
CharMatcher.InRange - Class in com.google.common.base
CharMatcher.Invisible - Class in com.google.common.base
Implementation of CharMatcher.invisible().
CharMatcher.Is - Class in com.google.common.base
Implementation of CharMatcher.is(char).
CharMatcher.IsEither - Class in com.google.common.base
Implementation of CharMatcher.anyOf(CharSequence) for exactly two characters.
CharMatcher.IsNot - Class in com.google.common.base
Implementation of CharMatcher.isNot(char).
CharMatcher.JavaDigit - Class in com.google.common.base
Implementation of CharMatcher.javaDigit().
CharMatcher.JavaIsoControl - Class in com.google.common.base
Implementation of CharMatcher.javaIsoControl().
CharMatcher.JavaLetter - Class in com.google.common.base
Implementation of CharMatcher.javaLetter().
CharMatcher.JavaLetterOrDigit - Class in com.google.common.base
CharMatcher.JavaLowerCase - Class in com.google.common.base
Implementation of CharMatcher.javaLowerCase().
CharMatcher.JavaUpperCase - Class in com.google.common.base
Implementation of CharMatcher.javaUpperCase().
CharMatcher.NamedFastMatcher - Class in com.google.common.base
CharMatcher.FastMatcher which overrides toString() with a custom name.
CharMatcher.Negated - Class in com.google.common.base
Implementation of CharMatcher.Negated.negate().
CharMatcher.NegatedFastMatcher - Class in com.google.common.base
CharMatcher.None - Class in com.google.common.base
Implementation of CharMatcher.none().
CharMatcher.Or - Class in com.google.common.base
Implementation of CharMatcher.or(CharMatcher).
CharMatcher.RangesMatcher - Class in com.google.common.base
Implementation that matches characters that fall within multiple ranges.
CharMatcher.SingleWidth - Class in com.google.common.base
Implementation of CharMatcher.singleWidth().
CharMatcher.Whitespace - Class in com.google.common.base
Implementation of CharMatcher.whitespace().
chars - Variable in class com.google.common.base.CharMatcher.AnyOf
 
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.collect.testing.SampleElements.Chars
 
Chars() - Constructor for class com.google.common.primitives.Chars
 
Chars.CharArrayAsList - Class in com.google.common.primitives
 
Chars.LexicographicalComparator - Enum Class 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 - Variable in class com.google.common.io.CharSource.AsByteSource
 
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.AsByteSource - Class in com.google.common.io
A byte source that reads chars from this source and encodes them as bytes using a charset.
CharSource.CharSequenceCharSource - Class in com.google.common.io
 
CharSource.ConcatenatedCharSource - Class in com.google.common.io
 
CharSource.EmptyCharSource - Class in com.google.common.io
 
CharSource.StringCharSource - Class in com.google.common.io
Subclass specialized for string instances.
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
 
charToThreeUtf8Bytes(char) - Static method in class com.google.common.hash.Murmur3_32HashFunction
 
charToTwoUtf8Bytes(char) - Static method in class com.google.common.hash.Murmur3_32HashFunction
 
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
 
checkAllowsInsecure(Path, RecursiveDeleteOption[]) - Static method in class com.google.common.io.MoreFiles
Checks that the given options allow an insecure delete, throwing an exception if not.
checkAndSet(T, T) - Method in class com.google.common.collect.TreeMultiset.Reference
 
checkAndUpdateState(ClosingFuture.State, ClosingFuture.State) - Method in class com.google.common.util.concurrent.ClosingFuture
 
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, char) - 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, char, char) - 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, char, int) - 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, char, long) - 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, char, 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, int) - 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, int, char) - 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, int, int) - 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, int, long) - 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, int, 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, long) - 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, long, char) - 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, long, int) - 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, long, long) - 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, long, 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.
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.
checkArgument(boolean, String, Object, char) - 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, int) - 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, long) - 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, 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, Object, 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, Object, Object, 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.
checkCanCreate() - Method in class com.google.common.collect.testing.FeatureSpecificTestSuiteBuilder
checkCast(Class<?>, Object) - Static method in class com.google.common.collect.testing.Platform
 
checkConflict(String, Set<Feature<?>>, String, Set<Feature<?>>, Object) - Static method in class com.google.common.collect.testing.features.FeatureUtil
 
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.
checkedCast(long) - Static method in class com.google.common.primitives.UnsignedInts
Returns the int value that, when treated as unsigned, is equal to value, if possible.
checkedConnections(N) - Method in class com.google.common.graph.StandardNetwork
 
checkedConnections(N) - Method in class com.google.common.graph.StandardValueGraph
 
checkedCreate(SortedSet<Integer>) - Method in class com.google.common.collect.testing.google.SetGenerators.AbstractContiguousSetGenerator
 
checkedEntry(Map.Entry<Class<? extends B>, B>) - Static method in class com.google.common.collect.MutableClassToInstanceMap
Wraps the setValue implementation of an Entry to enforce the class constraint.
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.
checkedReferenceNode(E) - Method in class com.google.common.graph.StandardNetwork
 
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.
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
 
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
 
checkExceptionClassValidity(Class<? extends Exception>) - Static method in class com.google.common.util.concurrent.FuturesGetChecked
 
checkFilter(int) - Method in class com.google.common.base.SmallCharMatcher
 
checkFinite(double) - Static method in class com.google.common.math.DoubleMath
 
checkForConcurrentModification() - Method in class com.google.common.collect.CompactHashMap.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
 
checkIndex(int, int) - Static method in class com.google.common.math.Quantiles
 
checkInRangeForRoundingInputs(boolean, double, RoundingMode) - Static method in class com.google.common.math.MathPreconditions
 
checkIsE(Object) - Method in class com.google.common.collect.EnumMultiset
Returns element cast to E, if it actually is a nonnull E.
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
 
checkModCount() - Method in class com.google.common.collect.MinMaxPriorityQueue.QueueIterator
 
checkNoConflict(boolean, String, Object, Object) - Static method in class com.google.common.collect.ImmutableMap
 
checkNoConflictInKeyBucket(Object, Object, ImmutableMapEntry<K, V>, boolean) - Static method in class com.google.common.collect.RegularImmutableMap
Checks if the given key already appears in the hash chain starting at keyBucketHead.
checkNoConflictInValueBucket(Object, Map.Entry<?, ?>, ImmutableMapEntry<?, ?>) - Static method in class com.google.common.collect.RegularImmutableBiMap
 
checkNoDuplicate(R, C, V, V) - Method in class com.google.common.collect.RegularImmutableTable
 
checkNonLoadingCache() - Method in class com.google.common.cache.CacheBuilder
 
checkNonnegative(int) - Static method in class com.google.common.collect.Iterators
 
checkNonnegative(int, String) - Static method in class com.google.common.collect.CollectPreconditions
 
checkNonnegative(long, String) - Static method in class com.google.common.collect.CollectPreconditions
 
checkNonNegative(int) - Static method in class com.google.common.graph.Graphs
 
checkNonNegative(long) - Static method in class com.google.common.graph.Graphs
 
checkNonNegative(String, double) - Static method in class com.google.common.math.MathPreconditions
 
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
 
checkNoOverflow(boolean, String, int, int) - Static method in class com.google.common.math.MathPreconditions
 
checkNoOverflow(boolean, String, long, long) - Static method in class com.google.common.math.MathPreconditions
 
checkNoOverflow(long) - Static method in class com.google.common.primitives.Longs
 
checkNotClosed() - Method in class com.google.common.io.AppendableWriter
 
checkNotDone() - Method in class com.google.common.hash.MacHashFunction.MacHasher
 
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, char) - 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, char, char) - 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, char, int) - 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, char, long) - 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, char, 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, int) - 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, int, char) - 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, int, int) - 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, int, long) - 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, int, 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, long) - 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, long, char) - 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, long, int) - 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, long, long) - 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, long, 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.
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.
checkNotNull(T, String, Object, char) - 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, int) - 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, long) - 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, 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, Object, 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, Object, Object, 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 valid positions in an array, list or string of size size, and are in order.
checkPositive(int) - Static method in class com.google.common.graph.Graphs
 
checkPositive(int, String) - Static method in class com.google.common.collect.CollectPreconditions
 
checkPositive(long) - Static method in class com.google.common.graph.Graphs
 
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.
checkPositiveTimeout(long) - Static method in class com.google.common.util.concurrent.SimpleTimeLimiter
 
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, char) - 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, char, char) - 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, char, int) - 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, char, long) - 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, char, 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, int) - 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, int, char) - 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, int, int) - 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, int, long) - 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, int, 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, long) - 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, long, char) - 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, long, int) - 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, long, long) - 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, long, 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.
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.
checkState(boolean, String, Object, char) - 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, int) - 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, long) - 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, 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, Object, 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, Object, Object, 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(ImmutableSupplier<? extends Checksum>, int, String) - Constructor for class com.google.common.hash.ChecksumHashFunction
 
ChecksumHashFunction.ChecksumHasher - Class in com.google.common.hash
Hasher that updates a checksum.
ChecksumHashFunction.ChecksumMethodHandles - Class in com.google.common.hash
 
ChecksumMethodHandles() - Constructor for class com.google.common.hash.ChecksumHashFunction.ChecksumMethodHandles
 
checksumSupplier - Variable in class com.google.common.hash.ChecksumHashFunction
 
ChecksumType(String) - Constructor for enum class com.google.common.hash.Hashing.ChecksumType
 
checkValid(T) - Method in class com.google.common.collect.testing.SafeTreeMap
 
checkValid(T) - Method in class com.google.common.collect.testing.SafeTreeSet
 
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
 
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
Deprecated.
 
children(T) - Method in class com.google.common.collect.TreeTraverser
Deprecated.
Returns the children of the specified node.
chooseNextSelection(int[], int, int, int, int) - Static method in class com.google.common.math.Quantiles
Chooses the next selection to do from the required selections.
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
 
chop(String) - Method in class com.google.common.testing.AbstractPackageSanityTests.Chopper
 
Chopper() - Constructor for class com.google.common.testing.AbstractPackageSanityTests.Chopper
 
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
 
CHUNK_SIZE - Static variable in class com.google.common.hash.SipHashFunction.SipHasher
 
chunkSize - Variable in class com.google.common.hash.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.
CLASS_VALUE_VALIDATOR_NAME - Static variable in class com.google.common.util.concurrent.FuturesGetChecked.GetCheckedTypeValidatorHolder
 
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.
Classes of static utility methods - Search tag in package com.google.common.collect
Section
classesOnly() - Method in class com.google.common.reflect.TypeToken.TypeCollector
For just classes, we don't have to traverse interfaces.
classFilter - Variable in class com.google.common.testing.AbstractPackageSanityTests
 
ClassInfo(File, String, ClassLoader) - Constructor for class com.google.common.reflect.ClassPath.ClassInfo
 
classloader - Variable in class com.google.common.reflect.ClassPath.LocationInfo
 
className - Variable in class com.google.common.base.MoreObjects.ToStringHelper
 
className - Variable in class com.google.common.reflect.ClassPath.ClassInfo
 
ClassOwnership() - Constructor for enum class 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.LocationInfo - Class in com.google.common.reflect
Represents a single location (a directory or a jar file) in the class path and is responsible for scanning resources from this location.
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 and symlinks - Search tag in class com.google.common.reflect.ClassPath
Section
ClassSanityTester - Class in com.google.common.testing
Tester that runs automated sanity tests for any given class.
ClassSanityTester() - Constructor for class com.google.common.testing.ClassSanityTester
 
ClassSanityTester.FactoryMethodReturnsNullException - Exception Class in com.google.common.testing
Thrown if the test tries to invoke a static factory method to test instance methods but the factory returned null.
ClassSanityTester.FactoryMethodReturnValueTester - Class in com.google.common.testing
Runs sanity tests against return values of static factory methods declared by a class.
ClassSanityTester.ParameterHasNoDistinctValueException - Exception Class in com.google.common.testing
Thrown if the test fails to generate two distinct non-null values of a constructor or factory parameter in order to test Object.equals(java.lang.Object) and Object.hashCode() of the declaring class.
ClassSanityTester.ParameterNotInstantiableException - Exception Class in com.google.common.testing
Thrown if the test tries to invoke a constructor or static factory method but failed because the dummy value of a constructor or method parameter is unknown.
ClassSanityTester.SerializableDummyProxy - Class in com.google.common.testing
 
ClassSet() - Constructor for class com.google.common.reflect.TypeToken.ClassSet
 
classTesterRequirementsCache - Static variable in class com.google.common.collect.testing.features.FeatureUtil
 
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.
classValueValidator() - Static method in class com.google.common.util.concurrent.FuturesGetChecked
 
ClassValueValidator() - Constructor for enum class com.google.common.util.concurrent.FuturesGetChecked.GetCheckedTypeValidatorHolder.ClassValueValidator
 
clazz - Variable in class com.google.common.base.Predicates.InstanceOfPredicate
 
clazz - Variable in class com.google.common.base.Predicates.SubtypeOfPredicate
 
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() - 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(Reference<?>) - Method in class com.google.common.base.internal.Finalizer
Cleans up the given reference and any other references already in the queue.
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() - Method in class com.google.common.collect.CompactHashMap
 
clear() - Method in class com.google.common.collect.CompactHashSet
 
clear() - Method in class com.google.common.collect.CompactLinkedHashMap
 
clear() - Method in class com.google.common.collect.CompactLinkedHashSet
 
clear() - Method in class com.google.common.collect.ConcurrentHashMultiset
 
clear() - Method in class com.google.common.collect.EnumMultiset
 
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
Deprecated.
Unsupported operation.
clear() - Method in class com.google.common.collect.ImmutableTable
Deprecated.
Unsupported operation.
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.MapMakerInternalMap
 
clear() - Method in class com.google.common.collect.MapMakerInternalMap.EntrySet
 
clear() - Method in class com.google.common.collect.MapMakerInternalMap.KeySet
 
clear() - Method in class com.google.common.collect.MapMakerInternalMap.Segment
 
clear() - Method in class com.google.common.collect.MapMakerInternalMap.Values
 
clear() - Method in interface com.google.common.collect.MapMakerInternalMap.WeakValueReference
Unsets the referenced value.
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.IteratorBasedAbstractMap
 
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.UnmodifiableMultiset
 
clear() - Method in class com.google.common.collect.Multisets.ViewMultiset
 
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.Sets.SetView
Deprecated.
Unsupported 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 class com.google.common.collect.Synchronized.SynchronizedTable
 
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.testing.MinimalCollection
 
clear() - Method in class com.google.common.collect.testing.SafeTreeMap
 
clear() - Method in class com.google.common.collect.testing.SafeTreeSet
 
clear() - Method in class com.google.common.collect.TreeMultiset
 
clear() - Method in class com.google.common.collect.TreeMultiset.Reference
 
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.graph.MapIteratorCache
 
clear() - Method in class com.google.common.testing.TestLogHandler
 
clear() - Method in class com.google.common.util.concurrent.AtomicLongMap
Removes all of the mappings from this map.
clear(Buffer) - Static method in class com.google.common.base.Java8Compatibility
 
clear(Buffer) - Static method in class com.google.common.hash.Java8Compatibility
 
clear(Buffer) - Static method in class com.google.common.io.Java8Compatibility
 
clear(Iterator<?>) - Static method in class com.google.common.collect.Iterators
Clears the iterator using its remove method.
clearCache() - Method in class com.google.common.graph.MapIteratorCache
 
clearCache() - Method in class com.google.common.graph.MapRetrievalCache
 
clearKeyReferenceQueue() - Method in class com.google.common.cache.LocalCache.Segment
 
clearListeners(AbstractFuture.Listener) - Method in class com.google.common.util.concurrent.AbstractFuture
Clears the AbstractFuture.listeners list and prepends its contents to onto, least recently added first.
clearReferenceQueue(ReferenceQueue<T>) - 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.
clearSeenExceptions() - Method in class com.google.common.util.concurrent.AggregateFutureState
 
clearValueForTesting(K, int, MapMakerInternalMap.WeakValueReference<K, V, ? extends MapMakerInternalMap.InternalEntry<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
 
client - Variable in class com.google.common.net.InetAddresses.TeredoInfo
 
clone(T[]) - Static method in class com.google.common.collect.testing.Platform
 
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() - 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 class com.google.common.io.LittleEndianDataOutputStream
 
close() - Method in class com.google.common.io.MultiInputStream
 
close() - Method in class com.google.common.io.MultiReader
 
close() - Method in class com.google.common.io.ReaderInputStream
 
close() - Method in class com.google.common.testing.TestLogHandler
 
close() - Method in class com.google.common.util.concurrent.ClosingFuture
 
close() - Method in class com.google.common.util.concurrent.ClosingFuture.CloseableList
 
close(Closeable, boolean) - Static method in class com.google.common.io.Closeables
Closes a Closeable, with control over whether an IOException may be thrown.
CloseableList() - Constructor for class com.google.common.util.concurrent.ClosingFuture.CloseableList
 
closeables - Variable in class com.google.common.util.concurrent.ClosingFuture
 
closeables - Variable in class com.google.common.util.concurrent.ClosingFuture.Combiner
 
Closeables - Class in com.google.common.io
Utility methods for working with Closeable objects.
Closeables() - Constructor for class com.google.common.io.Closeables
 
closeAll(BaseStream<?, ?>[]) - Static method in class com.google.common.collect.Streams
 
closeAsync() - Method in class com.google.common.util.concurrent.ClosingFuture.ValueAndCloser
Starts closing all closeable objects captured during the ClosingFuture's asynchronous operation on the Executors specified by calls to ClosingFuture.DeferredCloser.eventuallyClose(Object, Executor).
closed - Variable in class com.google.common.io.AppendableWriter
 
closed - Variable in class com.google.common.util.concurrent.ClosingFuture.CloseableList
 
closed(int, int) - Static method in class com.google.common.collect.ContiguousSet
Returns a nonempty contiguous set containing all int values from lower (inclusive) to upper (inclusive).
closed(long, long) - Static method in class com.google.common.collect.ContiguousSet
Returns a nonempty contiguous set containing all long values from lower (inclusive) to upper (inclusive).
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 - Enum constant in enum class com.google.common.collect.BoundType
 
CLOSED - Enum constant in enum class com.google.common.util.concurrent.ClosingFuture.State
The ClosingFuture.CloseableList has been closed.
closedOpen(int, int) - Static method in class com.google.common.collect.ContiguousSet
Returns a contiguous set containing all int values from lower (inclusive) to upper (exclusive).
closedOpen(long, long) - Static method in class com.google.common.collect.ContiguousSet
Returns a contiguous set containing all long values from lower (inclusive) to upper (exclusive).
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.
closeQuietly(AutoCloseable, Executor) - Static method in class com.google.common.util.concurrent.ClosingFuture
 
closer - Variable in class com.google.common.util.concurrent.ClosingFuture.CloseableList
 
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.Suppressor - Interface in com.google.common.io
Suppression strategy interface.
CLOSING - Enum constant in enum class com.google.common.util.concurrent.ClosingFuture.State
The callback that closes the ClosingFuture.CloseableList is running, but it has not completed.
closingFuture - Variable in class com.google.common.util.concurrent.ClosingFuture.ValueAndCloser
 
ClosingFuture<V> - Class in com.google.common.util.concurrent
A step in a pipeline of an asynchronous computation.
ClosingFuture(ListenableFuture<V>) - Constructor for class com.google.common.util.concurrent.ClosingFuture
 
ClosingFuture(ListenableFuture<V>, ClosingFuture.CloseableList) - Constructor for class com.google.common.util.concurrent.ClosingFuture
 
ClosingFuture.AsyncClosingCallable<V> - Interface in com.google.common.util.concurrent
An operation that computes a ClosingFuture of a result.
ClosingFuture.AsyncClosingFunction<T,U> - Interface in com.google.common.util.concurrent
A function from an input to a ClosingFuture of a result.
ClosingFuture.CloseableList - Class in com.google.common.util.concurrent
 
ClosingFuture.ClosingCallable<V> - Interface in com.google.common.util.concurrent
An operation that computes a result.
ClosingFuture.ClosingFunction<T,U> - Interface in com.google.common.util.concurrent
A function from an input to a result.
ClosingFuture.Combiner - Class in com.google.common.util.concurrent
A builder of a ClosingFuture step that is derived from more than one input step.
ClosingFuture.Combiner.AsyncCombiningCallable<V> - Interface in com.google.common.util.concurrent
An operation that returns a ClosingFuture result and may throw an exception.
ClosingFuture.Combiner.CombiningCallable<V> - Interface in com.google.common.util.concurrent
An operation that returns a result and may throw an exception.
ClosingFuture.Combiner2<V1,V2> - Class in com.google.common.util.concurrent
A generic ClosingFuture.Combiner that lets you use a lambda or method reference to combine two ClosingFutures.
ClosingFuture.Combiner2.AsyncClosingFunction2<V1,V2,U> - Interface in com.google.common.util.concurrent
A function that returns a ClosingFuture when applied to the values of the two futures passed to ClosingFuture.whenAllSucceed(ClosingFuture, ClosingFuture).
ClosingFuture.Combiner2.ClosingFunction2<V1,V2,U> - Interface in com.google.common.util.concurrent
A function that returns a value when applied to the values of the two futures passed to ClosingFuture.whenAllSucceed(ClosingFuture, ClosingFuture).
ClosingFuture.Combiner3<V1,V2,V3> - Class in com.google.common.util.concurrent
A generic ClosingFuture.Combiner that lets you use a lambda or method reference to combine three ClosingFutures.
ClosingFuture.Combiner3.AsyncClosingFunction3<V1,V2,V3,U> - Interface in com.google.common.util.concurrent
A function that returns a ClosingFuture when applied to the values of the three futures passed to ClosingFuture.whenAllSucceed(ClosingFuture, ClosingFuture, ClosingFuture).
ClosingFuture.Combiner3.ClosingFunction3<V1,V2,V3,U> - Interface in com.google.common.util.concurrent
A function that returns a value when applied to the values of the three futures passed to ClosingFuture.whenAllSucceed(ClosingFuture, ClosingFuture, ClosingFuture).
ClosingFuture.Combiner4<V1,V2,V3,V4> - Class in com.google.common.util.concurrent
A generic ClosingFuture.Combiner that lets you use a lambda or method reference to combine four ClosingFutures.
ClosingFuture.Combiner4.AsyncClosingFunction4<V1,V2,V3,V4,U> - Interface in com.google.common.util.concurrent
A function that returns a ClosingFuture when applied to the values of the four futures passed to ClosingFuture.whenAllSucceed(ClosingFuture, ClosingFuture, ClosingFuture, ClosingFuture).
ClosingFuture.Combiner4.ClosingFunction4<V1,V2,V3,V4,U> - Interface in com.google.common.util.concurrent
A function that returns a value when applied to the values of the four futures passed to ClosingFuture.whenAllSucceed(ClosingFuture, ClosingFuture, ClosingFuture, ClosingFuture).
ClosingFuture.Combiner5<V1,V2,V3,V4,V5> - Class in com.google.common.util.concurrent
A generic ClosingFuture.Combiner that lets you use a lambda or method reference to combine five ClosingFutures.
ClosingFuture.Combiner5.AsyncClosingFunction5<V1,V2,V3,V4,V5,U> - Interface in com.google.common.util.concurrent
A function that returns a ClosingFuture when applied to the values of the five futures passed to ClosingFuture.whenAllSucceed(ClosingFuture, ClosingFuture, ClosingFuture, ClosingFuture, ClosingFuture).
ClosingFuture.Combiner5.ClosingFunction5<V1,V2,V3,V4,V5,U> - Interface in com.google.common.util.concurrent
A function that returns a value when applied to the values of the five futures passed to ClosingFuture.whenAllSucceed(ClosingFuture, ClosingFuture, ClosingFuture, ClosingFuture, ClosingFuture).
ClosingFuture.DeferredCloser - Class in com.google.common.util.concurrent
An object that can capture objects to be closed later, when a ClosingFuture pipeline is done.
ClosingFuture.Peeker - Class in com.google.common.util.concurrent
An object that can return the value of the ClosingFutures that are passed to ClosingFuture.whenAllComplete(Iterable) or ClosingFuture.whenAllSucceed(Iterable).
ClosingFuture.State - Enum Class in com.google.common.util.concurrent
ClosingFuture.ValueAndCloser<V> - Class in com.google.common.util.concurrent
An object that holds the final result of an asynchronous ClosingFuture operation and allows the user to close all the closeable objects that were captured during it for later closing.
ClosingFuture.ValueAndCloserConsumer<V> - Interface in com.google.common.util.concurrent
Represents an operation that accepts a ClosingFuture.ValueAndCloser for the last step in a ClosingFuture pipeline.
ClusterException - Exception Class in com.google.common.testing
An ClusterException is a data structure that allows for some code to "throw multiple exceptions", or something close to it.
ClusterException(Collection<? extends Throwable>) - Constructor for exception class com.google.common.testing.ClusterException
 
coalesce(Range<K>, V, Map.Entry<Cut<K>, TreeRangeMap.RangeMapEntry<K, V>>) - Static method in class com.google.common.collect.TreeRangeMap
Returns the range that spans the given range and entry, if the entry can be coalesced.
coalescedRange(Range<K>, V) - Method in class com.google.common.collect.TreeRangeMap
Computes the coalesced range for the given range+value - does not mutate the map.
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.
codePointToFourUtf8Bytes(int) - Static method in class com.google.common.hash.Murmur3_32HashFunction
 
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.
coldFactor - Variable in class com.google.common.util.concurrent.SmoothRateLimiter.SmoothWarmingUp
 
collapseFrom(CharSequence, char) - Method in class com.google.common.base.CharMatcher.Any
 
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 matching BMP characters replaced by a single replacement character.
collapseFrom(CharSequence, char) - Method in class com.google.common.base.CharMatcher.None
 
CollectCollectors - Class in com.google.common.collect
Collectors utilities for common.collect internals.
CollectCollectors() - Constructor for class com.google.common.collect.CollectCollectors
 
CollectCollectors.EnumMapAccumulator<K,V> - Class in com.google.common.collect
 
CollectCollectors.EnumSetAccumulator<E> - Class in com.google.common.collect
 
COLLECTED - Enum constant in enum class com.google.common.cache.RemovalCause
The entry was removed automatically because its key or value was garbage-collected.
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 - Variable in class com.google.common.collect.testing.AbstractCollectionTester
 
collection(Collection<E>, Object) - Static method in class com.google.common.collect.Synchronized
 
CollectionAddAllTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests addAll operations on a collection.
CollectionAddAllTester() - Constructor for class com.google.common.collect.testing.testers.CollectionAddAllTester
 
CollectionAddTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests add operations on a collection.
CollectionAddTester() - Constructor for class com.google.common.collect.testing.testers.CollectionAddTester
 
CollectionClearTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests clear() operations on a collection.
CollectionClearTester() - Constructor for class com.google.common.collect.testing.testers.CollectionClearTester
 
CollectionContainsAllTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests containsAll() operations on a collection.
CollectionContainsAllTester() - Constructor for class com.google.common.collect.testing.testers.CollectionContainsAllTester
 
CollectionContainsTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests contains() operations on a collection.
CollectionContainsTester() - Constructor for class com.google.common.collect.testing.testers.CollectionContainsTester
 
CollectionCreationTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests creation (typically through a constructor or static factory method) of a collection.
CollectionCreationTester() - Constructor for class com.google.common.collect.testing.testers.CollectionCreationTester
 
CollectionEqualsTester<E> - Class in com.google.common.collect.testing.testers
CollectionEqualsTester() - Constructor for class com.google.common.collect.testing.testers.CollectionEqualsTester
 
CollectionFeature - Enum Class in com.google.common.collect.testing.features
Optional features of classes derived from Collection.
CollectionFeature(Feature<? super Collection>...) - Constructor for enum class com.google.common.collect.testing.features.CollectionFeature
 
CollectionFeature.Require - Annotation Interface in com.google.common.collect.testing.features
 
CollectionForEachTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests forEach operations on a collection.
CollectionForEachTester() - Constructor for class com.google.common.collect.testing.testers.CollectionForEachTester
 
CollectionFuture<V,C> - Class in com.google.common.util.concurrent
Aggregate future that collects (stores) results of each future.
CollectionFuture(ImmutableCollection<? extends ListenableFuture<? extends V>>, boolean) - Constructor for class com.google.common.util.concurrent.CollectionFuture
 
CollectionFuture.ListFuture<V> - Class in com.google.common.util.concurrent
CollectionFuture.Present<V> - Class in com.google.common.util.concurrent
The result of a successful Future.
collectionGenerator - Variable in class com.google.common.collect.testing.DerivedTestIteratorGenerator
 
CollectionIsEmptyTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests isEmpty() operations on a collection.
CollectionIsEmptyTester() - Constructor for class com.google.common.collect.testing.testers.CollectionIsEmptyTester
 
CollectionIteratorTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests iterator operations on a collection.
CollectionIteratorTester() - Constructor for class com.google.common.collect.testing.testers.CollectionIteratorTester
 
collectionIteratorTesterNumIterations() - Static method in class com.google.common.collect.testing.testers.Platform
collectionOf(int) - Static method in class com.google.common.collect.testing.google.MapGenerators.ImmutableMapValuesAsSingletonSetGenerator
 
CollectionRemoveAllTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests removeAll operations on a collection.
CollectionRemoveAllTester() - Constructor for class com.google.common.collect.testing.testers.CollectionRemoveAllTester
 
CollectionRemoveIfTester<E> - Class in com.google.common.collect.testing.testers
CollectionRemoveIfTester() - Constructor for class com.google.common.collect.testing.testers.CollectionRemoveIfTester
 
CollectionRemoveTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests remove operations on a collection.
CollectionRemoveTester() - Constructor for class com.google.common.collect.testing.testers.CollectionRemoveTester
 
CollectionRetainAllTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests retainAll operations on a collection.
CollectionRetainAllTester() - Constructor for class com.google.common.collect.testing.testers.CollectionRetainAllTester
 
CollectionRetainAllTester.Target - Class in com.google.common.collect.testing.testers
A collection of elements to retain, along with a description for use in failure messages.
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
 
CollectionSerializationEqualTester<E> - Class in com.google.common.collect.testing.testers
Basic reserialization test for collection types that must preserve equals() behavior when reserialized.
CollectionSerializationEqualTester() - Constructor for class com.google.common.collect.testing.testers.CollectionSerializationEqualTester
 
CollectionSerializationTester<E> - Class in com.google.common.collect.testing.testers
Basic reserialization test for collections.
CollectionSerializationTester() - Constructor for class com.google.common.collect.testing.testers.CollectionSerializationTester
 
collectionSize - Variable in class com.google.common.collect.testing.OneSizeGenerator
 
CollectionSize - Enum Class in com.google.common.collect.testing.features
When describing the features of the collection produced by a given generator (i.e.
CollectionSize(int) - Constructor for enum class com.google.common.collect.testing.features.CollectionSize
 
CollectionSize(Feature<? super Collection>...) - Constructor for enum class com.google.common.collect.testing.features.CollectionSize
 
CollectionSize.Require - Annotation Interface in com.google.common.collect.testing.features
 
CollectionSizeTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests size() operations on a collection.
CollectionSizeTester() - Constructor for class com.google.common.collect.testing.testers.CollectionSizeTester
 
CollectionSpliteratorTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests spliterator operations on a collection.
CollectionSpliteratorTester() - Constructor for class com.google.common.collect.testing.testers.CollectionSpliteratorTester
 
CollectionStreamTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests stream operations on a collection.
CollectionStreamTester() - Constructor for class com.google.common.collect.testing.testers.CollectionStreamTester
 
CollectionTestSuiteBuilder<E> - Class in com.google.common.collect.testing
Concrete instantiation of AbstractCollectionTestSuiteBuilder for testing collections that do not have a more specific tester like ListTestSuiteBuilder or SetTestSuiteBuilder.
CollectionTestSuiteBuilder() - Constructor for class com.google.common.collect.testing.CollectionTestSuiteBuilder
 
CollectionTestSuiteBuilder.ReserializedCollectionGenerator<E> - Class in com.google.common.collect.testing
 
CollectionToArrayTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests toArray() operations on a collection.
CollectionToArrayTester() - Constructor for class com.google.common.collect.testing.testers.CollectionToArrayTester
 
CollectionToStringTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests toString() operations on a collection.
CollectionToStringTester() - Constructor for class com.google.common.collect.testing.testers.CollectionToStringTester
 
Collection types - Search tag in package com.google.common.collect
Section
collectOneValue(int, InputT) - Method in class com.google.common.util.concurrent.AggregateFuture
If allMustSucceed is true, called as each future completes; otherwise, if collectsValues is true, called for each future when all futures complete.
collectOneValue(int, Object) - Method in class com.google.common.util.concurrent.CombinedFuture
 
collectOneValue(int, V) - Method in class com.google.common.util.concurrent.CollectionFuture
 
collector - Variable in class com.google.common.testing.CollectorTester
 
CollectorTester<T,A,R> - Class in com.google.common.testing
Tester for Collector implementations.
CollectorTester(Collector<T, A, R>, BiPredicate<? super R, ? super R>) - Constructor for class com.google.common.testing.CollectorTester
 
CollectorTester.CollectStrategy - Enum Class in com.google.common.testing
Different orderings for combining the elements of an input array, which must all produce the same result.
CollectPreconditions - Class in com.google.common.collect
Precondition checks useful in collection implementations.
CollectPreconditions() - Constructor for class com.google.common.collect.CollectPreconditions
 
CollectSpliterators - Class in com.google.common.collect
Spliterator utilities for common.collect internals.
CollectSpliterators() - Constructor for class com.google.common.collect.CollectSpliterators
 
CollectSpliterators.FlatMapSpliterator<InElementT,OutElementT,OutSpliteratorT> - Class in com.google.common.collect
Implements the
invalid reference
Stream#flatMap
operation on spliterators.
CollectSpliterators.FlatMapSpliterator.Factory<InElementT,OutSpliteratorT> - Interface in com.google.common.collect
Factory for constructing CollectSpliterators.FlatMapSpliterator instances.
CollectSpliterators.FlatMapSpliteratorOfDouble<InElementT> - Class in com.google.common.collect
CollectSpliterators.FlatMapSpliteratorOfInt<InElementT> - Class in com.google.common.collect
CollectSpliterators.FlatMapSpliteratorOfLong<InElementT> - Class in com.google.common.collect
CollectSpliterators.FlatMapSpliteratorOfObject<InElementT,OutElementT> - Class in com.google.common.collect
Implementation of
invalid reference
Stream#flatMap
with an object spliterator output type.
CollectSpliterators.FlatMapSpliteratorOfPrimitive<InElementT,OutElementT,OutConsumerT,OutSpliteratorT> - Class in com.google.common.collect
Implementation of
invalid reference
Stream#flatMap
with a primitive spliterator output type.
CollectStrategy() - Constructor for enum class com.google.common.testing.CollectorTester.CollectStrategy
 
collectsValues - Variable in class com.google.common.util.concurrent.AggregateFuture
 
collectTypes(Iterable<? extends K>) - Method in class com.google.common.reflect.TypeToken.TypeCollector
 
collectTypes(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.
collectValueFromNonCancelledFuture(int, Future<? extends InputT>) - Method in class com.google.common.util.concurrent.AggregateFuture
Collects the result (success or failure) of one input future.
Collider(int) - Constructor for class com.google.common.collect.testing.SampleElements.Collider
 
Colliders() - Constructor for class com.google.common.collect.testing.SampleElements.Colliders
 
column - Variable in class com.google.common.collect.TableCollectors.MutableCell
 
column(C) - Method in class com.google.common.collect.ArrayTable
Returns a view of all mappings that have the given column key.
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) - Method in class com.google.common.collect.Synchronized.SynchronizedTable
 
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(C) - Method in class com.google.common.collect.Tables.UnmodifiableTable
 
column(R) - Method in class com.google.common.collect.Tables.TransposeTable
 
Column(int) - Constructor for class com.google.common.collect.ArrayTable.Column
 
Column(int) - Constructor for class com.google.common.collect.DenseImmutableTable.Column
 
Column(C) - Constructor for class com.google.common.collect.StandardTable.Column
 
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
Deprecated.
Store the Comparator alongside the Table. Or, if you know that the Table contains at least one value, you can retrieve the Comparator with: ((SortedMap<C, V>) table.rowMap().values().iterator().next()).comparator();.
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.
columnKeys - Variable in class com.google.common.collect.ImmutableTable.SerializedForm
 
columnKeySet - Variable in class com.google.common.collect.StandardTable
 
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() - Method in class com.google.common.collect.StandardTable
Returns a set of column keys that have one or more values in the table.
columnKeySet() - Method in class com.google.common.collect.Synchronized.SynchronizedTable
 
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
 
ColumnKeySet() - Constructor for class com.google.common.collect.StandardTable.ColumnKeySet
 
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 - Variable in class com.google.common.collect.DenseImmutableTable
 
columnMap - Variable in class com.google.common.collect.SparseImmutableTable
 
columnMap - Variable in class com.google.common.collect.StandardTable
 
columnMap() - Method in class com.google.common.collect.ArrayTable
 
columnMap() - Method in class com.google.common.collect.DenseImmutableTable
 
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() - Method in class com.google.common.collect.SparseImmutableTable
 
columnMap() - Method in class com.google.common.collect.StandardTable
 
columnMap() - Method in class com.google.common.collect.Synchronized.SynchronizedTable
 
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
 
ColumnMap() - Constructor for class com.google.common.collect.ArrayTable.ColumnMap
 
ColumnMap() - Constructor for class com.google.common.collect.DenseImmutableTable.ColumnMap
 
ColumnMap() - Constructor for class com.google.common.collect.StandardTable.ColumnMap
 
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
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
Discouraged (in favor of Caffeine) caching utilities.
com.google.common.collect - package com.google.common.collect
Collection interfaces and implementations, and other utilities for collections.
com.google.common.collect.testing - package com.google.common.collect.testing
 
com.google.common.collect.testing.features - package com.google.common.collect.testing.features
 
com.google.common.collect.testing.google - package com.google.common.collect.testing.google
 
com.google.common.collect.testing.testers - package com.google.common.collect.testing.testers
 
com.google.common.escape - package com.google.common.escape
Interfaces, utilities, and simple implementations of escapers and encoders.
com.google.common.escape.testing - package com.google.common.escape.testing
Testing utilities for use in tests of com.google.common.escape.
com.google.common.eventbus - package com.google.common.eventbus
Discouraged in favor of dependency injection and concurrency frameworks, EventBus allows publish-subscribe-style communication.
com.google.common.graph - package com.google.common.graph
An API for representing graph (node and edge) data.
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
Utility methods and classes for 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 on BigInteger and BigDecimal instances.
com.google.common.net - package com.google.common.net
Utility methods and classes for networking (such as IP addresses and domain names).
com.google.common.primitives - package com.google.common.primitives
Static utilities for the eight primitive types and void, and value types for treating them as unsigned or storing them in immutable arrays.
com.google.common.reflect - package com.google.common.reflect
Utilities for reflection.
com.google.common.testing - package com.google.common.testing
Testing utilities.
com.google.common.util.concurrent - package com.google.common.util.concurrent
Concurrency utilities.
com.google.common.util.concurrent.internal - package com.google.common.util.concurrent.internal
 
com.google.common.util.concurrent.testing - package com.google.common.util.concurrent.testing
 
com.google.common.xml - package com.google.common.xml
Escapers for XML.
com.google.thirdparty.publicsuffix - package com.google.thirdparty.publicsuffix
 
combinations(Set<E>, int) - Static method in class com.google.common.collect.Sets
Returns the set of all subsets of set of size size.
combine(int, int) - Static method in class com.google.common.hash.Crc32cHashFunction.Crc32cHasher
 
combine(CollectCollectors.EnumMapAccumulator<K, V>) - Method in class com.google.common.collect.CollectCollectors.EnumMapAccumulator
 
combine(CollectCollectors.EnumSetAccumulator<E>) - Method in class com.google.common.collect.CollectCollectors.EnumSetAccumulator
 
combine(ImmutableList.Builder<E>) - Method in class com.google.common.collect.ImmutableList.Builder
 
combine(ImmutableMap.Builder<K, V>) - Method in class com.google.common.collect.ImmutableBiMap.Builder
 
combine(ImmutableMap.Builder<K, V>) - Method in class com.google.common.collect.ImmutableMap.Builder
 
combine(ImmutableMap.Builder<K, V>) - Method in class com.google.common.collect.ImmutableSortedMap.Builder
 
combine(ImmutableMultimap.Builder<K, V>) - Method in class com.google.common.collect.ImmutableListMultimap.Builder
 
combine(ImmutableMultimap.Builder<K, V>) - Method in class com.google.common.collect.ImmutableMultimap.Builder
 
combine(ImmutableMultimap.Builder<K, V>) - Method in class com.google.common.collect.ImmutableSetMultimap.Builder
 
combine(ImmutableRangeMap.Builder<K, V>) - Method in class com.google.common.collect.ImmutableRangeMap.Builder
 
combine(ImmutableRangeSet.Builder<C>) - Method in class com.google.common.collect.ImmutableRangeSet.Builder
 
combine(ImmutableSet.Builder<E>) - Method in class com.google.common.collect.ImmutableSet.Builder
 
combine(ImmutableSet.Builder<E>) - Method in class com.google.common.collect.ImmutableSortedSet.Builder
 
combine(ImmutableSet.SetBuilderImpl<E>) - Method in class com.google.common.collect.ImmutableSet.SetBuilderImpl
Adds all the elements from the specified SetBuilderImpl to this SetBuilderImpl.
combine(ImmutableTable.Builder<R, C, V>) - Method in class com.google.common.collect.ImmutableTable.Builder
 
combine(MoreCollectors.ToOptionalState) - Method in class com.google.common.collect.MoreCollectors.ToOptionalState
 
combine(TableCollectors.ImmutableTableCollectorState<R, C, V>, BinaryOperator<V>) - Method in class com.google.common.collect.TableCollectors.ImmutableTableCollectorState
 
combine(TopKSelector<T>) - Method in class com.google.common.collect.TopKSelector
 
combine(List<CollectionFuture.Present<V>>) - Method in class com.google.common.util.concurrent.CollectionFuture
 
combine(List<CollectionFuture.Present<V>>) - Method in class com.google.common.util.concurrent.CollectionFuture.ListFuture
 
combineBuffers(Queue<byte[]>, int) - Static method in class com.google.common.io.ByteStreams
 
CombinedFuture<V> - Class in com.google.common.util.concurrent
Aggregate future that computes its value by calling a callable.
CombinedFuture(ImmutableCollection<? extends ListenableFuture<?>>, boolean, Executor, AsyncCallable<V>) - Constructor for class com.google.common.util.concurrent.CombinedFuture
 
CombinedFuture(ImmutableCollection<? extends ListenableFuture<?>>, boolean, Executor, Callable<V>) - Constructor for class com.google.common.util.concurrent.CombinedFuture
 
CombinedFuture.AsyncCallableInterruptibleTask - Class in com.google.common.util.concurrent
 
CombinedFuture.CallableInterruptibleTask - Class in com.google.common.util.concurrent
 
CombinedFuture.CombinedFutureInterruptibleTask<T> - Class in com.google.common.util.concurrent
 
CombinedFutureInterruptibleTask(Executor) - Constructor for class com.google.common.util.concurrent.CombinedFuture.CombinedFutureInterruptibleTask
 
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(boolean, Iterable<? extends ClosingFuture<?>>) - Constructor for class com.google.common.util.concurrent.ClosingFuture.Combiner
 
Combiner2(ClosingFuture<V1>, ClosingFuture<V2>) - Constructor for class com.google.common.util.concurrent.ClosingFuture.Combiner2
 
Combiner3(ClosingFuture<V1>, ClosingFuture<V2>, ClosingFuture<V3>) - Constructor for class com.google.common.util.concurrent.ClosingFuture.Combiner3
 
Combiner4(ClosingFuture<V1>, ClosingFuture<V2>, ClosingFuture<V3>, ClosingFuture<V4>) - Constructor for class com.google.common.util.concurrent.ClosingFuture.Combiner4
 
Combiner5(ClosingFuture<V1>, ClosingFuture<V2>, ClosingFuture<V3>, ClosingFuture<V4>, ClosingFuture<V5>) - Constructor for class com.google.common.util.concurrent.ClosingFuture.Combiner5
 
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.
Combining - Search tag in class com.google.common.util.concurrent.ClosingFuture
Section
COMMA_JOINER - Static variable in class com.google.common.reflect.Types
Class#toString without the "class " and "interface " prefixes
CommonMatcher - Class in com.google.common.base
The subset of the Matcher API which is used by this package, and also shared with the re2j library.
CommonMatcher() - Constructor for class com.google.common.base.CommonMatcher
 
CommonPattern - Class in com.google.common.base
The subset of the Pattern API which is used by this package, and also shared with the re2j library.
CommonPattern() - Constructor for class com.google.common.base.CommonPattern
 
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.
Common ways to use - Search tag in class com.google.common.base.Converter
Section
CompactHashing - Class in com.google.common.collect
Helper classes and static methods for implementing compact hash-based collections.
CompactHashing() - Constructor for class com.google.common.collect.CompactHashing
 
CompactHashMap<K,V> - Class in com.google.common.collect
CompactHashMap is an implementation of a Map.
CompactHashMap() - Constructor for class com.google.common.collect.CompactHashMap
Constructs a new empty instance of CompactHashMap.
CompactHashMap(int) - Constructor for class com.google.common.collect.CompactHashMap
Constructs a new instance of CompactHashMap with the specified capacity.
CompactHashMap.EntrySetView - Class in com.google.common.collect
 
CompactHashMap.Itr<T> - Class in com.google.common.collect
 
CompactHashMap.KeySetView - Class in com.google.common.collect
 
CompactHashMap.MapEntry - Class in com.google.common.collect
 
CompactHashMap.ValuesView - Class in com.google.common.collect
 
CompactHashSet<E> - Class in com.google.common.collect
CompactHashSet is an implementation of a Set.
CompactHashSet() - Constructor for class com.google.common.collect.CompactHashSet
Constructs a new empty instance of CompactHashSet.
CompactHashSet(int) - Constructor for class com.google.common.collect.CompactHashSet
Constructs a new instance of CompactHashSet with the specified capacity.
CompactLinkedHashMap<K,V> - Class in com.google.common.collect
CompactLinkedHashMap is an implementation of a Map with insertion or LRU iteration order, maintained with a doubly linked list through the entries.
CompactLinkedHashMap() - Constructor for class com.google.common.collect.CompactLinkedHashMap
 
CompactLinkedHashMap(int) - Constructor for class com.google.common.collect.CompactLinkedHashMap
 
CompactLinkedHashMap(int, boolean) - Constructor for class com.google.common.collect.CompactLinkedHashMap
 
CompactLinkedHashSet<E> - Class in com.google.common.collect
CompactLinkedHashSet is an implementation of a Set, which a predictable iteration order that matches the insertion order.
CompactLinkedHashSet() - Constructor for class com.google.common.collect.CompactLinkedHashSet
 
CompactLinkedHashSet(int) - Constructor for class com.google.common.collect.CompactLinkedHashSet
 
CompactStriped(int, Supplier<L>) - Constructor for class com.google.common.util.concurrent.Striped.CompactStriped
 
COMPARABLE_REVERSED - Static variable in class com.google.common.collect.testing.google.SetGenerators.ImmutableSortedSetExplicitSuperclassComparatorGenerator
 
comparator - Variable 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 - Variable in class com.google.common.collect.GeneralRange
 
comparator - Variable in class com.google.common.collect.ImmutableSortedMap.Builder
 
comparator - Variable in class com.google.common.collect.ImmutableSortedMap.SerializedForm
 
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 - Variable in class com.google.common.collect.ImmutableSortedSet.SerializedForm
 
comparator - Variable in class com.google.common.collect.Maps.DescendingMap
 
comparator - Variable in class com.google.common.collect.MinMaxPriorityQueue.Builder
 
comparator - Variable in class com.google.common.collect.MultimapBuilder.TreeSetSupplier
 
comparator - Variable in class com.google.common.collect.testing.DerivedCollectionGenerators.SortedSetSubsetTestSetGenerator
 
comparator - Variable in class com.google.common.collect.TopKSelector
 
comparator - Variable in class com.google.common.collect.TreeBasedTable.Factory
 
comparator - Variable in class com.google.common.graph.ElementOrder
 
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() - Method in class com.google.common.collect.AbstractSortedMultiset
 
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() - Method in class com.google.common.collect.GeneralRange
 
comparator() - Method in class com.google.common.collect.ImmutableSortedAsList
 
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() - Method in class com.google.common.collect.ImmutableSortedMultiset
 
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() - 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() - Method in class com.google.common.collect.MinMaxPriorityQueue
Returns the comparator used to order the elements in this queue.
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() - 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() - Method in class com.google.common.collect.testing.SafeTreeMap
 
comparator() - Method in class com.google.common.collect.testing.SafeTreeSet
 
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
 
comparator() - Method in class com.google.common.graph.ElementOrder
Returns the Comparator used.
comparator(SortedSet<E>) - Static method in class com.google.common.collect.SortedIterables
 
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
 
Comparators - Class in com.google.common.collect
Provides static methods for working with Comparator instances.
Comparators() - Constructor for class com.google.common.collect.Comparators
 
compare(boolean[], boolean[]) - Method in enum class com.google.common.primitives.Booleans.LexicographicalComparator
 
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(byte[], byte[]) - Method in enum class com.google.common.primitives.SignedBytes.LexicographicalComparator
 
compare(byte[], byte[]) - Method in enum class com.google.common.primitives.UnsignedBytes.LexicographicalComparatorHolder.PureJavaComparator
 
compare(byte[], byte[]) - Method in enum class com.google.common.primitives.UnsignedBytes.LexicographicalComparatorHolder.UnsafeComparator
 
compare(byte, byte) - Static method in class com.google.common.primitives.SignedBytes
Compares the two specified byte values.
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(char[], char[]) - Method in enum class com.google.common.primitives.Chars.LexicographicalComparator
 
compare(char, char) - Static method in class com.google.common.primitives.Chars
Compares the two specified char values.
compare(double[], double[]) - Method in enum class com.google.common.primitives.Doubles.LexicographicalComparator
 
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(double, double) - Method in class com.google.common.collect.ComparisonChain.InactiveComparisonChain
 
compare(double, double) - Static method in class com.google.common.primitives.Doubles
Compares the two specified double values.
compare(float[], float[]) - Method in enum class com.google.common.primitives.Floats.LexicographicalComparator
 
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(float, float) - Method in class com.google.common.collect.ComparisonChain.InactiveComparisonChain
 
compare(float, float) - Static method in class com.google.common.primitives.Floats
Compares the two specified float values using Float.compare(float, float).
compare(int[], int[]) - Method in enum class com.google.common.primitives.Ints.LexicographicalComparator
 
compare(int[], int[]) - Method in enum class com.google.common.primitives.UnsignedInts.LexicographicalComparator
 
compare(int, int) - Method in class com.google.common.collect.ComparisonChain
Compares two int values as specified by Integer.compare(int, int), if the result of this comparison chain has not already been determined.
compare(int, int) - Method in class com.google.common.collect.ComparisonChain.InactiveComparisonChain
 
compare(int, int) - Static method in class com.google.common.primitives.Ints
Compares the two specified int values.
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(long[], long[]) - Method in enum class com.google.common.primitives.Longs.LexicographicalComparator
 
compare(long[], long[]) - Method in enum class com.google.common.primitives.UnsignedLongs.LexicographicalComparator
 
compare(long, long) - Method in class com.google.common.collect.ComparisonChain
Compares two long values as specified by Long.compare(long, long), if the result of this comparison chain has not already been determined.
compare(long, long) - Method in class com.google.common.collect.ComparisonChain.InactiveComparisonChain
 
compare(long, long) - Static method in class com.google.common.primitives.Longs
Compares the two specified long values.
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(short[], short[]) - Method in enum class com.google.common.primitives.Shorts.LexicographicalComparator
 
compare(short, short) - Static method in class com.google.common.primitives.Shorts
Compares the two specified short values.
compare(Multiset.Entry<?>, Multiset.Entry<?>) - Method in class com.google.common.collect.Multisets.DecreasingCount
 
compare(Range<?>, Range<?>) - Method in class com.google.common.collect.Range.RangeLexOrdering
 
compare(F, F) - Method in class com.google.common.collect.ByFunctionOrdering
 
compare(Boolean, Boolean) - Method in class com.google.common.collect.ComparisonChain
Deprecated.
Use ComparisonChain.compareFalseFirst(boolean, boolean); or, if the parameters passed are being either negated or reversed, undo the negation or reversal and use ComparisonChain.compareTrueFirst(boolean, boolean).
compare(Boolean, Boolean) - Method in enum class com.google.common.primitives.Booleans.BooleanComparator
 
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(Comparable<?>, Comparable<?>) - Method in class com.google.common.collect.ComparisonChain.InactiveComparisonChain
 
compare(Comparable<?>, Comparable<?>) - Method in class com.google.common.collect.NaturalOrdering
 
compare(Comparable<?>, Comparable<?>) - Method in class com.google.common.collect.ReverseNaturalOrdering
 
compare(Iterable<T>, Iterable<T>) - Method in class com.google.common.collect.LexicographicalOrdering
 
compare(Object, Object) - Method in class com.google.common.collect.AllEqualOrdering
 
compare(Object, Object) - Method in class com.google.common.collect.Ordering.ArbitraryOrdering
 
compare(Object, Object) - Method in class com.google.common.collect.TreeBasedTable.TreeRow
 
compare(Object, Object) - Method in class com.google.common.collect.UsingToStringOrdering
 
compare(Object, Object) - Method in class com.google.common.testing.ArbitraryInstances.AlwaysEqual
 
compare(String, String) - Method in class com.google.common.collect.testing.Helpers.NullsBefore
 
compare(Map.Entry<K, V>, Map.Entry<K, V>) - Method in class com.google.common.collect.testing.Helpers.EntryComparator
 
compare(T, T) - Method in class com.google.common.collect.ComparatorOrdering
 
compare(T, T) - Method in class com.google.common.collect.CompoundOrdering
 
compare(T, T) - Method in class com.google.common.collect.ExplicitOrdering
 
compare(T, T) - Method in class com.google.common.collect.NullsFirstOrdering
 
compare(T, T) - Method in class com.google.common.collect.NullsLastOrdering
 
compare(T, T) - Method in class com.google.common.collect.Ordering
 
compare(T, T) - Method in class com.google.common.collect.ReverseOrdering
 
compare(T, T) - Method in class com.google.common.collect.testing.TestsForMapsInJavaUtil.NullFriendlyComparator
 
compare(T, T) - Method in class com.google.common.collect.testing.TestsForSetsInJavaUtil.NullFriendlyComparator
 
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(T, T, Comparator<T>) - Method in class com.google.common.collect.ComparisonChain.InactiveComparisonChain
 
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.
compareAndSetSeenExceptions(AggregateFutureState<?>, Set<Throwable>, Set<Throwable>) - Method in class com.google.common.util.concurrent.AggregateFutureState.AtomicHelper
Atomic compare-and-set of the AggregateFutureState.seenExceptions field.
compareAndSetSeenExceptions(AggregateFutureState<?>, Set<Throwable>, Set<Throwable>) - Method in class com.google.common.util.concurrent.AggregateFutureState.SafeAtomicHelper
 
compareAndSetSeenExceptions(AggregateFutureState<?>, Set<Throwable>, Set<Throwable>) - Method in class com.google.common.util.concurrent.AggregateFutureState.SynchronizedAtomicHelper
 
compareAndUpdateState(ClosingFuture.State, ClosingFuture.State) - Method in class com.google.common.util.concurrent.ClosingFuture
 
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
 
compareResultsForThisListOfStimuli() - Method in class com.google.common.collect.testing.AbstractIteratorTester
 
compareTo(Cut<C>) - Method in class com.google.common.collect.Cut
 
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(BaseComparable) - Method in class com.google.common.collect.testing.BaseComparable
 
compareTo(UnhashableObject) - Method in class com.google.common.collect.testing.UnhashableObject
 
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(Object) - Method in class com.google.common.testing.ArbitraryInstances.ByToString
 
compareTo(Delayed) - Method in class com.google.common.util.concurrent.MoreExecutors.ScheduledListeningDecorator.ListenableScheduledTask
 
compareTo(Delayed) - Method in class com.google.common.util.concurrent.testing.SameThreadScheduledExecutorService.ImmediateScheduledFuture
 
compareTo(Delayed) - Method in class com.google.common.util.concurrent.testing.TestingExecutors.NoOpScheduledExecutorService.NeverScheduledFuture
 
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
 
Comparison to alternatives - Search tag in class com.google.common.base.Verify
Section
Comparison to a map of collections - Search tag in interface com.google.common.collect.Multimap
Section
Comparison to streams - Search tag in class com.google.common.collect.FluentIterable
Section
Comparison with synchronized and ReentrantLock - Search tag in class com.google.common.util.concurrent.Monitor
Section
compile(String) - Static method in class com.google.common.base.CommonPattern
 
compile(String) - Method in interface com.google.common.base.PatternCompiler
Compiles the given pattern.
compile(String) - Method in class com.google.common.base.Platform.JdkPatternCompiler
 
compilePattern(String) - Static method in class com.google.common.base.Platform
 
complement - Variable in class com.google.common.collect.ImmutableRangeSet
 
complement - Variable in class com.google.common.collect.TreeRangeSet
 
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() - Method in class com.google.common.collect.TreeRangeSet
 
complement() - Method in class com.google.common.collect.TreeRangeSet.Complement
 
Complement() - Constructor for 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(AbstractFuture<?>, boolean) - Static method in class com.google.common.util.concurrent.AbstractFuture
Unblocks all threads and runs all listeners.
COMPLETE - Enum constant in enum class com.google.common.graph.Graphs.NodeVisitState
 
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<? 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.
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.
CompositionPredicate(Predicate<B>, Function<A, ? extends B>) - Constructor for class com.google.common.base.Predicates.CompositionPredicate
 
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.
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.
CompoundOrdering<T> - Class in com.google.common.collect
An ordering that tries several comparators in order.
CompoundOrdering(Iterable<? extends Comparator<? super T>>) - Constructor for class com.google.common.collect.CompoundOrdering
 
CompoundOrdering(Comparator<? super T>, 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 Class in com.google.common.collect
Deprecated.
This exception is no longer thrown by com.google.common. Previously, it was thrown by MapMaker computing maps. When support for computing maps was removed from MapMaker, it was added to CacheBuilder, which throws ExecutionException, UncheckedExecutionException, and ExecutionError. Any code that is still catching ComputationException may need to be updated to catch some of those types instead. (Note that this type, though deprecated, is not planned to be removed from Guava.)
ComputationException(Throwable) - Constructor for exception class com.google.common.collect.ComputationException
Deprecated.
Creates a new instance with the given cause.
compute(double...) - Method in class com.google.common.math.Quantiles.ScaleAndIndex
Computes the quantile value of the given dataset.
compute(double...) - Method in class com.google.common.math.Quantiles.ScaleAndIndexes
Computes the quantile values of the given dataset.
compute(int...) - Method in class com.google.common.math.Quantiles.ScaleAndIndex
Computes the quantile value of the given dataset.
compute(int...) - Method in class com.google.common.math.Quantiles.ScaleAndIndexes
Computes the quantile values of the given dataset.
compute(long...) - Method in class com.google.common.math.Quantiles.ScaleAndIndex
Computes the quantile value of the given dataset.
compute(long...) - Method in class com.google.common.math.Quantiles.ScaleAndIndexes
Computes the quantile values of the given dataset.
compute(Collection<? extends Number>) - Method in class com.google.common.math.Quantiles.ScaleAndIndex
Computes the quantile value of the given dataset.
compute(Collection<? extends Number>) - Method in class com.google.common.math.Quantiles.ScaleAndIndexes
Computes the quantile values of the given dataset.
compute(K, int, BiFunction<? super K, ? super V, ? extends V>) - Method in class com.google.common.cache.LocalCache.Segment
 
compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class com.google.common.cache.LocalCache
 
compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class com.google.common.cache.LocalCache.LoadingValueReference
 
compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class com.google.common.collect.ImmutableMap
Deprecated.
Unsupported operation.
compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class com.google.common.collect.Maps.UnmodifiableBiMap
 
compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class com.google.common.collect.Synchronized.SynchronizedMap
 
computeArrayListCapacity(int) - Static method in class com.google.common.collect.Lists
 
computeAsMapFeatures(Set<Feature<?>>) - Static method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder
 
computeBackingRowMap() - Method in class com.google.common.collect.StandardTable.Row
 
computeBackingRowMap() - Method in class com.google.common.collect.TreeBasedTable.TreeRow
 
computeCommonDerivedCollectionFeatures(Set<Feature<?>>) - Static method in class com.google.common.collect.testing.google.BiMapTestSuiteBuilder
 
computeCommonDerivedCollectionFeatures(Set<Feature<?>>) - Static method in class com.google.common.collect.testing.MapTestSuiteBuilder
 
computeDerivedCollectionFeatures(Set<Feature<?>>) - Static method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder
 
computeElementSetFeatures(Set<Feature<?>>) - Static method in class com.google.common.collect.testing.google.MultisetTestSuiteBuilder
 
computeEntriesFeatures(Set<Feature<?>>) - Static method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder
 
computeEntriesTestSuite(FeatureSpecificTestSuiteBuilder<?, ? extends OneSizeTestContainerGenerator<SetMultimap<K, V>, Map.Entry<K, V>>>) - Method in class com.google.common.collect.testing.google.SetMultimapTestSuiteBuilder
 
computeEntriesTestSuite(FeatureSpecificTestSuiteBuilder<?, ? extends OneSizeTestContainerGenerator<M, Map.Entry<K, V>>>) - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder
 
computeEntrySetFeatures(Set<Feature<?>>) - Static method in class com.google.common.collect.testing.google.MultisetTestSuiteBuilder
 
computeEntrySetFeatures(Set<Feature<?>>) - Static method in class com.google.common.collect.testing.MapTestSuiteBuilder
 
computeForWord(int) - Static method in class com.google.common.hash.Crc32cHashFunction.Crc32cHasher
 
computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class com.google.common.cache.LocalCache
 
computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class com.google.common.collect.ImmutableMap
Deprecated.
Unsupported operation.
computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class com.google.common.collect.Maps.UnmodifiableBiMap
 
computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class com.google.common.collect.Synchronized.SynchronizedMap
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class com.google.common.cache.LocalCache
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class com.google.common.collect.ImmutableMap
Deprecated.
Unsupported operation.
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class com.google.common.collect.Maps.UnmodifiableBiMap
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class com.google.common.collect.Synchronized.SynchronizedMap
 
computeInPlace(double...) - Method in class com.google.common.math.Quantiles.ScaleAndIndex
Computes the quantile value of the given dataset, performing the computation in-place.
computeInPlace(double...) - Method in class com.google.common.math.Quantiles.ScaleAndIndexes
Computes the quantile values of the given dataset, performing the computation in-place.
computeInverseFeatures(Set<Feature<?>>) - Static method in class com.google.common.collect.testing.google.BiMapTestSuiteBuilder
 
computeKeySetFeatures(Set<Feature<?>>) - Static method in class com.google.common.collect.testing.MapTestSuiteBuilder
 
computeKeysFeatures(Set<Feature<?>>) - Static method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder
 
computeKeysTestSuite(FeatureSpecificTestSuiteBuilder<?, ? extends OneSizeTestContainerGenerator<M, Map.Entry<K, V>>>) - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder
 
computeMultimapAsMapGetFeatures(Set<Feature<?>>) - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder
 
computeMultimapAsMapGetTestSuite(FeatureSpecificTestSuiteBuilder<?, ? extends OneSizeTestContainerGenerator<ListMultimap<K, V>, Map.Entry<K, V>>>) - Method in class com.google.common.collect.testing.google.ListMultimapTestSuiteBuilder
 
computeMultimapAsMapGetTestSuite(FeatureSpecificTestSuiteBuilder<?, ? extends OneSizeTestContainerGenerator<SetMultimap<K, V>, Map.Entry<K, V>>>) - Method in class com.google.common.collect.testing.google.SetMultimapTestSuiteBuilder
 
computeMultimapAsMapGetTestSuite(FeatureSpecificTestSuiteBuilder<?, ? extends OneSizeTestContainerGenerator<SetMultimap<K, V>, Map.Entry<K, V>>>) - Method in class com.google.common.collect.testing.google.SortedSetMultimapTestSuiteBuilder
 
computeMultimapAsMapGetTestSuite(FeatureSpecificTestSuiteBuilder<?, ? extends OneSizeTestContainerGenerator<M, Map.Entry<K, V>>>) - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder
 
computeMultimapGetFeatures(Set<Feature<?>>) - Method in class com.google.common.collect.testing.google.ListMultimapTestSuiteBuilder
 
computeMultimapGetFeatures(Set<Feature<?>>) - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder
 
computeMultimapGetTestSuite(FeatureSpecificTestSuiteBuilder<?, ? extends OneSizeTestContainerGenerator<ListMultimap<K, V>, Map.Entry<K, V>>>) - Method in class com.google.common.collect.testing.google.ListMultimapTestSuiteBuilder
 
computeMultimapGetTestSuite(FeatureSpecificTestSuiteBuilder<?, ? extends OneSizeTestContainerGenerator<SetMultimap<K, V>, Map.Entry<K, V>>>) - Method in class com.google.common.collect.testing.google.SetMultimapTestSuiteBuilder
 
computeMultimapGetTestSuite(FeatureSpecificTestSuiteBuilder<?, ? extends OneSizeTestContainerGenerator<SetMultimap<K, V>, Map.Entry<K, V>>>) - Method in class com.google.common.collect.testing.google.SortedSetMultimapTestSuiteBuilder
 
computeMultimapGetTestSuite(FeatureSpecificTestSuiteBuilder<?, ? extends OneSizeTestContainerGenerator<M, Map.Entry<K, V>>>) - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder
 
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() - 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.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
Deprecated.
 
computeNext() - Method in class com.google.common.graph.EndpointPairIterator.Directed
 
computeNext() - Method in class com.google.common.graph.EndpointPairIterator.Undirected
 
computeNext(T) - Method in class com.google.common.collect.AbstractSequentialIterator
Returns the element that follows previous, or returns null if no elements remain.
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.
computeReserializedCollectionFeatures(Set<Feature<?>>) - Static method in class com.google.common.collect.testing.CollectionTestSuiteBuilder
 
computeReserializedCollectionFeatures(Set<Feature<?>>) - Static method in class com.google.common.collect.testing.ListTestSuiteBuilder
 
computeReserializedCollectionFeatures(Set<Feature<?>>) - Static method in class com.google.common.collect.testing.SetTestSuiteBuilder
 
computeReserializedMapFeatures(Set<Feature<?>>) - Static method in class com.google.common.collect.testing.MapTestSuiteBuilder
 
computeReserializedMultimapFeatures(Set<Feature<?>>) - Static method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder
 
computeReserializedMultisetFeatures(Set<Feature<?>>) - Static method in class com.google.common.collect.testing.google.MultisetTestSuiteBuilder
 
computeToString() - Method in class com.google.common.net.MediaType
 
computeValuesCollectionFeatures(Set<Feature<?>>) - Static method in class com.google.common.collect.testing.MapTestSuiteBuilder
 
computeValuesFeatures(Set<Feature<?>>) - Static method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder
 
computeValuesSetFeatures(Set<Feature<?>>) - Static method in class com.google.common.collect.testing.google.BiMapTestSuiteBuilder
 
computeValuesTestSuite(FeatureSpecificTestSuiteBuilder<?, ? extends OneSizeTestContainerGenerator<M, Map.Entry<K, V>>>) - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder
 
computingFunction - Variable in class com.google.common.cache.CacheLoader.FunctionToCacheLoader
 
computingSupplier - Variable in class com.google.common.cache.CacheLoader.SupplierToCacheLoader
 
ComputingValueReference(LocalCache.ValueReference<K, V>) - Constructor for class com.google.common.cache.LocalCache.ComputingValueReference
 
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.
concat(ByteSource...) - Static method in class com.google.common.io.ByteSource
Concatenates multiple ByteSource 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(Iterable<? extends 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(Iterable<? extends Iterable<? extends T>>) - Static method in class com.google.common.collect.FluentIterable
Returns a fluent iterable that combines several iterables.
concat(Iterable<? extends Iterable<? extends T>>) - Static method in class com.google.common.collect.Iterables
Combines multiple iterables into a single iterable.
concat(Iterable<? extends T>...) - Static method in class com.google.common.collect.FluentIterable
Returns a fluent iterable that combines several iterables.
concat(Iterable<? extends T>...) - Static method in class com.google.common.collect.Iterables
Combines multiple iterables into a single iterable.
concat(Iterable<? extends T>, Iterable<? extends T>) - Static method in class com.google.common.collect.FluentIterable
Returns a fluent iterable that combines two iterables.
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.FluentIterable
Returns a fluent iterable that combines three iterables.
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.FluentIterable
Returns a fluent iterable that combines four iterables.
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(Collection<IOException>, Collection<IOException>) - Static method in class com.google.common.io.MoreFiles
Concatenates the contents of the two given collections of exceptions.
concat(Iterator<? extends ByteSource>) - Static method in class com.google.common.io.ByteSource
Concatenates multiple ByteSource 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(Iterator<? extends Iterator<? extends T>>) - Static method in class com.google.common.collect.Iterators
Combines multiple 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 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(DoubleStream...) - Static method in class com.google.common.collect.Streams
Returns a DoubleStream containing the elements of the first stream, followed by the elements of the second stream, and so on.
concat(IntStream...) - Static method in class com.google.common.collect.Streams
Returns an IntStream containing the elements of the first stream, followed by the elements of the second stream, and so on.
concat(LongStream...) - Static method in class com.google.common.collect.Streams
Returns a LongStream containing the elements of the first stream, followed by the elements of the second stream, and so on.
concat(Stream<? extends T>...) - Static method in class com.google.common.collect.Streams
Returns a Stream containing the elements of the first stream, followed by the elements of the second stream, and so on.
concat(T[], T) - Static method in class com.google.common.collect.ObjectArrays
Returns a new array that appends element to array.
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.
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
 
ConcatenatedIterator(Iterator<? extends Iterator<? extends T>>) - Constructor for class com.google.common.collect.Iterators.ConcatenatedIterator
 
concatenating(HashFunction, HashFunction, HashFunction...) - Static method in class com.google.common.hash.Hashing
Returns a hash function which computes its hash code by concatenating the hash codes of the underlying hash functions together.
concatenating(Iterable<HashFunction>) - Static method in class com.google.common.hash.Hashing
Returns a hash function which computes its hash code by concatenating the hash codes of the underlying hash functions together.
concatNoDefensiveCopy(Iterable<? extends T>...) - Static method in class com.google.common.collect.FluentIterable
Concatenates a varargs array of iterables without making a defensive copy of the array.
concatNoDefensiveCopy(Iterator<? extends T>...) - Static method in class com.google.common.collect.Iterators
Concats a varargs array of iterators without making a defensive copy of the array.
concurrencyLevel - Variable in class com.google.common.cache.CacheBuilder
 
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 - Variable in class com.google.common.collect.MapMaker
 
concurrencyLevel - Variable in class com.google.common.collect.MapMakerInternalMap.AbstractSerializationProxy
 
concurrencyLevel - Variable in class com.google.common.collect.MapMakerInternalMap
The concurrency level.
concurrencyLevel(int) - Method in class com.google.common.cache.CacheBuilder
Guides the allowed concurrency among update operations.
concurrencyLevel(int) - Method in class com.google.common.collect.Interners.InternerBuilder
Sets the concurrency level that will be used by the to-be-built Interner.
concurrencyLevel(int) - Method in class com.google.common.collect.MapMaker
Guides the allowed concurrency among update operations.
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
 
ConcurrentHashMultiset.EntrySet - Class in com.google.common.collect
 
ConcurrentHashMultiset.FieldSettersHolder - Class in com.google.common.collect
 
ConcurrentMapPutIfAbsentTester<K,V> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests putIfAbsent operations on a concurrent map.
ConcurrentMapPutIfAbsentTester() - Constructor for class com.google.common.collect.testing.testers.ConcurrentMapPutIfAbsentTester
 
ConcurrentMapRemoveTester<K,V> - Class in com.google.common.collect.testing.testers
ConcurrentMapRemoveTester() - Constructor for class com.google.common.collect.testing.testers.ConcurrentMapRemoveTester
 
ConcurrentMapReplaceEntryTester<K,V> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests replace(K, V, V) operations on a concurrent map.
ConcurrentMapReplaceEntryTester() - Constructor for class com.google.common.collect.testing.testers.ConcurrentMapReplaceEntryTester
 
ConcurrentMapReplaceTester<K,V> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests replace(K, V) operations on a concurrent map.
ConcurrentMapReplaceTester() - Constructor for class com.google.common.collect.testing.testers.ConcurrentMapReplaceTester
 
ConcurrentMapTestSuiteBuilder<K,V> - Class in com.google.common.collect.testing
Creates, based on your criteria, a JUnit test suite that exhaustively tests a ConcurrentMap implementation.
ConcurrentMapTestSuiteBuilder() - Constructor for class com.google.common.collect.testing.ConcurrentMapTestSuiteBuilder
 
ConcurrentNavigableMapTestSuiteBuilder<K,V> - Class in com.google.common.collect.testing
Creates, based on your criteria, a JUnit test suite that exhaustively tests a ConcurrentNavigableMap implementation.
ConcurrentNavigableMapTestSuiteBuilder() - Constructor for class com.google.common.collect.testing.ConcurrentNavigableMapTestSuiteBuilder
 
condition - Variable in class com.google.common.util.concurrent.Monitor.Guard
 
conflictException(String, Object, Object) - Static method in class com.google.common.collect.ImmutableMap
 
ConflictingRequirementsException - Exception Class in com.google.common.collect.testing.features
Thrown when requirements on a tester method or class conflict with each other.
ConflictingRequirementsException(String, Set<Feature<?>>, Object) - Constructor for exception class com.google.common.collect.testing.features.ConflictingRequirementsException
 
conflictingStackTrace - Variable in exception class com.google.common.util.concurrent.CycleDetectingLockFactory.PotentialDeadlockException
 
conflicts - Variable in exception class com.google.common.collect.testing.features.ConflictingRequirementsException
 
connectAccessOrder(ReferenceEntry<K, V>, ReferenceEntry<K, V>) - Static method in class com.google.common.cache.LocalCache
 
connectedPredicate(N, N) - Method in class com.google.common.graph.AbstractNetwork
 
CONNECTION - Static variable in class com.google.common.net.HttpHeaders
The HTTP Connection header field name.
connectionsOf(Graph<N>, N) - Static method in class com.google.common.graph.ImmutableGraph
 
connectionsOf(Network<N, E>, N) - Static method in class com.google.common.graph.ImmutableNetwork
 
connectionsOf(ValueGraph<N, V>, N) - Static method in class com.google.common.graph.ImmutableValueGraph
 
connectWriteOrder(ReferenceEntry<K, V>, ReferenceEntry<K, V>) - Static method in class com.google.common.cache.LocalCache
 
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.
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.
constant(E) - Static method in class com.google.common.base.Functions
Returns a function that ignores its input and always returns value.
ConstantFunction(E) - Constructor for class com.google.common.base.Functions.ConstantFunction
 
constrainToRange(char, char, char) - Static method in class com.google.common.primitives.Chars
Returns the value nearest to value which is within the closed range [min..max].
constrainToRange(double, double, double) - Static method in class com.google.common.primitives.Doubles
Returns the value nearest to value which is within the closed range [min..max].
constrainToRange(float, float, float) - Static method in class com.google.common.primitives.Floats
Returns the value nearest to value which is within the closed range [min..max].
constrainToRange(int, int, int) - Static method in class com.google.common.primitives.Ints
Returns the value nearest to value which is within the closed range [min..max].
constrainToRange(long, long, long) - Static method in class com.google.common.primitives.Longs
Returns the value nearest to value which is within the closed range [min..max].
constrainToRange(short, short, short) - Static method in class com.google.common.primitives.Shorts
Returns the value nearest to value which is within the closed range [min..max].
construct(Object...) - Static method in class com.google.common.collect.ImmutableList
Views the array as an immutable list.
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.
CONSTRUCTOR - Static variable in class com.google.common.hash.Hashing.Crc32cMethodHandles
 
ConstructorInvokable(Constructor<?>) - Constructor for class com.google.common.reflect.Invokable.ConstructorInvokable
 
consumeCharacter(char) - Method in class com.google.common.net.MediaType.Tokenizer
 
consumeCharacter(CharMatcher) - Method in class com.google.common.net.MediaType.Tokenizer
 
consumerizer - Variable in class com.google.common.collect.testing.SpliteratorTester.GeneralSpliteratorOfPrimitive
 
consumeSeparator(MediaType.Tokenizer, char) - Static method in class com.google.common.net.MediaType
 
consumeToken(CharMatcher) - Method in class com.google.common.net.MediaType.Tokenizer
 
consumeTokenIfPresent(CharMatcher) - Method in class com.google.common.net.MediaType.Tokenizer
 
consumingForArray(I...) - Static method in class com.google.common.collect.Iterators
Returns an Iterator that walks the specified array, nulling out elements behind it.
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<T> - Class in com.google.common.collect
An Iterator implementation which draws elements from a queue, removing them from the queue as it iterates.
ConsumingQueueIterator(Queue<T>) - Constructor for class com.google.common.collect.ConsumingQueueIterator
 
container - Variable in class com.google.common.collect.testing.AbstractContainerTester
 
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(byte[], byte) - Static method in class com.google.common.primitives.Bytes
Returns true if target is present as an element anywhere in array.
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) - Method in class com.google.common.primitives.ImmutableDoubleArray
Returns true if target is present at any index in this 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(float[], float) - Static method in class com.google.common.primitives.Floats
Returns true if target is present as an element anywhere in array.
contains(int) - Method in class com.google.common.primitives.ImmutableIntArray
Returns true if target is present at any index in this array.
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(long) - Method in class com.google.common.primitives.ImmutableLongArray
Returns true if target is present at any index in this array.
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(short[], short) - Static method in class com.google.common.primitives.Shorts
Returns true if target is present as an element anywhere in array.
contains(C) - Method in class com.google.common.collect.AbstractRangeSet
 
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(C) - Method in class com.google.common.collect.TreeRangeSet.Complement
 
contains(C) - Method in class com.google.common.collect.TreeRangeSet.SubRangeSet
 
contains(Iterable<? extends Object>, Object) - Static method in class com.google.common.collect.Iterables
Returns true if iterable contains any element o for which Objects.equals(o, element) would return true.
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(Object) - Method in class com.google.common.collect.AbstractTable.CellSet
 
contains(Object) - Method in class com.google.common.collect.AbstractTable.Values
 
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.CompactHashMap.EntrySetView
 
contains(Object) - Method in class com.google.common.collect.CompactHashSet
 
contains(Object) - Method in class com.google.common.collect.DescendingImmutableSortedSet
 
contains(Object) - Method in class com.google.common.collect.EmptyContiguousSet
 
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(target) is true.
contains(Object) - Method in class com.google.common.collect.ForwardingCollection
 
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.ElementSet
 
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) - Method in class com.google.common.collect.JdkBackedImmutableSet
 
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.MapMakerInternalMap.EntrySet
 
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 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(Object) - Method in class com.google.common.collect.RegularContiguousSet
 
contains(Object) - Method in class com.google.common.collect.RegularImmutableMap.KeySet
 
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.CartesianSet
 
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.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) - 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) - Method in class com.google.common.collect.testing.MinimalCollection
 
contains(Object) - Method in class com.google.common.collect.testing.SafeTreeSet
 
contains(Object) - Method in class com.google.common.graph.EdgesConnecting
 
contains(Object) - Method in class com.google.common.graph.IncidentEdgeSet
 
contains(Object) - Method in class com.google.common.graph.MultiEdgesConnecting
 
contains(Object) - Method in class com.google.common.primitives.Booleans.BooleanArrayAsList
 
contains(Object) - Method in class com.google.common.primitives.Bytes.ByteArrayAsList
 
contains(Object) - Method in class com.google.common.primitives.Chars.CharArrayAsList
 
contains(Object) - Method in class com.google.common.primitives.Doubles.DoubleArrayAsList
 
contains(Object) - Method in class com.google.common.primitives.Floats.FloatArrayAsList
 
contains(Object) - Method in class com.google.common.primitives.ImmutableDoubleArray.AsList
 
contains(Object) - Method in class com.google.common.primitives.ImmutableIntArray.AsList
 
contains(Object) - Method in class com.google.common.primitives.ImmutableLongArray.AsList
 
contains(Object) - Method in class com.google.common.primitives.Ints.IntArrayAsList
 
contains(Object) - Method in class com.google.common.primitives.Longs.LongArrayAsList
 
contains(Object) - Method in class com.google.common.primitives.Shorts.ShortArrayAsList
 
contains(Object, Object) - Method in class com.google.common.collect.AbstractTable
 
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, Object) - Method in class com.google.common.collect.ForwardingTable
 
contains(Object, Object) - Method in class com.google.common.collect.ImmutableTable
 
contains(Object, Object) - Method in class com.google.common.collect.StandardTable
 
contains(Object, Object) - Method in class com.google.common.collect.Synchronized.SynchronizedTable
 
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(Iterator<?>, Object) - Static method in class com.google.common.collect.Iterators
Returns true if iterator contains element.
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(K) - Method in class com.google.common.collect.TreeRangeMap.RangeMapEntry
 
contains(T) - Method in class com.google.common.collect.GeneralRange
 
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(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.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.ForwardingCollection
 
containsAll(Collection<?>) - Method in class com.google.common.collect.ImmutableEnumSet
 
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(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
 
containsAll(Collection<?>) - Method in class com.google.common.collect.testing.MinimalCollection
 
containsAll(Collection<?>) - Method in class com.google.common.collect.testing.SafeTreeSet
 
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.StandardTable
 
containsColumn(Object) - Method in class com.google.common.collect.Synchronized.SynchronizedTable
 
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
 
containsDuplicates - Variable in class com.google.common.collect.testing.testers.CollectionRetainAllTester
 
containsEdge(E) - Method in class com.google.common.graph.StandardNetwork
 
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.
containsKey(Object) - Method in class com.google.common.cache.LocalCache
 
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.CompactHashMap
 
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.MapMakerInternalMap
 
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.testing.SafeTreeMap
 
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.graph.MapIteratorCache
 
containsKey(Object) - Method in class com.google.common.util.concurrent.AtomicLongMap
Returns true if this map contains a mapping for the specified key.
containsKey(Object, int) - Method in class com.google.common.cache.LocalCache.Segment
 
containsKey(Object, int) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
 
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
 
containsNaN(double...) - Static method in class com.google.common.math.Quantiles
Returns whether any of the values in dataset are NaN.
containsNode(N) - Method in class com.google.common.graph.StandardNetwork
 
containsNode(N) - Method in class com.google.common.graph.StandardValueGraph
 
containsNullable(Annotation[]) - Static method in class com.google.common.testing.NullPointerTester
 
containsNullKey - Variable in class com.google.common.collect.testing.testers.MapPutAllTester
 
containsNullValue - Variable in class com.google.common.collect.testing.testers.MapPutAllTester
 
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(CommonPattern) - 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.StandardTable
 
containsRow(Object) - Method in class com.google.common.collect.Synchronized.SynchronizedTable
 
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.CompactHashMap
 
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.HashBiMap
Returns true if this BiMap contains an entry whose value is equal to value (or, equivalently, if this inverse view contains a key that is equal to value).
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.ImmutableTable
 
containsValue(Object) - Method in class com.google.common.collect.LinkedListMultimap
 
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 class com.google.common.collect.Synchronized.SynchronizedTable
 
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
 
containsValue(Object) - Method in class com.google.common.collect.testing.SafeTreeMap
 
containsValueImpl(Map<?, ?>, Object) - Static method in class com.google.common.collect.Maps
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.ImmutableList.Builder
 
contents - Variable in class com.google.common.collect.ImmutableMultiset.Builder
 
contents - Variable in class com.google.common.collect.testing.MinimalCollection
 
Contents - Search tag in package com.google.common.base
Section
Contents - Search tag in package com.google.common.primitives
Section
context(Object) - Method in class com.google.common.eventbus.Subscriber
Gets the context for the given event.
ContiguousSet<C> - 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
 
ContiguousSetDescendingGenerator() - Constructor for class com.google.common.collect.testing.google.SetGenerators.ContiguousSetDescendingGenerator
 
ContiguousSetGenerator() - Constructor for class com.google.common.collect.testing.google.SetGenerators.ContiguousSetGenerator
 
ContiguousSetHeadsetGenerator() - Constructor for class com.google.common.collect.testing.google.SetGenerators.ContiguousSetHeadsetGenerator
 
ContiguousSetSubsetGenerator() - Constructor for class com.google.common.collect.testing.google.SetGenerators.ContiguousSetSubsetGenerator
 
ContiguousSetTailsetGenerator() - Constructor for class com.google.common.collect.testing.google.SetGenerators.ContiguousSetTailsetGenerator
 
convert(A) - Method in class com.google.common.base.Converter
Returns a representation of a as an instance of type B.
convert(CaseFormat, String) - Method in enum class com.google.common.base.CaseFormat
Enum values can override for performance reasons.
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 class com.google.common.base.CaseFormat
Returns a serializable Converter that converts strings from this format to targetFormat.
convertToHashFloodingResistantImplementation() - Method in class com.google.common.collect.CompactHashMap
 
convertToHashFloodingResistantImplementation() - Method in class com.google.common.collect.CompactHashSet
 
convertToHashFloodingResistantImplementation() - Method in class com.google.common.collect.CompactLinkedHashMap
 
convertToHashFloodingResistantImplementation() - Method in class com.google.common.collect.CompactLinkedHashSet
 
COOKIE - Static variable in class com.google.common.net.HttpHeaders
The HTTP Cookie header field name.
coolDownIntervalMicros() - Method in class com.google.common.util.concurrent.SmoothRateLimiter
Returns the number of microseconds during cool down that we have to wait to get a new permit.
coolDownIntervalMicros() - Method in class com.google.common.util.concurrent.SmoothRateLimiter.SmoothBursty
 
coolDownIntervalMicros() - Method in class com.google.common.util.concurrent.SmoothRateLimiter.SmoothWarmingUp
 
copy() - Method in class com.google.common.collect.ImmutableSet.Builder
 
copy() - Method in class com.google.common.collect.ImmutableSet.EmptySetBuilderImpl
 
copy() - Method in class com.google.common.collect.ImmutableSet.JdkBackedSetBuilderImpl
 
copy() - Method in class com.google.common.collect.ImmutableSet.RegularSetBuilderImpl
 
copy() - Method in class com.google.common.collect.ImmutableSet.SetBuilderImpl
Creates a new copy of this SetBuilderImpl.
copy() - Method in class com.google.common.collect.ImmutableSortedSet.Builder
 
copy() - Method in class com.google.common.graph.GraphBuilder
 
copy() - Method in class com.google.common.graph.ValueGraphBuilder
 
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.LockFreeBitArray
 
copy(MapMakerInternalMap.StrongKeyDummyValueSegment<K>, MapMakerInternalMap.StrongKeyDummyValueEntry<K>, MapMakerInternalMap.StrongKeyDummyValueEntry<K>) - Method in class com.google.common.collect.MapMakerInternalMap.StrongKeyDummyValueEntry.Helper
 
copy(MapMakerInternalMap.StrongKeyStrongValueSegment<K, V>, MapMakerInternalMap.StrongKeyStrongValueEntry<K, V>, MapMakerInternalMap.StrongKeyStrongValueEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.StrongKeyStrongValueEntry.Helper
 
copy(MapMakerInternalMap.StrongKeyWeakValueSegment<K, V>, MapMakerInternalMap.StrongKeyWeakValueEntry<K, V>, MapMakerInternalMap.StrongKeyWeakValueEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.StrongKeyWeakValueEntry.Helper
 
copy(MapMakerInternalMap.WeakKeyDummyValueSegment<K>, MapMakerInternalMap.WeakKeyDummyValueEntry<K>, MapMakerInternalMap.WeakKeyDummyValueEntry<K>) - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyDummyValueEntry.Helper
 
copy(MapMakerInternalMap.WeakKeyStrongValueSegment<K, V>, MapMakerInternalMap.WeakKeyStrongValueEntry<K, V>, MapMakerInternalMap.WeakKeyStrongValueEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyStrongValueEntry.Helper
 
copy(MapMakerInternalMap.WeakKeyWeakValueSegment<K, V>, MapMakerInternalMap.WeakKeyWeakValueEntry<K, V>, MapMakerInternalMap.WeakKeyWeakValueEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyWeakValueEntry.Helper
 
copy(File, File) - Static method in class com.google.common.io.Files
Copies all the bytes from one file to another.
copy(File, OutputStream) - Static method in class com.google.common.io.Files
Copies all bytes from a file to an output stream.
copy(File, Charset, Appendable) - Static method in class com.google.common.io.Files
Deprecated.
Prefer asCharSource(from, charset).copyTo(to).
copy(InputStream, OutputStream) - Static method in class com.google.common.io.ByteStreams
Copies all bytes from the input stream to the output stream.
copy(Object[], int, int, T[]) - Static method in class com.google.common.collect.Platform
Equivalent to Arrays.copyOfRange(source, from, to, arrayOfType.getClass()).
copy(Readable, Appendable) - Static method in class com.google.common.io.CharStreams
Copies all characters between the Readable and Appendable objects.
copy(URL, OutputStream) - Static method in class com.google.common.io.Resources
Copies all bytes from a URL to an 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(S, E, E) - Method in interface com.google.common.collect.MapMakerInternalMap.InternalEntryHelper
Returns a freshly created entry, typed at the E type, for the given segment, that is a copy of the given entry.
copyAccessEntry(ReferenceEntry<K, V>, ReferenceEntry<K, V>) - Method in enum class 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.Segment<K, V>, ReferenceEntry<K, V>, ReferenceEntry<K, V>, K) - Method in enum class com.google.common.cache.LocalCache.EntryFactory
Copies an entry, assigning it a new next entry.
copyEntry(ReferenceEntry<K, V>, ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache
This method is a convenience for testing.
copyEntry(ReferenceEntry<K, V>, ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.Segment
Copies original into a new entry chained to newNext.
copyEntry(E, E) - Method in class com.google.common.collect.MapMakerInternalMap
This method is a convenience for testing.
copyEntry(E, E) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Returns a copy of the given entry.
copyFor(ReferenceQueue<V>, E) - Method in interface com.google.common.collect.MapMakerInternalMap.WeakValueReference
Returns a freshly created MapMakerInternalMap.WeakValueReference for the given entry (and on the given queue) with the same value as this MapMakerInternalMap.WeakValueReference.
copyFor(ReferenceQueue<V>, E) - Method in class com.google.common.collect.MapMakerInternalMap.WeakValueReferenceImpl
 
copyFor(ReferenceQueue<V>, V, ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.LoadingValueReference
 
copyFor(ReferenceQueue<V>, V, ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.SoftValueReference
 
copyFor(ReferenceQueue<V>, V, ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.StrongValueReference
 
copyFor(ReferenceQueue<V>, V, 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, ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.WeakValueReference
 
copyFor(ReferenceQueue<V>, V, ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.WeightedSoftValueReference
 
copyFor(ReferenceQueue<V>, V, ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.WeightedWeakValueReference
 
copyForTesting(MapMakerInternalMap.InternalEntry<K, V, ?>, MapMakerInternalMap.InternalEntry<K, V, ?>) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Unsafely returns a copy of the given entry.
copyFromElements(E...) - Static method in class com.google.common.collect.ImmutableMultiset
 
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 puts the highest count first, with ties broken by the iteration order of the original multiset.
copyIfNecessary() - Method in class com.google.common.collect.ImmutableSet.Builder
 
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.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.ImmutableMapEntrySet.RegularEntrySet
 
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.ImmutableSet.Indexed
 
copyIntoArray(Object[], int) - Method in class com.google.common.collect.IndexedImmutableSet
 
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.SingletonImmutableSet
 
copyOf(double[]) - Static method in class com.google.common.primitives.ImmutableDoubleArray
Returns an immutable array containing the given values, in order.
copyOf(int[]) - Static method in class com.google.common.primitives.ImmutableIntArray
Returns an immutable array containing the given values, in order.
copyOf(long[]) - Static method in class com.google.common.primitives.ImmutableLongArray
Returns an immutable array containing the given values, 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(Multimap<? extends K, ? extends V>) - Static method in class com.google.common.collect.ImmutableMultimap
Returns an immutable multimap containing the same mappings as multimap, in the "key-grouped" iteration order described in the class documentation.
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(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(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(Graph<N>) - Static method in class com.google.common.graph.Graphs
Creates a mutable copy of graph with the same nodes and edges.
copyOf(Graph<N>) - Static method in class com.google.common.graph.ImmutableGraph
Returns an immutable copy of graph.
copyOf(ImmutableGraph<N>) - Static method in class com.google.common.graph.ImmutableGraph
Deprecated.
no need to use this
copyOf(ImmutableNetwork<N, E>) - Static method in class com.google.common.graph.ImmutableNetwork
Deprecated.
no need to use this
copyOf(ImmutableValueGraph<N, V>) - Static method in class com.google.common.graph.ImmutableValueGraph
Deprecated.
no need to use this
copyOf(Network<N, E>) - Static method in class com.google.common.graph.Graphs
Creates a mutable copy of network with the same nodes and edges.
copyOf(Network<N, E>) - Static method in class com.google.common.graph.ImmutableNetwork
Returns an immutable copy of network.
copyOf(ValueGraph<N, V>) - Static method in class com.google.common.graph.Graphs
Creates a mutable copy of graph with the same nodes, edges, and edge values.
copyOf(ValueGraph<N, V>) - Static method in class com.google.common.graph.ImmutableValueGraph
Returns an immutable copy of graph.
copyOf(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.ImmutableMultiset
Returns an immutable multiset containing the given elements, in the "grouped iteration order" described in the class documentation.
copyOf(E[]) - Static method in class com.google.common.collect.ImmutableSet
Returns an immutable set containing each of elements, minus duplicates, in the order each appears first in the source array.
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(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 Table.Cell<? extends R, ? extends C, ? extends V>>) - Static method in class com.google.common.collect.ImmutableTable
 
copyOf(Iterable<? extends E>) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing the given elements, in order.
copyOf(Iterable<? extends E>) - Static method in class com.google.common.collect.ImmutableMultiset
Returns an immutable multiset containing the given elements, in the "grouped iteration order" described in the class documentation.
copyOf(Iterable<? extends E>) - Static method in class com.google.common.collect.ImmutableSet
Returns an immutable set containing each of elements, minus duplicates, in the order each appears first in the source iterable.
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(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(Iterable<? extends Map.Entry<? extends K, ? extends V>>) - Static method in class com.google.common.collect.ImmutableBiMap
Returns an immutable bimap containing the given entries.
copyOf(Iterable<? extends Map.Entry<? extends K, ? extends V>>) - Static method in class com.google.common.collect.ImmutableListMultimap
Returns an immutable multimap containing the specified entries.
copyOf(Iterable<? extends Map.Entry<? extends K, ? extends V>>) - Static method in class com.google.common.collect.ImmutableMap
Returns an immutable map containing the specified entries.
copyOf(Iterable<? extends Map.Entry<? extends K, ? extends V>>) - Static method in class com.google.common.collect.ImmutableMultimap
Returns an immutable multimap containing the specified entries.
copyOf(Iterable<? extends Map.Entry<? extends K, ? extends V>>) - Static method in class com.google.common.collect.ImmutableSetMultimap
Returns an immutable multimap containing the specified entries.
copyOf(Iterable<? extends Map.Entry<? extends K, ? extends V>>) - Static method in class com.google.common.collect.ImmutableSortedMap
Returns an immutable map containing the given entries, with keys sorted by their natural ordering.
copyOf(Iterable<? extends Map.Entry<? extends K, ? extends V>>, Comparator<? super K>) - Static method in class com.google.common.collect.ImmutableSortedMap
Returns an immutable map containing the given entries, with keys sorted by the provided comparator.
copyOf(Iterable<Range<C>>) - Static method in class com.google.common.collect.ImmutableRangeSet
Returns an ImmutableRangeSet containing each of the specified disjoint ranges.
copyOf(Iterable<Double>) - Static method in class com.google.common.primitives.ImmutableDoubleArray
Returns an immutable array containing the given values, in order.
copyOf(Iterable<Integer>) - Static method in class com.google.common.primitives.ImmutableIntArray
Returns an immutable array containing the given values, in order.
copyOf(Iterable<Long>) - Static method in class com.google.common.primitives.ImmutableLongArray
Returns an immutable array containing the given values, 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(Collection<? extends E>) - Static method in class com.google.common.collect.ImmutableSet
Returns an immutable set containing each of elements, minus duplicates, in the order each appears first in the source collection.
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(Collection<Double>) - Static method in class com.google.common.primitives.ImmutableDoubleArray
Returns an immutable array containing the given values, in order.
copyOf(Collection<Integer>) - Static method in class com.google.common.primitives.ImmutableIntArray
Returns an immutable array containing the given values, in order.
copyOf(Collection<Long>) - Static method in class com.google.common.primitives.ImmutableLongArray
Returns an immutable array containing the given values, in order.
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(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(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>, 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(Iterator<? 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.ImmutableMultiset
Returns an immutable multiset containing the given elements, in the "grouped iteration order" described in the class documentation.
copyOf(Iterator<? extends E>) - Static method in class com.google.common.collect.ImmutableSet
Returns an immutable set containing each of elements, minus duplicates, in the order each appears first in the source iterator.
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(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(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(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 K, ? extends V>) - Static method in class com.google.common.collect.ImmutableMap
Returns an immutable map containing the same entries as map.
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(DoubleStream) - Static method in class com.google.common.primitives.ImmutableDoubleArray
Returns an immutable array containing all the values from stream, in order.
copyOf(IntStream) - Static method in class com.google.common.primitives.ImmutableIntArray
Returns an immutable array containing all the values from stream, in order.
copyOf(LongStream) - Static method in class com.google.common.primitives.ImmutableLongArray
Returns an immutable array containing all the values from stream, in order.
copyOf(Z[]) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Deprecated.
Pass parameters of type Comparable to use ImmutableSortedMultiset.copyOf(Comparable[]).
copyOf(Z[]) - Static method in class com.google.common.collect.ImmutableSortedSet
Deprecated.
Pass parameters of type Comparable to use ImmutableSortedSet.copyOf(Comparable[]).
copyOfEnumMap(EnumMap<?, ? extends V>) - Static method in class com.google.common.collect.ImmutableMap
 
copyOfEnumSet(EnumSet<?>) - Static method in class com.google.common.collect.ImmutableSet
 
copyOfInternal(Map<? extends K, ? extends V>, Comparator<? super K>) - Static method in class com.google.common.collect.ImmutableSortedMap
 
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(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(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
 
copyOnWrite - Variable in class com.google.common.collect.ImmutableList.Builder
 
copyReaderToBuilder(Reader, StringBuilder) - Static method in class com.google.common.io.CharStreams
Copies all characters between the Reader and StringBuilder objects.
copyReaderToWriter(Reader, Writer) - Static method in class com.google.common.io.CharStreams
Copies all characters between the Reader and Writer objects.
copyTo(ByteSink) - Method in class com.google.common.io.ByteSource
Copies the contents of this byte source to the given ByteSink.
copyTo(CharSink) - Method in class com.google.common.io.CharSource
Copies the contents of this source to the given sink.
copyTo(CharSink) - Method in class com.google.common.io.CharSource.StringCharSource
 
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(Appendable) - Method in class com.google.common.io.CharSource
Appends the contents of this source to the given Appendable (such as a Writer).
copyTo(Appendable) - Method in class com.google.common.io.CharSource.StringCharSource
 
copyToList(E[]) - Static method in class com.google.common.collect.testing.Helpers
 
copyToList(Iterable<? extends E>) - Static method in class com.google.common.collect.testing.Helpers
 
copyToSet(E[]) - Static method in class com.google.common.collect.testing.Helpers
 
copyToSet(Iterable<? extends E>) - Static method in class com.google.common.collect.testing.Helpers
 
copyWriteEntry(ReferenceEntry<K, V>, ReferenceEntry<K, V>) - Method in enum class com.google.common.cache.LocalCache.EntryFactory
 
correctedDoBackward(A) - Method in class com.google.common.base.Converter.ReverseConverter
 
correctedDoBackward(B) - Method in class com.google.common.base.Converter
 
correctedDoBackward(C) - Method in class com.google.common.base.Converter.ConverterComposition
 
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 - 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 - Variable in class com.google.common.collect.Multisets.ImmutableEntry
 
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.Stats
 
count - Variable in class com.google.common.math.StatsAccumulator
 
count - Variable in class com.google.common.primitives.ImmutableDoubleArray.Builder
 
count - Variable in class com.google.common.primitives.ImmutableIntArray.Builder
 
count - Variable in class com.google.common.primitives.ImmutableLongArray.Builder
 
count() - Method in class com.google.common.math.PairedStats
Returns the number of pairs in the dataset.
count() - Method in class com.google.common.math.PairedStatsAccumulator
Returns the number of pairs in the dataset.
count() - Method in class com.google.common.math.Stats
Returns the number of values.
count() - Method in class com.google.common.math.StatsAccumulator
Returns the number of values.
count(Object) - Method in class com.google.common.collect.AbstractMapBasedMultiset
 
count(Object) - Method in class com.google.common.collect.ConcurrentHashMultiset
Returns the number of occurrences of element in this multiset.
count(Object) - Method in class com.google.common.collect.DescendingImmutableSortedMultiset
 
count(Object) - Method in class com.google.common.collect.EnumMultiset
 
count(Object) - Method in class com.google.common.collect.ForwardingMultiset
 
count(Object) - Method in class com.google.common.collect.ImmutableMultimap.Keys
 
count(Object) - Method in class com.google.common.collect.JdkBackedImmutableMultiset
 
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(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(Object) - Method in class com.google.common.collect.TreeMultiset
 
count(Comparator<? super E>, E) - Method in class com.google.common.collect.TreeMultiset.AvlNode
 
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_MAP_FIELD_SETTER - Static variable in class com.google.common.collect.ConcurrentHashMultiset.FieldSettersHolder
 
countBySkipping(InputStream) - Method in class com.google.common.io.ByteSource
Counts the bytes in the given input stream using skip if possible.
countBySkipping(Reader) - Method in class com.google.common.io.CharSource
 
countDownLatch - Variable in class com.google.common.util.concurrent.testing.MockFutureListener
 
counter - Variable in class com.google.common.collect.Ordering.ArbitraryOrdering
 
countIn(CharSequence) - Method in class com.google.common.base.CharMatcher.Any
 
countIn(CharSequence) - Method in class com.google.common.base.CharMatcher
Returns the number of matching chars found in a character sequence.
countIn(CharSequence) - Method in class com.google.common.base.CharMatcher.Negated
 
countIn(CharSequence) - Method in class com.google.common.base.CharMatcher.None
 
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.EnumMultiset
 
counts - Variable in class com.google.common.collect.ImmutableMultiset.SerializedForm
 
counts - Variable in class com.google.common.collect.ImmutableSortedMultiset.SerializedForm
 
countTrue(boolean...) - Static method in class com.google.common.primitives.Booleans
Returns the number of values that are true.
covariantly(Type) - Static method in class com.google.common.reflect.TypeResolver
Returns a resolver that resolves types "covariantly".
covariantTypeResolver - Variable in class com.google.common.reflect.TypeToken
Resolver for resolving covariant types with TypeToken.runtimeType as context.
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_32 - Enum constant in enum class com.google.common.hash.Hashing.ChecksumType
 
CRC_32_C - Static variable in class com.google.common.hash.Crc32cHashFunction
 
CRC_32C - Enum constant in enum class com.google.common.hash.Hashing.ChecksumType
 
crc0 - Variable in class com.google.common.hash.Crc32cHashFunction.Crc32cHasher
 
crc1 - Variable in class com.google.common.hash.Crc32cHashFunction.Crc32cHasher
 
crc2 - Variable in class com.google.common.hash.Crc32cHashFunction.Crc32cHasher
 
crc3 - 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).
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.
crc32cConstructor() - Static method in class com.google.common.hash.Hashing.Crc32cMethodHandles
 
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
 
Crc32cMethodHandles() - Constructor for class com.google.common.hash.Hashing.Crc32cMethodHandles
 
Crc32CSupplier() - Constructor for enum class com.google.common.hash.Hashing.Crc32CSupplier
 
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() - Static method in class com.google.common.collect.CompactHashMap
Creates an empty CompactHashMap instance.
create() - Static method in class com.google.common.collect.CompactHashSet
Creates an empty CompactHashSet instance.
create() - Static method in class com.google.common.collect.CompactLinkedHashMap
Creates an empty CompactLinkedHashMap instance.
create() - Static method in class com.google.common.collect.CompactLinkedHashSet
Creates an empty CompactLinkedHashSet instance.
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() - Static method in class com.google.common.collect.HashBasedTable
Creates an empty HashBasedTable.
create() - Static method in class com.google.common.collect.HashBiMap
Returns a new, empty HashBiMap with the default initial capacity (16).
create() - Static method in class com.google.common.collect.HashMultimap
Creates a new, empty HashMultimap with the default initial capacities.
create() - Static method in class com.google.common.collect.HashMultiset
Creates a new, empty HashMultiset using the default initial capacity.
create() - Static method in class com.google.common.collect.LinkedHashMultimap
Creates a new, empty LinkedHashMultimap with the default initial capacities.
create() - Static method in class com.google.common.collect.LinkedHashMultiset
Creates a new, empty LinkedHashMultiset using the default initial capacity.
create() - Static method in class com.google.common.collect.LinkedListMultimap
Creates a new, empty LinkedListMultimap with the default initial capacity.
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() - 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() - 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() - 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() - Static method in class com.google.common.collect.TreeMultimap
Creates an empty TreeMultimap ordered by the natural ordering of its keys and values.
create() - Static method in class com.google.common.collect.TreeMultiset
Creates a new, empty multiset, 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() - Static method in class com.google.common.hash.LongAddables
 
create() - Static method in class com.google.common.io.Closer
Creates a new Closer.
create() - Static method in class com.google.common.util.concurrent.AtomicLongMap
Creates an AtomicLongMap.
create() - Static method in class com.google.common.util.concurrent.ExecutionSequencer
Creates a new instance.
create() - Static method in class com.google.common.util.concurrent.SettableFuture
Creates a new SettableFuture that can be completed or cancelled by a later method call.
create() - Static method in class com.google.common.util.concurrent.testing.TestingExecutors.NoOpScheduledExecutorService.NeverScheduledFuture
 
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(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(double, long, TimeUnit, double, RateLimiter.SleepingStopwatch) - Static method in class com.google.common.util.concurrent.RateLimiter
 
create(double, RateLimiter.SleepingStopwatch) - Static method in class com.google.common.util.concurrent.RateLimiter
 
create(double, Duration) - 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(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(int) - Static method in class com.google.common.collect.HashBiMap
Constructs a new, empty bimap with the specified expected size.
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(int) - Static method in class com.google.common.collect.LinkedHashMultiset
Creates a new, empty LinkedHashMultiset with the specified expected number of distinct elements.
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(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(int, int) - Static method in class com.google.common.collect.HashBasedTable
Creates an empty HashBasedTable with the specified map sizes.
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(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(int, Map.Entry<K, V>[]) - Static method in class com.google.common.collect.JdkBackedImmutableBiMap
 
create(int, Map.Entry<K, V>[], boolean) - Static method in class com.google.common.collect.JdkBackedImmutableMap
Creates an ImmutableMap backed by a JDK HashMap.
create(Cut<C>, Cut<C>) - Static method in class com.google.common.collect.Range
 
create(ImmutableTable<?, ?, ?>, int[], int[]) - Static method in class com.google.common.collect.ImmutableTable.SerializedForm
 
create(MapMaker) - Static method in class com.google.common.collect.MapMakerInternalMap
Returns a fresh MapMakerInternalMap as specified by the given builder.
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(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(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(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(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(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(RangeSet<C>) - Static method in class com.google.common.collect.TreeRangeSet
Returns a TreeRangeSet initialized with the ranges in the specified range set.
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(Table<R, C, ? extends V>) - Static method in class com.google.common.collect.ArrayTable
Creates an ArrayTable with the mappings in the provided table.
create(AnEnum[]) - Method in class com.google.common.collect.testing.google.TestEnumMultisetGenerator
 
create(AnEnum[]) - Method in class com.google.common.collect.testing.TestEnumSetGenerator
 
create(UnhashableObject[]) - Method in class com.google.common.collect.testing.google.ListGenerators.UnhashableElementsImmutableListGenerator
 
create(UnhashableObject[]) - Method in class com.google.common.collect.testing.google.MapGenerators.ImmutableMapUnhashableValuesGenerator
 
create(UnhashableObject[]) - Method in class com.google.common.collect.testing.google.SetGenerators.ImmutableSortedSetUnhashableGenerator
 
create(UnhashableObject[]) - Method in class com.google.common.collect.testing.TestUnhashableCollectionGenerator
Creates a new collection containing the given elements; implement this method instead of TestUnhashableCollectionGenerator.create(Object...).
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(EventBus, Object, Method) - Static method in class com.google.common.eventbus.Subscriber
Creates a Subscriber for method on listener.
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(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>, long) - 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(Funnel<? super T>, long, 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>, long, double, BloomFilter.Strategy) - Static method in class com.google.common.hash.BloomFilter
 
create(AsyncCallable<V>) - Static method in class com.google.common.util.concurrent.TrustedListenableFutureTask
 
create(ListenableFuture<? extends V>, Class<X>, Function<? super X, ? extends V>, Executor) - Static method in class com.google.common.util.concurrent.AbstractCatchingFuture
 
create(ListenableFuture<I>, Function<? super I, ? extends O>, Executor) - Static method in class com.google.common.util.concurrent.AbstractTransformFuture
 
create(ListenableFuture<V>, long, TimeUnit, ScheduledExecutorService) - Static method in class com.google.common.util.concurrent.TimeoutFuture
 
create(E...) - Static method in class com.google.common.collect.CompactHashSet
Creates a mutable CompactHashSet instance containing the given elements in unspecified order.
create(E...) - Static method in class com.google.common.collect.CompactLinkedHashSet
Creates a CompactLinkedHashSet instance containing the given elements in unspecified order.
create(Character[]) - Method in class com.google.common.collect.testing.google.ListGenerators.CharactersOfCharSequenceGenerator
 
create(Character[]) - Method in class com.google.common.collect.testing.google.ListGenerators.CharactersOfStringGenerator
 
create(Character[]) - Method in class com.google.common.collect.testing.TestCharacterListGenerator
Creates a new collection containing the given elements; implement this method instead of TestCharacterListGenerator.create(Object...).
create(Class<E>) - Static method in class com.google.common.collect.EnumMultiset
Creates an empty EnumMultiset.
create(Class<K>) - Static method in class com.google.common.collect.EnumHashBiMap
Returns a new, empty EnumHashBiMap using the specified key type.
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(Integer[]) - Method in class com.google.common.collect.testing.google.SetGenerators.ContiguousSetDescendingGenerator
 
create(Integer[]) - Method in class com.google.common.collect.testing.google.SetGenerators.ContiguousSetGenerator
 
create(Integer[]) - Method in class com.google.common.collect.testing.google.SetGenerators.ContiguousSetHeadsetGenerator
 
create(Integer[]) - Method in class com.google.common.collect.testing.google.SetGenerators.ContiguousSetSubsetGenerator
 
create(Integer[]) - Method in class com.google.common.collect.testing.google.SetGenerators.ContiguousSetTailsetGenerator
 
create(Integer[]) - Method in class com.google.common.collect.testing.TestIntegerSetGenerator
 
create(Integer[]) - Method in class com.google.common.collect.testing.TestIntegerSortedSetGenerator
 
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(Iterable<? extends E>) - Static method in class com.google.common.collect.HashMultiset
Creates a new HashMultiset containing the specified elements.
create(Iterable<? extends E>) - Static method in class com.google.common.collect.LinkedHashMultiset
Creates a new LinkedHashMultiset containing the specified elements.
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(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(Iterable<? extends R>, Iterable<? extends C>) - Static method in class com.google.common.collect.ArrayTable
Creates an ArrayTable filled with null.
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(Iterable<Range<C>>) - Static method in class com.google.common.collect.TreeRangeSet
Returns a TreeRangeSet representing the union of the specified ranges.
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(Object...) - Method in class com.google.common.collect.testing.CollectionTestSuiteBuilder.ReserializedCollectionGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.ForwardingTestMapGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.MapEntrySetGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.MapKeySetGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.MapSortedKeySetGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.MapValueCollectionGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.SortedMapSubmapTestMapGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.SortedSetSubsetTestSetGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.google.DerivedGoogleCollectionGenerators.BiMapValueSetGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.google.DerivedGoogleCollectionGenerators.InverseBiMapGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.google.DerivedGoogleCollectionGenerators.MapGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.google.ListMultimapTestSuiteBuilder.MultimapAsMapGetGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.google.ListMultimapTestSuiteBuilder.MultimapGetGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.google.MapGenerators.ImmutableMapEntryListGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.google.MapGenerators.ImmutableMapValuesAsSingletonSetGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.AsMapGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.EntriesGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.KeysGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.MultimapAsMapGetGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.MultimapGetGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.ReserializedMultimapGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.ValuesGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.google.MultisetTestSuiteBuilder.ElementSetGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.google.MultisetTestSuiteBuilder.EntrySetGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.google.MultisetTestSuiteBuilder.ReserializedMultisetGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.google.SetGenerators.ImmutableSetWithBadHashesGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.google.SetMultimapTestSuiteBuilder.EntriesGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.google.SetMultimapTestSuiteBuilder.MultimapAsMapGetGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.google.SetMultimapTestSuiteBuilder.MultimapGetGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.google.SortedMapGenerators.ImmutableSortedMapEntryListGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.google.SortedMultisetTestSuiteBuilder.ForwardingTestMultisetGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.google.TestEnumMultisetGenerator
 
create(Object...) - Method in interface com.google.common.collect.testing.google.TestMultisetGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.google.TestStringBiMapGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.google.TestStringListMultimapGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.google.TestStringMultisetGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.google.TestStringSetMultimapGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.ListTestSuiteBuilder.ReserializedListGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.MapTestSuiteBuilder.ReserializedMapGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.NavigableMapTestSuiteBuilder.DescendingTestMapGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.OneSizeGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.ReserializingTestCollectionGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.ReserializingTestSetGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.SetTestSuiteBuilder.ReserializedSetGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.TestCharacterListGenerator
 
create(Object...) - Method in interface com.google.common.collect.testing.TestContainerGenerator
Creates a new container containing the given elements.
create(Object...) - Method in class com.google.common.collect.testing.TestEnumMapGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.TestEnumSetGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.TestIntegerSetGenerator
 
create(Object...) - Method in interface com.google.common.collect.testing.TestListGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.TestMapEntrySetGenerator
 
create(Object...) - Method in interface com.google.common.collect.testing.TestQueueGenerator
 
create(Object...) - Method in interface com.google.common.collect.testing.TestSetGenerator
 
create(Object...) - Method in interface com.google.common.collect.testing.TestSortedMapGenerator
 
create(Object...) - Method in interface com.google.common.collect.testing.TestSortedSetGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.TestStringCollectionGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.TestStringListGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.TestStringMapGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.TestStringQueueGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.TestStringSetGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.TestStringSortedMapGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.TestStringSortedSetGenerator
 
create(Object...) - Method in class com.google.common.collect.testing.TestUnhashableCollectionGenerator
 
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(Runnable, V) - Static method in class com.google.common.util.concurrent.TrustedListenableFutureTask
Creates a ListenableFutureTask that will upon running, execute the given Runnable, and arrange that get will return the given result on successful completion.
create(String[]) - Method in class com.google.common.collect.testing.google.ListGenerators.BuilderAddAllListGenerator
 
create(String[]) - Method in class com.google.common.collect.testing.google.ListGenerators.BuilderAddListGenerator
 
create(String[]) - Method in class com.google.common.collect.testing.google.ListGenerators.BuilderReversedListGenerator
 
create(String[]) - Method in class com.google.common.collect.testing.google.ListGenerators.ImmutableListHeadSubListGenerator
 
create(String[]) - Method in class com.google.common.collect.testing.google.ListGenerators.ImmutableListMiddleSubListGenerator
 
create(String[]) - Method in class com.google.common.collect.testing.google.ListGenerators.ImmutableListOfGenerator
 
create(String[]) - Method in class com.google.common.collect.testing.google.ListGenerators.ImmutableListTailSubListGenerator
 
create(String[]) - Method in class com.google.common.collect.testing.google.MapGenerators.ImmutableMapKeyListGenerator
 
create(String[]) - Method in class com.google.common.collect.testing.google.MapGenerators.ImmutableMapValueListGenerator
 
create(String[]) - Method in class com.google.common.collect.testing.google.SetGenerators.DegeneratedImmutableSetGenerator
 
create(String[]) - Method in class com.google.common.collect.testing.google.SetGenerators.ImmutableSetAsListGenerator
 
create(String[]) - Method in class com.google.common.collect.testing.google.SetGenerators.ImmutableSetCopyOfGenerator
 
create(String[]) - Method in class com.google.common.collect.testing.google.SetGenerators.ImmutableSetSizedBuilderGenerator
 
create(String[]) - Method in class com.google.common.collect.testing.google.SetGenerators.ImmutableSetTooBigBuilderGenerator
 
create(String[]) - Method in class com.google.common.collect.testing.google.SetGenerators.ImmutableSetTooSmallBuilderGenerator
 
create(String[]) - Method in class com.google.common.collect.testing.google.SetGenerators.ImmutableSetUnsizedBuilderGenerator
 
create(String[]) - Method in class com.google.common.collect.testing.google.SetGenerators.ImmutableSortedSetAsListGenerator
 
create(String[]) - Method in class com.google.common.collect.testing.google.SetGenerators.ImmutableSortedSetAsListSubListGenerator
 
create(String[]) - Method in class com.google.common.collect.testing.google.SetGenerators.ImmutableSortedSetCopyOfGenerator
 
create(String[]) - Method in class com.google.common.collect.testing.google.SetGenerators.ImmutableSortedSetDescendingAsListGenerator
 
create(String[]) - Method in class com.google.common.collect.testing.google.SetGenerators.ImmutableSortedSetDescendingGenerator
 
create(String[]) - Method in class com.google.common.collect.testing.google.SetGenerators.ImmutableSortedSetExplicitComparator
 
create(String[]) - Method in class com.google.common.collect.testing.google.SetGenerators.ImmutableSortedSetExplicitSuperclassComparatorGenerator
 
create(String[]) - Method in class com.google.common.collect.testing.google.SetGenerators.ImmutableSortedSetHeadsetGenerator
 
create(String[]) - Method in class com.google.common.collect.testing.google.SetGenerators.ImmutableSortedSetReversedOrderGenerator
 
create(String[]) - Method in class com.google.common.collect.testing.google.SetGenerators.ImmutableSortedSetSubsetAsListGenerator
 
create(String[]) - Method in class com.google.common.collect.testing.google.SetGenerators.ImmutableSortedSetSubsetAsListSubListGenerator
 
create(String[]) - Method in class com.google.common.collect.testing.google.SetGenerators.ImmutableSortedSetSubsetGenerator
 
create(String[]) - Method in class com.google.common.collect.testing.google.SetGenerators.ImmutableSortedSetTailsetGenerator
 
create(String[]) - Method in class com.google.common.collect.testing.google.SortedMapGenerators.ImmutableSortedMapKeyListGenerator
 
create(String[]) - Method in class com.google.common.collect.testing.google.SortedMapGenerators.ImmutableSortedMapValueListGenerator
 
create(String[]) - Method in class com.google.common.collect.testing.google.TestStringMultisetGenerator
 
create(String[]) - Method in class com.google.common.collect.testing.TestStringCollectionGenerator
 
create(String[]) - Method in class com.google.common.collect.testing.TestStringListGenerator
Creates a new collection containing the given elements; implement this method instead of TestStringListGenerator.create(Object...).
create(String[]) - Method in class com.google.common.collect.testing.TestStringQueueGenerator
 
create(String[]) - Method in class com.google.common.collect.testing.TestStringSetGenerator
 
create(String[]) - Method in class com.google.common.collect.testing.TestStringSortedSetGenerator
 
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(Throwable...) - Static method in exception class com.google.common.testing.ClusterException
create(Collection<? extends Multiset.Entry<? extends E>>) - Static method in class com.google.common.collect.JdkBackedImmutableMultiset
 
create(Collection<? extends Multiset.Entry<? extends E>>) - Static method in class com.google.common.collect.RegularImmutableMultiset
 
create(Collection<? extends E>) - Static method in class com.google.common.collect.CompactHashSet
Creates a mutable CompactHashSet instance containing the elements of the given collection in unspecified order.
create(Collection<? extends E>) - Static method in class com.google.common.collect.CompactLinkedHashSet
Creates a mutable CompactLinkedHashSet instance containing the elements of the given collection in the order returned by the collection's iterator.
create(Collection<? extends Throwable>) - Static method in exception class com.google.common.testing.ClusterException
Given a collection of exceptions, returns a RuntimeException, with the following rules: If exceptions has a single exception and that exception is a RuntimeException, return it If exceptions has a single exceptions and that exceptions is not a RuntimeException, return a simple RuntimeException that wraps it Otherwise, return an instance of ClusterException that wraps the first exception in the exceptions collection.
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(Comparator<? super K>, Comparator<? super V>) - Static method in class com.google.common.collect.TreeMultimap
Creates an empty TreeMultimap instance using explicit comparators.
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(Callable<V>) - Static method in class com.google.common.util.concurrent.ListenableFutureTask
Creates a ListenableFutureTask that will upon running, execute the given Callable.
create(Callable<V>) - Static method in class com.google.common.util.concurrent.TrustedListenableFutureTask
 
create(ConcurrentMap<E, AtomicInteger>) - Static method in class com.google.common.collect.ConcurrentHashMultiset
Creates a new, empty ConcurrentHashMultiset using countMap as the internal backing map.
create(ExecutorService) - Static method in class com.google.common.util.concurrent.SimpleTimeLimiter
Creates a TimeLimiter instance using the given executor service to execute method calls.
create(List<? extends List<? extends E>>) - Static method in class com.google.common.collect.CartesianList
 
create(List<? extends Set<? extends E>>) - Static method in class com.google.common.collect.Sets.CartesianSet
 
create(Map.Entry<AnEnum, String>[]) - Method in class com.google.common.collect.testing.google.MapGenerators.ImmutableEnumMapGenerator
 
create(Map.Entry<AnEnum, String>[]) - Method in class com.google.common.collect.testing.google.MapGenerators.ImmutableMapCopyOfEnumMapGenerator
 
create(Map.Entry<AnEnum, String>[]) - Method in class com.google.common.collect.testing.TestEnumMapGenerator
 
create(Map.Entry<String, String>[]) - Method in class com.google.common.collect.testing.google.BiMapGenerators.ImmutableBiMapCopyOfEntriesGenerator
 
create(Map.Entry<String, String>[]) - Method in class com.google.common.collect.testing.google.BiMapGenerators.ImmutableBiMapCopyOfGenerator
 
create(Map.Entry<String, String>[]) - Method in class com.google.common.collect.testing.google.BiMapGenerators.ImmutableBiMapGenerator
 
create(Map.Entry<String, String>[]) - Method in class com.google.common.collect.testing.google.MapGenerators.ImmutableMapCopyOfEntriesGenerator
 
create(Map.Entry<String, String>[]) - Method in class com.google.common.collect.testing.google.MapGenerators.ImmutableMapCopyOfGenerator
 
create(Map.Entry<String, String>[]) - Method in class com.google.common.collect.testing.google.MapGenerators.ImmutableMapGenerator
 
create(Map.Entry<String, String>[]) - Method in class com.google.common.collect.testing.google.SortedMapGenerators.ImmutableSortedMapCopyOfEntriesGenerator
 
create(Map.Entry<String, String>[]) - Method in class com.google.common.collect.testing.google.SortedMapGenerators.ImmutableSortedMapGenerator
 
create(Map.Entry<String, String>[]) - Method in class com.google.common.collect.testing.google.TestStringBiMapGenerator
 
create(Map.Entry<String, String>[]) - Method in class com.google.common.collect.testing.google.TestStringListMultimapGenerator
 
create(Map.Entry<String, String>[]) - Method in class com.google.common.collect.testing.google.TestStringSetMultimapGenerator
 
create(Map.Entry<String, String>[]) - Method in class com.google.common.collect.testing.TestStringMapGenerator
 
create(Map.Entry<String, String>[]) - Method in class com.google.common.collect.testing.TestStringSortedMapGenerator
 
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(Map<? extends K, ? extends V>) - Static method in class com.google.common.collect.HashBiMap
Constructs a new bimap containing initial values from map.
create(Map<Character, String>) - Static method in class com.google.common.escape.ArrayBasedEscaperMap
Returns a new ArrayBasedEscaperMap for creating ArrayBasedCharEscaper or ArrayBasedUnicodeEscaper instances.
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(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(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(K, V, RemovalCause) - Static method in class com.google.common.cache.RemovalNotification
Creates a new RemovalNotification for the given key/value pair, with the given cause for the removal.
create(V, V) - Static method in class com.google.common.collect.Maps.ValueDifferenceImpl
 
createApplicationType(String) - Static method in class com.google.common.net.MediaType
Creates a media type with the "application" type and the given subtype.
createArray(int) - Method in class com.google.common.collect.testing.CollectionTestSuiteBuilder.ReserializedCollectionGenerator
 
createArray(int) - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.ForwardingTestMapGenerator
 
createArray(int) - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.MapEntrySetGenerator
 
createArray(int) - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.MapKeySetGenerator
 
createArray(int) - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.MapValueCollectionGenerator
 
createArray(int) - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.SortedSetSubsetTestSetGenerator
 
createArray(int) - Method in class com.google.common.collect.testing.google.DerivedGoogleCollectionGenerators.BiMapValueSetGenerator
 
createArray(int) - Method in class com.google.common.collect.testing.google.DerivedGoogleCollectionGenerators.InverseBiMapGenerator
 
createArray(int) - Method in class com.google.common.collect.testing.google.DerivedGoogleCollectionGenerators.MapGenerator
 
createArray(int) - Method in class com.google.common.collect.testing.google.MapGenerators.ImmutableMapEntryListGenerator
 
createArray(int) - Method in class com.google.common.collect.testing.google.MapGenerators.ImmutableMapValuesAsSingletonSetGenerator
 
createArray(int) - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.AsMapGenerator
 
createArray(int) - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.EntriesGenerator
 
createArray(int) - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.KeysGenerator
 
createArray(int) - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.MultimapGetGenerator
 
createArray(int) - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.ReserializedMultimapGenerator
 
createArray(int) - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.ValuesGenerator
 
createArray(int) - Method in class com.google.common.collect.testing.google.MultisetTestSuiteBuilder.ElementSetGenerator
 
createArray(int) - Method in class com.google.common.collect.testing.google.MultisetTestSuiteBuilder.EntrySetGenerator
 
createArray(int) - Method in class com.google.common.collect.testing.google.MultisetTestSuiteBuilder.ReserializedMultisetGenerator
 
createArray(int) - Method in class com.google.common.collect.testing.google.SortedMapGenerators.ImmutableSortedMapEntryListGenerator
 
createArray(int) - Method in class com.google.common.collect.testing.google.SortedMultisetTestSuiteBuilder.ForwardingTestMultisetGenerator
 
createArray(int) - Method in class com.google.common.collect.testing.google.TestEnumMultisetGenerator
 
createArray(int) - Method in class com.google.common.collect.testing.google.TestStringBiMapGenerator
 
createArray(int) - Method in class com.google.common.collect.testing.google.TestStringListMultimapGenerator
 
createArray(int) - Method in class com.google.common.collect.testing.google.TestStringMultisetGenerator
 
createArray(int) - Method in class com.google.common.collect.testing.google.TestStringSetMultimapGenerator
 
createArray(int) - Method in class com.google.common.collect.testing.ListTestSuiteBuilder.ReserializedListGenerator
 
createArray(int) - Method in class com.google.common.collect.testing.MapTestSuiteBuilder.ReserializedMapGenerator
 
createArray(int) - Method in class com.google.common.collect.testing.OneSizeGenerator
 
createArray(int) - Method in class com.google.common.collect.testing.ReserializingTestCollectionGenerator
 
createArray(int) - Method in class com.google.common.collect.testing.SetTestSuiteBuilder.ReserializedSetGenerator
 
createArray(int) - Method in class com.google.common.collect.testing.TestCharacterListGenerator
 
createArray(int) - Method in class com.google.common.collect.testing.TestCollidingSetGenerator
 
createArray(int) - Method in interface com.google.common.collect.testing.TestContainerGenerator
Helper method to create an array of the appropriate type used by this generator.
createArray(int) - Method in class com.google.common.collect.testing.TestEnumMapGenerator
 
createArray(int) - Method in class com.google.common.collect.testing.TestEnumSetGenerator
 
createArray(int) - Method in class com.google.common.collect.testing.TestIntegerSetGenerator
 
createArray(int) - Method in class com.google.common.collect.testing.TestMapEntrySetGenerator
 
createArray(int) - Method in class com.google.common.collect.testing.TestStringCollectionGenerator
 
createArray(int) - Method in class com.google.common.collect.testing.TestStringListGenerator
 
createArray(int) - Method in class com.google.common.collect.testing.TestStringMapGenerator
 
createArray(int) - Method in class com.google.common.collect.testing.TestStringQueueGenerator
 
createArray(int) - Method in class com.google.common.collect.testing.TestStringSetGenerator
 
createArray(int) - Method in class com.google.common.collect.testing.TestUnhashableCollectionGenerator
 
createArrayWithDuplicateElement() - Method in class com.google.common.collect.testing.AbstractContainerTester
 
createArrayWithNullElement() - Method in class com.google.common.collect.testing.AbstractCollectionTester
 
createArrayWithNullKey() - Method in class com.google.common.collect.testing.AbstractMapTester
 
createArrayWithNullKey() - Method in class com.google.common.collect.testing.google.AbstractMultimapTester
 
createArrayWithNullKeyAndValue() - Method in class com.google.common.collect.testing.google.AbstractMultimapTester
 
createArrayWithNullValue() - Method in class com.google.common.collect.testing.AbstractMapTester
 
createArrayWithNullValue() - Method in class com.google.common.collect.testing.google.AbstractMultimapTester
 
createAsList() - Method in class com.google.common.collect.ImmutableMapEntrySet.RegularEntrySet
 
createAsList() - Method in class com.google.common.collect.ImmutableSet.CachingAsList
 
createAsList() - Method in class com.google.common.collect.ImmutableSet.Indexed
 
createAsList() - Method in class com.google.common.collect.IndexedImmutableSet
 
createAsList() - Method in class com.google.common.collect.RegularContiguousSet
 
createAsList() - Method in class com.google.common.collect.RegularImmutableBiMap.Inverse.InverseEntrySet
 
createAsList() - Method in class com.google.common.collect.RegularImmutableSet
 
createAsList() - Method in class com.google.common.collect.RegularImmutableSortedSet
 
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.CustomListMultimap
 
createAsMap() - Method in class com.google.common.collect.Multimaps.CustomMultimap
 
createAsMap() - Method in class com.google.common.collect.Multimaps.CustomSetMultimap
 
createAsMap() - Method in class com.google.common.collect.Multimaps.CustomSortedSetMultimap
 
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
 
createAsync(ListenableFuture<? extends V>, Class<X>, AsyncFunction<? super X, ? extends V>, Executor) - Static method in class com.google.common.util.concurrent.AbstractCatchingFuture
 
createAsync(ListenableFuture<I>, AsyncFunction<? super I, ? extends O>, Executor) - Static method in class com.google.common.util.concurrent.AbstractTransformFuture
 
createAudioType(String) - Static method in class com.google.common.net.MediaType
Creates a media type with the "audio" type and the given subtype.
createBuffer() - Static method in class com.google.common.io.ByteStreams
Creates a new byte array for buffering reads or writes.
createBuffer() - Static method in class com.google.common.io.CharStreams
Creates a new CharBuffer for buffering reads or writes.
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() - 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.LinkedHashMultimap
Creates the collection of values for a single 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(Iterable<? extends String>) - Method in class com.google.common.collect.testing.google.TestStringListMultimapGenerator
 
createCollection(Iterable<? extends String>) - Method in class com.google.common.collect.testing.google.TestStringSetMultimapGenerator
 
createCollection(Iterable<? extends V>) - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.ReserializedMultimapGenerator
 
createCollection(Iterable<? extends V>) - Method in interface com.google.common.collect.testing.google.TestMultimapGenerator
 
createCollection(K) - Method in class com.google.common.collect.AbstractMapBasedMultimap
Creates the collection of values for an explicitly provided key.
createCollection(K) - Method in class com.google.common.collect.LinkedHashMultimap
Creates the collection of values for an explicitly provided key.
createCollection(K) - Method in class com.google.common.collect.TreeMultimap
 
createCollection(V) - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.AsMapGenerator
 
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
 
createDerivedEntrySetSuite(TestSetGenerator<Map.Entry<K, V>>) - Method in class com.google.common.collect.testing.MapTestSuiteBuilder
 
createDerivedKeySetSuite(TestSetGenerator<K>) - Method in class com.google.common.collect.testing.MapTestSuiteBuilder
 
createDerivedKeySetSuite(TestSetGenerator<K>) - Method in class com.google.common.collect.testing.NavigableMapTestSuiteBuilder
 
createDerivedKeySetSuite(TestSetGenerator<K>) - Method in class com.google.common.collect.testing.SortedMapTestSuiteBuilder
 
createDerivedSuites(FeatureSpecificTestSuiteBuilder<?, ? extends OneSizeTestContainerGenerator<BiMap<K, V>, Map.Entry<K, V>>>) - Method in class com.google.common.collect.testing.google.BiMapTestSuiteBuilder
 
createDerivedSuites(FeatureSpecificTestSuiteBuilder<?, ? extends OneSizeTestContainerGenerator<Collection<E>, E>>) - Method in class com.google.common.collect.testing.CollectionTestSuiteBuilder
 
createDerivedSuites(FeatureSpecificTestSuiteBuilder<?, ? extends OneSizeTestContainerGenerator<Collection<E>, E>>) - Method in class com.google.common.collect.testing.google.MultisetTestSuiteBuilder
 
createDerivedSuites(FeatureSpecificTestSuiteBuilder<?, ? extends OneSizeTestContainerGenerator<Collection<E>, E>>) - Method in class com.google.common.collect.testing.ListTestSuiteBuilder
 
createDerivedSuites(FeatureSpecificTestSuiteBuilder<?, ? extends OneSizeTestContainerGenerator<Collection<E>, E>>) - Method in class com.google.common.collect.testing.NavigableSetTestSuiteBuilder
 
createDerivedSuites(FeatureSpecificTestSuiteBuilder<?, ? extends OneSizeTestContainerGenerator<Collection<E>, E>>) - Method in class com.google.common.collect.testing.SetTestSuiteBuilder
 
createDerivedSuites(FeatureSpecificTestSuiteBuilder<?, ? extends OneSizeTestContainerGenerator<Collection<E>, E>>) - Method in class com.google.common.collect.testing.SortedSetTestSuiteBuilder
 
createDerivedSuites(FeatureSpecificTestSuiteBuilder<?, ? extends OneSizeTestContainerGenerator<Map<K, V>, Map.Entry<K, V>>>) - Method in class com.google.common.collect.testing.MapTestSuiteBuilder
 
createDerivedSuites(FeatureSpecificTestSuiteBuilder<?, ? extends OneSizeTestContainerGenerator<Map<K, V>, Map.Entry<K, V>>>) - Method in class com.google.common.collect.testing.NavigableMapTestSuiteBuilder
 
createDerivedSuites(FeatureSpecificTestSuiteBuilder<?, ? extends OneSizeTestContainerGenerator<Map<K, V>, Map.Entry<K, V>>>) - Method in class com.google.common.collect.testing.SortedMapTestSuiteBuilder
 
createDerivedSuites(FeatureSpecificTestSuiteBuilder<?, ? extends OneSizeTestContainerGenerator<M, Map.Entry<K, V>>>) - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder
 
createDerivedSuites(FeatureSpecificTestSuiteBuilder<?, ? extends OneSizeTestContainerGenerator<T, E>>) - Method in class com.google.common.collect.testing.PerCollectionSizeTestSuiteBuilder
 
createDerivedSuites(SortedMultisetTestSuiteBuilder<E>) - Method in class com.google.common.collect.testing.google.SortedMultisetTestSuiteBuilder
 
createDerivedValueCollectionSuite(TestCollectionGenerator<V>) - Method in class com.google.common.collect.testing.MapTestSuiteBuilder
 
createDescendingMultiset() - Method in class com.google.common.collect.AbstractSortedMultiset
 
createDescendingSet() - Method in class com.google.common.collect.ContiguousSet
 
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.ImmutableRangeSet.AsSet
 
createDescendingSet() - Method in class com.google.common.collect.ImmutableSortedSet
 
createDescendingSet() - Method in class com.google.common.collect.RegularImmutableSortedSet
 
createDescendingSuite(FeatureSpecificTestSuiteBuilder<?, ? extends OneSizeTestContainerGenerator<Collection<E>, E>>) - Method in class com.google.common.collect.testing.NavigableSetTestSuiteBuilder
Create a suite whose maps are descending views of other maps.
createDescendingSuite(FeatureSpecificTestSuiteBuilder<?, ? extends OneSizeTestContainerGenerator<Map<K, V>, Map.Entry<K, V>>>) - Method in class com.google.common.collect.testing.NavigableMapTestSuiteBuilder
Create a suite whose maps are descending views of other maps.
createDescendingSuite(SortedMultisetTestSuiteBuilder<E>) - Method in class com.google.common.collect.testing.google.SortedMultisetTestSuiteBuilder
 
createDisjointCollection() - Method in class com.google.common.collect.testing.AbstractContainerTester
 
createDisjointCollection() - Method in class com.google.common.collect.testing.AbstractMapTester
 
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
 
createElementSetTestSuite(FeatureSpecificTestSuiteBuilder<?, ? extends OneSizeTestContainerGenerator<Collection<E>, E>>) - Method in class com.google.common.collect.testing.google.MultisetTestSuiteBuilder
 
createElementSetTestSuite(FeatureSpecificTestSuiteBuilder<?, ? extends OneSizeTestContainerGenerator<Collection<E>, E>>) - Method in class com.google.common.collect.testing.google.SortedMultisetTestSuiteBuilder
 
createEmptyArray(Class<T>) - Static method in class com.google.common.testing.ArbitraryInstances
 
createEntries() - Method in class com.google.common.collect.AbstractMapBasedMultimap
 
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
 
createEntries() - Method in class com.google.common.collect.Multimaps.MapMultimap
 
createEntries() - Method in class com.google.common.collect.Multimaps.TransformedEntriesMultimap
 
createEntryArray(int) - Static method in class com.google.common.collect.ImmutableMapEntry
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.CompactHashMap
 
createEntrySet() - Method in class com.google.common.collect.CompactLinkedHashMap
 
createEntrySet() - Method in class com.google.common.collect.ConcurrentHashMultiset
Deprecated.
Internal method, use AbstractMultiset.entrySet().
createEntrySet() - Method in class com.google.common.collect.DescendingMultiset
 
createEntrySet() - Method in class com.google.common.collect.FilteredEntryMultimap.AsMap
 
createEntrySet() - Method in class com.google.common.collect.ImmutableMap
 
createEntrySet() - Method in class com.google.common.collect.ImmutableMap.IteratorBasedImmutableMap
 
createEntrySet() - Method in class com.google.common.collect.ImmutableMultiset
 
createEntrySet() - Method in class com.google.common.collect.ImmutableSortedMap
 
createEntrySet() - Method in class com.google.common.collect.JdkBackedImmutableBiMap
 
createEntrySet() - Method in class com.google.common.collect.JdkBackedImmutableMap
 
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.ViewCachingAbstractMap
Creates the entry set to be returned by Maps.ViewCachingAbstractMap.entrySet().
createEntrySet() - Method in class com.google.common.collect.Multimaps.AsMap
 
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.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.RowMap
 
createExplicitComparator(String[]) - Static method in class com.google.common.collect.testing.google.SetGenerators
 
createFontType(String) - Static method in class com.google.common.net.MediaType
Creates a media type with the "font" type and the given subtype.
createFromEntries(Map.Entry<K, V>[]) - Method in class com.google.common.collect.testing.TestMapEntrySetGenerator
 
createFromSystemTimer() - Static method in class com.google.common.util.concurrent.RateLimiter.SleepingStopwatch
 
createHashFloodingResistantDelegate(int) - Method in class com.google.common.collect.CompactHashMap
 
createHashFloodingResistantDelegate(int) - Method in class com.google.common.collect.CompactHashSet
 
createHashFloodingResistantDelegate(int) - Method in class com.google.common.collect.CompactLinkedHashMap
 
createImageType(String) - Static method in class com.google.common.net.MediaType
Creates a media type with the "image" type and the given subtype.
createInstance(Invokable<?, ? extends T>, List<?>) - Static method in class com.google.common.testing.ClassSanityTester
 
createInverse() - Method in class com.google.common.math.LinearTransformation.RegularLinearTransformation
 
createInverse() - Method in class com.google.common.math.LinearTransformation.VerticalLinearTransformation
 
createKeyArray(int) - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.ForwardingTestMapGenerator
 
createKeyArray(int) - Method in class com.google.common.collect.testing.google.DerivedGoogleCollectionGenerators.InverseBiMapGenerator
 
createKeyArray(int) - Method in class com.google.common.collect.testing.google.DerivedGoogleCollectionGenerators.MapGenerator
 
createKeyArray(int) - Method in class com.google.common.collect.testing.google.MapGenerators.ImmutableMapValuesAsSingletonSetGenerator
 
createKeyArray(int) - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.AsMapGenerator
 
createKeyArray(int) - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.ReserializedMultimapGenerator
 
createKeyArray(int) - Method in interface com.google.common.collect.testing.google.TestBiMapGenerator
 
createKeyArray(int) - Method in interface com.google.common.collect.testing.google.TestMultimapGenerator
 
createKeyArray(int) - Method in class com.google.common.collect.testing.google.TestStringBiMapGenerator
 
createKeyArray(int) - Method in class com.google.common.collect.testing.google.TestStringListMultimapGenerator
 
createKeyArray(int) - Method in class com.google.common.collect.testing.google.TestStringSetMultimapGenerator
 
createKeyArray(int) - Method in class com.google.common.collect.testing.MapTestSuiteBuilder.ReserializedMapGenerator
 
createKeyArray(int) - Method in class com.google.common.collect.testing.TestEnumMapGenerator
 
createKeyArray(int) - Method in interface com.google.common.collect.testing.TestMapGenerator
 
createKeyArray(int) - Method in class com.google.common.collect.testing.TestStringMapGenerator
 
createKeys() - Method in class com.google.common.collect.AbstractMapBasedMultimap
 
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
 
createKeys() - Method in class com.google.common.collect.LinkedListMultimap
 
createKeys() - Method in class com.google.common.collect.Multimaps.MapMultimap
 
createKeys() - Method in class com.google.common.collect.Multimaps.TransformedEntriesMultimap
 
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.AbstractSortedKeySortedSetMultimap
 
createKeySet() - Method in class com.google.common.collect.CompactHashMap
 
createKeySet() - Method in class com.google.common.collect.CompactLinkedHashMap
 
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.FilteredEntryMultimap
 
createKeySet() - Method in class com.google.common.collect.FilteredKeyMultimap
 
createKeySet() - Method in class com.google.common.collect.ImmutableMap
 
createKeySet() - Method in class com.google.common.collect.ImmutableMap.IteratorBasedImmutableMap
 
createKeySet() - Method in class com.google.common.collect.ImmutableMap.MapViewOfValuesAsSingletonSets
 
createKeySet() - Method in class com.google.common.collect.ImmutableMultimap
 
createKeySet() - Method in class com.google.common.collect.ImmutableSortedMap
 
createKeySet() - Method in class com.google.common.collect.JdkBackedImmutableBiMap
 
createKeySet() - Method in class com.google.common.collect.JdkBackedImmutableMap
 
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.ViewCachingAbstractMap
 
createKeySet() - Method in class com.google.common.collect.Multimaps.CustomListMultimap
 
createKeySet() - Method in class com.google.common.collect.Multimaps.CustomMultimap
 
createKeySet() - Method in class com.google.common.collect.Multimaps.CustomSetMultimap
 
createKeySet() - Method in class com.google.common.collect.Multimaps.CustomSortedSetMultimap
 
createKeySet() - Method in class com.google.common.collect.Multimaps.MapMultimap
 
createKeySet() - Method in class com.google.common.collect.Multimaps.TransformedEntriesMultimap
 
createKeySet() - Method in class com.google.common.collect.RegularImmutableBiMap
 
createKeySet() - Method in class com.google.common.collect.RegularImmutableBiMap.Inverse
 
createKeySet() - Method in class com.google.common.collect.RegularImmutableMap
 
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
 
createListenableFuture(V, Exception, CountDownLatch) - Method in class com.google.common.util.concurrent.testing.AbstractListenableFutureTest
Constructs a listenable future with a value available after the latch has counted down.
createMap() - Method in class com.google.common.collect.MultimapBuilder.MultimapBuilderWithKeys
 
createMap(int) - Method in class com.google.common.graph.ElementOrder
Returns an empty mutable map whose keys will respect this ElementOrder.
createMatchResult() - Static method in class com.google.common.testing.ArbitraryInstances
Returns a new MatchResult that corresponds to a successful match.
createMaybeNavigableAsMap() - Method in class com.google.common.collect.AbstractMapBasedMultimap
 
createMaybeNavigableKeySet() - Method in class com.google.common.collect.AbstractMapBasedMultimap
 
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.
createOrderedArray() - Method in class com.google.common.collect.testing.AbstractContainerTester
 
createParentDirectories(Path, FileAttribute<?>...) - Static method in class com.google.common.io.MoreFiles
Creates any necessary but nonexistent parent directories of the specified path.
createParentDirs(File) - Static method in class com.google.common.io.Files
Creates any necessary but nonexistent parent directories of the specified file.
createRangeMap() - Method in class com.google.common.collect.ImmutableRangeMap.SerializedForm
 
createReplacementArray(Map<Character, String>) - Static method in class com.google.common.escape.ArrayBasedEscaperMap
 
createReserializedSuite(SortedMultisetTestSuiteBuilder<E>) - Method in class com.google.common.collect.testing.google.SortedMultisetTestSuiteBuilder
 
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.
createSamplesArray() - Method in class com.google.common.collect.testing.AbstractContainerTester
 
createSegment(int) - Method in class com.google.common.collect.MapMakerInternalMap
 
createSegment(int, long, AbstractCache.StatsCounter) - Method in class com.google.common.cache.LocalCache
 
createSplit(F, long) - Method in class com.google.common.collect.Streams.MapWithIndexSpliterator
 
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.
createSubMap(SortedMap<K, V>, K, K) - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.SortedMapSubmapTestMapGenerator
Calls the smallest subMap overload that filters out the extreme values.
createSubMap(SortedMap<K, V>, K, K) - Method in class com.google.common.collect.testing.NavigableMapTestSuiteBuilder.NavigableMapSubmapTestMapGenerator
 
createSubmapSuite(FeatureSpecificTestSuiteBuilder<?, ? extends OneSizeTestContainerGenerator<Map<K, V>, Map.Entry<K, V>>>, DerivedCollectionGenerators.Bound, DerivedCollectionGenerators.Bound) - Method in class com.google.common.collect.testing.SortedMapTestSuiteBuilder
Creates a suite whose map has some elements filtered out of view.
createSubMultisetSuite(SortedMultisetTestSuiteBuilder<E>, SortedMultisetTestSuiteBuilder.Bound, SortedMultisetTestSuiteBuilder.Bound) - Method in class com.google.common.collect.testing.google.SortedMultisetTestSuiteBuilder
 
createSubSet(SortedSet<E>, E, E) - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.SortedSetSubsetTestSetGenerator
Calls the smallest subSet overload that filters out the extreme values.
createSubSet(SortedSet<E>, E, E) - Method in class com.google.common.collect.testing.NavigableSetTestSuiteBuilder.NavigableSetSubsetTestSetGenerator
 
createSubsetSuite(FeatureSpecificTestSuiteBuilder<?, ? extends OneSizeTestContainerGenerator<Collection<E>, E>>, DerivedCollectionGenerators.Bound, DerivedCollectionGenerators.Bound) - Method in class com.google.common.collect.testing.SortedSetTestSuiteBuilder
Creates a suite whose set has some elements filtered out of view.
createTable(int) - Static method in class com.google.common.collect.CompactHashing
Creates and returns a properly-sized array with the given number of buckets.
createTable(int) - Method in class com.google.common.collect.HashBiMap
 
createTempDir() - Static method in class com.google.common.io.Files
Deprecated.
For Android users, see the Data and File Storage overview to select an appropriate temporary directory (perhaps context.getCacheDir()), and create your own directory under that. (For example, you might use new File(context.getCacheDir(), "directoryname").mkdir(), or, if you need an arbitrary number of temporary directories, you might have to generate multiple directory names in a loop until mkdir() returns true.) For JRE users, prefer Files.createTempDirectory(java.nio.file.Path, java.lang.String, java.nio.file.attribute.FileAttribute<?>...), transforming it to a File using toFile() if needed. To restrict permissions as this method does, pass PosixFilePermissions.asFileAttribute(PosixFilePermissions.fromString("rwx------")) to your call to createTempDirectory.
createTempDir() - Method in class com.google.common.io.TempFileCreator
 
createTempDir() - Method in class com.google.common.io.TempFileCreator.JavaIoCreator
 
createTempDir() - Method in class com.google.common.io.TempFileCreator.JavaNioCreator
 
createTempDir() - Method in class com.google.common.io.TempFileCreator.ThrowingCreator
 
createTempFile(String) - Method in class com.google.common.io.TempFileCreator
 
createTempFile(String) - Method in class com.google.common.io.TempFileCreator.JavaIoCreator
 
createTempFile(String) - Method in class com.google.common.io.TempFileCreator.JavaNioCreator
 
createTempFile(String) - Method in class com.google.common.io.TempFileCreator.ThrowingCreator
 
createTestSubject() - Method in class com.google.common.collect.testing.OneSizeGenerator
 
createTestSubject() - Method in interface com.google.common.collect.testing.TestSubjectGenerator
 
createTestSuite() - Method in class com.google.common.collect.testing.FeatureSpecificTestSuiteBuilder
Creates a runnable JUnit test suite based on the criteria already given.
createTestSuite() - Method in class com.google.common.collect.testing.google.SortedMultisetTestSuiteBuilder
 
createTestSuite() - Method in class com.google.common.collect.testing.ListTestSuiteBuilder
Specifies CollectionFeature.KNOWN_ORDER for all list tests, since lists have an iteration ordering corresponding to the insertion order.
createTestSuite() - Method in class com.google.common.collect.testing.PerCollectionSizeTestSuiteBuilder
Creates a runnable JUnit test suite based on the criteria already given.
createTestSuite() - Method in class com.google.common.collect.testing.SortedMapTestSuiteBuilder
 
createTestSuite() - Method in class com.google.common.collect.testing.SortedSetTestSuiteBuilder
 
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
 
createUnreachableLatchFinalizer(CountDownLatch) - Static method in class com.google.common.testing.GcFinalization
Creates a garbage object that counts down the latch in its finalizer.
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.
createValueArray(int) - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.ForwardingTestMapGenerator
 
createValueArray(int) - Method in class com.google.common.collect.testing.google.DerivedGoogleCollectionGenerators.InverseBiMapGenerator
 
createValueArray(int) - Method in class com.google.common.collect.testing.google.DerivedGoogleCollectionGenerators.MapGenerator
 
createValueArray(int) - Method in class com.google.common.collect.testing.google.MapGenerators.ImmutableMapValuesAsSingletonSetGenerator
 
createValueArray(int) - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.AsMapGenerator
 
createValueArray(int) - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.ReserializedMultimapGenerator
 
createValueArray(int) - Method in interface com.google.common.collect.testing.google.TestBiMapGenerator
 
createValueArray(int) - Method in interface com.google.common.collect.testing.google.TestMultimapGenerator
 
createValueArray(int) - Method in class com.google.common.collect.testing.google.TestStringBiMapGenerator
 
createValueArray(int) - Method in class com.google.common.collect.testing.google.TestStringListMultimapGenerator
 
createValueArray(int) - Method in class com.google.common.collect.testing.google.TestStringSetMultimapGenerator
 
createValueArray(int) - Method in class com.google.common.collect.testing.MapTestSuiteBuilder.ReserializedMapGenerator
 
createValueArray(int) - Method in class com.google.common.collect.testing.TestEnumMapGenerator
 
createValueArray(int) - Method in interface com.google.common.collect.testing.TestMapGenerator
 
createValueArray(int) - Method in class com.google.common.collect.testing.TestStringMapGenerator
 
createValues() - Method in class com.google.common.collect.AbstractMapBasedMultimap
 
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.CompactHashMap
 
createValues() - Method in class com.google.common.collect.CompactLinkedHashMap
 
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.ImmutableBiMap
 
createValues() - Method in class com.google.common.collect.ImmutableMap
 
createValues() - Method in class com.google.common.collect.ImmutableMap.IteratorBasedImmutableMap
 
createValues() - Method in class com.google.common.collect.ImmutableMultimap
 
createValues() - Method in class com.google.common.collect.ImmutableSortedMap
 
createValues() - Method in class com.google.common.collect.ImmutableTable
 
createValues() - Method in class com.google.common.collect.JdkBackedImmutableMap
 
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.ViewCachingAbstractMap
 
createValues() - Method in class com.google.common.collect.Multimaps.MapMultimap
 
createValues() - Method in class com.google.common.collect.Multimaps.TransformedEntriesMultimap
 
createValues() - Method in class com.google.common.collect.RegularImmutableMap
 
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.
createWithDummyValues(MapMaker) - Static method in class com.google.common.collect.MapMakerInternalMap
Returns a fresh MapMakerInternalMap with MapMaker.Dummy values but otherwise as specified by the given builder.
createWithExpectedSize(int) - Static method in class com.google.common.collect.CompactHashMap
Creates a CompactHashMap instance, with a high enough "initial capacity" that it should hold expectedSize elements without growth.
createWithExpectedSize(int) - Static method in class com.google.common.collect.CompactHashSet
Creates a CompactHashSet instance, with a high enough "initial capacity" that it should hold expectedSize elements without growth.
createWithExpectedSize(int) - Static method in class com.google.common.collect.CompactLinkedHashMap
Creates a CompactLinkedHashMap instance, with a high enough "initial capacity" that it should hold expectedSize elements without rebuilding internal data structures.
createWithExpectedSize(int) - Static method in class com.google.common.collect.CompactLinkedHashSet
Creates a CompactLinkedHashSet instance, with a high enough "initial capacity" that it should hold expectedSize elements without rebuilding internal data structures.
Creation - Search tag in class com.google.common.collect.ImmutableCollection
Section
CRITICAL_CH - Static variable in class com.google.common.net.HttpHeaders
The HTTP Critical-CH header field name.
CROSS_ORIGIN_EMBEDDER_POLICY - Static variable in class com.google.common.net.HttpHeaders
The HTTP Cross-Origin-Embedder-Policy header field name.
CROSS_ORIGIN_EMBEDDER_POLICY_REPORT_ONLY - Static variable in class com.google.common.net.HttpHeaders
CROSS_ORIGIN_OPENER_POLICY - Static variable in class com.google.common.net.HttpHeaders
The HTTP Cross-Origin-Opener-Policy header field name.
CROSS_ORIGIN_RESOURCE_POLICY - Static variable in class com.google.common.net.HttpHeaders
The HTTP Cross-Origin-Resource-Policy header field name.
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 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 class 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.SupplantableFuture
 
currentIndex - Variable in class com.google.common.collect.CompactHashMap.Itr
 
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
 
custom(int, Supplier<L>) - Static method in class com.google.common.util.concurrent.Striped
Creates a Striped<L> with eagerly initialized, strongly referenced locks.
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> - 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> - Class in com.google.common.collect
 
Cut.BelowAll - Class in com.google.common.collect
 
Cut.BelowValue<C> - 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(Iterable<T>) - Static method in class com.google.common.collect.Iterators
Returns an iterator that cycles indefinitely over the elements of iterable.
cycle(Iterable<T>) - Static method in class com.google.common.collect.testing.Helpers
 
cycle(T...) - Static method in class com.google.common.collect.Iterables
Returns an iterable whose iterators cycle indefinitely over the provided elements.
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 Class 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 Class 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 Class in com.google.common.util.concurrent
Represents a detected cycle in lock acquisition ordering.
CycleDetectingLockFactory.WithExplicitOrdering<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
 
D - Enum constant in enum class com.google.common.collect.testing.AnEnum
 
daemon - Variable in class com.google.common.util.concurrent.ThreadFactoryBuilder
 
DART_UTF_8 - Static variable in class com.google.common.net.MediaType
Files in the dart programming language.
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.LockFreeBitArray
 
dataLength() - Method in class com.google.common.hash.BloomFilterStrategies.LockFreeBitArray
Returns the number of longs in the underlying AtomicLongArray.
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.
Dead Events - Search tag in class com.google.common.eventbus.EventBus
Section
declaration - Variable in class com.google.common.reflect.Parameter
 
declaresInterruptedEx(Method) - Static method in class com.google.common.util.concurrent.SimpleTimeLimiter
 
declaringClass - Variable in class com.google.common.testing.ClassSanityTester.FactoryMethodReturnValueTester
 
decodabet - Variable in class com.google.common.io.BaseEncoding.Alphabet
 
decodabetFor(char[]) - Static method 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[].
decodeTo(byte[], CharSequence) - Method in class com.google.common.io.BaseEncoding.Base16Encoding
 
decodeTo(byte[], CharSequence) - Method in class com.google.common.io.BaseEncoding.Base64Encoding
 
decodeTo(byte[], CharSequence) - Method in class com.google.common.io.BaseEncoding
 
decodeTo(byte[], CharSequence) - Method in class com.google.common.io.BaseEncoding.SeparatedBaseEncoding
 
decodeTo(byte[], CharSequence) - Method in class com.google.common.io.BaseEncoding.StandardBaseEncoding
 
DecodingException(String) - Constructor for exception class 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(Reader) - Method in class com.google.common.io.BaseEncoding.SeparatedBaseEncoding
 
decodingStream(Reader) - Method in class com.google.common.io.BaseEncoding.StandardBaseEncoding
 
DecoupledLoader() - Constructor for class com.google.common.base.FinalizableReferenceQueue.DecoupledLoader
 
DecreasingCount() - Constructor for class com.google.common.collect.Multisets.DecreasingCount
 
decrement() - Method in class com.google.common.cache.LongAdder
Equivalent to add(-1).
decrement() - Method in class com.google.common.hash.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.
decrementAndGetRemainingCount(AggregateFutureState<?>) - Method in class com.google.common.util.concurrent.AggregateFutureState.AtomicHelper
Atomic decrement-and-get of the AggregateFutureState.remaining field.
decrementAndGetRemainingCount(AggregateFutureState<?>) - Method in class com.google.common.util.concurrent.AggregateFutureState.SafeAtomicHelper
 
decrementAndGetRemainingCount(AggregateFutureState<?>) - Method in class com.google.common.util.concurrent.AggregateFutureState.SynchronizedAtomicHelper
 
decrementCountAndMaybeComplete(ImmutableCollection<? extends Future<? extends InputT>>) - Method in class com.google.common.util.concurrent.AggregateFuture
 
decrementRemainingAndGet() - Method in class com.google.common.util.concurrent.AggregateFutureState
 
dedupe(String[]) - Static method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
dedupedElements - Variable in class com.google.common.collect.ImmutableSet.SetBuilderImpl
 
DEFAULT_BUF_SIZE - Static variable in class com.google.common.io.CharStreams
 
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_EDGE_COUNT - Static variable in class com.google.common.graph.GraphConstants
 
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_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_NODE_COUNT - Static variable in class com.google.common.graph.GraphConstants
 
DEFAULT_REFRESH_NANOS - Static variable in class com.google.common.cache.CacheBuilder
 
DEFAULT_SIZE - Static variable in class com.google.common.collect.CompactHashing
Default size of a compact hash-based collection.
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
 
defaultConverter(TypeToken<F>, TypeToken<T>) - Method in class com.google.common.testing.NullPointerTester
 
defaultEquivalence() - Method in enum class 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 class com.google.common.collect.MapMakerInternalMap.Strength
Returns the default equivalence strategy used to compare and hash keys or values referenced at this strength.
defaultGenerate(Class<T>) - Method in class com.google.common.testing.FreshValueGenerator
 
defaultLoader - Variable in class com.google.common.cache.LocalCache
The default cache loader to use on loading operations.
defaults - Variable in class com.google.common.testing.NullPointerTester
 
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.testing.ArbitraryInstances
 
defaultValue - Variable in class com.google.common.base.Functions.ForMapWithDefault
 
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.
defaultValues - Variable in class com.google.common.testing.ClassSanityTester
 
defensiveCopy(Iterable<T>) - Static method in class com.google.common.base.Predicates
 
defensiveCopy(T...) - Static method in class com.google.common.base.Predicates
 
DeferredCloser(ClosingFuture.CloseableList) - Constructor for class com.google.common.util.concurrent.ClosingFuture.DeferredCloser
 
Definition - Search tag in interface com.google.common.hash.HashFunction
Section
Definition and notes on interpolation - Search tag in class com.google.common.math.Quantiles
Section
DegeneratedImmutableSetGenerator() - Constructor for class com.google.common.collect.testing.google.SetGenerators.DegeneratedImmutableSetGenerator
 
degree(N) - Method in class com.google.common.graph.AbstractBaseGraph
 
degree(N) - Method in class com.google.common.graph.AbstractNetwork
 
degree(N) - Method in interface com.google.common.graph.BaseGraph
Returns the count of node's incident edges, counting self-loops twice (equivalently, the number of times an edge touches node).
degree(N) - Method in class com.google.common.graph.ForwardingGraph
 
degree(N) - Method in class com.google.common.graph.ForwardingNetwork
 
degree(N) - Method in class com.google.common.graph.ForwardingValueGraph
 
degree(N) - Method in interface com.google.common.graph.Graph
Returns the count of node's incident edges, counting self-loops twice (equivalently, the number of times an edge touches node).
degree(N) - Method in interface com.google.common.graph.Network
Returns the count of node's incident edges, counting self-loops twice (equivalently, the number of times an edge touches node).
degree(N) - Method in interface com.google.common.graph.ValueGraph
Returns the count of node's incident edges, counting self-loops twice (equivalently, the number of times an edge touches node).
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.NonSerializableMemoizingSupplier
 
delegate - Variable in class com.google.common.base.Suppliers.ThreadSafeSupplier
 
delegate - Variable in class com.google.common.cache.ForwardingCache.SimpleForwardingCache
 
delegate - Variable in class com.google.common.cache.ForwardingLoadingCache.SimpleForwardingLoadingCache
 
delegate - Variable in class com.google.common.cache.LocalCache.ManualSerializationProxy
 
delegate - Variable in class com.google.common.collect.AbstractBiMap.BiMapEntry
 
delegate - Variable in class com.google.common.collect.AbstractBiMap
 
delegate - Variable in class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection
 
delegate - Variable in class com.google.common.collect.EvictingQueue
 
delegate - Variable 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.ImmutableMultiset.ElementSet
 
delegate - Variable in class com.google.common.collect.ImmutableSet.JdkBackedSetBuilderImpl
 
delegate - Variable in class com.google.common.collect.JdkBackedImmutableSet
 
delegate - Variable in class com.google.common.collect.MapMakerInternalMap.AbstractSerializationProxy
 
delegate - Variable in class com.google.common.collect.Maps.UnmodifiableBiMap
 
delegate - Variable in class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
delegate - Variable in class com.google.common.collect.Multimaps.UnmodifiableMultimap
 
delegate - Variable in class com.google.common.collect.Multisets.UnmodifiableMultiset
 
delegate - Variable in class com.google.common.collect.MutableClassToInstanceMap
 
delegate - Variable in class com.google.common.collect.RegularImmutableAsList
 
delegate - Variable in class com.google.common.collect.Sets.CartesianSet
 
delegate - Variable in class com.google.common.collect.Sets.UnmodifiableNavigableSet
 
delegate - Variable in class com.google.common.collect.Synchronized.SynchronizedObject
 
delegate - Variable in class com.google.common.collect.Tables.UnmodifiableTable
 
delegate - Variable in class com.google.common.collect.testing.DerivedCollectionGenerators.ForwardingTestMapGenerator
 
delegate - Variable in class com.google.common.collect.testing.DerivedCollectionGenerators.MapSortedKeySetGenerator
 
delegate - Variable in class com.google.common.collect.testing.DerivedCollectionGenerators.SortedSetSubsetTestSetGenerator
 
delegate - Variable in class com.google.common.collect.testing.google.SortedMultisetTestSuiteBuilder.ForwardingTestMultisetGenerator
 
delegate - Variable in class com.google.common.collect.testing.ReserializingTestCollectionGenerator
 
delegate - Variable in class com.google.common.collect.testing.SafeTreeMap
 
delegate - Variable in class com.google.common.collect.testing.SafeTreeSet
 
delegate - Variable in class com.google.common.collect.TreeRangeSet.AsRanges
 
delegate - Variable in class com.google.common.graph.InvalidatableSet
 
delegate - Variable in class com.google.common.io.BaseEncoding.SeparatedBaseEncoding
 
delegate - Variable in class com.google.common.reflect.ImmutableTypeToInstanceMap
 
delegate - Variable in class com.google.common.reflect.MutableTypeToInstanceMap.UnmodifiableEntry
 
delegate - Variable in class com.google.common.reflect.TypeToken.TypeCollector.ForwardingTypeCollector
 
delegate - Variable in class com.google.common.testing.EquivalenceTester
 
delegate - Variable in class com.google.common.util.concurrent.AbstractExecutionThreadService
 
delegate - Variable in class com.google.common.util.concurrent.AbstractIdleService
 
delegate - Variable in class com.google.common.util.concurrent.AbstractScheduledService
 
delegate - Variable in class com.google.common.util.concurrent.AbstractScheduledService.FutureAsCancellable
 
delegate - Variable in class com.google.common.util.concurrent.ExecutionSequencer.TaskNonReentrantExecutor
Executor the task was set to run on.
delegate - Variable in class com.google.common.util.concurrent.ForwardingFluentFuture
 
delegate - Variable in class com.google.common.util.concurrent.ForwardingFuture.SimpleForwardingFuture
 
delegate - Variable in class com.google.common.util.concurrent.ForwardingListenableFuture.SimpleForwardingListenableFuture
 
delegate - Variable in class com.google.common.util.concurrent.Futures.NonCancellationPropagatingFuture
 
delegate - Variable 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.Striped.WeakSafeCondition
 
delegate - Variable in class com.google.common.util.concurrent.Striped.WeakSafeLock
 
delegate - Variable in class com.google.common.util.concurrent.Striped.WeakSafeReadWriteLock
 
delegate - Variable in class com.google.common.util.concurrent.testing.SameThreadScheduledExecutorService
 
delegate - Variable in class com.google.common.util.concurrent.WrappingExecutorService
 
delegate - Variable in class com.google.common.util.concurrent.WrappingScheduledExecutorService
 
delegate() - Method in class com.google.common.cache.ForwardingCache
 
delegate() - Method in class com.google.common.cache.ForwardingCache.SimpleForwardingCache
 
delegate() - Method in class com.google.common.cache.ForwardingLoadingCache
 
delegate() - Method in class com.google.common.cache.ForwardingLoadingCache.SimpleForwardingLoadingCache
 
delegate() - Method in class com.google.common.cache.LocalCache.ManualSerializationProxy
 
delegate() - Method in class com.google.common.collect.AbstractBiMap.BiMapEntry
 
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() - Method in class com.google.common.collect.DescendingMultiset
 
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
Deprecated.
 
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() - Method in class com.google.common.collect.ImmutableClassToInstanceMap
 
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() - Method in class com.google.common.collect.Maps.UnmodifiableBiMap
 
delegate() - Method in class com.google.common.collect.Maps.UnmodifiableEntries
 
delegate() - Method in class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
delegate() - Method in class com.google.common.collect.Multimaps.UnmodifiableListMultimap
 
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() - Method in class com.google.common.collect.Multisets.UnmodifiableMultiset
 
delegate() - Method in class com.google.common.collect.MutableClassToInstanceMap
 
delegate() - Method in class com.google.common.collect.Sets.CartesianSet
 
delegate() - Method in class com.google.common.collect.Sets.DescendingSet
 
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() - 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.Synchronized.SynchronizedTable
 
delegate() - Method in class com.google.common.collect.Tables.UnmodifiableRowSortedMap
 
delegate() - Method in class com.google.common.collect.Tables.UnmodifiableTable
 
delegate() - Method in class com.google.common.collect.testing.NavigableMapTestSuiteBuilder.DescendingTestMapGenerator
 
delegate() - Method in class com.google.common.collect.TreeRangeSet.AsRanges
 
delegate() - Method in class com.google.common.collect.UnmodifiableSortedMultiset
 
delegate() - Method in class com.google.common.graph.ForwardingGraph
 
delegate() - Method in class com.google.common.graph.ForwardingNetwork
 
delegate() - Method in class com.google.common.graph.ForwardingValueGraph
 
delegate() - Method in class com.google.common.graph.Graphs.TransposedGraph
 
delegate() - Method in class com.google.common.graph.Graphs.TransposedNetwork
 
delegate() - Method in class com.google.common.graph.Graphs.TransposedValueGraph
 
delegate() - Method in class com.google.common.graph.ImmutableGraph
 
delegate() - Method in class com.google.common.graph.InvalidatableSet
 
delegate() - Method in class com.google.common.graph.StandardMutableGraph
 
delegate() - Method in class com.google.common.reflect.ImmutableTypeToInstanceMap
 
delegate() - Method in class com.google.common.reflect.MutableTypeToInstanceMap
 
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() - Method in class com.google.common.reflect.TypeToken.TypeSet
 
delegate() - Method in class com.google.common.util.concurrent.ForwardingBlockingDeque
 
delegate() - Method in class com.google.common.util.concurrent.ForwardingBlockingQueue
 
delegate() - Method in class com.google.common.util.concurrent.ForwardingCondition
 
delegate() - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
delegate() - Method in class com.google.common.util.concurrent.ForwardingFuture
 
delegate() - Method in class com.google.common.util.concurrent.ForwardingFuture.SimpleForwardingFuture
 
delegate() - Method in class com.google.common.util.concurrent.ForwardingListenableFuture
 
delegate() - Method in class com.google.common.util.concurrent.ForwardingListenableFuture.SimpleForwardingListenableFuture
 
delegate() - Method in class com.google.common.util.concurrent.ForwardingListeningExecutorService
 
delegate() - Method in class com.google.common.util.concurrent.ForwardingLock
 
delegate() - Method in class com.google.common.util.concurrent.JdkFutureAdapters.ListenableFutureAdapter
 
delegate() - Method in class com.google.common.util.concurrent.Striped.WeakSafeCondition
 
delegate() - Method in class com.google.common.util.concurrent.Striped.WeakSafeLock
 
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
 
delegateIndex - Variable in class com.google.common.util.concurrent.Futures.InCompletionOrderState
 
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.JdkBackedImmutableSet
 
delegateList - Variable in class com.google.common.collect.RegularImmutableAsList
 
delegateList() - Method in class com.google.common.collect.RegularImmutableAsList
 
delegateMap - Variable in class com.google.common.collect.JdkBackedImmutableMap
 
delegateMap - Variable in class com.google.common.collect.JdkBackedImmutableMultiset
 
delegateOrNull() - Method in class com.google.common.collect.CompactHashMap
 
delegateOrNull() - Method in class com.google.common.collect.CompactHashSet
 
delegateRef - Variable in class com.google.common.util.concurrent.TimeoutFuture
 
DelegateService() - Constructor for class com.google.common.util.concurrent.AbstractIdleService.DelegateService
 
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.
deleteDirectoryContents(Path, RecursiveDeleteOption...) - Static method in class com.google.common.io.MoreFiles
Deletes all files within the directory at the given path recursively.
deleteDirectoryContentsInsecure(DirectoryStream<Path>) - Static method in class com.google.common.io.MoreFiles
Simple, insecure method for deleting the contents of a directory for file systems that don't support SecureDirectoryStream.
deleteDirectoryContentsSecure(SecureDirectoryStream<Path>) - Static method in class com.google.common.io.MoreFiles
Secure method for deleting the contents of a directory using SecureDirectoryStream.
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
 
deleteRecursively(Path, RecursiveDeleteOption...) - Static method in class com.google.common.io.MoreFiles
Deletes the file or directory at the given path recursively.
deleteRecursivelyInsecure(Path) - Static method in class com.google.common.io.MoreFiles
Insecure recursive delete for file systems that don't support SecureDirectoryStream.
deleteRecursivelySecure(SecureDirectoryStream<Path>, Path) - Static method in class com.google.common.io.MoreFiles
Secure recursive delete using SecureDirectoryStream.
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
 
depthFirstPostOrder(Iterable<? extends N>) - Method in class com.google.common.graph.Traverser
Returns an unmodifiable Iterable over the nodes reachable from any of the startNodes, in the order of a depth-first post-order traversal.
depthFirstPostOrder(N) - Method in class com.google.common.graph.Traverser
Returns an unmodifiable Iterable over the nodes reachable from startNode, in the order of a depth-first post-order traversal.
depthFirstPreOrder(Iterable<? extends N>) - Method in class com.google.common.graph.Traverser
Returns an unmodifiable Iterable over the nodes reachable from any of the startNodes, in the order of a depth-first pre-order traversal.
depthFirstPreOrder(N) - Method in class com.google.common.graph.Traverser
Returns an unmodifiable Iterable over the nodes reachable from startNode, in the order of a depth-first pre-order traversal.
deque(Deque<E>, Object) - Static method in class com.google.common.collect.Synchronized
 
derive(FluentFuture<U>) - Method in class com.google.common.util.concurrent.ClosingFuture
 
DerivedCollectionGenerators - Class in com.google.common.collect.testing
Derived suite generators, split out of the suite builders so that they are available to GWT.
DerivedCollectionGenerators() - Constructor for class com.google.common.collect.testing.DerivedCollectionGenerators
 
DerivedCollectionGenerators.Bound - Enum Class in com.google.common.collect.testing
Two bounds (from and to) define how to build a subMap.
DerivedCollectionGenerators.ForwardingTestMapGenerator<K,V> - Class in com.google.common.collect.testing
 
DerivedCollectionGenerators.MapEntrySetGenerator<K,V> - Class in com.google.common.collect.testing
 
DerivedCollectionGenerators.MapKeySetGenerator<K,V> - Class in com.google.common.collect.testing
 
DerivedCollectionGenerators.MapSortedKeySetGenerator<K,V> - Class in com.google.common.collect.testing
 
DerivedCollectionGenerators.MapValueCollectionGenerator<K,V> - Class in com.google.common.collect.testing
 
DerivedCollectionGenerators.SortedMapSubmapTestMapGenerator<K,V> - Class in com.google.common.collect.testing
 
DerivedCollectionGenerators.SortedSetSubsetTestSetGenerator<E> - Class in com.google.common.collect.testing
 
DerivedComparable - Class in com.google.common.collect.testing
Simple derived class to verify that we handle generics correctly.
DerivedComparable(String) - Constructor for class com.google.common.collect.testing.DerivedComparable
 
DerivedGenerator - Interface in com.google.common.collect.testing
A generator that relies on a preexisting generator for most of its work.
DerivedGoogleCollectionGenerators - Class in com.google.common.collect.testing.google
Derived suite generators for Guava collection interfaces, split out of the suite builders so that they are available to GWT.
DerivedGoogleCollectionGenerators() - Constructor for class com.google.common.collect.testing.google.DerivedGoogleCollectionGenerators
 
DerivedGoogleCollectionGenerators.BiMapValueSetGenerator<K,V> - Class in com.google.common.collect.testing.google
 
DerivedGoogleCollectionGenerators.InverseBiMapGenerator<K,V> - Class in com.google.common.collect.testing.google
 
DerivedGoogleCollectionGenerators.MapGenerator<K,V> - Class in com.google.common.collect.testing.google
 
Derived steps - Search tag in class com.google.common.util.concurrent.ClosingFuture
Section
DerivedTestIteratorGenerator<E> - Class in com.google.common.collect.testing
Adapts a test iterable generator to give a TestIteratorGenerator.
DerivedTestIteratorGenerator(TestSubjectGenerator<? extends Iterable<E>>) - Constructor for class com.google.common.collect.testing.DerivedTestIteratorGenerator
 
DESCENDING - Enum constant in enum class com.google.common.collect.testing.google.SortedMultisetTestSuiteBuilder.NoRecurse
 
DESCENDING - Enum constant in enum class com.google.common.collect.testing.SortedMapTestSuiteBuilder.NoRecurse
 
DESCENDING_VIEW - Enum constant in enum class com.google.common.collect.testing.features.CollectionFeature
 
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.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
 
descendingIterator() - Method in class com.google.common.collect.testing.SafeTreeSet
 
descendingKeySet - Variable in class com.google.common.collect.Synchronized.SynchronizedNavigableMap
 
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() - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableMap
 
descendingKeySet() - Method in class com.google.common.collect.testing.SafeTreeMap
 
descendingMap - Variable in class com.google.common.collect.ImmutableSortedMap
 
descendingMap - Variable 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.AbstractMapBasedMultimap.NavigableAsMap
 
descendingMap() - Method in class com.google.common.collect.AbstractNavigableMap
 
descendingMap() - Method in class com.google.common.collect.ForwardingNavigableMap
 
descendingMap() - Method in class com.google.common.collect.ImmutableSortedMap
 
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() - Method in class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
descendingMap() - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableMap
 
descendingMap() - Method in class com.google.common.collect.testing.SafeTreeMap
 
DescendingMap() - Constructor for class com.google.common.collect.AbstractNavigableMap.DescendingMap
 
DescendingMap() - Constructor for class com.google.common.collect.Maps.DescendingMap
 
descendingMultiset - Variable in class com.google.common.collect.AbstractSortedMultiset
 
descendingMultiset - Variable in class com.google.common.collect.ImmutableSortedMultiset
 
descendingMultiset - Variable in class com.google.common.collect.UnmodifiableSortedMultiset
 
descendingMultiset() - Method in class com.google.common.collect.AbstractSortedMultiset
 
descendingMultiset() - Method in class com.google.common.collect.DescendingImmutableSortedMultiset
 
descendingMultiset() - Method in class com.google.common.collect.DescendingMultiset
 
descendingMultiset() - Method in class com.google.common.collect.ForwardingSortedMultiset
 
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() - Method in class com.google.common.collect.UnmodifiableSortedMultiset
 
DescendingMultiset<E> - Class in com.google.common.collect
A skeleton implementation of a descending multiset.
DescendingMultiset() - Constructor for class com.google.common.collect.DescendingMultiset
 
descendingSet - Variable in class com.google.common.collect.ImmutableSortedSet
 
descendingSet - Variable in class com.google.common.collect.Sets.UnmodifiableNavigableSet
 
descendingSet - Variable in class com.google.common.collect.Synchronized.SynchronizedNavigableSet
 
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() - Method in class com.google.common.collect.ImmutableSortedSet
 
descendingSet() - Method in class com.google.common.collect.Maps.NavigableKeySet
 
descendingSet() - Method in class com.google.common.collect.Sets.DescendingSet
 
descendingSet() - Method in class com.google.common.collect.Sets.FilteredNavigableSet
 
descendingSet() - Method in class com.google.common.collect.Sets.UnmodifiableNavigableSet
 
descendingSet() - Method in class com.google.common.collect.SortedMultisets.NavigableElementSet
 
descendingSet() - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableSet
 
descendingSet() - Method in class com.google.common.collect.testing.SafeTreeSet
 
DescendingSet(NavigableSet<E>) - Constructor for class com.google.common.collect.Sets.DescendingSet
 
DescendingTestMapGenerator(TestSortedMapGenerator<K, V>) - Constructor for class com.google.common.collect.testing.NavigableMapTestSuiteBuilder.DescendingTestMapGenerator
 
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.NamedFastMatcher
 
description - Variable in class com.google.common.base.CharMatcher.RangesMatcher
 
description - Variable in class com.google.common.collect.testing.testers.CollectionRetainAllTester.Target
 
Desirable properties - Search tag in interface com.google.common.hash.HashFunction
Section
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 class com.google.common.reflect.Types.ClassOwnership
 
DeterministicRandom() - Constructor for class com.google.common.testing.ArbitraryInstances.Dummies.DeterministicRandom
 
DEVICE_MEMORY - Static variable in class com.google.common.net.HttpHeaders
The HTTP Device-Memory header field name.
difference(Multiset<E>, Multiset<?>) - Static method in class com.google.common.collect.Multisets
Returns an unmodifiable view of the difference of two multisets.
difference(RangeSet<C>) - Method in class com.google.common.collect.ImmutableRangeSet
Returns a new range set consisting of the difference of this range set and other.
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(Set<E>, Set<?>) - Static method in class com.google.common.collect.Sets
Returns an unmodifiable view of the difference of two sets.
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.
differences - Variable in class com.google.common.collect.Maps.MapDifferenceImpl
 
digest - Variable in class com.google.common.hash.MessageDigestHashFunction.MessageDigestHasher
 
digit() - Static method in class com.google.common.base.CharMatcher
Deprecated.
Many digits are supplementary characters; see the class documentation.
digit(char) - Static method in class com.google.common.primitives.Longs.AsciiDigits
 
Digit() - Constructor for class com.google.common.base.CharMatcher.Digit
 
DIGIT_MATCHER - Static variable in class com.google.common.net.InternetDomainName
 
DIRECT_JOINER - Static variable in class com.google.thirdparty.publicsuffix.TrieParser
 
directed - Variable in class com.google.common.graph.AbstractGraphBuilder
 
directed() - Static method in class com.google.common.graph.GraphBuilder
Returns a GraphBuilder for building directed graphs.
directed() - Static method in class com.google.common.graph.NetworkBuilder
Returns a NetworkBuilder for building directed networks.
directed() - Static method in class com.google.common.graph.ValueGraphBuilder
Returns a ValueGraphBuilder for building directed graphs.
Directed(BaseGraph<N>) - Constructor for class com.google.common.graph.EndpointPairIterator.Directed
 
DirectedGraphConnections<N,V> - Class in com.google.common.graph
An implementation of GraphConnections for directed graphs.
DirectedGraphConnections(Map<N, Object>, List<DirectedGraphConnections.NodeConnection<N>>, int, int) - Constructor for class com.google.common.graph.DirectedGraphConnections
 
DirectedGraphConnections.NodeConnection<N> - Class in com.google.common.graph
A value class representing single connection between the origin node and another node.
DirectedGraphConnections.NodeConnection.Pred<N> - Class in com.google.common.graph
 
DirectedGraphConnections.NodeConnection.Succ<N> - Class in com.google.common.graph
 
DirectedGraphConnections.PredAndSucc - Class in com.google.common.graph
A wrapper class to indicate a node is both a predecessor and successor while still providing the successor value.
DirectedMultiNetworkConnections<N,E> - Class in com.google.common.graph
An implementation of NetworkConnections for directed networks with parallel edges.
DirectedMultiNetworkConnections(Map<E, N>, Map<E, N>, int) - Constructor for class com.google.common.graph.DirectedMultiNetworkConnections
 
DirectedNetworkConnections<N,E> - Class in com.google.common.graph
An implementation of NetworkConnections for directed networks.
DirectedNetworkConnections(Map<E, N>, Map<E, N>, int) - Constructor for class com.google.common.graph.DirectedNetworkConnections
 
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 - Enum Class in com.google.common.util.concurrent
An Executor that runs each task in the thread that invokes execute.
DirectExecutor() - Constructor for enum class com.google.common.util.concurrent.DirectExecutor
 
DirectExecutorService - Class in com.google.common.util.concurrent
See newDirectExecutorService javadoc for behavioral notes.
DirectExecutorService() - Constructor for class com.google.common.util.concurrent.DirectExecutorService
 
DirectLoader() - Constructor for class com.google.common.base.FinalizableReferenceQueue.DirectLoader
 
directoryPermissions - Static variable in class com.google.common.io.TempFileCreator.JavaNioCreator
 
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
 
DISABLED - Enum constant in enum class com.google.common.util.concurrent.CycleDetectingLockFactory.Policies
Disables cycle detection.
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
 
discardingQueue() - Static method in class com.google.common.cache.LocalCache
Queue that discards all elements.
DiscreteDomain<C> - 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(boolean) - Constructor for class com.google.common.collect.DiscreteDomain
Private constructor for built-in DiscreteDomains supporting fast offset.
DiscreteDomain.BigIntegerDomain - Class in com.google.common.collect
 
DiscreteDomain.IntegerDomain - Class in com.google.common.collect
 
DiscreteDomain.LongDomain - Class in com.google.common.collect
 
disjoint - Variable in class com.google.common.collect.testing.testers.CollectionRetainAllTester
 
dispatch() - Method in class com.google.common.util.concurrent.ListenerCallQueue
Dispatches all events enqueued prior to this call, serially and in order, for every listener.
dispatch() - Method in class com.google.common.util.concurrent.ListenerCallQueue.PerListenerQueue
Dispatches all listeners enqueued prior to this call, serially and in order.
dispatch(Object, Iterator<Subscriber>) - Method in class com.google.common.eventbus.Dispatcher
Dispatches the given event to the given subscribers.
dispatch(Object, Iterator<Subscriber>) - Method in class com.google.common.eventbus.Dispatcher.ImmediateDispatcher
 
dispatch(Object, Iterator<Subscriber>) - Method in class com.google.common.eventbus.Dispatcher.LegacyAsyncDispatcher
 
dispatch(Object, Iterator<Subscriber>) - Method in class com.google.common.eventbus.Dispatcher.PerThreadQueuedDispatcher
 
dispatcher - Variable in class com.google.common.eventbus.EventBus
 
Dispatcher - Class in com.google.common.eventbus
Handler for dispatching events to subscribers, providing different event ordering guarantees that make sense for different situations.
Dispatcher() - Constructor for class com.google.common.eventbus.Dispatcher
 
Dispatcher.ImmediateDispatcher - Class in com.google.common.eventbus
Implementation of Dispatcher.immediate().
Dispatcher.LegacyAsyncDispatcher - Class in com.google.common.eventbus
Implementation of a Dispatcher.legacyAsync() dispatcher.
Dispatcher.LegacyAsyncDispatcher.EventWithSubscriber - Class in com.google.common.eventbus
 
Dispatcher.PerThreadQueuedDispatcher - Class in com.google.common.eventbus
Implementation of a Dispatcher.perThreadDispatchQueue() dispatcher.
Dispatcher.PerThreadQueuedDispatcher.Event - Class in com.google.common.eventbus
 
dispatchEvent(Object) - Method in class com.google.common.eventbus.Subscriber
Dispatches event to this subscriber using the proper executor.
dispatching - Variable in class com.google.common.eventbus.Dispatcher.PerThreadQueuedDispatcher
Per-thread dispatch state, used to avoid reentrant event dispatching.
dispatchListenerEvents() - Method in class com.google.common.util.concurrent.AbstractService
Attempts to execute all the listeners in AbstractService.listeners while not holding the AbstractService.monitor.
dispatchListenerEvents() - Method in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState
Attempts to execute all the listeners in ServiceManager.ServiceManagerState.listeners.
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
 
distance(BigInteger, BigInteger) - Method in class com.google.common.collect.DiscreteDomain.BigIntegerDomain
 
distinct - Variable in class com.google.common.collect.ImmutableSet.SetBuilderImpl
 
DISTINCT - Enum constant in enum class com.google.common.collect.TreeMultiset.Aggregate
 
DISTINCT_CHARS - Static variable in class com.google.common.base.CharMatcher
 
distinctElements - Variable in class com.google.common.collect.EnumMultiset
 
distinctElements - Variable in class com.google.common.collect.TreeMultiset.AvlNode
 
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.EnumMultiset
 
distinctElements() - Method in class com.google.common.collect.Multimaps.Keys
 
distinctElements() - Method in class com.google.common.collect.Multisets.ViewMultiset
 
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
 
distinctValues - Variable in class com.google.common.testing.ClassSanityTester
 
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(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) - Static method in class com.google.common.primitives.UnsignedLongs
Returns dividend / divisor, where the dividend and divisor are treated as unsigned 64-bit quantities.
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(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.
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(A) - Method in class com.google.common.base.Converter.ReverseConverter
 
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(B) - Method in class com.google.common.collect.Maps.BiMapConverter
 
doBackward(C) - Method in class com.google.common.base.Converter.ConverterComposition
 
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
 
doBackward(String) - Method in class com.google.common.base.CaseFormat.StringConverter
 
doBackward(T) - Method in class com.google.common.base.Converter.IdentityConverter
 
doBackward(T) - Method in class com.google.common.base.Enums.StringConverter
 
doBuild(ThreadFactoryBuilder) - Static method in class com.google.common.util.concurrent.ThreadFactoryBuilder
 
doCancelStart() - Method in class com.google.common.util.concurrent.AbstractService
This method is called by AbstractService.stopAsync() when the service is still starting (i.e.
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(F, F) - Method in class com.google.common.base.FunctionalEquivalence
 
doEquivalent(Iterable<T>, Iterable<T>) - Method in class com.google.common.base.PairwiseEquivalence
 
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(T, T) - Method in class com.google.common.base.Equivalence
Implemented by the user to determine whether a and b are considered equivalent, subject to the requirements specified in Equivalence.equivalent(T, T).
doExpectCollects(R, List<T>) - Method in class com.google.common.testing.CollectorTester
 
doFallback(Function<? super X, ? extends V>, X) - Method in class com.google.common.util.concurrent.AbstractCatchingFuture.CatchingFuture
 
doFallback(AsyncFunction<? super X, ? extends V>, X) - Method in class com.google.common.util.concurrent.AbstractCatchingFuture.AsyncCatchingFuture
 
doFallback(F, X) - Method in class com.google.common.util.concurrent.AbstractCatchingFuture
Template method for subtypes to actually run the fallback.
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(A) - Method in class com.google.common.collect.Maps.BiMapConverter
 
doForward(B) - Method in class com.google.common.base.Converter.ReverseConverter
 
doForward(String) - Method in class com.google.common.base.CaseFormat.StringConverter
 
doForward(String) - Method in class com.google.common.base.Enums.StringConverter
 
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
 
doForward(T) - Method in class com.google.common.base.Converter.IdentityConverter
 
doGetRate() - Method in class com.google.common.util.concurrent.RateLimiter
 
doGetRate() - Method in class com.google.common.util.concurrent.SmoothRateLimiter
 
doHash(F) - Method in class com.google.common.base.FunctionalEquivalence
 
doHash(Iterable<T>) - Method in class com.google.common.base.PairwiseEquivalence
 
doHash(Object) - Method in class com.google.common.base.Equivalence.Equals
 
doHash(Object) - Method in class com.google.common.base.Equivalence.Identity
 
doHash(T) - Method in class com.google.common.base.Equivalence
Implemented by the user to return a hash code for t, subject to the requirements specified in Equivalence.hash(T).
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.collect.Iterators.SingletonIterator
 
done - Variable in class com.google.common.hash.MacHashFunction.MacHasher
 
done - Variable in class com.google.common.hash.MessageDigestHashFunction.MessageDigestHasher
 
done() - Method in class com.google.common.util.concurrent.ListenableFutureTask
Internal implementation detail used to invoke the listeners.
DONE - Enum constant in enum class com.google.common.base.AbstractIterator.State
 
DONE - Enum constant in enum class com.google.common.collect.AbstractIterator.State
We have reached the end of the data and are finished.
DONE - Static variable in class com.google.common.util.concurrent.InterruptibleTask
 
doneFlushing - Variable in class com.google.common.io.ReaderInputStream
Whether we've successfully flushed the encoder.
doNothing() - Static method in class com.google.common.util.concurrent.Runnables
Returns a Runnable instance that does nothing when run.
DoNothingRunnable() - Constructor for class com.google.common.util.concurrent.InterruptibleTask.DoNothingRunnable
 
doParseTrieToBuilder(Deque<CharSequence>, CharSequence, int, 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, 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
 
doSetRate(double, long) - Method in class com.google.common.util.concurrent.RateLimiter
 
doSetRate(double, long) - Method in class com.google.common.util.concurrent.SmoothRateLimiter
 
doStart() - Method in class com.google.common.util.concurrent.AbstractIdleService.DelegateService
 
doStart() - Method in class com.google.common.util.concurrent.AbstractScheduledService.ServiceDelegate
 
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.AbstractIdleService.DelegateService
 
doStop() - Method in class com.google.common.util.concurrent.AbstractScheduledService.ServiceDelegate
 
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_SPLITTER - Static variable in class com.google.common.net.InternetDomainName
 
doTestEquals(Class<?>) - Method in class com.google.common.testing.ClassSanityTester
 
doTestNulls(Class<?>, NullPointerTester.Visibility) - Method in class com.google.common.testing.ClassSanityTester
 
doTestSet(E) - Method in class com.google.common.collect.testing.testers.ListSetTester
 
doTransform(Function<? super I, ? extends O>, I) - Method in class com.google.common.util.concurrent.AbstractTransformFuture.TransformFuture
 
doTransform(AsyncFunction<? super I, ? extends O>, I) - Method in class com.google.common.util.concurrent.AbstractTransformFuture.AsyncTransformFuture
 
doTransform(F, I) - Method in class com.google.common.util.concurrent.AbstractTransformFuture
Template method for subtypes to actually run the transform.
DOTS_MATCHER - Static variable in class com.google.common.net.InternetDomainName
 
DOUBLE_DEFAULT - Static variable in class com.google.common.base.Defaults
 
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
 
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 Class in com.google.common.primitives
 
DoublesMethodsForWeb - Class in com.google.common.primitives
Holder for web specializations of methods of Doubles.
DoublesMethodsForWeb() - Constructor for class com.google.common.primitives.DoublesMethodsForWeb
 
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.hash.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.
DOWNLINK - Static variable in class com.google.common.net.HttpHeaders
The HTTP Downlink header field name.
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.
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.
drain(byte[], int, int) - Method in class com.google.common.io.ReaderInputStream
Copy as much of the byte buffer into the output array as possible, returning the (positive) number of characters copied.
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(BlockingQueue<E>, Collection<? super E>, int, Duration) - 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.
draining - Variable in class com.google.common.io.ReaderInputStream
Whether we're copying encoded bytes to the caller's buffer.
drainKeyReferenceQueue() - Method in class com.google.common.cache.LocalCache.Segment
 
drainKeyReferenceQueue(ReferenceQueue<K>) - 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.
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.
drainTo(Collection<? super E>) - Method in class com.google.common.collect.ForwardingBlockingDeque
Deprecated.
 
drainTo(Collection<? super E>) - Method in class com.google.common.util.concurrent.ForwardingBlockingDeque
 
drainTo(Collection<? super E>) - Method in class com.google.common.util.concurrent.ForwardingBlockingQueue
 
drainTo(Collection<? super E>, int) - Method in class com.google.common.collect.ForwardingBlockingDeque
Deprecated.
 
drainTo(Collection<? super E>, int) - Method in class com.google.common.util.concurrent.ForwardingBlockingDeque
 
drainTo(Collection<? super E>, int) - 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.
drainUninterruptibly(BlockingQueue<E>, Collection<? super E>, int, Duration) - Static method in class com.google.common.collect.Queues
Drains the queue as Queues.drain(BlockingQueue, Collection, int, Duration), but with a different behavior in case it is interrupted while waiting.
drainValueReferenceQueue() - Method in class com.google.common.cache.LocalCache.Segment
 
drainValueReferenceQueue(ReferenceQueue<V>) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
 
Dummies() - Constructor for class com.google.common.testing.ArbitraryInstances.Dummies
 
Dummy() - Constructor for enum class com.google.common.collect.MapMaker.Dummy
 
DummyCountDownLatch() - Constructor for class com.google.common.testing.ArbitraryInstances.Dummies.DummyCountDownLatch
 
DummyExecutor() - Constructor for class com.google.common.testing.ArbitraryInstances.Dummies.DummyExecutor
 
DummyHandler(TypeToken<?>) - Constructor for class com.google.common.testing.DummyProxy.DummyHandler
 
DummyInternalEntry() - Constructor for class com.google.common.collect.MapMakerInternalMap.DummyInternalEntry
 
DummyProxy - Class in com.google.common.testing
Generates a dummy interface proxy that simply returns a dummy value for each method.
DummyProxy() - Constructor for class com.google.common.testing.DummyProxy
 
DummyProxy.DummyHandler - Class in com.google.common.testing
 
dummyReturnValue(TypeToken<R>) - Method in class com.google.common.testing.ClassSanityTester.SerializableDummyProxy
 
dummyReturnValue(TypeToken<R>) - Method in class com.google.common.testing.DummyProxy
Returns the dummy return value for returnType.
DummyRunnable() - Constructor for class com.google.common.testing.ArbitraryInstances.Dummies.DummyRunnable
 
DummyScheduledThreadPoolExecutor() - Constructor for class com.google.common.testing.ArbitraryInstances.Dummies.DummyScheduledThreadPoolExecutor
 
DummyThreadFactory() - Constructor for class com.google.common.testing.ArbitraryInstances.Dummies.DummyThreadFactory
 
duplicate - Variable in class com.google.common.collect.testing.AbstractContainerTester.ArrayWithDuplicate
 
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

E - Enum constant in enum class com.google.common.collect.testing.AnEnum
 
e0 - Variable in class com.google.common.collect.testing.SampleElements
 
e0() - Method in class com.google.common.collect.testing.AbstractContainerTester
 
e0() - Method in class com.google.common.collect.testing.SampleElements
 
e1 - Variable in class com.google.common.collect.testing.SampleElements
 
e1() - Method in class com.google.common.collect.testing.AbstractContainerTester
 
e1() - Method in class com.google.common.collect.testing.SampleElements
 
e2 - Variable in class com.google.common.collect.testing.SampleElements
 
e2() - Method in class com.google.common.collect.testing.AbstractContainerTester
 
e2() - Method in class com.google.common.collect.testing.SampleElements
 
e3 - Variable in class com.google.common.collect.testing.SampleElements
 
e3() - Method in class com.google.common.collect.testing.AbstractContainerTester
 
e3() - Method in class com.google.common.collect.testing.SampleElements
 
e4 - Variable in class com.google.common.collect.testing.SampleElements
 
e4() - Method in class com.google.common.collect.testing.AbstractContainerTester
 
e4() - Method in class com.google.common.collect.testing.SampleElements
 
EARLY_DATA - Static variable in class com.google.common.net.HttpHeaders
The HTTP Early-Data header field name.
ECT - Static variable in class com.google.common.net.HttpHeaders
The HTTP ECT header field name.
EDGE_ALREADY_EXISTS - Static variable in class com.google.common.graph.GraphConstants
 
EDGE_EXISTS - Enum constant in enum class com.google.common.graph.GraphConstants.Presence
 
EDGE_NOT_IN_GRAPH - Static variable in class com.google.common.graph.GraphConstants
 
EDGE_REMOVED_FROM_GRAPH - Static variable in class com.google.common.graph.GraphConstants
 
edgeConnecting(EndpointPair<N>) - Method in class com.google.common.graph.AbstractNetwork
 
edgeConnecting(EndpointPair<N>) - Method in class com.google.common.graph.ForwardingNetwork
 
edgeConnecting(EndpointPair<N>) - Method in class com.google.common.graph.Graphs.TransposedNetwork
 
edgeConnecting(EndpointPair<N>) - Method in interface com.google.common.graph.Network
Returns the single edge that directly connects endpoints (in the order, if any, specified by endpoints), if one is present, or Optional.empty() if no such edge exists.
edgeConnecting(N, N) - Method in class com.google.common.graph.AbstractNetwork
 
edgeConnecting(N, N) - Method in class com.google.common.graph.ForwardingNetwork
 
edgeConnecting(N, N) - Method in class com.google.common.graph.Graphs.TransposedNetwork
 
edgeConnecting(N, N) - Method in interface com.google.common.graph.Network
Returns the single edge that directly connects nodeU to nodeV, if one is present, or Optional.empty() if no such edge exists.
edgeConnectingOrNull(EndpointPair<N>) - Method in class com.google.common.graph.AbstractNetwork
 
edgeConnectingOrNull(EndpointPair<N>) - Method in class com.google.common.graph.ForwardingNetwork
 
edgeConnectingOrNull(EndpointPair<N>) - Method in class com.google.common.graph.Graphs.TransposedNetwork
 
edgeConnectingOrNull(EndpointPair<N>) - Method in interface com.google.common.graph.Network
Returns the single edge that directly connects endpoints (in the order, if any, specified by endpoints), if one is present, or null if no such edge exists.
edgeConnectingOrNull(N, N) - Method in class com.google.common.graph.AbstractNetwork
 
edgeConnectingOrNull(N, N) - Method in class com.google.common.graph.ForwardingNetwork
 
edgeConnectingOrNull(N, N) - Method in class com.google.common.graph.Graphs.TransposedNetwork
 
edgeConnectingOrNull(N, N) - Method in interface com.google.common.graph.Network
Returns the single edge that directly connects nodeU to nodeV, if one is present, or null if no such edge exists.
edgeCount - Variable in class com.google.common.graph.StandardValueGraph
 
edgeCount() - Method in class com.google.common.graph.AbstractBaseGraph
Returns the number of edges in this graph; used to calculate the size of Graph.edges().
edgeCount() - Method in class com.google.common.graph.ForwardingGraph
Defer to AbstractBaseGraph.edges() (based on ForwardingGraph.successors(Object)) for full edges() implementation.
edgeCount() - Method in class com.google.common.graph.ForwardingValueGraph
Defer to AbstractBaseGraph.edges() (based on ForwardingValueGraph.successors(Object)) for full edges() implementation.
edgeCount() - Method in class com.google.common.graph.StandardValueGraph
 
edgeIncidentNodesMap(Network<N, E>) - Static method in class com.google.common.graph.AbstractNetwork
 
edgeInvalidatableSet(Set<T>, E) - Method in class com.google.common.graph.AbstractNetwork
Returns a Set whose methods throw IllegalStateException when the given edge is not present in this network.
edgeOrder - Variable in class com.google.common.graph.NetworkBuilder
 
edgeOrder - Variable in class com.google.common.graph.StandardNetwork
 
edgeOrder() - Method in class com.google.common.graph.ForwardingNetwork
 
edgeOrder() - Method in interface com.google.common.graph.Network
Returns the order of iteration for the elements of Network.edges().
edgeOrder() - Method in class com.google.common.graph.StandardNetwork
 
edgeOrder(ElementOrder<E1>) - Method in class com.google.common.graph.NetworkBuilder
Specifies the order of iteration for the elements of Network.edges().
edges() - Method in class com.google.common.graph.AbstractBaseGraph
An implementation of BaseGraph.edges() defined in terms of Graph.nodes() and BaseGraph.successors(Object).
edges() - Method in interface com.google.common.graph.BaseGraph
Returns all edges in this graph.
edges() - Method in class com.google.common.graph.ForwardingNetwork
 
edges() - Method in interface com.google.common.graph.Graph
Returns all edges in this graph.
edges() - Method in interface com.google.common.graph.Network
Returns all edges in this network, in the order specified by Network.edgeOrder().
edges() - Method in class com.google.common.graph.StandardNetwork
 
edges() - Method in interface com.google.common.graph.ValueGraph
Returns all edges in this graph.
edgesConnecting(EndpointPair<N>) - Method in class com.google.common.graph.AbstractNetwork
 
edgesConnecting(EndpointPair<N>) - Method in class com.google.common.graph.ForwardingNetwork
 
edgesConnecting(EndpointPair<N>) - Method in class com.google.common.graph.Graphs.TransposedNetwork
 
edgesConnecting(EndpointPair<N>) - Method in interface com.google.common.graph.Network
Returns a live view of the set of edges that each directly connect endpoints (in the order, if any, specified by endpoints).
edgesConnecting(N) - Method in class com.google.common.graph.DirectedMultiNetworkConnections
 
edgesConnecting(N) - Method in class com.google.common.graph.DirectedNetworkConnections
 
edgesConnecting(N) - Method in interface com.google.common.graph.NetworkConnections
Returns the set of edges connecting the origin node to node.
edgesConnecting(N) - Method in class com.google.common.graph.UndirectedMultiNetworkConnections
 
edgesConnecting(N) - Method in class com.google.common.graph.UndirectedNetworkConnections
 
edgesConnecting(N, N) - Method in class com.google.common.graph.AbstractNetwork
 
edgesConnecting(N, N) - Method in class com.google.common.graph.ForwardingNetwork
 
edgesConnecting(N, N) - Method in class com.google.common.graph.Graphs.TransposedNetwork
 
edgesConnecting(N, N) - Method in interface com.google.common.graph.Network
Returns a live view of the set of edges that each directly connect nodeU to nodeV.
edgesConnecting(N, N) - Method in class com.google.common.graph.StandardNetwork
 
EdgesConnecting<E> - Class in com.google.common.graph
A class to represent the set of edges connecting an (implicit) origin node to a target node.
EdgesConnecting(Map<?, E>, Object) - Constructor for class com.google.common.graph.EdgesConnecting
 
edgeToReferenceNode - Variable in class com.google.common.graph.StandardNetwork
 
edgeValue(EndpointPair<N>) - Method in class com.google.common.graph.AbstractValueGraph
 
edgeValue(EndpointPair<N>) - Method in class com.google.common.graph.ForwardingValueGraph
 
edgeValue(EndpointPair<N>) - Method in class com.google.common.graph.Graphs.TransposedValueGraph
 
edgeValue(EndpointPair<N>) - Method in interface com.google.common.graph.ValueGraph
Returns the value of the edge that connects endpoints (in the order, if any, specified by endpoints), if one is present; otherwise, returns Optional.empty().
edgeValue(N, N) - Method in class com.google.common.graph.AbstractValueGraph
 
edgeValue(N, N) - Method in class com.google.common.graph.ForwardingValueGraph
 
edgeValue(N, N) - Method in class com.google.common.graph.Graphs.TransposedValueGraph
 
edgeValue(N, N) - Method in interface com.google.common.graph.ValueGraph
Returns the value of the edge that connects nodeU to nodeV (in the order, if any, specified by endpoints), if one is present; otherwise, returns Optional.empty().
edgeValueMap(ValueGraph<N, V>) - Static method in class com.google.common.graph.AbstractValueGraph
 
edgeValueOrDefault(EndpointPair<N>, V) - Method in class com.google.common.graph.ForwardingValueGraph
 
edgeValueOrDefault(EndpointPair<N>, V) - Method in class com.google.common.graph.Graphs.TransposedValueGraph
 
edgeValueOrDefault(EndpointPair<N>, V) - Method in class com.google.common.graph.StandardValueGraph
 
edgeValueOrDefault(EndpointPair<N>, V) - Method in interface com.google.common.graph.ValueGraph
Returns the value of the edge that connects endpoints (in the order, if any, specified by endpoints), if one is present; otherwise, returns defaultValue.
edgeValueOrDefault(N, N, V) - Method in class com.google.common.graph.ForwardingValueGraph
 
edgeValueOrDefault(N, N, V) - Method in class com.google.common.graph.Graphs.TransposedValueGraph
 
edgeValueOrDefault(N, N, V) - Method in class com.google.common.graph.StandardValueGraph
 
edgeValueOrDefault(N, N, V) - Method in interface com.google.common.graph.ValueGraph
Returns the value of the edge that connects nodeU to nodeV, if one is present; otherwise, returns defaultValue.
edgeValueOrDefaultInternal(N, N, V) - Method in class com.google.common.graph.StandardValueGraph
 
elapsed() - Method in class com.google.common.base.Stopwatch
Returns the current elapsed time shown on this stopwatch as a Duration.
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 - Variable in class com.google.common.collect.MoreCollectors.ToOptionalState
 
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.ForwardingQueue
 
element() - Method in class com.google.common.collect.Synchronized.SynchronizedQueue
 
element(int) - Method in class com.google.common.collect.CompactHashSet
 
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
 
elementIterator() - Method in class com.google.common.collect.AbstractMapBasedMultiset
 
elementIterator() - Method in class com.google.common.collect.AbstractMultiset
 
elementIterator() - Method in class com.google.common.collect.ConcurrentHashMultiset
 
elementIterator() - Method in class com.google.common.collect.EnumMultiset
 
elementIterator() - Method in class com.google.common.collect.Multimaps.Keys
 
elementIterator() - Method in class com.google.common.collect.Multisets.FilteredMultiset
 
elementIterator() - Method in class com.google.common.collect.TreeMultiset
 
elementIterator(Iterator<Multiset.Entry<E>>) - Static method in class com.google.common.collect.Multisets
 
elementOrder - Variable in class com.google.common.collect.LexicographicalOrdering
 
ElementOrder<T> - Class in com.google.common.graph
Used to represent the order of elements in a data structure that supports different options for iteration order guarantees.
ElementOrder(ElementOrder.Type, Comparator<T>) - Constructor for class com.google.common.graph.ElementOrder
 
ElementOrder.Type - Enum Class in com.google.common.graph
The type of ordering that this object specifies.
elements - Variable in class com.google.common.collect.CompactHashSet
The elements contained in the set, in the range of [0, size()).
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.Builder
 
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
 
elements - Variable in class com.google.common.collect.testing.AbstractContainerTester.ArrayWithDuplicate
 
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 - Variable in class com.google.common.collect.DescendingMultiset
 
elementSet - Variable in class com.google.common.collect.JdkBackedImmutableMultiset
 
elementSet - Variable in class com.google.common.collect.Multisets.UnmodifiableMultiset
 
elementSet - Variable in class com.google.common.collect.RegularImmutableMultiset
 
elementSet - Variable in class com.google.common.collect.RegularImmutableSortedMultiset
 
elementSet - Variable in class com.google.common.collect.Synchronized.SynchronizedMultiset
 
elementSet() - Method in class com.google.common.collect.AbstractMultiset
 
elementSet() - Method in class com.google.common.collect.AbstractSortedMultiset
 
elementSet() - Method in class com.google.common.collect.DescendingImmutableSortedMultiset
 
elementSet() - Method in class com.google.common.collect.DescendingMultiset
 
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.ImmutableMultiset
 
elementSet() - Method in class com.google.common.collect.ImmutableSortedMultiset
 
elementSet() - Method in class com.google.common.collect.JdkBackedImmutableMultiset
 
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() - Method in class com.google.common.collect.Multisets.UnmodifiableMultiset
 
elementSet() - Method in class com.google.common.collect.RegularImmutableMultiset
 
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() - Method in class com.google.common.collect.Synchronized.SynchronizedMultiset
 
elementSet() - Method in class com.google.common.collect.UnmodifiableSortedMultiset
 
ElementSet() - Constructor for class com.google.common.collect.AbstractMultiset.ElementSet
 
ElementSet() - Constructor for class com.google.common.collect.Multisets.ElementSet
 
ElementSet(SortedMultiset<E>) - Constructor for class com.google.common.collect.SortedMultisets.ElementSet
 
ElementSet(List<Multiset.Entry<E>>, Multiset<E>) - Constructor for class com.google.common.collect.ImmutableMultiset.ElementSet
 
ElementSetGenerator(OneSizeTestContainerGenerator<Collection<E>, E>) - Constructor for class com.google.common.collect.testing.google.MultisetTestSuiteBuilder.ElementSetGenerator
 
elementsToInsert - Variable in class com.google.common.collect.testing.AbstractIteratorTester
 
ElementTypesAreNonnullByDefault - Annotation Interface in com.google.common.base
Marks all "top-level" types as non-null in a way that is recognized by Kotlin.
ElementTypesAreNonnullByDefault - Annotation Interface in com.google.common.cache
Marks all "top-level" types as non-null in a way that is recognized by Kotlin.
ElementTypesAreNonnullByDefault - Annotation Interface in com.google.common.collect
Marks all "top-level" types as non-null in a way that is recognized by Kotlin.
ElementTypesAreNonnullByDefault - Annotation Interface in com.google.common.collect.testing
Marks all "top-level" types as non-null in a way that is recognized by Kotlin.
ElementTypesAreNonnullByDefault - Annotation Interface in com.google.common.collect.testing.google
Marks all "top-level" types as non-null in a way that is recognized by Kotlin.
ElementTypesAreNonnullByDefault - Annotation Interface in com.google.common.collect.testing.testers
Marks all "top-level" types as non-null in a way that is recognized by Kotlin.
ElementTypesAreNonnullByDefault - Annotation Interface in com.google.common.escape
Marks all "top-level" types as non-null in a way that is recognized by Kotlin.
ElementTypesAreNonnullByDefault - Annotation Interface in com.google.common.eventbus
Marks all "top-level" types as non-null in a way that is recognized by Kotlin.
ElementTypesAreNonnullByDefault - Annotation Interface in com.google.common.graph
Marks all "top-level" types as non-null in a way that is recognized by Kotlin.
ElementTypesAreNonnullByDefault - Annotation Interface in com.google.common.hash
Marks all "top-level" types as non-null in a way that is recognized by Kotlin.
ElementTypesAreNonnullByDefault - Annotation Interface in com.google.common.html
Marks all "top-level" types as non-null in a way that is recognized by Kotlin.
ElementTypesAreNonnullByDefault - Annotation Interface in com.google.common.io
Marks all "top-level" types as non-null in a way that is recognized by Kotlin.
ElementTypesAreNonnullByDefault - Annotation Interface in com.google.common.math
Marks all "top-level" types as non-null in a way that is recognized by Kotlin.
ElementTypesAreNonnullByDefault - Annotation Interface in com.google.common.net
Marks all "top-level" types as non-null in a way that is recognized by Kotlin.
ElementTypesAreNonnullByDefault - Annotation Interface in com.google.common.primitives
Marks all "top-level" types as non-null in a way that is recognized by Kotlin.
ElementTypesAreNonnullByDefault - Annotation Interface in com.google.common.reflect
Marks all "top-level" types as non-null in a way that is recognized by Kotlin.
ElementTypesAreNonnullByDefault - Annotation Interface in com.google.common.testing
Marks all "top-level" types as non-null in a way that is recognized by Kotlin.
ElementTypesAreNonnullByDefault - Annotation Interface in com.google.common.util.concurrent
Marks all "top-level" types as non-null in a way that is recognized by Kotlin.
ElementTypesAreNonnullByDefault - Annotation Interface in com.google.common.xml
Marks all "top-level" types as non-null in a way that is recognized by Kotlin.
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.
emptiesFirst(Comparator<? super T>) - Static method in class com.google.common.collect.Comparators
Returns a comparator of Optional values which treats Optional.empty() as less than all other values, and orders the rest using valueComparator on the contained value.
emptiesLast(Comparator<? super T>) - Static method in class com.google.common.collect.Comparators
Returns a comparator of Optional values which treats Optional.empty() as greater than all other values, and orders the rest using valueComparator on the contained value.
empty - Variable in class com.google.common.collect.testing.testers.CollectionRetainAllTester
 
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 - Static variable in class com.google.common.collect.ImmutableClassToInstanceMap
 
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.Iterators.ArrayItr
 
EMPTY - Static variable in class com.google.common.collect.RegularImmutableBiMap
 
EMPTY - Static variable in class com.google.common.collect.RegularImmutableList
 
EMPTY - Static variable in class com.google.common.collect.RegularImmutableMap
 
EMPTY - Static variable in class com.google.common.collect.RegularImmutableMultiset
 
EMPTY - Static variable in class com.google.common.collect.RegularImmutableSet
 
EMPTY - Static variable in class com.google.common.collect.SparseImmutableTable
 
EMPTY - Static variable in class com.google.common.hash.Crc32cHashFunction.Crc32cHasher
 
EMPTY - Static variable in class com.google.common.primitives.ImmutableDoubleArray
 
EMPTY - Static variable in class com.google.common.primitives.ImmutableIntArray
 
EMPTY - Static variable in class com.google.common.primitives.ImmutableLongArray
 
EMPTY_ARRAY - Static variable in class com.google.common.collect.ImmutableCollection
 
EMPTY_ARRAY - Static variable in class com.google.common.collect.RegularImmutableMultiset
 
EMPTY_ARRAY - Static variable in class com.google.common.collect.RegularImmutableSet
 
EMPTY_ENTRY_ARRAY - Static variable in class com.google.common.collect.ImmutableMap
 
EMPTY_GENERATORS - Static variable in class com.google.common.testing.FreshValueGenerator
 
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.ImmutableSetMultimap.SetFieldSettersHolder
 
EMPTY_STACK_TRACE - Static variable in exception class 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
 
emptyCollection() - Method in class com.google.common.collect.testing.AbstractContainerTester
 
EmptyContiguousSet<C> - Class in com.google.common.collect
An empty contiguous set.
EmptyContiguousSet(DiscreteDomain<C>) - Constructor for class com.google.common.collect.EmptyContiguousSet
 
EmptyContiguousSet.SerializedForm<C> - Class in com.google.common.collect
 
EmptyImmutableListMultimap - Class in com.google.common.collect
Implementation of ImmutableListMultimap with no entries.
EmptyImmutableListMultimap() - Constructor for class com.google.common.collect.EmptyImmutableListMultimap
 
EmptyImmutableSetMultimap - Class in com.google.common.collect
Implementation of ImmutableListMultimap with no entries.
EmptyImmutableSetMultimap() - Constructor for class com.google.common.collect.EmptyImmutableSetMultimap
 
emptyInstanceGenerated - Variable in class com.google.common.testing.FreshValueGenerator
The freshness level at which the @Empty annotated method was invoked to generate instance.
emptyIterator() - Static method in class com.google.common.collect.Iterators
Returns the empty iterator.
emptyListIterator() - Static method in class com.google.common.collect.Iterators
Returns the empty iterator.
emptyMap() - Method in class com.google.common.collect.testing.testers.MapPutAllTester
 
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().
EmptyModifiableIterator() - Constructor for enum class com.google.common.collect.Iterators.EmptyModifiableIterator
 
emptyMultiset(Comparator<? super E>) - Static method in class com.google.common.collect.ImmutableSortedMultiset
 
EmptyServiceManagerWarning() - Constructor for exception 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 E>) - Static method in class com.google.common.collect.ImmutableSortedSet
 
emptySet(Comparator<? super V>) - Static method in class com.google.common.collect.ImmutableSetMultimap
 
EmptySetBuilderImpl() - Constructor for class com.google.common.collect.ImmutableSet.EmptySetBuilderImpl
 
emptySubRangeMap() - Method in class com.google.common.collect.TreeRangeMap
 
emptyToNull(String) - Static method in class com.google.common.base.Platform
Returns the string if it is not empty, or a null string otherwise.
emptyToNull(String) - Static method in class com.google.common.base.Strings
Returns the given string if it is nonempty; null otherwise.
emulated() - Element in annotation interface com.google.common.annotations.GwtCompatible
When true, the annotated type is emulated in GWT.
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.
enclosesAll(Iterable<Range<C>>) - Method in interface com.google.common.collect.RangeSet
Returns true if for each range in other there exists a member range in this range set which encloses it.
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.
encode(int) - Method in class com.google.common.io.BaseEncoding.Alphabet
 
encodeChunkTo(Appendable, byte[], int, int) - Method in class com.google.common.io.BaseEncoding.StandardBaseEncoding
 
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
 
encoder - Variable in class com.google.common.io.ReaderInputStream
 
encodeTo(Appendable, byte[], int, int) - Method in class com.google.common.io.BaseEncoding.Base16Encoding
 
encodeTo(Appendable, byte[], int, int) - Method in class com.google.common.io.BaseEncoding.Base64Encoding
 
encodeTo(Appendable, byte[], int, int) - Method in class com.google.common.io.BaseEncoding
 
encodeTo(Appendable, byte[], int, int) - Method in class com.google.common.io.BaseEncoding.SeparatedBaseEncoding
 
encodeTo(Appendable, byte[], int, int) - Method in class com.google.common.io.BaseEncoding.StandardBaseEncoding
 
encoding - Variable in class com.google.common.io.BaseEncoding.Base16Encoding
 
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(Writer) - Method in class com.google.common.io.BaseEncoding.SeparatedBaseEncoding
 
encodingStream(Writer) - 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.ImmutableDoubleArray
 
end - Variable in class com.google.common.primitives.ImmutableIntArray
 
end - Variable in class com.google.common.primitives.ImmutableLongArray
 
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
 
end() - Method in class com.google.common.base.CommonMatcher
 
end() - Method in class com.google.common.base.JdkPattern.JdkMatcher
 
endInclusive - Variable in class com.google.common.base.CharMatcher.InRange
 
Ending a pipeline - Search tag in class com.google.common.util.concurrent.ClosingFuture
Section
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.
endOfInput - Variable in class com.google.common.io.ReaderInputStream
Whether we've finished reading the reader.
endpoint - Variable in class com.google.common.collect.Cut
 
endpoint() - Method in class com.google.common.collect.Cut.AboveAll
 
endpoint() - Method in class com.google.common.collect.Cut.BelowAll
 
endpoint() - Method in class com.google.common.collect.Cut
 
ENDPOINT - Static variable in class com.google.common.collect.CompactLinkedHashMap
 
ENDPOINT - Static variable in class com.google.common.collect.CompactLinkedHashSet
 
EndpointPair<N> - Class in com.google.common.graph
An immutable pair representing the two endpoints of an edge in a graph.
EndpointPair(N, N) - Constructor for class com.google.common.graph.EndpointPair
 
EndpointPair.Ordered<N> - Class in com.google.common.graph
 
EndpointPair.Unordered<N> - Class in com.google.common.graph
 
EndpointPairIterator<N> - Class in com.google.common.graph
A class to facilitate the set returned by Graph.edges().
EndpointPairIterator(BaseGraph<N>) - Constructor for class com.google.common.graph.EndpointPairIterator
 
EndpointPairIterator.Directed<N> - Class in com.google.common.graph
If the graph is directed, each ordered [source, target] pair will be visited once if there is an edge connecting them.
EndpointPairIterator.Undirected<N> - Class in com.google.common.graph
If the graph is undirected, each unordered [node, otherNode] pair (except self-loops) will be visited twice if there is an edge connecting them.
ENDPOINTS_MISMATCH - Static variable in class com.google.common.graph.GraphConstants
 
endTask() - Method in class com.google.common.util.concurrent.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.
enqueue(ListenerCallQueue.Event<L>) - Method in class com.google.common.util.concurrent.ListenerCallQueue
Enqueues an event to be run on currently known listeners.
enqueue(ListenerCallQueue.Event<L>, String) - Method in class com.google.common.util.concurrent.ListenerCallQueue
Enqueues an event to be run on currently known listeners, with a label.
enqueueFailedEvent(Service) - Method in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState
 
enqueueFailedEvent(Service.State, Throwable) - Method in class com.google.common.util.concurrent.AbstractService
 
enqueueHealthyEvent() - Method in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState
 
enqueueHelper(ListenerCallQueue.Event<L>, Object) - Method in class com.google.common.util.concurrent.ListenerCallQueue
 
enqueueNotification(K, int, V, int, RemovalCause) - Method in class com.google.common.cache.LocalCache.Segment
 
enqueueRunningEvent() - Method in class com.google.common.util.concurrent.AbstractService
 
enqueueStartingEvent() - Method in class com.google.common.util.concurrent.AbstractService
 
enqueueStoppedEvent() - Method in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState
 
enqueueStoppingEvent(Service.State) - Method in class com.google.common.util.concurrent.AbstractService
 
enqueueTerminatedEvent(Service.State) - Method in class com.google.common.util.concurrent.AbstractService
 
ensureBuilderMapNonNull() - Method in class com.google.common.collect.ImmutableMultimap.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) - Method in class com.google.common.collect.ImmutableMap.Builder
 
ensureCapacity(int) - Method in class com.google.common.collect.ImmutableSet.SetBuilderImpl
Resizes internal data structures if necessary to store the specified number of distinct elements.
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.
ensureInUnitRange(double) - Static method in class com.google.common.math.PairedStats
 
ensureInUnitRange(double) - Static method in class com.google.common.math.PairedStatsAccumulator
 
ensureNonNegative(double) - Static method in class com.google.common.math.DoubleUtils
Returns its argument if it is non-negative, zero if it is negative.
ensurePositive(double) - Static method in class com.google.common.math.PairedStats
 
ensurePositive(double) - Method in class com.google.common.math.PairedStatsAccumulator
 
ensureRoomFor(int) - Method in class com.google.common.collect.ImmutableList.Builder
 
ensureRoomFor(int) - Method in class com.google.common.primitives.ImmutableDoubleArray.Builder
 
ensureRoomFor(int) - Method in class com.google.common.primitives.ImmutableIntArray.Builder
 
ensureRoomFor(int) - Method in class com.google.common.primitives.ImmutableLongArray.Builder
 
ensureTableCapacity(int) - Method in class com.google.common.collect.ImmutableSet.RegularSetBuilderImpl
 
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.
enter(Duration) - 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.
enterIf(Monitor.Guard, Duration) - 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.
enterIfInterruptibly(Monitor.Guard, Duration) - 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.
enterInterruptibly(Duration) - 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.
enterWhen(Monitor.Guard, Duration) - 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.
enterWhenUninterruptibly(Monitor.Guard, Duration) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor when the guard is satisfied.
entries - Variable in class com.google.common.collect.AbstractMultimap
 
entries - Variable in class com.google.common.collect.CompactHashMap
Contains the logical entries, in the range of [0, size()).
entries - Variable in class com.google.common.collect.CompactHashSet
Contains the logical entries, in the range of [0, size()).
entries - Variable in class com.google.common.collect.ImmutableMap.Builder
 
entries - Variable in class com.google.common.collect.ImmutableMapEntrySet.RegularEntrySet
 
entries - Variable in class com.google.common.collect.ImmutableMultiset.ElementSet
 
entries - Variable in class com.google.common.collect.ImmutableRangeMap.Builder
 
entries - Variable in class com.google.common.collect.ImmutableSetMultimap
 
entries - Variable in class com.google.common.collect.JdkBackedImmutableBiMap
 
entries - Variable in class com.google.common.collect.JdkBackedImmutableMap
 
entries - Variable in class com.google.common.collect.JdkBackedImmutableMultiset
 
entries - Variable in class com.google.common.collect.Maps.UnmodifiableEntries
 
entries - Variable in class com.google.common.collect.Multimaps.UnmodifiableMultimap
 
entries - Variable in class com.google.common.collect.RegularImmutableBiMap
 
entries - Variable in class com.google.common.collect.RegularImmutableMap
 
entries - Variable in class com.google.common.collect.RegularImmutableMultiset
 
entries - Variable in class com.google.common.collect.Synchronized.SynchronizedMultimap
 
entries - Variable in class com.google.common.collect.testing.google.MultisetNavigationTester
 
entries - Variable in class com.google.common.collect.testing.testers.NavigableMapNavigationTester
 
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() - Method in class com.google.common.collect.AbstractMultimap
 
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() - 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() - Method in class com.google.common.collect.ImmutableMultimap
Returns an immutable collection of all key-value pairs in the multimap.
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() - 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() - Method in class com.google.common.collect.Multimaps.MapMultimap
 
entries() - Method in class com.google.common.collect.Multimaps.UnmodifiableMultimap
 
entries() - Method in class com.google.common.collect.Multimaps.UnmodifiableSetMultimap
 
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() - Method in class com.google.common.collect.Synchronized.SynchronizedMultimap
 
entries() - Method in class com.google.common.collect.Synchronized.SynchronizedSetMultimap
 
Entries() - Constructor for class com.google.common.collect.AbstractMultimap.Entries
 
Entries() - Constructor for class com.google.common.collect.FilteredKeyMultimap.Entries
 
Entries() - Constructor for class com.google.common.collect.Multimaps.Entries
 
ENTRIES_ARE_VIEWS - Enum constant in enum class com.google.common.collect.testing.google.MultisetFeature
Indicates that elements from Multiset.entrySet() update to reflect changes in the backing multiset.
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
 
EntriesGenerator(OneSizeTestContainerGenerator<SetMultimap<K, V>, Map.Entry<K, V>>) - Constructor for class com.google.common.collect.testing.google.SetMultimapTestSuiteBuilder.EntriesGenerator
 
EntriesGenerator(OneSizeTestContainerGenerator<M, Map.Entry<K, V>>) - Constructor for class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.EntriesGenerator
 
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
 
entriesUsed - Variable in class com.google.common.collect.ImmutableMap.Builder
 
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.WeakValueReferenceImpl
 
entry(int) - Method in class com.google.common.collect.CompactHashMap
 
entry(int) - Method in class com.google.common.collect.CompactHashSet
 
entry(K, V) - Method in class com.google.common.collect.testing.AbstractMapTester
 
EntryCollection(ImmutableMultimap<K, V>) - Constructor for class com.google.common.collect.ImmutableMultimap.EntryCollection
 
entryComparator - Variable in class com.google.common.collect.testing.DerivedCollectionGenerators.SortedMapSubmapTestMapGenerator
 
entryComparator(Comparator<? super K>) - Static method in class com.google.common.collect.testing.Helpers
 
EntryComparator(Comparator<? super K>) - Constructor for class com.google.common.collect.testing.Helpers.EntryComparator
 
entryFactory - Variable in class com.google.common.cache.LocalCache
Factory used to create new entries.
EntryFactory() - Constructor for enum class com.google.common.cache.LocalCache.EntryFactory
 
EntryFunction() - Constructor for enum class com.google.common.collect.Maps.EntryFunction
 
entryHelper - Variable in class com.google.common.collect.MapMakerInternalMap
Strategy for handling entries and segments in a type-safe and efficient manner.
entryIterable - Variable in class com.google.common.collect.TreeRangeMap.AsMapOfRanges
 
entryIterator - Variable in class com.google.common.collect.AbstractMapBasedMultiset.MapBasedMultisetIterator
 
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.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() - 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.ArrayTable.ArrayMap
 
entryIterator() - Method in class com.google.common.collect.ConcurrentHashMultiset
 
entryIterator() - Method in class com.google.common.collect.DenseImmutableTable.ImmutableArrayMap
 
entryIterator() - Method in class com.google.common.collect.DescendingMultiset
 
entryIterator() - Method in class com.google.common.collect.EnumMultiset
 
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.HashBiMap
 
entryIterator() - Method in class com.google.common.collect.HashBiMap.Inverse
 
entryIterator() - Method in class com.google.common.collect.ImmutableEnumMap
 
entryIterator() - Method in class com.google.common.collect.ImmutableMap.IteratorBasedImmutableMap
 
entryIterator() - Method in class com.google.common.collect.ImmutableMap.MapViewOfValuesAsSingletonSets
 
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() - 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.IteratorBasedAbstractMap
 
entryIterator() - Method in class com.google.common.collect.Maps.NavigableAsMapView
 
entryIterator() - Method in class com.google.common.collect.Maps.TransformedEntriesMap
 
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() - Method in class com.google.common.collect.StandardTable.Row
 
entryIterator() - Method in class com.google.common.collect.TreeMultiset
 
entryIterator() - Method in class com.google.common.collect.TreeRangeMap.AsMapOfRanges
 
entryIterator() - Method in class com.google.common.collect.TreeRangeMap.SubRangeMap.SubRangeMapAsMap
 
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
 
EntryIterator() - Constructor for class com.google.common.cache.LocalCache.EntryIterator
 
EntryIterator() - Constructor for class com.google.common.collect.MapMakerInternalMap.EntryIterator
 
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 - Variable in class com.google.common.collect.Maps.FilteredEntryNavigableMap
 
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
 
entrySet - Variable in class com.google.common.cache.LocalCache
 
entrySet - Variable in class com.google.common.collect.AbstractBiMap
 
entrySet - Variable in class com.google.common.collect.AbstractMultiset
 
entrySet - Variable in class com.google.common.collect.DescendingMultiset
 
entrySet - Variable in class com.google.common.collect.ImmutableMap
 
entrySet - Variable in class com.google.common.collect.ImmutableMultiset
 
entrySet - Variable in class com.google.common.collect.MapMakerInternalMap
 
entrySet - Variable in class com.google.common.collect.Maps.DescendingMap
 
entrySet - Variable in class com.google.common.collect.Maps.ViewCachingAbstractMap
 
entrySet - Variable in class com.google.common.collect.Multisets.UnmodifiableMultiset
 
entrySet - Variable in class com.google.common.collect.Synchronized.SynchronizedMap
 
entrySet - Variable 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.cache.LocalCache
 
entrySet() - Method in class com.google.common.collect.AbstractBiMap
 
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() - Method in class com.google.common.collect.AbstractMultiset
 
entrySet() - Method in class com.google.common.collect.CompactHashMap
 
entrySet() - Method in class com.google.common.collect.DescendingMultiset
 
entrySet() - Method in class com.google.common.collect.FilteredEntryMultimap.Keys
 
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.ImmutableMap
Returns an immutable set of the mappings in this map.
entrySet() - Method in class com.google.common.collect.ImmutableMultiset
 
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() - Method in class com.google.common.collect.MapMakerInternalMap
 
entrySet() - Method in class com.google.common.collect.Maps.DescendingMap
 
entrySet() - Method in class com.google.common.collect.Maps.FilteredEntryNavigableMap
 
entrySet() - Method in class com.google.common.collect.Maps.IteratorBasedAbstractMap
 
entrySet() - Method in class com.google.common.collect.Maps.ViewCachingAbstractMap
 
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() - Method in class com.google.common.collect.Multisets.UnmodifiableMultiset
 
entrySet() - Method in class com.google.common.collect.MutableClassToInstanceMap
 
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() - Method in class com.google.common.collect.Synchronized.SynchronizedAsMap
 
entrySet() - Method in class com.google.common.collect.Synchronized.SynchronizedMap
 
entrySet() - Method in class com.google.common.collect.Synchronized.SynchronizedMultiset
 
entrySet() - Method in class com.google.common.collect.testing.SafeTreeMap
 
entrySet() - Method in class com.google.common.collect.TreeRangeMap.SubRangeMap.SubRangeMapAsMap
 
entrySet() - Method in class com.google.common.reflect.MutableTypeToInstanceMap
 
EntrySet() - Constructor for class com.google.common.cache.LocalCache.EntrySet
 
EntrySet() - Constructor for class com.google.common.collect.AbstractBiMap.EntrySet
 
EntrySet() - Constructor for class com.google.common.collect.AbstractMultimap.EntrySet
 
EntrySet() - Constructor for class com.google.common.collect.AbstractMultiset.EntrySet
 
EntrySet() - Constructor for class com.google.common.collect.ConcurrentHashMultiset.EntrySet
 
EntrySet() - Constructor for class com.google.common.collect.FilteredKeySetMultimap.EntrySet
 
EntrySet() - Constructor for class com.google.common.collect.ImmutableMultiset.EntrySet
 
EntrySet() - Constructor for class com.google.common.collect.MapMakerInternalMap.EntrySet
 
EntrySet() - Constructor for class com.google.common.collect.Maps.EntrySet
 
EntrySet() - Constructor for class com.google.common.collect.Maps.FilteredEntryMap.EntrySet
 
EntrySet() - Constructor for class com.google.common.collect.Multimaps.AsMap.EntrySet
 
EntrySet() - Constructor for class com.google.common.collect.Multisets.EntrySet
 
EntrySet() - Constructor for class com.google.common.collect.StandardTable.Column.EntrySet
 
EntrySet() - Constructor for class com.google.common.collect.StandardTable.RowMap.EntrySet
 
EntrySet(ImmutableSetMultimap<K, V>) - Constructor for class com.google.common.collect.ImmutableSetMultimap.EntrySet
 
EntrySetGenerator(OneSizeTestContainerGenerator<Collection<E>, E>) - Constructor for class com.google.common.collect.testing.google.MultisetTestSuiteBuilder.EntrySetGenerator
 
entrySetIterator() - Method in class com.google.common.collect.AbstractBiMap
 
entrySetIterator() - Method in class com.google.common.collect.CompactHashMap
 
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
 
entrySetView - Variable in class com.google.common.collect.CompactHashMap
 
EntrySetView() - Constructor for class com.google.common.collect.CompactHashMap.EntrySetView
 
entrySpliterator() - Method in class com.google.common.collect.AbstractMapBasedMultimap
 
entrySpliterator() - Method in class com.google.common.collect.AbstractMultimap
 
entrySpliterator() - Method in class com.google.common.collect.ArrayTable.ArrayMap
 
entrySpliterator() - Method in class com.google.common.collect.ImmutableEnumMap
 
entrySpliterator() - Method in class com.google.common.collect.ImmutableMap.IteratorBasedImmutableMap
 
entrySpliterator() - Method in class com.google.common.collect.ImmutableMultimap
 
entrySpliterator() - Method in class com.google.common.collect.LinkedHashMultimap
 
entrySpliterator() - Method in class com.google.common.collect.Maps.IteratorBasedAbstractMap
 
entrySpliterator() - Method in class com.google.common.collect.Maps.NavigableAsMapView
 
entrySpliterator() - Method in class com.google.common.collect.Maps.TransformedEntriesMap
 
entrySpliterator() - Method in class com.google.common.collect.StandardTable.Row
 
entrySplitter - Variable in class com.google.common.base.Splitter.MapSplitter
 
EnumBiMap<K,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
 
enumConstants - Variable in class com.google.common.collect.EnumMultiset
 
EnumHashBiMap<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.
EnumMapAccumulator(BinaryOperator<V>) - Constructor for class com.google.common.collect.CollectCollectors.EnumMapAccumulator
 
EnumMultiset<E> - Class in com.google.common.collect
Multiset implementation specialized for enum elements, supporting all single-element operations in O(1).
EnumMultiset(Class<E>) - Constructor for class com.google.common.collect.EnumMultiset
Creates an empty EnumMultiset.
EnumMultiset.Itr<T> - Class in com.google.common.collect
 
Enums - Class in com.google.common.base
Utility methods for working with Enum instances.
Enums() - Constructor for class com.google.common.base.Enums
 
Enums() - Constructor for class com.google.common.collect.testing.SampleElements.Enums
 
Enums.StringConverter<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
 
EnumSetAccumulator() - Constructor for class com.google.common.collect.CollectCollectors.EnumSetAccumulator
 
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
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(File, File) - Static method in class com.google.common.io.Files
Returns true if the given files exist, are not directories, and contain the same bytes.
equal(Object, Object) - Static method in class com.google.common.base.Objects
Determines whether two possibly-null objects are equal.
equal(Object, Object) - Static method in class com.google.common.collect.testing.AbstractMapTester
 
equal(Object, Object) - Static method in class com.google.common.collect.testing.Helpers
 
equal(Path, Path) - Static method in class com.google.common.io.MoreFiles
Returns true if the files located by the given paths exist, are not directories, and contain the same bytes.
EQUAL_TO_NOTHING - Enum constant in enum class com.google.common.testing.EqualsTester.NotAnInstance
 
equalityGroups - Variable in class com.google.common.testing.EqualsTester
 
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(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(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
May return true if object is a Function that behaves identically 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.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.Predicates.SubtypeOfPredicate
 
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.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.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.ImmutableEnumMap
 
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 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.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 class com.google.common.collect.Synchronized.SynchronizedTable
 
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.testing.BaseComparable
 
equals(Object) - Method in class com.google.common.collect.testing.features.TesterRequirements
 
equals(Object) - Method in class com.google.common.collect.testing.Helpers.NullsBefore
 
equals(Object) - Method in class com.google.common.collect.testing.MinimalSet
 
equals(Object) - Method in class com.google.common.collect.testing.SafeTreeMap
 
equals(Object) - Method in class com.google.common.collect.testing.SafeTreeSet
 
equals(Object) - Method in class com.google.common.collect.testing.SampleElements.Collider
 
equals(Object) - Method in class com.google.common.collect.testing.UnhashableObject
 
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.Subscriber
 
equals(Object) - Method in class com.google.common.eventbus.SubscriberRegistry.MethodIdentifier
 
equals(Object) - Method in class com.google.common.graph.AbstractGraph
 
equals(Object) - Method in class com.google.common.graph.AbstractNetwork
 
equals(Object) - Method in class com.google.common.graph.AbstractValueGraph
 
equals(Object) - Method in class com.google.common.graph.DirectedGraphConnections.NodeConnection.Pred
 
equals(Object) - Method in class com.google.common.graph.DirectedGraphConnections.NodeConnection.Succ
 
equals(Object) - Method in class com.google.common.graph.ElementOrder
 
equals(Object) - Method in class com.google.common.graph.EndpointPair
Two ordered EndpointPairs are equal if their EndpointPair.source() and EndpointPair.target() are equal.
equals(Object) - Method in class com.google.common.graph.EndpointPair.Ordered
 
equals(Object) - Method in class com.google.common.graph.EndpointPair.Unordered
 
equals(Object) - Method in interface com.google.common.graph.Graph
Returns true iff object is a Graph that has the same elements and the same structural relationships as those in this graph.
equals(Object) - Method in interface com.google.common.graph.Network
Returns true iff object is a Network that has the same elements and the same structural relationships as those in this network.
equals(Object) - Method in interface com.google.common.graph.ValueGraph
Returns true iff object is a ValueGraph that has the same elements and the same structural relationships as those in this graph.
equals(Object) - Method in class com.google.common.hash.BloomFilter
 
equals(Object) - Method in class com.google.common.hash.BloomFilterStrategies.LockFreeBitArray
 
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
Returns true if object is a HashCode instance with the identical byte representation to this hash code.
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.io.BaseEncoding.Alphabet
 
equals(Object) - Method in class com.google.common.io.BaseEncoding.StandardBaseEncoding
 
equals(Object) - Method in class com.google.common.math.PairedStats
equals(Object) - Method in class com.google.common.math.Stats
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.ImmutableDoubleArray.AsList
 
equals(Object) - Method in class com.google.common.primitives.ImmutableDoubleArray
Returns true if object is an ImmutableDoubleArray containing the same values as this one, in the same order.
equals(Object) - Method in class com.google.common.primitives.ImmutableIntArray.AsList
 
equals(Object) - Method in class com.google.common.primitives.ImmutableIntArray
Returns true if object is an ImmutableIntArray containing the same values as this one, in the same order.
equals(Object) - Method in class com.google.common.primitives.ImmutableLongArray.AsList
 
equals(Object) - Method in class com.google.common.primitives.ImmutableLongArray
Returns true if object is an ImmutableLongArray containing the same values as this one, in the same order.
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.LocationInfo
 
equals(Object) - Method in class com.google.common.reflect.ClassPath.ResourceInfo
 
equals(Object) - Method in class com.google.common.reflect.Invokable
 
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.
equals(Object) - Method in class com.google.common.testing.ClassSanityTester.SerializableDummyProxy
 
equals(Object) - Method in class com.google.common.testing.DummyProxy.DummyHandler
 
equals(Object) - Method in class com.google.common.testing.FreshValueGenerator.FreshInvocationHandler
 
equals(Object) - Method in class com.google.common.testing.NullPointerTester.Signature
 
Equals() - Constructor for class com.google.common.base.Equivalence.Equals
 
EQUALS_TEST_METHOD_NAMES - Static variable in class com.google.common.testing.AbstractPackageSanityTests
 
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(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(Table<?, ?, ?>, Object) - Static method in class com.google.common.collect.Tables
 
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(Set<?>, Object) - Static method in class com.google.common.collect.Sets
An implementation for Set.equals(Object).
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
 
EqualsTester - Class in com.google.common.testing
Tester for equals() and hashCode() methods of a class.
EqualsTester() - Constructor for class com.google.common.testing.EqualsTester
Constructs an empty EqualsTester instance
EqualsTester(RelationshipTester.ItemReporter) - Constructor for class com.google.common.testing.EqualsTester
 
EqualsTester.NotAnInstance - Enum Class in com.google.common.testing
Class used to test whether equals() correctly handles an instance of an incompatible class.
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 - Variable in class com.google.common.base.Equivalence.EquivalentToPredicate
 
equivalence - Variable in class com.google.common.base.Equivalence.Wrapper
 
equivalence - Variable in class com.google.common.testing.CollectorTester
 
equivalence - Variable in class com.google.common.testing.EquivalenceTester
 
equivalence - Variable in class com.google.common.testing.RelationshipTester
A word about using Equivalence, which automatically checks for null and identical inputs: This sounds like it ought to be a problem here, since the goals of this class include testing that equals() is reflexive and is tolerant of null.
Equivalence<T> - Class in com.google.common.base
A strategy for determining whether two instances are considered equivalent, and for computing hash codes in a manner consistent with that equivalence.
Equivalence() - Constructor for class com.google.common.base.Equivalence
Constructor for use by subclasses.
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
EquivalenceTester<T> - Class in com.google.common.testing
Tester for Equivalence relationships between groups of objects.
EquivalenceTester(Equivalence<? super T>) - Constructor for class com.google.common.testing.EquivalenceTester
 
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.
errorMessage - Variable in class com.google.common.graph.InvalidatableSet
 
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(char) - Method in class com.google.common.escape.ArrayBasedCharEscaper
Escapes a single character using the replacement array and safe range values.
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(char) - Method in class com.google.common.escape.CharEscaperBuilder.CharArrayDecorator
 
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(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(int) - Method in class com.google.common.net.PercentEscaper
Escapes the given Unicode code point in UTF-8.
escape(String) - Method in class com.google.common.escape.ArrayBasedCharEscaper
 
escape(String) - Method in class com.google.common.escape.ArrayBasedUnicodeEscaper
 
escape(String) - Method in class com.google.common.escape.CharEscaper
Returns the escaped form of a given literal string.
escape(String) - 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(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
 
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.
EscaperAsserts - Class in com.google.common.escape.testing
Extra assert methods for testing Escaper implementations.
EscaperAsserts() - Constructor for class com.google.common.escape.testing.EscaperAsserts
 
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
 
estimatedSize - Variable in class com.google.common.collect.CollectSpliterators.FlatMapSpliterator
 
estimatedSizeForUnknownDuplication(int) - Static method in class com.google.common.collect.ImmutableSet
 
estimateSize() - Method in class com.google.common.collect.CollectSpliterators.FlatMapSpliterator
 
estimateSize() - Method in class com.google.common.collect.Streams.MapWithIndexSpliterator
 
estimateSize() - Method in class com.google.common.collect.testing.SpliteratorTester.GeneralSpliterator
 
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.Dispatcher.LegacyAsyncDispatcher.EventWithSubscriber
 
event - Variable in class com.google.common.eventbus.Dispatcher.PerThreadQueuedDispatcher.Event
 
event - Variable in class com.google.common.eventbus.SubscriberExceptionContext
 
Event(Object, Iterator<Subscriber>) - Constructor for class com.google.common.eventbus.Dispatcher.PerThreadQueuedDispatcher.Event
 
eventBus - 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(SubscriberExceptionHandler) - Constructor for class com.google.common.eventbus.EventBus
Creates a new EventBus with the given SubscriberExceptionHandler.
EventBus(String) - Constructor for class com.google.common.eventbus.EventBus
Creates a new EventBus with the given identifier.
EventBus(String, Executor, Dispatcher, SubscriberExceptionHandler) - Constructor for class com.google.common.eventbus.EventBus
 
EventBus.LoggingHandler - Class in com.google.common.eventbus
Simple logging handler for subscriber exceptions.
EventBus Summary - Search tag in class com.google.common.eventbus.EventBus
Section
eventuallyClose(C, Executor) - Method in class com.google.common.util.concurrent.ClosingFuture.DeferredCloser
Captures an object to be closed when a ClosingFuture pipeline is done.
eventuallyClosing(ListenableFuture<C>, Executor) - Static method in class com.google.common.util.concurrent.ClosingFuture
Deprecated.
Creating Futures of closeable types is dangerous in general because the underlying value may never be closed if the Future is canceled after its operation begins. Consider replacing code that creates ListenableFutures of closeable types, including those that pass them to this method, with ClosingFuture.submit(ClosingCallable, Executor) in order to ensure that resources do not leak. Or, to start a pipeline with a ListenableFuture that doesn't create values that should be closed, use ClosingFuture.from(com.google.common.util.concurrent.ListenableFuture<V>).
EventWithSubscriber(Object, Subscriber) - Constructor for class com.google.common.eventbus.Dispatcher.LegacyAsyncDispatcher.EventWithSubscriber
 
every(Type[]) - Static method in class com.google.common.reflect.TypeToken
 
everySixteenthFactorial - Static variable in class com.google.common.math.DoubleMath
 
evictEntries(ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.Segment
Performs eviction if the segment is over capacity.
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.
evictsBySize() - Method in class com.google.common.cache.LocalCache
 
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.
Example - Search tag in class com.google.common.base.Converter
Section
Example - Search tag in class com.google.common.collect.FluentIterable
Section
Example - Search tag in interface com.google.common.collect.Multimap
Section
Examples - Search tag in class com.google.common.math.Quantiles
Section
ExampleStackTrace(CycleDetectingLockFactory.LockGraphNode, CycleDetectingLockFactory.LockGraphNode) - Constructor for exception class com.google.common.util.concurrent.CycleDetectingLockFactory.ExampleStackTrace
 
Example usage - Search tag in class com.google.common.collect.ImmutableCollection
Section
exception - Variable in class com.google.common.util.concurrent.AbstractFuture.Failure
 
exceptionHandler - Variable in class com.google.common.eventbus.EventBus
 
exceptions - Variable in exception class com.google.common.testing.ClusterException
 
exceptionType - Variable in class com.google.common.util.concurrent.AbstractCatchingFuture
 
ExceptionTypePolicy() - Constructor for enum class com.google.common.testing.NullPointerTester.ExceptionTypePolicy
 
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 class com.google.common.util.concurrent.CycleDetectingLockFactory.ExampleStackTrace
 
EXCLUSIVE - Enum constant in enum class com.google.common.collect.testing.DerivedCollectionGenerators.Bound
 
EXCLUSIVE - Enum constant in enum class com.google.common.collect.testing.google.SortedMultisetTestSuiteBuilder.Bound
 
execute() - Method in class com.google.common.util.concurrent.CombinedFuture.CombinedFutureInterruptibleTask
 
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.testing.ArbitraryInstances.Dummies.DummyExecutor
 
execute(Runnable) - Method in enum class com.google.common.util.concurrent.DirectExecutor
 
execute(Runnable) - Method in class com.google.common.util.concurrent.DirectExecutorService
 
execute(Runnable) - Method in class com.google.common.util.concurrent.ExecutionSequencer.TaskNonReentrantExecutor
 
execute(Runnable) - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
execute(Runnable) - Method in class com.google.common.util.concurrent.MoreExecutors.ListeningDecorator
 
execute(Runnable) - Method in class com.google.common.util.concurrent.SequentialExecutor
Adds a task to the queue and makes sure a worker thread is running.
execute(Runnable) - Method in class com.google.common.util.concurrent.testing.SameThreadScheduledExecutorService
 
execute(Runnable) - Method in class com.google.common.util.concurrent.testing.TestingExecutors.NoOpScheduledExecutorService
 
execute(Runnable) - Method in class com.google.common.util.concurrent.WrappingExecutorService
 
execute(Iterator<?>) - Method in interface com.google.common.collect.testing.AbstractIteratorTester.IteratorOperation
 
executeAndCompare(ListIterator<E>, T) - Method in class com.google.common.collect.testing.AbstractIteratorTester.Stimulus
Send this stimulus to both iterators and return normally only if both produce the same response.
executed - Variable in class com.google.common.util.concurrent.ExecutionList
 
executeListener(Runnable, Executor) - Static method in class com.google.common.util.concurrent.AbstractFuture
Submits the given runnable to the given Executor catching and logging all runtime exceptions thrown by the executor.
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.
ExecutionError - Exception Class in com.google.common.util.concurrent
ExecutionError() - Constructor for exception class com.google.common.util.concurrent.ExecutionError
Deprecated.
Prefer ExecutionError(java.lang.Error) a constructor that accepts a cause: Users of this class typically expect for instances to have a non-null cause. At the moment, you can usually still preserve behavior by passing an explicit null cause. Note, however, that passing an explicit null cause prevents anyone from calling Throwable.initCause(java.lang.Throwable) later, so it is not quite equivalent to using a constructor that omits the cause.
ExecutionError(Error) - Constructor for exception class com.google.common.util.concurrent.ExecutionError
Creates a new instance with null as its detail message and the given cause.
ExecutionError(String) - Constructor for exception class com.google.common.util.concurrent.ExecutionError
Deprecated.
Prefer ExecutionError(java.lang.String,java.lang.Error) a constructor that accepts a cause: Users of this class typically expect for instances to have a non-null cause. At the moment, you can usually still preserve behavior by passing an explicit null cause. Note, however, that passing an explicit null cause prevents anyone from calling Throwable.initCause(java.lang.Throwable) later, so it is not quite equivalent to using a constructor that omits the cause.
ExecutionError(String, Error) - Constructor for exception class com.google.common.util.concurrent.ExecutionError
Creates a new instance with the given detail message and cause.
executionList - Variable in class com.google.common.util.concurrent.JdkFutureAdapters.ListenableFutureAdapter
 
executionList - Variable in class com.google.common.util.concurrent.ListenableFutureTask
 
ExecutionList - Class in com.google.common.util.concurrent
A support class for ListenableFuture implementations to manage their listeners.
ExecutionList() - Constructor for class com.google.common.util.concurrent.ExecutionList
Creates a new, empty ExecutionList.
ExecutionList.RunnableExecutorPair - Class in com.google.common.util.concurrent
 
ExecutionSequencer - Class in com.google.common.util.concurrent
Serializes execution of tasks, somewhat like an "asynchronous synchronized block." Each enqueued callable will not be submitted to its associated executor until the previous callable has returned -- and, if the previous callable was an AsyncCallable, not until the Future it returned is
invalid reference
done
(successful, failed, or cancelled).
ExecutionSequencer() - Constructor for class com.google.common.util.concurrent.ExecutionSequencer
 
ExecutionSequencer.RunningState - Enum Class in com.google.common.util.concurrent
 
ExecutionSequencer.TaskNonReentrantExecutor - Class in com.google.common.util.concurrent
This class helps avoid a StackOverflowError when large numbers of tasks are submitted with MoreExecutors.directExecutor().
ExecutionSequencer.ThreadConfinedTaskQueue - Class in com.google.common.util.concurrent
This object is unsafely published, but avoids problematic races by relying exclusively on the identity equality of its Thread field so that the task field is only accessed by a single thread.
executor - Variable in class com.google.common.eventbus.EventBus
 
executor - Variable in class com.google.common.eventbus.Subscriber
Executor to use for dispatching events to this subscriber.
executor - Variable in class com.google.common.util.concurrent.AbstractFuture.Listener
 
executor - Variable in class com.google.common.util.concurrent.AbstractScheduledService.CustomScheduler.ReschedulableCallable
The executor on which this Callable will be scheduled.
executor - Variable in class com.google.common.util.concurrent.ExecutionList.RunnableExecutorPair
 
executor - Variable in class com.google.common.util.concurrent.ListenerCallQueue.PerListenerQueue
 
executor - Variable in class com.google.common.util.concurrent.SequentialExecutor
Underlying executor that all submitted Runnable objects are run on.
executor - Variable in class com.google.common.util.concurrent.SimpleTimeLimiter
 
executor() - Method in class com.google.common.eventbus.EventBus
Returns the default executor this event bus uses for dispatching events to subscribers.
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() - Method in class com.google.common.util.concurrent.AbstractScheduledService
executorService - Variable in class com.google.common.util.concurrent.AbstractScheduledService.ServiceDelegate
 
exhaust(InputStream) - Static method in class com.google.common.io.ByteStreams
Reads and discards data from the given InputStream until the end of the stream is reached.
exhaust(Readable) - Static method in class com.google.common.io.CharStreams
Reads and discards data from the given Readable until the end of the stream is reached.
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
Deprecated.
 
expandedCapacity(int, int) - Static method in class com.google.common.collect.ImmutableCollection.Builder
 
expandedCapacity(int, int) - Static method in class com.google.common.primitives.ImmutableDoubleArray.Builder
 
expandedCapacity(int, int) - Static method in class com.google.common.primitives.ImmutableIntArray.Builder
 
expandedCapacity(int, int) - Static method in class com.google.common.primitives.ImmutableLongArray.Builder
 
expandTableThreshold - Variable in class com.google.common.collect.ImmutableSet.RegularSetBuilderImpl
 
expect(Iterable<?>) - Method in class com.google.common.collect.testing.SpliteratorTester
 
expect(Object...) - Method in class com.google.common.collect.testing.SpliteratorTester
 
EXPECT - Static variable in class com.google.common.net.HttpHeaders
The HTTP Expect header field name.
expectAdded(int, E...) - Method in class com.google.common.collect.testing.AbstractContainerTester
 
expectAdded(int, Collection<E>) - Method in class com.google.common.collect.testing.AbstractContainerTester
 
expectAdded(E...) - Method in class com.google.common.collect.testing.AbstractContainerTester
Asserts that the collection under test contains exactly the elements it was initialized with plus the given elements, according to AbstractContainerTester.expectContents(java.util.Collection).
expectAddFailure(SortedMultiset<E>, Multiset.Entry<E>) - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
expectArgument(Class<T>, Object) - Static method in class com.google.common.reflect.TypeResolver
 
expectArrayContentsAnyOrder(Object[], Object[]) - Method in class com.google.common.collect.testing.testers.CollectionToArrayTester
 
expectArrayContentsInOrder(List<E>, Object[]) - Method in class com.google.common.collect.testing.testers.CollectionToArrayTester
 
expectCollects(R, T...) - Method in class com.google.common.testing.CollectorTester
Verifies that the specified expected result is always produced by collecting the specified inputs, regardless of how the elements are divided.
expectContents(E...) - Method in class com.google.common.collect.testing.AbstractContainerTester
 
expectContents(Collection<E>) - Method in class com.google.common.collect.testing.AbstractContainerTester
Asserts that the collection under test contains exactly the given elements, respecting cardinality but not order.
expectContents(Collection<E>) - Method in class com.google.common.collect.testing.testers.AbstractListTester
Asserts that the collection under test contains exactly the given elements, respecting cardinality but not order.
expectContents(Collection<Map.Entry<K, V>>) - Method in class com.google.common.collect.testing.AbstractMapTester
 
expectContents(Collection<Map.Entry<K, V>>) - Method in class com.google.common.collect.testing.google.AbstractBiMapTester
 
EXPECTED_DEGREE - Static variable in class com.google.common.graph.GraphConstants
 
expectedEdgeCount - Variable in class com.google.common.graph.NetworkBuilder
 
expectedEdgeCount(int) - Method in class com.google.common.graph.NetworkBuilder
Specifies the expected number of edges in the network.
expectedElements - Variable in class com.google.common.collect.testing.AbstractIteratorTester
 
expectedEntries(int, List<Multiset.Entry<E>>) - Method in enum class com.google.common.collect.testing.google.MultisetNavigationTester.SubMultisetSpec
 
ExpectedException() - Constructor for exception class com.google.common.collect.testing.testers.MapComputeIfAbsentTester.ExpectedException
 
ExpectedException() - Constructor for exception class com.google.common.collect.testing.testers.MapComputeIfPresentTester.ExpectedException
 
ExpectedException() - Constructor for exception class com.google.common.collect.testing.testers.MapComputeTester.ExpectedException
 
ExpectedException() - Constructor for exception class com.google.common.collect.testing.testers.MapMergeTester.ExpectedException
 
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.
expectedMetadata - Variable in class com.google.common.collect.CompactHashMap.Itr
 
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
 
expectedNodeCount - Variable in class com.google.common.graph.AbstractGraphBuilder
 
expectedNodeCount(int) - Method in class com.google.common.graph.GraphBuilder
Specifies the expected number of nodes in the graph.
expectedNodeCount(int) - Method in class com.google.common.graph.NetworkBuilder
Specifies the expected number of nodes in the network.
expectedNodeCount(int) - Method in class com.google.common.graph.ValueGraphBuilder
Specifies the expected number of nodes in the graph.
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.
expectedToString(Set<Map.Entry<K, V>>) - Method in class com.google.common.collect.testing.testers.MapToStringTester
 
expectedValueCollectionSize(int, Iterable<?>) - Method in class com.google.common.collect.ImmutableMultimap.Builder
By default, if we are handed a value collection bigger than expectedValuesPerKey, presize to accept that many elements.
expectedValueCollectionSize(int, Iterable<?>) - Method in class com.google.common.collect.ImmutableSetMultimap.Builder
 
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.ImmutableMultimap.Builder
 
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
 
expectedValuesPerKey(int) - Method in class com.google.common.collect.ImmutableListMultimap.Builder
Provides a hint for how many values will be associated with each key newly added to the builder after this call.
expectedValuesPerKey(int) - Method in class com.google.common.collect.ImmutableMultimap.Builder
Provides a hint for how many values will be associated with each key newly added to the builder after this call.
expectedValuesPerKey(int) - Method in class com.google.common.collect.ImmutableSetMultimap.Builder
Provides a hint for how many values will be associated with each key newly added to the builder after this call.
expectFirstRemoved(Map.Entry<K, V>[]) - Method in class com.google.common.collect.testing.testers.MapCreationTester
 
expectMissing(E...) - Method in class com.google.common.collect.testing.AbstractContainerTester
 
expectMissing(Map.Entry<K, V>...) - Method in class com.google.common.collect.testing.AbstractMapTester
 
expectMissing(Map.Entry<K, V>...) - Method in class com.google.common.collect.testing.google.AbstractBiMapTester
 
expectMissingKeys(K...) - Method in class com.google.common.collect.testing.AbstractMapTester
 
expectMissingValues(V...) - Method in class com.google.common.collect.testing.AbstractMapTester
 
expectNullKeyMissingWhenNullKeysUnsupported(String) - Method in class com.google.common.collect.testing.AbstractMapTester
Equivalent to expectMissingKeys (null) except that the call to contains(null) is permitted to throw a NullPointerException.
expectNullMissingWhenNullUnsupported(String) - Method in class com.google.common.collect.testing.AbstractCollectionTester
Equivalent to expectMissing(null) except that the call to contains(null) is permitted to throw a NullPointerException.
expectNullValueMissingWhenNullValuesUnsupported(String) - Method in class com.google.common.collect.testing.AbstractMapTester
Equivalent to expectMissingValues (null) except that the call to contains(null) is permitted to throw a NullPointerException.
expectRemoveZero(SortedMultiset<E>, Multiset.Entry<E>) - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
expectReplacement(Map.Entry<K, V>) - Method in class com.google.common.collect.testing.AbstractMapTester
 
expectReturnsFalse(CollectionRetainAllTester.Target) - Method in class com.google.common.collect.testing.testers.CollectionRetainAllTester
 
expectReturnsFalseOrThrows(CollectionRetainAllTester.Target) - Method in class com.google.common.collect.testing.testers.CollectionRetainAllTester
 
expectReturnsTrue(CollectionRetainAllTester.Target) - Method in class com.google.common.collect.testing.testers.CollectionRetainAllTester
 
expectSetCountFailure(SortedMultiset<E>, Multiset.Entry<E>) - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
expectThrows(CollectionRetainAllTester.Target) - Method in class com.google.common.collect.testing.testers.CollectionRetainAllTester
 
expectUnchanged() - Method in class com.google.common.collect.testing.AbstractContainerTester
 
expirationNanos - Variable in class com.google.common.base.Suppliers.ExpiringMemoizingSupplier
 
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(Duration) - 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.
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
 
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(Duration) - 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.
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
 
EXPIRED - Enum constant in enum class com.google.common.cache.RemovalCause
The entry's expiration timestamp has passed.
expireEntries(long) - Method in class com.google.common.cache.LocalCache.Segment
 
expires() - Method in class com.google.common.cache.LocalCache
 
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
 
expiresAfterWrite() - Method in class com.google.common.cache.LocalCache
 
ExpiringMemoizingSupplier(Supplier<T>, long) - 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.
EXPLICIT - Enum constant in enum class com.google.common.cache.RemovalCause
The entry was manually removed by the user.
ExplicitOrdering<T> - Class in com.google.common.collect
An ordering that compares objects according to a given order.
ExplicitOrdering(ImmutableMap<T, Integer>) - Constructor for class com.google.common.collect.ExplicitOrdering
 
ExplicitOrdering(List<T>) - 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
 
Extension - Search tag in class com.google.common.util.concurrent.FluentFuture
Section
Extension - Search tag in class com.google.common.util.concurrent.ForwardingFluentFuture
Section
externalState() - Method in class com.google.common.util.concurrent.AbstractService.StateSnapshot
 
extract(byte[], int) - Static method in class com.google.common.io.BaseEncoding
 
extractMethod(Test) - Static method in class com.google.common.collect.testing.FeatureSpecificTestSuiteBuilder
 
ExtraObjectsMethodsForWeb - Class in com.google.common.base
Holder for extra methods of Objects only in web.
ExtraObjectsMethodsForWeb() - Constructor for class com.google.common.base.ExtraObjectsMethodsForWeb
 
extras - Variable in class com.google.common.collect.MoreCollectors.ToOptionalState
 

F

f - Variable in class com.google.common.base.Functions.FunctionComposition
 
f - Variable in class com.google.common.base.Predicates.CompositionPredicate
 
F - Enum constant in enum class com.google.common.collect.testing.AnEnum
 
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 class com.google.common.cache.LocalCache.EntryFactory
Look-up table for factories.
factories - Variable in class com.google.common.testing.ClassSanityTester.FactoryMethodReturnValueTester
 
factory - Variable in class com.google.common.collect.CollectSpliterators.FlatMapSpliterator
 
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(int) - Constructor for class com.google.common.collect.HashBasedTable.Factory
 
Factory(Comparator<? super C>) - Constructor for class com.google.common.collect.TreeBasedTable.Factory
 
FactoryMethodReturnsNullException(Invokable<?, ?>) - Constructor for exception class com.google.common.testing.ClassSanityTester.FactoryMethodReturnsNullException
 
FactoryMethodReturnValueTester(Class<?>, ImmutableList<Invokable<?, ?>>, String) - Constructor for class com.google.common.testing.ClassSanityTester.FactoryMethodReturnValueTester
 
factoryMethodsDescription - Variable in class com.google.common.testing.ClassSanityTester.FactoryMethodReturnValueTester
 
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
 
FAILED - Enum constant in enum class com.google.common.base.AbstractIterator.State
 
FAILED - Enum constant in enum class com.google.common.collect.AbstractIterator.State
We've suffered an exception and are kaput.
FAILED - Enum constant in enum class com.google.common.util.concurrent.Service.State
A service in this state has encountered a problem and may not be operational.
FailedService(Service) - Constructor for exception class com.google.common.util.concurrent.ServiceManager.FailedService
 
FAILS_FAST_ON_CONCURRENT_MODIFICATION - Enum constant in enum class com.google.common.collect.testing.features.CollectionFeature
 
FAILS_FAST_ON_CONCURRENT_MODIFICATION - Enum constant in enum class com.google.common.collect.testing.features.MapFeature
 
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.
Failure(Throwable) - Constructor for class com.google.common.util.concurrent.AbstractFuture.Failure
 
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.
FakeTicker - Class in com.google.common.testing
A Ticker whose value can be advanced programmatically in test.
FakeTicker() - Constructor for class com.google.common.testing.FakeTicker
 
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
 
fallback - Variable in class com.google.common.util.concurrent.AbstractCatchingFuture
 
FALLBACK_INSTANCE - Static variable in class com.google.common.util.concurrent.AbstractFuture.Failure
 
FALSE_FIRST - Enum constant in enum class com.google.common.primitives.Booleans.BooleanComparator
 
falseFirst() - Static method in class com.google.common.primitives.Booleans
Returns a Comparator<Boolean> that sorts false before true.
FARMHASH_FINGERPRINT_64 - Static variable in class com.google.common.hash.FarmHashFingerprint64
 
farmHashFingerprint64() - Static method in class com.google.common.hash.Hashing
Returns a hash function implementing FarmHash's Fingerprint64, an open-source algorithm.
FarmHashFingerprint64 - Class in com.google.common.hash
Implementation of FarmHash Fingerprint64, an open-source fingerprinting algorithm for strings.
FarmHashFingerprint64() - Constructor for class com.google.common.hash.FarmHashFingerprint64
 
FastMatcher() - Constructor for class com.google.common.base.CharMatcher.FastMatcher
 
Feature<T> - Interface in com.google.common.collect.testing.features
Base class for enumerating the features of an interface to be tested.
features - Variable in class com.google.common.collect.testing.AbstractIteratorTester
 
features - Variable in class com.google.common.collect.testing.FeatureSpecificTestSuiteBuilder
 
FeatureSpecificTestSuiteBuilder<B,G> - Class in com.google.common.collect.testing
Creates, based on your criteria, a JUnit test suite that exhaustively tests the object generated by a G, selecting appropriate tests by matching them against specified features.
FeatureSpecificTestSuiteBuilder() - Constructor for class com.google.common.collect.testing.FeatureSpecificTestSuiteBuilder
 
FeatureUtil - Class in com.google.common.collect.testing.features
Utilities for collecting and validating tester requirements from annotations.
FeatureUtil() - Constructor for class com.google.common.collect.testing.features.FeatureUtil
 
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 - Variable in class com.google.common.reflect.ClassPath.ResourceInfo
 
file() - Method in class com.google.common.reflect.ClassPath.LocationInfo
Returns the file this location is from.
FILE_SEPARATOR - Enum constant in enum class com.google.common.base.StandardSystemProperty
File separator ("/" on UNIX).
FILE_TREE - 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
 
filePermissions - Static variable in class com.google.common.io.TempFileCreator.JavaNioCreator
 
FilePredicate() - Constructor for enum class 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 Class in com.google.common.io
 
fileThreshold - Variable in class com.google.common.io.FileBackedOutputStream
 
fileTraverser() - Static method in class com.google.common.io.Files
Returns a Traverser instance for the file and directory tree.
fileTraverser() - Static method in class com.google.common.io.MoreFiles
Returns a Traverser instance for the file and directory tree.
fileTreeChildren(Path) - Static method in class com.google.common.io.MoreFiles
 
FileWriteMode - Enum Class in com.google.common.io
Modes for opening a file for writing.
FileWriteMode() - Constructor for enum class 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.
fillInStackTrace() - Method in exception class com.google.common.util.concurrent.TimeoutFuture.TimeoutFutureException
 
filter - Variable in class com.google.common.base.SmallCharMatcher
 
filter(Predicate<? super E>) - Method in class com.google.common.collect.FluentIterable
Returns the elements from this fluent iterable that satisfy a predicate.
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(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<?>, Class<T>) - Static method in class com.google.common.collect.Iterables
Returns a view of unfiltered containing all elements that are of the type desiredType.
filter(Iterable<T>, Predicate<? super T>) - Static method in class com.google.common.collect.Iterables
Returns a view of unfiltered containing all elements that satisfy the input predicate retainIfTrue.
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(Iterator<?>, Class<T>) - Static method in class com.google.common.collect.Iterators
Returns a view of unfiltered containing all elements that are of the type desiredType.
filter(Iterator<T>, Predicate<? super T>) - Static method in class com.google.common.collect.Iterators
Returns a view of unfiltered containing all elements that satisfy the input predicate retainIfTrue.
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.
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(Spliterator<T>, Predicate<? super T>) - Static method in class com.google.common.collect.CollectSpliterators
Returns a Spliterator filtered by the specified 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(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.
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(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(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.
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.
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.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(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.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.
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(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.
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(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(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(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.
filterSuite(TestSuite) - Method in class com.google.common.collect.testing.FeatureSpecificTestSuiteBuilder
 
filterUpperBounds(Iterable<Type>) - Static method in class com.google.common.reflect.Types
 
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.
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(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(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.
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.
finalize() - Method in class com.google.common.util.concurrent.ClosingFuture
 
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
 
finalizeReference(Reference<?>, Method) - Method in class com.google.common.base.internal.Finalizer
Cleans up the given reference.
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() - Method in class com.google.common.base.CommonMatcher
 
find() - Method in class com.google.common.base.JdkPattern.JdkMatcher
 
find(int) - Method in class com.google.common.base.CommonMatcher
 
find(int) - Method in class com.google.common.base.JdkPattern.JdkMatcher
 
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(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(Object) - Method in class com.google.common.collect.testing.testers.AbstractListIndexOfTester
Override to call indexOf() or lastIndexOf().
find(Object) - Method in class com.google.common.collect.testing.testers.ListIndexOfTester
 
find(Object) - Method in class com.google.common.collect.testing.testers.ListLastIndexOfTester
 
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.
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.
findAllSubscribers(Object) - Method in class com.google.common.eventbus.SubscriberRegistry
Returns all subscribers for the given listener grouped by the type of event they subscribe to.
findClassesToTest(Iterable<? extends Class<?>>, Iterable<String>) - Method in class com.google.common.testing.AbstractPackageSanityTests
Finds the classes not ending with a test suffix and not covered by an explicit test whose name is explicitTestNames.
findInterruptibleMethods(Class<?>) - Static method in class com.google.common.util.concurrent.SimpleTimeLimiter
 
findLast(DoubleStream) - Static method in class com.google.common.collect.Streams
Returns the last element of the specified stream, or OptionalDouble.empty() if the stream is empty.
findLast(IntStream) - Static method in class com.google.common.collect.Streams
Returns the last element of the specified stream, or OptionalInt.empty() if the stream is empty.
findLast(LongStream) - Static method in class com.google.common.collect.Streams
Returns the last element of the specified stream, or OptionalLong.empty() if the stream is empty.
findLast(Stream<T>) - Static method in class com.google.common.collect.Streams
Returns the last element of the specified stream, or Optional.empty() if the stream is empty.
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.
findSuffixOfType(Optional<PublicSuffixType>) - Method in class com.google.common.net.InternetDomainName
Returns the index of the leftmost part of the suffix, or -1 if not found.
fingerprint(byte[], int, int) - Static method in class com.google.common.hash.FarmHashFingerprint64
 
fingerprint(byte[], int, int) - Static method in class com.google.common.hash.Fingerprint2011
 
FINGERPRINT_2011 - Static variable in class com.google.common.hash.Fingerprint2011
 
fingerprint2011() - Static method in class com.google.common.hash.Hashing
Returns a hash function implementing the Fingerprint2011 hashing function (64 hash bits).
Fingerprint2011 - Class in com.google.common.hash
Implementation of Geoff Pike's fingerprint2011 hash function.
Fingerprint2011() - Constructor for class com.google.common.hash.Fingerprint2011
 
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
 
finished - Variable in class com.google.common.hash.Crc32cHashFunction.Crc32cHasher
 
finishLine(boolean) - Method in class com.google.common.io.LineBuffer
Called when a line is complete.
finishToFuture() - Method in class com.google.common.util.concurrent.ClosingFuture
Marks this step as the last step in the ClosingFuture pipeline.
finishToValueAndCloser(ClosingFuture.ValueAndCloserConsumer<? super V>, Executor) - Method in class com.google.common.util.concurrent.ClosingFuture
Marks this step as the last step in the ClosingFuture pipeline.
Fire(TimeoutFuture<V>) - Constructor for class com.google.common.util.concurrent.TimeoutFuture.Fire
 
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 - 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.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.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() - 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
 
first() - Method in class com.google.common.collect.testing.SafeTreeSet
 
FIRST_AFTER - Enum constant in enum class com.google.common.collect.SortedLists.KeyPresentBehavior
Return the index of the first list element that compares as greater than the key, or list.size() if there is no such element.
FIRST_PRESENT - Enum constant in enum class com.google.common.collect.SortedLists.KeyPresentBehavior
Return the index of the first list element that compares as equal to the key.
firstCharOnlyToUpper(String) - Static method in enum class com.google.common.base.CaseFormat
 
firstEntry - Variable in class com.google.common.collect.CompactLinkedHashMap
Pointer to the first node in the linked list, or ENDPOINT if there are no entries.
firstEntry - Variable in class com.google.common.collect.CompactLinkedHashSet
Pointer to the first node in the linked list, or ENDPOINT if there are no entries.
firstEntry - Variable in class com.google.common.collect.LinkedHashMultimap.ValueSet
 
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.ForwardingNavigableMap
 
firstEntry() - Method in class com.google.common.collect.ForwardingSortedMultiset
 
firstEntry() - Method in class com.google.common.collect.ImmutableSortedMap
 
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.testing.SafeTreeMap
 
firstEntry() - Method in class com.google.common.collect.UnmodifiableSortedMultiset
 
firstEntryIndex() - Method in class com.google.common.collect.CompactHashMap
 
firstEntryIndex() - Method in class com.google.common.collect.CompactHashSet
 
firstEntryIndex() - Method in class com.google.common.collect.CompactLinkedHashMap
 
firstEntryIndex() - Method in class com.google.common.collect.CompactLinkedHashSet
 
firstInclusive - Variable in class com.google.common.collect.testing.DerivedCollectionGenerators.SortedMapSubmapTestMapGenerator
 
firstInclusive - Variable in class com.google.common.collect.testing.DerivedCollectionGenerators.SortedSetSubsetTestSetGenerator
 
firstInKeyInsertionOrder - Variable in class com.google.common.collect.HashBiMap
 
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.testing.SafeTreeMap
 
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.
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
 
flags() - Method in class com.google.common.base.CommonPattern
 
flags() - Method in class com.google.common.base.JdkPattern
 
flatMap(Spliterator<InElementT>, Function<? super InElementT, Spliterator<OutElementT>>, int, long) - Static method in class com.google.common.collect.CollectSpliterators
Returns a Spliterator that iterates over the elements of the spliterators generated by applying function to the elements of fromSpliterator.
FlatMapSpliterator(OutSpliteratorT, Spliterator<InElementT>, Function<? super InElementT, OutSpliteratorT>, CollectSpliterators.FlatMapSpliterator.Factory<InElementT, OutSpliteratorT>, int, long) - Constructor for class com.google.common.collect.CollectSpliterators.FlatMapSpliterator
 
FlatMapSpliteratorOfDouble(Spliterator.OfDouble, Spliterator<InElementT>, Function<? super InElementT, Spliterator.OfDouble>, int, long) - Constructor for class com.google.common.collect.CollectSpliterators.FlatMapSpliteratorOfDouble
 
FlatMapSpliteratorOfInt(Spliterator.OfInt, Spliterator<InElementT>, Function<? super InElementT, Spliterator.OfInt>, int, long) - Constructor for class com.google.common.collect.CollectSpliterators.FlatMapSpliteratorOfInt
 
FlatMapSpliteratorOfLong(Spliterator.OfLong, Spliterator<InElementT>, Function<? super InElementT, Spliterator.OfLong>, int, long) - Constructor for class com.google.common.collect.CollectSpliterators.FlatMapSpliteratorOfLong
 
FlatMapSpliteratorOfObject(Spliterator<OutElementT>, Spliterator<InElementT>, Function<? super InElementT, Spliterator<OutElementT>>, int, long) - Constructor for class com.google.common.collect.CollectSpliterators.FlatMapSpliteratorOfObject
 
FlatMapSpliteratorOfPrimitive(OutSpliteratorT, Spliterator<InElementT>, Function<? super InElementT, OutSpliteratorT>, CollectSpliterators.FlatMapSpliterator.Factory<InElementT, OutSpliteratorT>, int, long) - Constructor for class com.google.common.collect.CollectSpliterators.FlatMapSpliteratorOfPrimitive
 
flatMapToDouble(Spliterator<InElementT>, Function<? super InElementT, Spliterator.OfDouble>, int, long) - Static method in class com.google.common.collect.CollectSpliterators
Returns a Spliterator.OfDouble that iterates over the elements of the spliterators generated by applying function to the elements of fromSpliterator.
flatMapToInt(Spliterator<InElementT>, Function<? super InElementT, Spliterator.OfInt>, int, long) - Static method in class com.google.common.collect.CollectSpliterators
Returns a Spliterator.OfInt that iterates over the elements of the spliterators generated by applying function to the elements of fromSpliterator.
flatMapToLong(Spliterator<InElementT>, Function<? super InElementT, Spliterator.OfLong>, int, long) - Static method in class com.google.common.collect.CollectSpliterators
Returns a Spliterator.OfLong that iterates over the elements of the spliterators generated by applying function to the elements of fromSpliterator.
flattenHierarchy(Class<?>) - Static method in class com.google.common.eventbus.SubscriberRegistry
Flattens a class's type hierarchy into a set of Class objects including all superclasses (transitively) and all interfaces implemented by these superclasses.
flattenHierarchyCache - Static variable in class com.google.common.eventbus.SubscriberRegistry
Global cache of classes to their flattened hierarchy of supertypes.
flatteningToImmutableListMultimap(Function<? super T, ? extends K>, Function<? super T, ? extends Stream<? extends V>>) - Static method in class com.google.common.collect.CollectCollectors
 
flatteningToImmutableListMultimap(Function<? super T, ? extends K>, Function<? super T, ? extends Stream<? extends V>>) - Static method in class com.google.common.collect.ImmutableListMultimap
Returns a Collector accumulating entries into an ImmutableListMultimap.
flatteningToImmutableSetMultimap(Function<? super T, ? extends K>, Function<? super T, ? extends Stream<? extends V>>) - Static method in class com.google.common.collect.CollectCollectors
 
flatteningToImmutableSetMultimap(Function<? super T, ? extends K>, Function<? super T, ? extends Stream<? extends V>>) - Static method in class com.google.common.collect.ImmutableSetMultimap
Returns a Collector accumulating entries into an ImmutableSetMultimap.
flatteningToMultimap(Function<? super T, ? extends K>, Function<? super T, ? extends Stream<? extends V>>, Supplier<M>) - Static method in class com.google.common.collect.CollectCollectors
 
flatteningToMultimap(Function<? super T, ? extends K>, Function<? super T, ? extends Stream<? extends V>>, Supplier<M>) - Static method in class com.google.common.collect.Multimaps
Returns a Collector accumulating entries into a Multimap generated from the specified supplier.
flip(byte) - Static method in class com.google.common.primitives.UnsignedBytes
 
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.
flip(Buffer) - Static method in class com.google.common.base.Java8Compatibility
 
flip(Buffer) - Static method in class com.google.common.hash.Java8Compatibility
 
flip(Buffer) - Static method in class com.google.common.io.Java8Compatibility
 
FLOAT_DEFAULT - Static variable in class com.google.common.base.Defaults
 
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 Class in com.google.common.primitives
 
FloatsMethodsForWeb - Class in com.google.common.primitives
Holder for web specializations of methods of Floats.
FloatsMethodsForWeb() - Constructor for class com.google.common.primitives.FloatsMethodsForWeb
 
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.hash.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(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(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(E) - Method in class com.google.common.collect.testing.SafeTreeSet
 
floor(Comparator<? super E>, E) - Method in class com.google.common.collect.TreeMultiset.AvlNode
 
floor(K) - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableKeySet
 
floor(K) - Method in class com.google.common.collect.Maps.NavigableKeySet
 
floor(V) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedNavigableSet
 
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
 
floorEntry(K) - Method in class com.google.common.collect.testing.SafeTreeMap
 
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
 
floorKey(K) - Method in class com.google.common.collect.testing.SafeTreeMap
 
floorPowerOfTwo(int) - Static method in class com.google.common.math.IntMath
Returns the largest power of two less than or equal to x.
floorPowerOfTwo(long) - Static method in class com.google.common.math.LongMath
Returns the largest power of two less than or equal to x.
floorPowerOfTwo(BigInteger) - Static method in class com.google.common.math.BigIntegerMath
Returns the largest power of two less than or equal to x.
FluentFuture<V> - Class in com.google.common.util.concurrent
A ListenableFuture that supports fluent chains of operations.
FluentFuture() - Constructor for class com.google.common.util.concurrent.FluentFuture
 
FluentFuture.TrustedFuture<V> - Class in com.google.common.util.concurrent
A less abstract subclass of AbstractFuture.
FluentIterable<E> - Class in com.google.common.collect
A discouraged (but not deprecated) precursor to Java's superior Stream library.
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() - Method in class com.google.common.testing.TestLogHandler
 
flush(Flushable, boolean) - Static method in class com.google.common.io.Flushables
Flush a Flushable, with control over whether an IOException may be thrown.
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.
FLV_VIDEO - Static variable in class com.google.common.net.MediaType
Flash video.
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.
fn(long, long) - Method in class com.google.common.hash.LongAdder
Version of plus for use in retryUpdate
fn(long, long) - Method in class com.google.common.hash.Striped64
Computes the function of current and new value.
FOLLOW_LINKS - Static variable in class com.google.common.io.MoreFiles.PathByteSource
 
FOLLOW_ONLY_WHEN_PRERENDER_SHOWN - Static variable in class com.google.common.net.HttpHeaders
The HTTP Follow-Only-When-Prerender-Shown header field name.
followLinks - Variable in class com.google.common.io.MoreFiles.PathByteSource
 
followLinks(OpenOption[]) - Static method in class com.google.common.io.MoreFiles.PathByteSource
 
FONT_COLLECTION - Static variable in class com.google.common.net.MediaType
A collection of font outlines as defined by RFC 8081.
FONT_OTF - Static variable in class com.google.common.net.MediaType
Open Type Font Format (OTF) as defined by RFC 8081.
FONT_SFNT - Static variable in class com.google.common.net.MediaType
FONT_TTF - Static variable in class com.google.common.net.MediaType
True Type Font Format (TTF) as defined by RFC 8081.
FONT_TYPE - Static variable in class com.google.common.net.MediaType
 
FONT_WOFF - Static variable in class com.google.common.net.MediaType
FONT_WOFF2 - Static variable in class com.google.common.net.MediaType
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
 
forAllPublicStaticMethods(Class<?>) - Method in class com.google.common.testing.ClassSanityTester
Returns an object responsible for performing sanity tests against the return values of all public static methods declared by cls, excluding superclasses.
forArray(T...) - Static method in class com.google.common.collect.Iterators
Returns an iterator containing the elements of array in order.
forArrayWithPosition(T[], int) - Static method in class com.google.common.collect.Iterators
Returns a list iterator containing the elements in the specified array in order, starting at the specified position.
forBoolean(boolean) - Static method in enum class com.google.common.collect.BoundType
Returns the bound type corresponding to a boolean value for inclusivity.
forceCopy - Variable in class com.google.common.collect.ImmutableSet.Builder
 
forceJdk() - Method in class com.google.common.collect.ImmutableSet.Builder
 
forCells(Iterable<Table.Cell<R, C, V>>) - Static method in class com.google.common.collect.RegularImmutableTable
 
forCells(List<Table.Cell<R, C, V>>, Comparator<? super R>, Comparator<? super C>) - 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
 
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(K, V) - Method in class com.google.common.collect.ImmutableBiMap
Deprecated.
Unsupported operation.
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
 
forcePut(V, K) - Method in class com.google.common.collect.HashBiMap.Inverse
 
forEach(SpliteratorTester.GeneralSpliterator<E>, Consumer<? super E>) - Method in enum class com.google.common.collect.testing.SpliteratorTester.SpliteratorDecompositionStrategy
 
forEach(BiConsumer<? super K, ? super V>) - Method in class com.google.common.collect.AbstractMapBasedMultimap
 
forEach(BiConsumer<? super K, ? super V>) - Method in class com.google.common.collect.CompactHashMap
 
forEach(BiConsumer<? super K, ? super V>) - Method in class com.google.common.collect.HashBiMap
 
forEach(BiConsumer<? super K, ? super V>) - Method in class com.google.common.collect.ImmutableEnumMap
 
forEach(BiConsumer<? super K, ? super V>) - Method in class com.google.common.collect.ImmutableMultimap
 
forEach(BiConsumer<? super K, ? super V>) - Method in class com.google.common.collect.ImmutableSortedMap
 
forEach(BiConsumer<? super K, ? super V>) - Method in class com.google.common.collect.JdkBackedImmutableMap
 
forEach(BiConsumer<? super K, ? super V>) - Method in class com.google.common.collect.Maps.AsMapView
 
forEach(BiConsumer<? super K, ? super V>) - Method in class com.google.common.collect.Maps.NavigableAsMapView
 
forEach(BiConsumer<? super K, ? super V>) - Method in interface com.google.common.collect.Multimap
Performs the given action for all key-value pairs contained in this multimap.
forEach(BiConsumer<? super K, ? super V>) - Method in class com.google.common.collect.Multimaps.UnmodifiableMultimap
 
forEach(BiConsumer<? super K, ? super V>) - Method in class com.google.common.collect.RegularImmutableBiMap
 
forEach(BiConsumer<? super K, ? super V>) - Method in class com.google.common.collect.RegularImmutableMap
 
forEach(BiConsumer<? super K, ? super V>) - Method in class com.google.common.collect.SingletonImmutableBiMap
 
forEach(BiConsumer<? super K, ? super V>) - Method in class com.google.common.collect.Synchronized.SynchronizedMap
 
forEach(BiConsumer<? super K, ? super V>) - Method in class com.google.common.collect.Synchronized.SynchronizedMultimap
 
forEach(BiConsumer<? super K, ? super V2>) - Method in class com.google.common.collect.Maps.TransformedEntriesMap
 
forEach(BiConsumer<? super V, ? super K>) - Method in class com.google.common.collect.HashBiMap.Inverse
 
forEach(BiConsumer<? super V, ? super K>) - Method in class com.google.common.collect.RegularImmutableBiMap.Inverse
 
forEach(Consumer<? super E>) - Method in class com.google.common.collect.Collections2.FilteredCollection
 
forEach(Consumer<? super E>) - Method in class com.google.common.collect.CompactHashSet
 
forEach(Consumer<? super E>) - Method in class com.google.common.collect.ImmutableEnumSet
 
forEach(Consumer<? super E>) - Method in class com.google.common.collect.ImmutableList
 
forEach(Consumer<? super E>) - Method in class com.google.common.collect.ImmutableSet.Indexed
 
forEach(Consumer<? super E>) - Method in class com.google.common.collect.IndexedImmutableSet
 
forEach(Consumer<? super E>) - Method in interface com.google.common.collect.Multiset
forEach(Consumer<? super E>) - Method in class com.google.common.collect.RegularImmutableAsList
 
forEach(Consumer<? super E>) - Method in class com.google.common.collect.RegularImmutableSortedSet
 
forEach(Consumer<? super E>) - Method in class com.google.common.collect.Sets.UnmodifiableNavigableSet
 
forEach(Consumer<? super E>) - Method in class com.google.common.collect.Synchronized.SynchronizedCollection
 
forEach(Consumer<? super Map.Entry<K, V>>) - Method in class com.google.common.collect.ImmutableMapEntrySet.RegularEntrySet
 
forEach(Consumer<? super Map.Entry<V, K>>) - Method in class com.google.common.collect.RegularImmutableBiMap.Inverse.InverseEntrySet
 
forEach(Consumer<? super K>) - Method in class com.google.common.collect.CompactHashMap.KeySetView
 
forEach(Consumer<? super K>) - Method in class com.google.common.collect.ImmutableMapKeySet
 
forEach(Consumer<? super K>) - Method in class com.google.common.collect.Maps.KeySet
 
forEach(Consumer<? super K>) - Method in class com.google.common.collect.Multimaps.Keys
 
forEach(Consumer<? super T>) - Method in class com.google.common.collect.Collections2.TransformedCollection
 
forEach(Consumer<? super T>) - Method in class com.google.common.collect.Iterables.UnmodifiableIterable
 
forEach(Consumer<? super V>) - Method in class com.google.common.collect.CompactHashMap.ValuesView
 
forEach(Consumer<? super V>) - Method in class com.google.common.collect.ImmutableMapValues
 
forEach(Consumer<? super V>) - Method in class com.google.common.collect.LinkedHashMultimap.ValueSet
 
forEach(Consumer<? super V>) - Method in class com.google.common.collect.Maps.Values
 
forEach(DoubleConsumer) - Method in class com.google.common.primitives.ImmutableDoubleArray
Invokes consumer for each value contained in this array, in order.
forEach(IntConsumer) - Method in class com.google.common.primitives.ImmutableIntArray
Invokes consumer for each value contained in this array, in order.
forEach(LongConsumer) - Method in class com.google.common.primitives.ImmutableLongArray
Invokes consumer for each value contained in this array, in order.
forEachEntry(Consumer<? super Map.Entry<K, V>>) - Method in class com.google.common.collect.Maps.IteratorBasedAbstractMap
 
forEachEntry(ObjIntConsumer<? super E>) - Method in class com.google.common.collect.AbstractMapBasedMultiset
 
forEachEntry(ObjIntConsumer<? super E>) - Method in class com.google.common.collect.EnumMultiset
 
forEachEntry(ObjIntConsumer<? super E>) - Method in interface com.google.common.collect.Multiset
Runs the specified action for each distinct element in this multiset, and the number of occurrences of that element.
forEachEntry(ObjIntConsumer<? super E>) - Method in class com.google.common.collect.RegularImmutableSortedMultiset
 
forEachEntry(ObjIntConsumer<? super E>) - Method in class com.google.common.collect.TreeMultiset
 
forEachLine(Consumer<? super String>) - Method in class com.google.common.io.CharSource
Reads all lines of text from this source, running the given action for each line as it is read.
forEachPair(Stream<A>, Stream<B>, BiConsumer<? super A, ? super B>) - Static method in class com.google.common.collect.Streams
Invokes consumer once for each pair of corresponding elements in streamA and streamB.
forEachRemaining(Consumer<? super E>) - Method in class com.google.common.collect.testing.SpliteratorTester.GeneralSpliterator
 
forEachRemaining(Consumer<? super E>) - Method in class com.google.common.collect.testing.SpliteratorTester.GeneralSpliteratorOfObject
 
forEachRemaining(Consumer<? super E>) - Method in class com.google.common.collect.testing.SpliteratorTester.GeneralSpliteratorOfPrimitive
 
forEachRemaining(Consumer<? super OutElementT>) - Method in class com.google.common.collect.CollectSpliterators.FlatMapSpliterator
 
forEachRemaining(OutConsumerT) - Method in class com.google.common.collect.CollectSpliterators.FlatMapSpliteratorOfPrimitive
 
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
 
forGraph(SuccessorsFunction<N>) - Static method in class com.google.common.graph.Traverser
Creates a new traverser for the given general graph.
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, ? 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.base.Functions
Returns a function which performs a map lookup.
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.cache.CacheBuilderSpec
 
format(String, Object...) - Static method in class com.google.common.collect.testing.Platform
 
format(String, Object...) - Static method in class com.google.common.collect.testing.testers.Platform
Format the template with args, only supports the placeholder %s.
format(String, Object...) - Static method in class com.google.common.util.concurrent.ThreadFactoryBuilder
 
formatCompact4Digits(double) - Static method in class com.google.common.base.Platform
 
formatFeatureSet(Set<? extends Feature<?>>) - Static method in class com.google.common.collect.testing.FeatureSpecificTestSuiteBuilder
 
formatIllegalArgumentException(String, Object...) - Static method in class com.google.common.net.InetAddresses
 
formatRuntimeException(String, Object...) - Static method in class com.google.common.testing.GcFinalization
 
forNaN() - Static method in class com.google.common.math.LinearTransformation
Builds an instance for datasets which contains Double.NaN.
forOrderedComponents(ImmutableList<Table.Cell<R, C, V>>, ImmutableSet<R>, ImmutableSet<C>) - Static method in class com.google.common.collect.RegularImmutableTable
A factory that chooses the most space-efficient representation of the table.
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.
ForPredicate(Predicate<? super Character>) - Constructor for class com.google.common.base.CharMatcher.ForPredicate
 
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 ignores its input and returns the result of supplier.get().
forTree(SuccessorsFunction<N>) - Static method in class com.google.common.graph.Traverser
Creates a new traverser for a directed acyclic graph that has at most one path from the start node(s) to any node reachable from the start node(s), and has no paths from any start node to any other start node, such as a tree or forest.
forTypeVariable(TypeVariable<?>) - Method in class com.google.common.reflect.TypeResolver.WildcardCapturer
 
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.
forUriStringOrNull(String, boolean) - Static method in class com.google.common.net.InetAddresses
 
forward - Variable in class com.google.common.collect.DescendingImmutableSortedMultiset
 
forward - Variable in class com.google.common.collect.DescendingImmutableSortedSet
 
forward - Variable in class com.google.common.collect.RegularImmutableBiMap.InverseSerializedForm
 
forward - Variable in class com.google.common.collect.Sets.DescendingSet
 
forward - Variable in class com.google.common.collect.testing.google.BiMapInverseTester.BiMapPair
 
forward() - Method in class com.google.common.collect.AbstractNavigableMap.DescendingMap
 
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
 
forwardDelegate - Variable in class com.google.common.collect.JdkBackedImmutableBiMap
 
FORWARDED - Static variable in class com.google.common.net.HttpHeaders
The HTTP Forwarded header field name.
forwardFunction - Variable in class com.google.common.base.Converter.FunctionBasedConverter
 
ForwardingBlockingDeque<E> - Class in com.google.common.collect
Deprecated.
This class has moved to com.google.common.util.concurrent. Please use ForwardingBlockingDeque instead.
ForwardingBlockingDeque<E> - Class in com.google.common.util.concurrent
A BlockingDeque which forwards all its method calls to another BlockingDeque.
ForwardingBlockingDeque() - Constructor for class com.google.common.collect.ForwardingBlockingDeque
Deprecated.
Constructor for use by subclasses.
ForwardingBlockingDeque() - Constructor for class com.google.common.util.concurrent.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 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.
Forwarding collections - Search tag in package com.google.common.collect
Section
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.
ForwardingCondition - Class in com.google.common.util.concurrent
Forwarding wrapper around a Condition.
ForwardingCondition() - Constructor for class com.google.common.util.concurrent.ForwardingCondition
 
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.
ForwardingFluentFuture<V> - Class in com.google.common.util.concurrent
FluentFuture that forwards all calls to a delegate.
ForwardingFluentFuture(ListenableFuture<V>) - Constructor for class com.google.common.util.concurrent.ForwardingFluentFuture
 
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.
ForwardingGraph<N> - Class in com.google.common.graph
A class to allow Graph implementations to be backed by a BaseGraph.
ForwardingGraph() - Constructor for class com.google.common.graph.ForwardingGraph
 
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 delegate.
ForwardingLock - Class in com.google.common.util.concurrent
Forwarding wrapper around a Lock.
ForwardingLock() - Constructor for class com.google.common.util.concurrent.ForwardingLock
 
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
ForwardingMap.StandardValues - Class in com.google.common.collect
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().
ForwardingNetwork<N,E> - Class in com.google.common.graph
A class to allow Network implementations to be backed by a provided delegate.
ForwardingNetwork() - Constructor for class com.google.common.graph.ForwardingNetwork
 
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.
ForwardingTestMapGenerator(TestMapGenerator<K, V>) - Constructor for class com.google.common.collect.testing.DerivedCollectionGenerators.ForwardingTestMapGenerator
 
ForwardingTestMultisetGenerator(TestMultisetGenerator<E>) - Constructor for class com.google.common.collect.testing.google.SortedMultisetTestSuiteBuilder.ForwardingTestMultisetGenerator
 
ForwardingTypeCollector(TypeToken.TypeCollector<K>) - Constructor for class com.google.common.reflect.TypeToken.TypeCollector.ForwardingTypeCollector
 
ForwardingValueGraph<N,V> - Class in com.google.common.graph
A class to allow ValueGraph implementations to be backed by a provided delegate.
ForwardingValueGraph() - Constructor for class com.google.common.graph.ForwardingValueGraph
 
ForwardingWrapperTester - Class in com.google.common.testing
Tester to ensure forwarding wrapper works by delegating calls to the corresponding method with the same parameters forwarded and return value forwarded back or exception propagated as is.
ForwardingWrapperTester() - Constructor for class com.google.common.testing.ForwardingWrapperTester
 
ForwardingWrapperTester.InteractionTester<T> - Class in com.google.common.testing
Tests a single interaction against a method.
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
 
foundAndRemovedExactReference(Iterable<E>, E) - Method in class com.google.common.collect.MinMaxPriorityQueue.QueueIterator
Returns true if an exact reference (==) was found and removed from the supplied iterable.
fpPattern() - Static method in class com.google.common.primitives.Doubles
 
Frameworks - Search tag in class com.google.common.util.concurrent.FluentFuture
Section
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.
FreshInvocationHandler(Class<?>) - Constructor for class com.google.common.testing.FreshValueGenerator.FreshInvocationHandler
 
freshness - Variable in class com.google.common.testing.FreshValueGenerator
 
FreshValueGenerator - Class in com.google.common.testing
Generates fresh instances of types that are different from each other (if possible).
FreshValueGenerator() - Constructor for class com.google.common.testing.FreshValueGenerator
 
FreshValueGenerator.Empty - Annotation Interface in com.google.common.testing
Annotates a method to generate the "empty" instance of a collection.
FreshValueGenerator.FreshInvocationHandler - Class in com.google.common.testing
 
FreshValueGenerator.Generates - Annotation Interface in com.google.common.testing
Annotates a method to be the instance generator of a certain type.
from - Variable in class com.google.common.collect.CollectSpliterators.FlatMapSpliterator
 
from - Variable in class com.google.common.collect.testing.DerivedCollectionGenerators.SortedMapSubmapTestMapGenerator
 
from - Variable in class com.google.common.collect.testing.DerivedCollectionGenerators.SortedSetSubsetTestSetGenerator
 
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 separate forward and backward functions.
from(Function<K, V>) - Static method in class com.google.common.cache.CacheLoader
Returns a cache loader that uses function to load keys, without supporting either reloading or bulk loading.
from(Supplier<V>) - Static method in class com.google.common.cache.CacheLoader
Returns a cache loader based on an existing supplier instance.
from(CacheBuilderSpec) - Static method in class com.google.common.cache.CacheBuilder
Constructs a new CacheBuilder instance with the settings specified in spec.
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(Ordering<T>) - Static method in class com.google.common.collect.Ordering
Deprecated.
no need to use this
from(Range<T>) - Static method in class com.google.common.collect.GeneralRange
Converts a Range to a GeneralRange.
from(Graph<N>) - Static method in class com.google.common.graph.GraphBuilder
Returns a GraphBuilder initialized with all properties queryable from graph.
from(Network<N, E>) - Static method in class com.google.common.graph.NetworkBuilder
Returns a NetworkBuilder initialized with all properties queryable from network.
from(ValueGraph<N, V>) - Static method in class com.google.common.graph.ValueGraphBuilder
Returns a ValueGraphBuilder initialized with all properties queryable from graph.
from(FluentFuture<V>) - Static method in class com.google.common.util.concurrent.FluentFuture
Deprecated.
no need to use this
from(ListenableFuture<V>) - Static method in class com.google.common.util.concurrent.ClosingFuture
Starts a ClosingFuture pipeline with a ListenableFuture.
from(ListenableFuture<V>) - Static method in class com.google.common.util.concurrent.FluentFuture
Converts the given ListenableFuture to an equivalent FluentFuture.
from(E[]) - Static method in class com.google.common.collect.FluentIterable
Returns a fluent iterable containing elements in the specified order.
from(ClassLoader) - Static method in class com.google.common.reflect.ClassPath
Returns a ClassPath representing all classes and resources loadable from classloader and its ancestor class loaders.
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(Constructor<T>) - Static method in class com.google.common.reflect.Invokable
Returns Invokable of constructor.
from(Method) - Static method in class com.google.common.reflect.Invokable
Returns Invokable of method.
from(String) - 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.net.HostSpecifier
Attempts to return a HostSpecifier for the given string, throwing an exception if parsing fails.
from(String) - Static method in class com.google.common.net.InternetDomainName
Returns an instance of InternetDomainName after lenient validation.
from(BitSet, String) - Static method in class com.google.common.base.SmallCharMatcher
 
from(Collection<? extends E>) - Static method in class com.google.common.collect.testing.MinimalSet
 
from(Collection<E>) - Static method in class com.google.common.collect.testing.MinimalIterable
Returns an iterable whose iterator returns the given elements in order.
from(Comparator<T>) - Static method in class com.google.common.collect.Ordering
Returns an ordering based on an existing comparator instance.
FROM - Static variable in class com.google.common.net.HttpHeaders
The HTTP From header field name.
FROM_DECLARATION_AND_TYPE_USE_ANNOTATIONS - Enum constant in enum class com.google.common.testing.NullPointerTester.NullnessAnnotationReader
 
FROM_DECLARATION_ANNOTATIONS_ONLY - Enum constant in enum class com.google.common.testing.NullPointerTester.NullnessAnnotationReader
 
fromArrayWithExpectedSize(E[], int) - Static method in class com.google.common.collect.ImmutableSet
 
fromBigInteger(BigInteger, boolean) - Static method in class com.google.common.net.InetAddresses
Converts a BigInteger to either an IPv4 or IPv6 address.
fromByteArray(byte[]) - Static method in class com.google.common.math.PairedStats
Creates a PairedStats instance from the given byte representation which was obtained by PairedStats.toByteArray().
fromByteArray(byte[]) - Static method in class com.google.common.math.Stats
Creates a Stats instance from the given byte representation which was obtained by Stats.toByteArray().
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) - 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}).
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}).
fromBytesNoCopy(byte[]) - Static method in class com.google.common.hash.HashCode
Creates a HashCode from a byte array.
fromCode(char) - Static method in enum class 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, Iterable<? extends Map.Entry<? extends K, ? extends V>>) - Static method in class com.google.common.collect.ImmutableSortedMap
Accepts a collection of possibly-null entries.
fromEntries(Comparator<? super K>, boolean, Map.Entry<K, V>[], int) - Static method in class com.google.common.collect.ImmutableSortedMap
 
fromEntries(Map.Entry<K, V>...) - Static method in class com.google.common.collect.ImmutableSortedMap
 
fromEntries(Map.Entry<K, V>...) - Static method in class com.google.common.collect.RegularImmutableBiMap
 
fromEntries(Map.Entry<K, V>...) - Static method in class com.google.common.collect.RegularImmutableMap
 
fromEntryArray(int, Map.Entry<K, V>[]) - Static method in class com.google.common.collect.RegularImmutableBiMap
 
fromEntryArray(int, Map.Entry<K, V>[], boolean) - Static method in class com.google.common.collect.RegularImmutableMap
Creates an ImmutableMap from the first n entries in entryArray.
fromEntryArrayCheckingBucketOverflow(int, Map.Entry<K, V>[], boolean) - Static method in class com.google.common.collect.RegularImmutableMap
 
fromHashers(Hasher[]) - Method in class com.google.common.hash.AbstractCompositeHashFunction
 
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.
fromIPv4BigInteger(BigInteger) - Static method in class com.google.common.net.InetAddresses
Returns the Inet4Address corresponding to a given BigInteger.
fromIPv6BigInteger(BigInteger) - Static method in class com.google.common.net.InetAddresses
Returns the Inet6Address corresponding to a given BigInteger.
FromIterableFunction() - Constructor for class com.google.common.collect.FluentIterable.FromIterableFunction
 
fromJavaUtil(Optional<T>) - Static method in class com.google.common.base.Optional
Returns the equivalent com.google.common.base.Optional value to the given java.util.Optional, or null if the argument is null.
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
 
fromMapBuilderEntries(Collection<? extends Map.Entry<K, ImmutableCollection.Builder<V>>>, Comparator<? super V>) - Static method in class com.google.common.collect.ImmutableListMultimap
Creates an ImmutableListMultimap from an asMap.entrySet.
fromMapBuilderEntries(Collection<? extends Map.Entry<K, ImmutableCollection.Builder<V>>>, Comparator<? super V>) - Static method in class com.google.common.collect.ImmutableSetMultimap
Creates an ImmutableSetMultimap from a map to builders.
fromMapEntries(Collection<? extends Map.Entry<? extends K, ? extends Collection<? extends V>>>, Comparator<? super V>) - Static method in class com.google.common.collect.ImmutableListMultimap
Creates an ImmutableListMultimap from an asMap.entrySet.
fromMapEntries(Collection<? extends Map.Entry<? extends K, ? extends Collection<? extends V>>>, Comparator<? super V>) - Static method in class com.google.common.collect.ImmutableSetMultimap
Creates an ImmutableSetMultimap from an asMap.entrySet.
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.
fromSpliterator - Variable in class com.google.common.collect.Streams.MapWithIndexSpliterator
 
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.
FRONT - Enum constant in enum class com.google.common.graph.Traverser.InsertionOrder
 
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.
fullFingerprint(byte[], int, int) - Static method in class com.google.common.hash.Fingerprint2011
 
fullyFailedFuture(Throwable) - Method in class com.google.common.cache.LocalCache.LoadingValueReference
 
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.CollectSpliterators.FlatMapSpliterator
 
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.AbstractTransformFuture
 
Function<F,T> - Interface in com.google.common.base
Legacy version of java.util.function.Function.
FunctionalEquivalence<F,T> - Class in com.google.common.base
Equivalence applied on functional result.
FunctionalEquivalence(Function<? super 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 - Variable in class com.google.common.hash.AbstractCompositeHashFunction
 
Functions - Class in com.google.common.base
Static utility methods pertaining to com.google.common.base.Function instances; see that class for information about migrating to java.util.function.
Functions() - Constructor for class com.google.common.base.Functions
 
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 Class in com.google.common.base
 
Functions.PredicateFunction<T> - Class in com.google.common.base
 
Functions.SupplierFunction<F,T> - Class in com.google.common.base
 
Functions.ToStringFunction - Enum Class in com.google.common.base
 
FunctionToCacheLoader(Function<K, V>) - Constructor for class com.google.common.cache.CacheLoader.FunctionToCacheLoader
 
Function types - Search tag in package com.google.common.base
Section
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(byte[], PrimitiveSink) - Method in enum class com.google.common.hash.Funnels.ByteArrayFunnel
 
funnel(CharSequence, PrimitiveSink) - Method in class com.google.common.hash.Funnels.StringCharsetFunnel
 
funnel(CharSequence, PrimitiveSink) - Method in enum class com.google.common.hash.Funnels.UnencodedCharsFunnel
 
funnel(Integer, PrimitiveSink) - Method in enum class com.google.common.hash.Funnels.IntegerFunnel
 
funnel(Iterable<? extends E>, PrimitiveSink) - Method in class com.google.common.hash.Funnels.SequentialFunnel
 
funnel(Long, PrimitiveSink) - Method in enum class com.google.common.hash.Funnels.LongFunnel
 
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<T> - Interface in com.google.common.hash
An object which can send data from an object of type T into a PrimitiveSink.
Funnels - Class in com.google.common.hash
Funnels for common types.
Funnels() - Constructor for class com.google.common.hash.Funnels
 
Funnels.ByteArrayFunnel - Enum Class in com.google.common.hash
 
Funnels.IntegerFunnel - Enum Class in com.google.common.hash
 
Funnels.LongFunnel - Enum Class 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 Class in com.google.common.hash
 
Further reading - Search tag in class com.google.common.collect.Range
Section
future - Variable in class com.google.common.util.concurrent.AbstractFuture.SetFuture
 
future - Variable in class com.google.common.util.concurrent.ClosingFuture
 
future - Variable in class com.google.common.util.concurrent.Futures.CallbackListener
 
future - Variable in class com.google.common.util.concurrent.testing.AbstractListenableFutureTest
 
future - Variable in class com.google.common.util.concurrent.testing.MockFutureListener
 
future1 - Variable in class com.google.common.util.concurrent.ClosingFuture.Combiner2
 
future1 - Variable in class com.google.common.util.concurrent.ClosingFuture.Combiner3
 
future1 - Variable in class com.google.common.util.concurrent.ClosingFuture.Combiner4
 
future1 - Variable in class com.google.common.util.concurrent.ClosingFuture.Combiner5
 
future2 - Variable in class com.google.common.util.concurrent.ClosingFuture.Combiner2
 
future2 - Variable in class com.google.common.util.concurrent.ClosingFuture.Combiner3
 
future2 - Variable in class com.google.common.util.concurrent.ClosingFuture.Combiner4
 
future2 - Variable in class com.google.common.util.concurrent.ClosingFuture.Combiner5
 
future3 - Variable in class com.google.common.util.concurrent.ClosingFuture.Combiner3
 
future3 - Variable in class com.google.common.util.concurrent.ClosingFuture.Combiner4
 
future3 - Variable in class com.google.common.util.concurrent.ClosingFuture.Combiner5
 
future4 - Variable in class com.google.common.util.concurrent.ClosingFuture.Combiner4
 
future4 - Variable in class com.google.common.util.concurrent.ClosingFuture.Combiner5
 
future5 - Variable in class com.google.common.util.concurrent.ClosingFuture.Combiner5
 
FutureAsCancellable(Future<?>) - Constructor for class com.google.common.util.concurrent.AbstractScheduledService.FutureAsCancellable
 
FutureCallback<V> - Interface in com.google.common.util.concurrent
A callback for accepting the results of a Future computation asynchronously.
futureCombiner() - Method in class com.google.common.util.concurrent.ClosingFuture.Combiner
 
FutureCombiner(boolean, ImmutableList<ListenableFuture<? extends V>>) - Constructor for class com.google.common.util.concurrent.Futures.FutureCombiner
 
futures - Variable in class com.google.common.util.concurrent.AggregateFuture
The input futures.
futures - Variable in class com.google.common.util.concurrent.ClosingFuture.Peeker
 
futures - Variable in class com.google.common.util.concurrent.Futures.FutureCombiner
 
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.CallbackListener<V> - Class in com.google.common.util.concurrent
Futures.FutureCombiner<V> - Class in com.google.common.util.concurrent
A helper to create a new ListenableFuture whose result is generated from a combination of input futures.
Futures.InCompletionOrderFuture<T> - Class in com.google.common.util.concurrent
 
Futures.InCompletionOrderState<T> - Class in com.google.common.util.concurrent
 
Futures.NonCancellationPropagatingFuture<V> - Class in com.google.common.util.concurrent
A wrapped future that does not propagate cancellation to its delegate.
FuturesGetChecked - Class in com.google.common.util.concurrent
Static methods used to implement Futures.getChecked(Future, Class).
FuturesGetChecked() - Constructor for class com.google.common.util.concurrent.FuturesGetChecked
 
FuturesGetChecked.GetCheckedTypeValidator - Interface in com.google.common.util.concurrent
 
FuturesGetChecked.GetCheckedTypeValidatorHolder - Class in com.google.common.util.concurrent
Provides a check of whether an exception type is valid for use with FuturesGetChecked.getChecked(Future, Class), possibly using caching.
FuturesGetChecked.GetCheckedTypeValidatorHolder.ClassValueValidator - Enum Class in com.google.common.util.concurrent
 
FuturesGetChecked.GetCheckedTypeValidatorHolder.WeakSetValidator - Enum 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
 
gap(Range<C>) - Method in class com.google.common.collect.Range
Returns the maximal range lying between this range and otherRange, if such a range exists.
gasListeners(AbstractFuture<?>, AbstractFuture.Listener) - Method in class com.google.common.util.concurrent.AbstractFuture.AtomicHelper
Performs a GAS operation on the AbstractFuture.listeners field.
gasListeners(AbstractFuture<?>, AbstractFuture.Listener) - Method in class com.google.common.util.concurrent.AbstractFuture.SafeAtomicHelper
Performs a GAS operation on the AbstractFuture.listeners field.
gasListeners(AbstractFuture<?>, AbstractFuture.Listener) - Method in class com.google.common.util.concurrent.AbstractFuture.SynchronizedHelper
Performs a GAS operation on the AbstractFuture.listeners field.
gasListeners(AbstractFuture<?>, AbstractFuture.Listener) - Method in class com.google.common.util.concurrent.AbstractFuture.UnsafeAtomicHelper
Performs a GAS operation on the AbstractFuture.listeners field.
gasWaiters(AbstractFuture<?>, AbstractFuture.Waiter) - Method in class com.google.common.util.concurrent.AbstractFuture.AtomicHelper
Performs a GAS operation on the AbstractFuture.waiters field.
gasWaiters(AbstractFuture<?>, AbstractFuture.Waiter) - Method in class com.google.common.util.concurrent.AbstractFuture.SafeAtomicHelper
Performs a GAS operation on the AbstractFuture.waiters field.
gasWaiters(AbstractFuture<?>, AbstractFuture.Waiter) - Method in class com.google.common.util.concurrent.AbstractFuture.SynchronizedHelper
Performs a GAS operation on the AbstractFuture.waiters field.
gasWaiters(AbstractFuture<?>, AbstractFuture.Waiter) - Method in class com.google.common.util.concurrent.AbstractFuture.UnsafeAtomicHelper
Performs a GAS operation on the AbstractFuture.waiters field.
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.
GcFinalization - Class in com.google.common.testing
Testing utilities relating to garbage collection finalization.
GcFinalization() - Constructor for class com.google.common.testing.GcFinalization
 
GcFinalization.FinalizationPredicate - Interface in com.google.common.testing
A predicate that is expected to return true subsequent to finalization, that is, one of the following actions taken by the garbage collector when performing a full collection in response to System.gc(): invoking the finalize methods of unreachable objects clearing weak references to unreachable referents enqueuing weak references to unreachable referents in their reference queue
gen - Variable in class com.google.common.collect.testing.CollectionTestSuiteBuilder.ReserializedCollectionGenerator
 
gen - Variable in class com.google.common.collect.testing.google.MultisetTestSuiteBuilder.ElementSetGenerator
 
gen - Variable in class com.google.common.collect.testing.google.MultisetTestSuiteBuilder.EntrySetGenerator
 
gen - Variable in class com.google.common.collect.testing.google.MultisetTestSuiteBuilder.ReserializedMultisetGenerator
 
gen - Variable in class com.google.common.collect.testing.ListTestSuiteBuilder.ReserializedListGenerator
 
gen - Variable in class com.google.common.collect.testing.SetTestSuiteBuilder.ReserializedSetGenerator
 
GENERAL_PURPOSE - Enum constant in enum class com.google.common.collect.testing.features.CollectionFeature
Features supported by general-purpose collections - everything but CollectionFeature.RESTRICTS_ELEMENTS.
GENERAL_PURPOSE - Enum constant in enum class com.google.common.collect.testing.features.ListFeature
 
GENERAL_PURPOSE - Enum constant in enum class com.google.common.collect.testing.features.MapFeature
 
GENERAL_PURPOSE - Enum constant in enum class com.google.common.collect.testing.features.SetFeature
 
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
 
GeneralSpliterator(Spliterator<E>) - Constructor for class com.google.common.collect.testing.SpliteratorTester.GeneralSpliterator
 
GeneralSpliteratorOfObject(Spliterator<E>) - Constructor for class com.google.common.collect.testing.SpliteratorTester.GeneralSpliteratorOfObject
 
GeneralSpliteratorOfPrimitive(Spliterator.OfPrimitive<E, C, S>, Function<Consumer<? super E>, C>) - Constructor for class com.google.common.collect.testing.SpliteratorTester.GeneralSpliteratorOfPrimitive
 
General static utilities - Search tag in package com.google.common.primitives
Section
generate(TypeToken<?>) - Method in class com.google.common.testing.FreshValueGenerator
Generates an instance for type using the current FreshValueGenerator.freshness.
GENERATE_CANCELLATION_CAUSES - Static variable in class com.google.common.util.concurrent.AbstractFuture
 
generateArrayList(E) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateArrayListMultimap(K, V) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateBigDecimal() - Method in class com.google.common.testing.FreshValueGenerator
 
generateBigInteger() - Method in class com.google.common.testing.FreshValueGenerator
 
generateBimap(K, V) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateBoolean() - Method in class com.google.common.testing.FreshValueGenerator
 
generateBooleanObject() - Method in class com.google.common.testing.FreshValueGenerator
 
generateBuffer() - Method in class com.google.common.testing.FreshValueGenerator
 
generateByte() - Method in class com.google.common.testing.FreshValueGenerator
 
generateByteArrayInputStream() - Static method in class com.google.common.testing.FreshValueGenerator
 
generateByteBuffer() - Method in class com.google.common.testing.FreshValueGenerator
 
generateByteObject() - Method in class com.google.common.testing.FreshValueGenerator
 
generateChar() - Method in class com.google.common.testing.FreshValueGenerator
 
generateCharacter() - Method in class com.google.common.testing.FreshValueGenerator
 
generateCharBuffer() - Method in class com.google.common.testing.FreshValueGenerator
 
generateCharMatcher() - Method in class com.google.common.testing.FreshValueGenerator
 
generateCharSequence() - Method in class com.google.common.testing.FreshValueGenerator
 
generateCharset() - Method in class com.google.common.testing.FreshValueGenerator
 
generateClass() - Method in class com.google.common.testing.FreshValueGenerator
 
generateCollection(E) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateComparable() - Method in class com.google.common.testing.FreshValueGenerator
 
generateComparator() - Method in class com.google.common.testing.FreshValueGenerator
 
generateConcurrentMap() - Static method in class com.google.common.testing.FreshValueGenerator
 
generateConcurrentMap(K, V) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateCurrency() - Method in class com.google.common.testing.FreshValueGenerator
 
generateDouble() - Method in class com.google.common.testing.FreshValueGenerator
 
generateDoubleBuffer() - Method in class com.google.common.testing.FreshValueGenerator
 
generateDoubleObject() - Method in class com.google.common.testing.FreshValueGenerator
 
generateDummyArg(Parameter, FreshValueGenerator) - Static method in class com.google.common.testing.ClassSanityTester
 
generateEqualFactoryArguments(Invokable<?, ?>, List<Parameter>, List<Object>) - Method in class com.google.common.testing.ClassSanityTester
Returns dummy factory arguments that are equal to args but may be different instances, to be used to construct a second instance of the same equality group.
generateEquivalence() - Method in class com.google.common.testing.FreshValueGenerator
 
generateFile() - Method in class com.google.common.testing.FreshValueGenerator
 
generateFloat() - Method in class com.google.common.testing.FreshValueGenerator
 
generateFloatBuffer() - Method in class com.google.common.testing.FreshValueGenerator
 
generateFloatObject() - Method in class com.google.common.testing.FreshValueGenerator
 
generateFresh(TypeToken<?>) - Method in class com.google.common.testing.FreshValueGenerator
Returns a fresh instance for type if possible.
generateFresh(Class<T>) - Method in class com.google.common.testing.FreshValueGenerator
 
generateGoogleOptional() - Method in class com.google.common.testing.FreshValueGenerator
 
generateGoogleOptional(T) - Method in class com.google.common.testing.FreshValueGenerator
 
generateHashBasedTable(R, C, V) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateHashBiMap(K, V) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateHashdMap(K, V) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateHashMultimap(K, V) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateHashMultiset(E) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateHashSet(E) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateImmutableBimap(K, V) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateImmutableCollection(E) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateImmutableList(E) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateImmutableListMultimap(K, V) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateImmutableMap(K, V) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateImmutableMultimap(K, V) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateImmutableMultiset(E) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateImmutableSet(E) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateImmutableSetMultimap(K, V) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateImmutableSortedMap(K, V) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateImmutableSortedMultiset(E) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateImmutableSortedSet(E) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateImmutableTable(R, C, V) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateInputStream() - Static method in class com.google.common.testing.FreshValueGenerator
 
generateInt() - Method in class com.google.common.testing.FreshValueGenerator
 
generateIntBuffer() - Method in class com.google.common.testing.FreshValueGenerator
 
generateInteger() - Method in class com.google.common.testing.FreshValueGenerator
 
generateIterable(E) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateJavaOptional() - Method in class com.google.common.testing.FreshValueGenerator
 
generateJavaOptional(T) - Method in class com.google.common.testing.FreshValueGenerator
 
generateJoiner() - Method in class com.google.common.testing.FreshValueGenerator
 
generateLinkedHashMap(K, V) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateLinkedHashMultimap(K, V) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateLinkedHashMultiset(E) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateLinkedHashSet(E) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateLinkedList(E) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateList(E) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateListMultimap(K, V) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateLocale() - Method in class com.google.common.testing.FreshValueGenerator
 
generateLong() - Method in class com.google.common.testing.FreshValueGenerator
 
generateLongBuffer() - Method in class com.google.common.testing.FreshValueGenerator
 
generateLongObject() - Method in class com.google.common.testing.FreshValueGenerator
 
generateMap(K, V) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateMultimap(K, V) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateMultiset(E) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateNavigableMap(K, V) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateNavigableSet(E) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateNumber() - Method in class com.google.common.testing.FreshValueGenerator
 
generateObject() - Method in class com.google.common.testing.FreshValueGenerator
 
generateOptionalDouble() - Method in class com.google.common.testing.FreshValueGenerator
 
generateOptionalInt() - Method in class com.google.common.testing.FreshValueGenerator
 
generateOptionalLong() - Method in class com.google.common.testing.FreshValueGenerator
 
generateOrdering() - Method in class com.google.common.testing.FreshValueGenerator
 
generatePattern() - Method in class com.google.common.testing.FreshValueGenerator
 
generateRange() - Static method in class com.google.common.testing.FreshValueGenerator
 
generateRange(C) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateReadable() - Method in class com.google.common.testing.FreshValueGenerator
 
generateReader() - Method in class com.google.common.testing.FreshValueGenerator
 
generateRowSortedTable(R, C, V) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateSet(E) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateSetMultimap(K, V) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateShort() - Method in class com.google.common.testing.FreshValueGenerator
 
generateShortBuffer() - Method in class com.google.common.testing.FreshValueGenerator
 
generateShortObject() - Method in class com.google.common.testing.FreshValueGenerator
 
generateSortedMap(K, V) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateSortedMultiset(E) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateSortedSet(E) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateSplitter() - Method in class com.google.common.testing.FreshValueGenerator
 
generateString() - Method in class com.google.common.testing.FreshValueGenerator
 
generateStringReader() - Method in class com.google.common.testing.FreshValueGenerator
 
generateTable(R, C, V) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateTicker() - Method in class com.google.common.testing.FreshValueGenerator
 
generateTreeBasedTable(R, C, V) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateTreeMap(K, V) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateTreeMultiset(E) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateTreeSet(E) - Static method in class com.google.common.testing.FreshValueGenerator
 
generateTypeToken() - Method in class com.google.common.testing.FreshValueGenerator
 
generateUnsignedInteger() - Method in class com.google.common.testing.FreshValueGenerator
 
generateUnsignedLong() - Method in class com.google.common.testing.FreshValueGenerator
 
generator - Variable in class com.google.common.collect.testing.google.DerivedGoogleCollectionGenerators.InverseBiMapGenerator
 
generator - Variable in class com.google.common.collect.testing.google.DerivedGoogleCollectionGenerators.MapGenerator
 
generator - Variable in class com.google.common.collect.testing.OneSizeGenerator
 
GENERATORS - Static variable in class com.google.common.testing.FreshValueGenerator
 
GenericArrayTypeImpl(Type) - Constructor for class com.google.common.reflect.Types.GenericArrayTypeImpl
 
genericDeclaration - Variable in class com.google.common.reflect.Types.TypeVariableImpl
 
GEO_JSON - Static variable in class com.google.common.net.MediaType
Media type for the GeoJSON Format, a geospatial data interchange format based on JSON.
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.NonSerializableMemoizingSupplier
 
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() - Method in class com.google.common.cache.LocalCache.LoadingValueReference
 
get() - Method in class com.google.common.cache.LocalCache.StrongValueReference
 
get() - Method in interface com.google.common.cache.LocalCache.ValueReference
Returns the value.
get() - Method in class com.google.common.collect.Count
 
get() - Method in class com.google.common.collect.HashBasedTable.Factory
 
get() - Method in interface com.google.common.collect.MapMakerInternalMap.WeakValueReference
Returns the current value being referenced, or null if there is none (e.g.
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 class com.google.common.collect.MultimapBuilder.LinkedListSupplier
 
get() - Method in class com.google.common.collect.MultimapBuilder.TreeSetSupplier
 
get() - Method in class com.google.common.collect.testing.DerivedTestIteratorGenerator
 
get() - Method in interface com.google.common.collect.testing.TestIteratorGenerator
 
get() - Method in class com.google.common.collect.TreeBasedTable.Factory
 
get() - Method in class com.google.common.collect.TreeMultiset.Reference
 
get() - Method in interface com.google.common.io.TempFileCreator.JavaNioCreator.PermissionSupplier
 
get() - Method in class com.google.common.util.concurrent.AbstractFuture
get() - Method in class com.google.common.util.concurrent.AbstractFuture.TrustedFuture
 
get() - Method in class com.google.common.util.concurrent.AbstractIdleService.ThreadNameSupplier
 
get() - Method in class com.google.common.util.concurrent.AtomicDouble
Gets the current value.
get() - Method in class com.google.common.util.concurrent.ClosingFuture.ValueAndCloser
Returns the final value of the associated ClosingFuture, or throws an exception as Future.get() would.
get() - Method in class com.google.common.util.concurrent.FluentFuture.TrustedFuture
 
get() - Method in class com.google.common.util.concurrent.ForwardingFluentFuture
 
get() - Method in class com.google.common.util.concurrent.ForwardingFuture
 
get() - Method in class com.google.common.util.concurrent.ImmediateFuture
 
get() - Method in class com.google.common.util.concurrent.LazyLogger
 
get(int) - Method in class com.google.common.collect.AbstractIndexedListIterator
Returns the element with the specified index.
get(int) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedList
 
get(int) - Method in class com.google.common.collect.CartesianList
 
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(int) - Method in class com.google.common.collect.ImmutableList.ReverseImmutableList
 
get(int) - Method in class com.google.common.collect.ImmutableList.SubList
 
get(int) - Method in class com.google.common.collect.ImmutableMapKeySet
 
get(int) - Method in class com.google.common.collect.ImmutableMultiset.ElementSet
 
get(int) - Method in class com.google.common.collect.ImmutableMultiset.EntrySet
 
get(int) - Method in class com.google.common.collect.ImmutableRangeSet.ComplementRanges
 
get(int) - Method in class com.google.common.collect.ImmutableSet.Indexed
 
get(int) - Method in class com.google.common.collect.IndexedImmutableSet
 
get(int) - Method in class com.google.common.collect.Iterators.ArrayItr
 
get(int) - Method in class com.google.common.collect.JdkBackedImmutableBiMap.InverseEntries
 
get(int) - Method in class com.google.common.collect.JdkBackedImmutableSet
 
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(int) - Method in class com.google.common.collect.RegularImmutableAsList
 
get(int) - Method in class com.google.common.collect.RegularImmutableList
 
get(int) - Method in class com.google.common.collect.RegularImmutableMap.KeySet
 
get(int) - Method in class com.google.common.collect.RegularImmutableMap.Values
 
get(int) - Method in class com.google.common.collect.RegularImmutableTable.CellSet
 
get(int) - Method in class com.google.common.collect.RegularImmutableTable.Values
 
get(int) - Method in class com.google.common.collect.SingletonImmutableList
 
get(int) - Method in class com.google.common.collect.Synchronized.SynchronizedList
 
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.ImmutableDoubleArray.AsList
 
get(int) - Method in class com.google.common.primitives.ImmutableDoubleArray
Returns the double value present at the given index.
get(int) - Method in class com.google.common.primitives.ImmutableIntArray.AsList
 
get(int) - Method in class com.google.common.primitives.ImmutableIntArray
Returns the int value present at the given index.
get(int) - Method in class com.google.common.primitives.ImmutableLongArray.AsList
 
get(int) - Method in class com.google.common.primitives.ImmutableLongArray
Returns the long value present at the given index.
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(int) - Method in class com.google.common.util.concurrent.AtomicDoubleArray
Gets the current value at position i.
get(long) - Method in class com.google.common.hash.BloomFilterStrategies.LockFreeBitArray
 
get(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractFuture
get(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractFuture.TrustedFuture
 
get(long, TimeUnit) - Method in class com.google.common.util.concurrent.FluentFuture.TrustedFuture
 
get(long, TimeUnit) - Method in class com.google.common.util.concurrent.ForwardingFluentFuture
 
get(long, TimeUnit) - Method in class com.google.common.util.concurrent.ForwardingFuture
 
get(long, TimeUnit) - Method in class com.google.common.util.concurrent.ImmediateFuture
 
get(long, TimeUnit) - Method in class com.google.common.util.concurrent.ListenableFutureTask
 
get(long, TimeUnit) - Method in class com.google.common.util.concurrent.testing.SameThreadScheduledExecutorService.ImmediateScheduledFuture
 
get(Class<T>) - Static method in class com.google.common.testing.ArbitraryInstances
Returns an arbitrary instance for type, or null if no arbitrary instance can be determined.
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(Iterable<T>, int) - Static method in class com.google.common.collect.Iterables
Returns the element at the specified position in an iterable.
get(Object) - Method in class com.google.common.cache.LocalCache
 
get(Object) - Method in class com.google.common.collect.AbstractMapBasedMultimap.AsMap
 
get(Object) - Method in class com.google.common.collect.AbstractNavigableMap
 
get(Object) - Method in class com.google.common.collect.ArrayTable.ArrayMap
 
get(Object) - Method in class com.google.common.collect.CompactHashMap
 
get(Object) - Method in class com.google.common.collect.DenseImmutableTable.ImmutableArrayMap
 
get(Object) - Method in class com.google.common.collect.FilteredEntryMultimap.AsMap
 
get(Object) - Method in class com.google.common.collect.ForwardingMap
 
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(Object) - Method in class com.google.common.collect.ImmutableMap
 
get(Object) - Method in class com.google.common.collect.ImmutableMap.MapViewOfValuesAsSingletonSets
 
get(Object) - Method in class com.google.common.collect.ImmutableSortedMap
 
get(Object) - Method in class com.google.common.collect.JdkBackedImmutableBiMap
 
get(Object) - Method in class com.google.common.collect.JdkBackedImmutableMap
 
get(Object) - Method in class com.google.common.collect.MapMakerInternalMap
 
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(Object) - Method in class com.google.common.collect.Multimaps.AsMap
 
get(Object) - Method in class com.google.common.collect.RegularImmutableBiMap
 
get(Object) - Method in class com.google.common.collect.RegularImmutableBiMap.Inverse
 
get(Object) - Method in class com.google.common.collect.RegularImmutableMap
 
get(Object) - Method in class com.google.common.collect.SingletonImmutableBiMap
 
get(Object) - Method in class com.google.common.collect.StandardTable.Column
 
get(Object) - Method in class com.google.common.collect.StandardTable.ColumnMap
 
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(Object) - Method in class com.google.common.collect.Synchronized.SynchronizedMap
 
get(Object) - Method in class com.google.common.collect.testing.SafeTreeMap
 
get(Object) - Method in class com.google.common.collect.TreeRangeMap.AsMapOfRanges
 
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(Object) - Method in class com.google.common.graph.MapIteratorCache
 
get(Object) - Method in class com.google.common.graph.MapRetrievalCache
 
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
 
get(Object, int) - Method in class com.google.common.cache.LocalCache.Segment
 
get(Object, int) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
 
get(Object, ImmutableMapEntry<?, V>[], int) - Static method in class com.google.common.collect.RegularImmutableMap
 
get(Object, Object) - Method in class com.google.common.collect.AbstractTable
 
get(Object, Object) - Method in class com.google.common.collect.ArrayTable
 
get(Object, Object) - Method in class com.google.common.collect.DenseImmutableTable
 
get(Object, Object) - Method in class com.google.common.collect.ForwardingTable
 
get(Object, Object) - Method in class com.google.common.collect.StandardTable
 
get(Object, Object) - Method in class com.google.common.collect.Synchronized.SynchronizedTable
 
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(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(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<T>, int) - Static method in class com.google.common.collect.testing.Helpers
 
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(K) - Method in class com.google.common.cache.LocalCache.LoadingSerializationProxy
 
get(K) - Method in class com.google.common.cache.LocalCache.LocalLoadingCache
 
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(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(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(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(K) - Method in class com.google.common.collect.ForwardingListMultimap
 
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(K) - Method in class com.google.common.collect.ImmutableListMultimap
Returns an immutable list of the values for the given key.
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(K) - Method in class com.google.common.collect.ImmutableSetMultimap
Returns an immutable set of the values for the given key.
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(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(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(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(K) - Method in interface com.google.common.collect.SortedSetMultimap
Returns a collection view of all values associated with a key.
get(K) - Method in class com.google.common.collect.Synchronized.SynchronizedListMultimap
 
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(K) - Method in class com.google.common.collect.testing.AbstractMapTester
Wrapper for Map.get(Object) that forces the caller to pass in a key of the same type as the map.
get(K) - Method in class com.google.common.collect.TreeMultimap
 
get(K) - Method in class com.google.common.collect.TreeRangeMap
 
get(K) - Method in class com.google.common.collect.TreeRangeMap.SubRangeMap
 
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(K, int, CacheLoader<? super K, V>) - Method in class com.google.common.cache.LocalCache.Segment
 
get(K, CacheLoader<? super K, V>) - Method in class com.google.common.cache.LocalCache
 
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 loader if necessary.
get(K, Callable<? extends V>) - Method in class com.google.common.cache.ForwardingCache
 
get(K, Callable<? extends V>) - Method in class com.google.common.cache.LocalCache.LocalManualCache
 
GET_FEATURE_MAP - Static variable in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder
 
get6to4IPv4Address(Inet6Address) - Static method in class com.google.common.net.InetAddresses
Returns the IPv4 address embedded in a 6to4 address.
getAbsentFeatures() - Method in class com.google.common.collect.testing.features.TesterRequirements
 
getAccessTime() - Method in class com.google.common.cache.LocalCache.AbstractReferenceEntry
 
getAccessTime() - Method in enum class com.google.common.cache.LocalCache.NullEntry
 
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
 
getAccessTime() - Method in interface com.google.common.cache.ReferenceEntry
Returns the time that this entry was last accessed, in ns.
getActualTypeArguments() - Method in class com.google.common.reflect.Types.ParameterizedTypeImpl
 
getAddAllNullUnsupportedMethod() - Static method in class com.google.common.collect.testing.testers.CollectionAddAllTester
Returns the Method instance for CollectionAddAllTester.testAddAll_nullUnsupported() so that tests can suppress it with FeatureSpecificTestSuiteBuilder.suppressing() until Sun bug 5045147 is fixed.
getAddAllUnsupportedNonePresentMethod() - Static method in class com.google.common.collect.testing.testers.CollectionAddAllTester
Returns the Method instance for CollectionAddAllTester.testAddAll_unsupportedNonePresent() so that tests can suppress it with FeatureSpecificTestSuiteBuilder.suppressing() while we figure out what to do with ConcurrentHashMap support for entrySet().add().
getAddAllUnsupportedSomePresentMethod() - Static method in class com.google.common.collect.testing.testers.CollectionAddAllTester
Returns the Method instance for CollectionAddAllTester.testAddAll_unsupportedSomePresent() so that tests can suppress it with FeatureSpecificTestSuiteBuilder.suppressing() while we figure out what to do with ConcurrentHashMap support for entrySet().add().
getAddNullSupportedMethod() - Static method in class com.google.common.collect.testing.testers.CollectionAddTester
Returns the Method instance for CollectionAddTester.testAdd_nullSupported() so that tests of Collections.checkedCollection(java.util.Collection, Class) can suppress it with FeatureSpecificTestSuiteBuilder.suppressing() until Sun bug 6409434 is fixed.
getAddNullSupportedMethod() - Static method in class com.google.common.collect.testing.testers.ListAddAtIndexTester
Returns the Method instance for ListAddAtIndexTester.testAddAtIndex_nullSupported() so that tests can suppress it.
getAddNullUnsupportedMethod() - Static method in class com.google.common.collect.testing.testers.CollectionAddTester
Returns the Method instance for CollectionAddTester.testAdd_nullSupported() so that tests of TreeSet can suppress it with FeatureSpecificTestSuiteBuilder.suppressing() until Sun bug 5045147 is fixed.
getAddSupportedNullPresentMethod() - Static method in class com.google.common.collect.testing.testers.ListAddTester
Returns the Method instance for ListAddTester.testAdd_supportedNullPresent() so that tests can suppress it.
getAddSupportedNullPresentMethod() - Static method in class com.google.common.collect.testing.testers.SetAddTester
Returns the Method instance for SetAddTester.testAdd_supportedNullPresent() so that tests can suppress it.
getAddUnsupportedNotPresentMethod() - Static method in class com.google.common.collect.testing.testers.CollectionAddTester
Returns the Method instance for CollectionAddTester.testAdd_unsupportedNotPresent() so that tests can suppress it with FeatureSpecificTestSuiteBuilder.suppressing() while we figure out what to do with ConcurrentHashMap support for entrySet().add().
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.LocalCache
 
getAllPresent(Iterable<?>) - Method in class com.google.common.cache.LocalCache.LocalManualCache
 
getAllPresent(Iterable<? extends Object>) - Method in class com.google.common.cache.AbstractCache
Returns a map of the values associated with keys in this cache.
getAllPresent(Iterable<? extends Object>) - Method in interface com.google.common.cache.Cache
Returns a map of the values associated with keys in this cache.
getAllPresent(Iterable<? extends Object>) - Method in class com.google.common.cache.ForwardingCache
 
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
 
getAndAccumulate(double, DoubleBinaryOperator) - Method in class com.google.common.util.concurrent.AtomicDouble
Atomically updates the current value with the results of applying the given function to the current and given values.
getAndAccumulate(int, double, DoubleBinaryOperator) - Method in class com.google.common.util.concurrent.AtomicDoubleArray
Atomically updates the element at index i with the results of applying the given function to the current and given values.
getAndAccumulate(K, long, LongBinaryOperator) - Method in class com.google.common.util.concurrent.AtomicLongMap
Updates the value currently associated with key by combining it with x via the specified accumulator function, returning the old value.
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(double) - Method in class com.google.common.util.concurrent.AtomicDouble
Atomically sets to the given value and returns the old value.
getAndSet(int) - Method in class com.google.common.collect.Count
 
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.
getAndSet(Count, int) - Static method in class com.google.common.collect.AbstractMapBasedMultiset
 
getAndUpdate(int, DoubleUnaryOperator) - Method in class com.google.common.util.concurrent.AtomicDoubleArray
Atomically updates the element at index i with the results of applying the given function to the current value.
getAndUpdate(DoubleUnaryOperator) - Method in class com.google.common.util.concurrent.AtomicDouble
Atomically updates the current value with the results of applying the given function.
getAndUpdate(K, LongUnaryOperator) - Method in class com.google.common.util.concurrent.AtomicLongMap
Updates the value currently associated with key with the specified function, and returns the old value.
getAnnotatedMethods(Class<?>) - Static method in class com.google.common.eventbus.SubscriberRegistry
 
getAnnotatedMethodsNotCached(Class<?>) - Static method in class com.google.common.eventbus.SubscriberRegistry
 
getAnnotatedParameterTypes() - Method in class com.google.common.reflect.Invokable.ConstructorInvokable
 
getAnnotatedParameterTypes() - Method in class com.google.common.reflect.Invokable
 
getAnnotatedParameterTypes() - Method in class com.google.common.reflect.Invokable.MethodInvokable
 
getAnnotatedReturnType() - Method in class com.google.common.reflect.Invokable.ConstructorInvokable
 
getAnnotatedReturnType() - Method in class com.google.common.reflect.Invokable
Returns the AnnotatedType for the return type.
getAnnotatedReturnType() - Method in class com.google.common.reflect.Invokable.MethodInvokable
 
getAnnotatedType() - Method in class com.google.common.reflect.Parameter
Returns the AnnotatedType of the parameter.
getAnnotation(Class<A>) - Method in class com.google.common.reflect.Invokable
 
getAnnotation(Class<A>) - Method in class com.google.common.reflect.Parameter
 
getAnnotations() - Method in class com.google.common.reflect.Invokable
 
getAnnotations() - Method in class com.google.common.reflect.Parameter
 
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.
getBestValidator() - Static method in class com.google.common.util.concurrent.FuturesGetChecked.GetCheckedTypeValidatorHolder
Returns the ClassValue-using validator, or falls back to the "weak Set" implementation if unable to do so.
getBigThreadConstructor() - Static method in class com.google.common.base.internal.Finalizer
 
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.
getCauseAs(Throwable, Class<X>) - Static method in class com.google.common.base.Throwables
Returns throwable's cause, cast to expectedCauseType.
getCell(int) - Method in class com.google.common.collect.ArrayTable
 
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
 
getChecked(FuturesGetChecked.GetCheckedTypeValidator, Future<V>, Class<X>) - Static method in class com.google.common.util.concurrent.FuturesGetChecked
getChecked(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.
getChecked(Future<V>, Class<X>) - Static method in class com.google.common.util.concurrent.FuturesGetChecked
 
getChecked(Future<V>, Class<X>, long, TimeUnit) - 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.
getChecked(Future<V>, Class<X>, long, TimeUnit) - Static method in class com.google.common.util.concurrent.FuturesGetChecked
getChecked(Future<V>, Class<X>, Duration) - 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.
GetCheckedTypeValidatorHolder() - Constructor for class com.google.common.util.concurrent.FuturesGetChecked.GetCheckedTypeValidatorHolder
 
getClassLoaderUrls(ClassLoader) - Static method in class com.google.common.reflect.ClassPath
 
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
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
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.
getCollectionSize() - Method in class com.google.common.collect.testing.OneSizeGenerator
 
getCollectionSize() - Method in interface com.google.common.collect.testing.OneSizeTestContainerGenerator
 
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.TableCollectors.MutableCell
 
getColumnKey() - Method in class com.google.common.collect.Tables.ImmutableCell
 
getComparator() - Method in class com.google.common.collect.testing.SpliteratorTester.GeneralSpliterator
 
getCompatIPv4Address(Inet6Address) - Static method in class com.google.common.net.InetAddresses
Returns the IPv4 address embedded in an IPv4 compatible address.
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.
getComponentType(Type) - Static method in class com.google.common.reflect.Types
 
getConcurrencyLevel() - Method in class com.google.common.cache.CacheBuilder
 
getConcurrencyLevel() - Method in class com.google.common.collect.MapMaker
 
getConflictingStackTrace() - Method in exception class com.google.common.util.concurrent.CycleDetectingLockFactory.PotentialDeadlockException
 
getConflicts() - Method in exception class com.google.common.collect.testing.features.ConflictingRequirementsException
 
getConnectingEdge() - Method in class com.google.common.graph.EdgesConnecting
 
getContainsEntryWithIncomparableKeyMethod() - Static method in class com.google.common.collect.testing.testers.MapEntrySetTester
 
getContainsEntryWithIncomparableValueMethod() - Static method in class com.google.common.collect.testing.testers.MapEntrySetTester
 
getCopy(K) - Method in class com.google.common.collect.LinkedListMultimap
 
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
 
getCount(int) - Method in class com.google.common.collect.RegularImmutableSortedMultiset
 
getCountDuplicateInitializingMethods() - Static method in class com.google.common.collect.testing.google.MultisetCountTester
Returns Method instances for the read tests that assume multisets support duplicates so that the test of Multisets.forSet() can suppress them.
getCovariantTypeResolver() - Method in class com.google.common.reflect.TypeToken
 
getCreateWithNullKeyUnsupportedMethod() - Static method in class com.google.common.collect.testing.testers.MapCreationTester
Returns the Method instance for MapCreationTester.testCreateWithNullKeyUnsupported() so that tests can suppress it with FeatureSpecificTestSuiteBuilder.suppressing() until Sun bug 5045147 is fixed.
getCreateWithNullUnsupportedMethod() - Static method in class com.google.common.collect.testing.testers.CollectionCreationTester
Returns the Method instance for CollectionCreationTester.testCreateWithNull_unsupported() so that tests can suppress it with FeatureSpecificTestSuiteBuilder.suppressing() until Sun bug 5045147 is fixed.
getDeclaredAnnotation(Class<A>) - Method in class com.google.common.reflect.Parameter
 
getDeclaredAnnotations() - Method in class com.google.common.reflect.Invokable
 
getDeclaredAnnotations() - Method in class com.google.common.reflect.Parameter
 
getDeclaredAnnotationsByType(Class<A>) - Method in class com.google.common.reflect.Parameter
 
getDeclaringClass() - Method in class com.google.common.reflect.Invokable
 
getDeclaringClassOrObjectForJ2cl(E) - Static method in class com.google.common.collect.Platform
 
getDeclaringInvokable() - Method in class com.google.common.reflect.Parameter
Returns the Invokable that declares this parameter.
getDefaultValue(TypeToken<T>) - Method in class com.google.common.testing.NullPointerTester
 
getDelay(TimeUnit) - Method in class com.google.common.util.concurrent.MoreExecutors.ScheduledListeningDecorator.ListenableScheduledTask
 
getDelay(TimeUnit) - Method in class com.google.common.util.concurrent.testing.SameThreadScheduledExecutorService.ImmediateScheduledFuture
 
getDelay(TimeUnit) - Method in class com.google.common.util.concurrent.testing.TestingExecutors.NoOpScheduledExecutorService.NeverScheduledFuture
 
getDelegate() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection
 
getDelegate() - Method in class com.google.common.collect.FluentIterable
 
getDelegateIterator() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection.WrappedIterator
 
getDelegateListIterator() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedList.WrappedListIterator
 
getDone(ClosingFuture<D>) - Method in class com.google.common.util.concurrent.ClosingFuture.Peeker
Returns the value of closingFuture.
getDone(Future<V>) - Static method in class com.google.common.util.concurrent.Futures
Returns the result of the input Future, which must have already completed.
getDoneValue(Object) - Method in class com.google.common.util.concurrent.AbstractFuture
Unboxes obj.
getDummyArguments(Invokable<?, ?>) - Method in class com.google.common.testing.ClassSanityTester
 
getDummyValue(TypeToken<T>) - Method in class com.google.common.testing.ClassSanityTester
 
getEdgeToReferenceNode(Network<N, E>) - Static method in class com.google.common.graph.ImmutableNetwork
 
getElement() - Method in class com.google.common.collect.MoreCollectors.ToOptionalState
 
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
 
getElements() - Method in class com.google.common.collect.testing.AbstractIteratorTester.MultiExceptionListIterator
 
getElementSetDuplicateInitializingMethods() - Static method in class com.google.common.collect.testing.google.MultisetElementSetTester
Returns Method instances for the read tests that assume multisets support duplicates so that the test of Multisets.forSet() can suppress them.
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.
getEntriesMultipleNonNullKeys() - Method in class com.google.common.collect.testing.testers.MapCreationTester
 
getEntriesMultipleNullKeys() - Method in class com.google.common.collect.testing.testers.MapCreationTester
 
getEntry() - Method in class com.google.common.cache.LocalCache.LoadingValueReference
 
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 interface com.google.common.collect.MapMakerInternalMap.WeakValueReference
Returns the entry which contains this MapMakerInternalMap.WeakValueReference.
getEntry() - Method in class com.google.common.collect.MapMakerInternalMap.WeakValueReferenceImpl
 
getEntry(int) - Method in class com.google.common.collect.ArrayTable.ArrayMap
 
getEntry(int) - Method in class com.google.common.collect.DescendingImmutableSortedMultiset
 
getEntry(int) - Method in class com.google.common.collect.ImmutableMultimap.Keys
 
getEntry(int) - Method in class com.google.common.collect.ImmutableMultiset
 
getEntry(int) - Method in class com.google.common.collect.JdkBackedImmutableMultiset
 
getEntry(int) - Method in class com.google.common.collect.RegularImmutableMultiset
 
getEntry(int) - Method in class com.google.common.collect.RegularImmutableSortedMultiset
 
getEntry(Object) - Method in class com.google.common.cache.LocalCache
Returns the internal entry for the specified key.
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.cache.LocalCache.Segment
 
getEntry(Object, int) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
 
getEntry(K) - Method in class com.google.common.collect.ImmutableRangeMap
 
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(K) - Method in class com.google.common.collect.TreeRangeMap
 
getEntry(K) - Method in class com.google.common.collect.TreeRangeMap.SubRangeMap
 
getEntryNullReplaces() - Method in class com.google.common.collect.testing.AbstractMapTester
 
getEntryNullReplaces() - Method in class com.google.common.collect.testing.google.AbstractMultimapTester
 
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
 
getExactSizeIfKnown() - Method in class com.google.common.collect.testing.SpliteratorTester.GeneralSpliterator
 
getExceptionTypes() - Method in class com.google.common.reflect.Invokable
Returns all declared exception types of this Invokable.
getExitingExecutorService(ThreadPoolExecutor) - Method in class com.google.common.util.concurrent.MoreExecutors.Application
 
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.
getExitingExecutorService(ThreadPoolExecutor, long, TimeUnit) - 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, Duration) - 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) - Method in class com.google.common.util.concurrent.MoreExecutors.Application
 
getExitingScheduledExecutorService(ScheduledThreadPoolExecutor) - 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, long, TimeUnit) - 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, Duration) - Static method in class com.google.common.util.concurrent.MoreExecutors
Converts the given ScheduledThreadPoolExecutor into a ScheduledExecutorService that exits when the application is complete.
getExpireAfterAccessNanos() - Method in class com.google.common.cache.CacheBuilder
 
getExpireAfterWriteNanos() - Method in class com.google.common.cache.CacheBuilder
 
getExtremeValues() - Method in class com.google.common.collect.testing.google.SortedMultisetTestSuiteBuilder
Returns an array of four bogus elements that will always be too high or too low for the display.
getFactories(TypeToken<T>) - Static method in class com.google.common.testing.ClassSanityTester
Factories with the least number of parameters are listed first.
getFactoriesToTest() - Method in class com.google.common.testing.ClassSanityTester.FactoryMethodReturnValueTester
 
getFactory(LocalCache.Strength, boolean, boolean) - Static method in enum class com.google.common.cache.LocalCache.EntryFactory
 
getFeatures() - Method in class com.google.common.collect.testing.FeatureSpecificTestSuiteBuilder
 
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).
getFile() - Method in class com.google.common.reflect.ClassPath.ResourceInfo
Returns the file that includes this resource.
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.
getFileExtension(Path) - Static method in class com.google.common.io.MoreFiles
Returns the file extension for the file at the given path, 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() - Method in class com.google.common.collect.ForwardingDeque
 
getFirst() - Method in class com.google.common.collect.Synchronized.SynchronizedDeque
 
getFirst(int) - Method in class com.google.common.cache.LocalCache.Segment
Returns first entry of bin for given hash.
getFirst(int) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Returns first entry of bin for given hash.
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.
getFirstTypeParameter(Type) - Static method in class com.google.common.testing.NullPointerTester
 
getFlags() - Method in class com.google.common.net.InetAddresses.TeredoInfo
 
getForEachEntryDuplicateInitializingMethods() - Static method in class com.google.common.collect.testing.google.MultisetForEachEntryTester
Returns Method instances for the remove tests that assume multisets support duplicates so that the test of Multisets.forSet() can suppress them.
getForwardList() - Method in class com.google.common.collect.Lists.ReverseList
 
getFrom() - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.SortedMapSubmapTestMapGenerator
 
getFrom() - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.SortedSetSubsetTestSetGenerator
 
getFutureValue(ListenableFuture<?>) - Static method in class com.google.common.util.concurrent.AbstractFuture
Returns a value that satisfies the contract of the AbstractFuture.value field based on the state of given future.
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<E>.
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.
getGetMethod() - Static method in class com.google.common.base.Throwables
Returns the Method that can be used to resolve an individual StackTraceElement, or null if that method cannot be found (it is only to be found in fairly recent JDKs).
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 class com.google.common.cache.LocalCache.NullEntry
 
getHash() - Method in class com.google.common.cache.LocalCache.StrongEntry
 
getHash() - Method in class com.google.common.cache.LocalCache.WeakEntry
 
getHash() - Method in interface com.google.common.cache.ReferenceEntry
Returns the entry's hash.
getHash() - Method in class com.google.common.collect.MapMakerInternalMap.AbstractStrongKeyEntry
 
getHash() - Method in class com.google.common.collect.MapMakerInternalMap.AbstractWeakKeyEntry
 
getHash() - Method in class com.google.common.collect.MapMakerInternalMap.DummyInternalEntry
 
getHash() - Method in interface com.google.common.collect.MapMakerInternalMap.InternalEntry
Gets the entry's hash.
getHashCodeMethod() - Static method in class com.google.common.collect.testing.testers.ListHashCodeTester
Returns the Method instance for ListHashCodeTester.testHashCode() so that list tests on unhashable objects can suppress it with FeatureSpecificTestSuiteBuilder.suppressing().
getHashCodeMethods() - Static method in class com.google.common.collect.testing.testers.SetHashCodeTester
Returns the Method instances for the test methods in this class which call hashCode() on the set values so that set tests on unhashable objects can suppress it with FeatureSpecificTestSuiteBuilder.suppressing().
getHashPrefix(int, int) - Static method in class com.google.common.collect.CompactHashing
Returns the hash prefix given the current mask.
getHoleMethods() - Static method in class com.google.common.collect.testing.testers.NavigableSetNavigationTester
Returns the Method instances for the test methods in this class that create a set with a "hole" in it so that set tests of ContiguousSet can suppress them with FeatureSpecificTestSuiteBuilder.suppressing().
getHost() - Method in class com.google.common.net.HostAndPort
Returns the portion of this HostAndPort instance that should represent the hostname or IPv4/IPv6 literal.
getHostAndPortFromBracketedHost(String) - Static method in class com.google.common.net.HostAndPort
Parses a bracketed host-port string, throwing IllegalArgumentException if parsing fails.
getIfCached(Object) - Method in class com.google.common.graph.MapIteratorCache
 
getIfCached(Object) - Method in class com.google.common.graph.MapRetrievalCache
 
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
 
getImplementation(Class<T>) - Static method in class com.google.common.testing.ArbitraryInstances
 
getImpliedFeatures() - Method in enum class com.google.common.collect.testing.features.CollectionFeature
 
getImpliedFeatures() - Method in enum class com.google.common.collect.testing.features.CollectionSize
 
getImpliedFeatures() - Method in interface com.google.common.collect.testing.features.Feature
Returns the set of features that are implied by this feature.
getImpliedFeatures() - Method in enum class com.google.common.collect.testing.features.ListFeature
 
getImpliedFeatures() - Method in enum class com.google.common.collect.testing.features.MapFeature
 
getImpliedFeatures() - Method in enum class com.google.common.collect.testing.features.SetFeature
 
getImpliedFeatures() - Method in enum class com.google.common.collect.testing.google.BiMapTestSuiteBuilder.NoRecurse
 
getImpliedFeatures() - Method in enum class com.google.common.collect.testing.google.MultimapFeature
 
getImpliedFeatures() - Method in enum class com.google.common.collect.testing.google.MultisetFeature
 
getImpliedFeatures() - Method in enum class com.google.common.collect.testing.google.MultisetTestSuiteBuilder.NoRecurse
 
getImpliedFeatures() - Method in enum class com.google.common.collect.testing.google.SortedMultisetTestSuiteBuilder.NoRecurse
 
getImpliedFeatures() - Method in enum class com.google.common.collect.testing.SortedMapTestSuiteBuilder.NoRecurse
 
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
 
getInnerGenerator() - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.MapEntrySetGenerator
 
getInnerGenerator() - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.MapKeySetGenerator
 
getInnerGenerator() - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.MapValueCollectionGenerator
 
getInnerGenerator() - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.SortedMapSubmapTestMapGenerator
 
getInnerGenerator() - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.SortedSetSubsetTestSetGenerator
 
getInnerGenerator() - Method in interface com.google.common.collect.testing.DerivedGenerator
 
getInnerGenerator() - Method in class com.google.common.collect.testing.DerivedTestIteratorGenerator
 
getInnerGenerator() - Method in class com.google.common.collect.testing.google.DerivedGoogleCollectionGenerators.BiMapValueSetGenerator
 
getInnerGenerator() - Method in class com.google.common.collect.testing.google.DerivedGoogleCollectionGenerators.InverseBiMapGenerator
 
getInnerGenerator() - Method in class com.google.common.collect.testing.google.DerivedGoogleCollectionGenerators.MapGenerator
 
getInnerGenerator() - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.AsMapGenerator
 
getInnerGenerator() - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.EntriesGenerator
 
getInnerGenerator() - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.KeysGenerator
 
getInnerGenerator() - Method in class com.google.common.collect.testing.OneSizeGenerator
 
getInnerGenerator() - Method in interface com.google.common.collect.testing.OneSizeTestContainerGenerator
 
getInnerNodeCode() - Method in enum class com.google.thirdparty.publicsuffix.PublicSuffixType
 
getInstance(TypeToken<T>) - Method in class com.google.common.reflect.ImmutableTypeToInstanceMap
 
getInstance(TypeToken<T>) - Method in class com.google.common.reflect.MutableTypeToInstanceMap
 
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.
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(Class<T>) - Method in class com.google.common.reflect.ImmutableTypeToInstanceMap
 
getInstance(Class<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.
getInstanceMethods(Class<?>) - Method in enum class com.google.common.testing.NullPointerTester.Visibility
 
getInstanceMethodsToTest(Class<?>, NullPointerTester.Visibility) - Method in class com.google.common.testing.NullPointerTester
 
getInterfaces(K) - Method in class com.google.common.reflect.TypeToken.TypeCollector.ForwardingTypeCollector
 
getInterfaces(K) - Method in class com.google.common.reflect.TypeToken.TypeCollector
 
getIntLittleEndian(byte[], int) - Static method in class com.google.common.hash.Murmur3_32HashFunction
 
getInvariantTypeResolver() - Method in class com.google.common.reflect.TypeToken
 
getInverseSameAfterSerializingMethods() - Static method in class com.google.common.collect.testing.google.BiMapInverseTester
Returns Method instances for the tests that assume that the inverse will be the same after serialization.
getIsatapIPv4Address(Inet6Address) - Static method in class com.google.common.net.InetAddresses
Returns the IPv4 address embedded in an ISATAP address.
getItem(int, int) - Method in class com.google.common.testing.RelationshipTester
 
getIteratorDuplicateInitializingMethods() - Static method in class com.google.common.collect.testing.google.MultisetIteratorTester
Returns Method instances for the tests that assume multisets support duplicates so that the test of Multisets.forSet() can suppress them.
getJLA() - Static method in class com.google.common.base.Throwables
Returns the JavaLangAccess class that is present in all Sun JDKs.
getJlaMethod(String, Class<?>...) - Static method in class com.google.common.base.Throwables
 
getKey() - Method in class com.google.common.cache.LocalCache.AbstractReferenceEntry
 
getKey() - Method in enum class com.google.common.cache.LocalCache.NullEntry
 
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 interface com.google.common.cache.ReferenceEntry
Returns the key for this entry.
getKey() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection
 
getKey() - Method in class com.google.common.collect.AbstractMapEntry
 
getKey() - Method in class com.google.common.collect.CompactHashMap.MapEntry
 
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.AbstractStrongKeyEntry
 
getKey() - Method in class com.google.common.collect.MapMakerInternalMap.AbstractWeakKeyEntry
 
getKey() - Method in class com.google.common.collect.MapMakerInternalMap.DummyInternalEntry
 
getKey() - Method in interface com.google.common.collect.MapMakerInternalMap.InternalEntry
Gets the key for this entry.
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
 
getKey(int) - Method in class com.google.common.collect.ArrayTable.ArrayMap
 
getKey(int) - Method in class com.google.common.collect.DenseImmutableTable.ImmutableArrayMap
 
getKeyEquivalence() - Method in class com.google.common.cache.CacheBuilder
 
getKeyEquivalence() - Method in class com.google.common.collect.MapMaker
 
getKeyForNullValue() - Method in class com.google.common.collect.testing.AbstractMapTester
 
getKeyForNullValue() - Method in class com.google.common.collect.testing.google.AbstractMultimapTester
 
getKeyNotInPopulatedMap() - Method in class com.google.common.collect.testing.MapInterfaceTest
Creates a new key that is not expected to be found in MapInterfaceTest.makePopulatedMap().
getKeyReferenceQueueForTesting() - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Unsafely extracts the key reference queue used by this segment.
getKeyReferenceQueueForTesting() - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyDummyValueSegment
 
getKeyReferenceQueueForTesting() - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyStrongValueSegment
 
getKeyReferenceQueueForTesting() - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyWeakValueSegment
 
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() - Method in class com.google.common.collect.Synchronized.SynchronizedDeque
 
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(Iterable<T>) - Static method in class com.google.common.collect.Iterables
Returns the last element of iterable.
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(Iterator<T>) - Static method in class com.google.common.collect.Iterators
Advances iterator to the end, returning the last element.
getLastInNonemptyList(List<T>) - Static method in class com.google.common.collect.Iterables
 
getLeafNodeCode() - Method in enum class com.google.thirdparty.publicsuffix.PublicSuffixType
 
getLeftChildIndex(int) - Method in class com.google.common.collect.MinMaxPriorityQueue.Heap
 
getList() - Method in class com.google.common.collect.testing.testers.AbstractListTester
 
getListDelegate() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedList
 
getListIteratorFullyModifiableMethod() - Static method in class com.google.common.collect.testing.testers.ListListIteratorTester
Returns the Method instance for ListListIteratorTester.testListIterator_fullyModifiable() so that tests of CopyOnWriteArraySet can suppress it with FeatureSpecificTestSuiteBuilder.suppressing() until Sun bug 6570575 is fixed.
getListIteratorUnmodifiableMethod() - Static method in class com.google.common.collect.testing.testers.ListListIteratorTester
Returns the Method instance for ListListIteratorTester.testListIterator_unmodifiable() so that it can be suppressed in GWT tests.
getLiveEntry(Object, int) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
 
getLiveEntry(Object, int, long) - Method in class com.google.common.cache.LocalCache.Segment
 
getLiveValue(ReferenceEntry<K, V>, long) - Method in class com.google.common.cache.LocalCache
Gets the value from an entry.
getLiveValue(ReferenceEntry<K, V>, long) - Method in class com.google.common.cache.LocalCache.Segment
Gets the value from an entry.
getLiveValue(E) - Method in class com.google.common.collect.MapMakerInternalMap
Gets the value from an entry.
getLiveValue(E) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Gets the value from an entry.
getLiveValueForTesting(MapMakerInternalMap.InternalEntry<K, V, ?>) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Unsafely returns the value of the given entry if it's still live, or null otherwise.
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() - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory.LockGraphNode
 
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.
getLongLittleEndian(byte[], int) - Method in interface com.google.common.hash.LittleEndianByteArray.LittleEndianBytes
 
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
 
getMac(String, Key) - Static method in class com.google.common.hash.MacHashFunction
 
getMap() - Method in class com.google.common.collect.testing.AbstractMapTester
 
getMap() - Method in class com.google.common.collect.testing.google.AbstractBiMapTester
 
getMap() - Method in class com.google.common.collect.testing.testers.ConcurrentMapPutIfAbsentTester
 
getMap() - Method in class com.google.common.collect.testing.testers.ConcurrentMapRemoveTester
 
getMap() - Method in class com.google.common.collect.testing.testers.ConcurrentMapReplaceEntryTester
 
getMap() - Method in class com.google.common.collect.testing.testers.ConcurrentMapReplaceTester
 
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
 
getMergeNullValueMethod() - Static method in class com.google.common.collect.testing.testers.MapMergeTester
Returns the Method instance for MapMergeTester.testMergeNullValue() so that tests of Hashtable can suppress it with FeatureSpecificTestSuiteBuilder.suppressing().
getMessage() - Method in exception class com.google.common.collect.testing.features.ConflictingRequirementsException
 
getMessage() - Method in exception class 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(Class<?>, String) - Static method in class com.google.common.collect.testing.Helpers
 
getMethod(String) - Static method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
 
getMethod(String) - Static method in class com.google.common.collect.testing.google.BiMapInverseTester
 
getMethodName() - Method in class com.google.common.collect.testing.testers.AbstractListIndexOfTester
Override to return "indexOf" or "lastIndexOf()" for use in failure messages.
getMethodName() - Method in class com.google.common.collect.testing.testers.ListIndexOfTester
 
getMethodName() - Method in class com.google.common.collect.testing.testers.ListLastIndexOfTester
 
getModifiers() - Method in class com.google.common.reflect.Invokable
 
getMostConcreteMethods(Class<?>) - Static method in class com.google.common.testing.ForwardingWrapperTester
Returns the most concrete public methods from type.
getMultiset() - Method in class com.google.common.collect.testing.google.AbstractMultisetTester
 
getName() - Method in class com.google.common.collect.testing.AbstractTester
 
getName() - Method in class com.google.common.collect.testing.FeatureSpecificTestSuiteBuilder
 
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.Invokable
 
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.
getNameWithoutExtension(Path) - Static method in class com.google.common.io.MoreFiles
Returns the file name without its file extension or path.
getNext() - Method in class com.google.common.cache.LocalCache.AbstractReferenceEntry
 
getNext() - Method in enum class com.google.common.cache.LocalCache.NullEntry
 
getNext() - Method in class com.google.common.cache.LocalCache.StrongEntry
 
getNext() - Method in class com.google.common.cache.LocalCache.WeakEntry
 
getNext() - Method in interface com.google.common.cache.ReferenceEntry
Returns the next entry in the chain.
getNext() - Method in class com.google.common.collect.MapMakerInternalMap.AbstractStrongKeyEntry
 
getNext() - Method in class com.google.common.collect.MapMakerInternalMap.AbstractWeakKeyEntry
 
getNext() - Method in class com.google.common.collect.MapMakerInternalMap.DummyInternalEntry
 
getNext() - Method in interface com.google.common.collect.MapMakerInternalMap.InternalEntry
Gets the next entry in the chain.
getNext() - Method in class com.google.common.collect.MapMakerInternalMap.StrongKeyDummyValueEntry.LinkedStrongKeyDummyValueEntry
 
getNext() - Method in class com.google.common.collect.MapMakerInternalMap.StrongKeyStrongValueEntry.LinkedStrongKeyStrongValueEntry
 
getNext() - Method in class com.google.common.collect.MapMakerInternalMap.StrongKeyWeakValueEntry.LinkedStrongKeyWeakValueEntry
 
getNext() - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyDummyValueEntry.LinkedWeakKeyDummyValueEntry
 
getNext() - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyStrongValueEntry.LinkedWeakKeyStrongValueEntry
 
getNext() - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyWeakValueEntry.LinkedWeakKeyWeakValueEntry
 
getNext(int, int) - Static method in class com.google.common.collect.CompactHashing
Returns the index, or 0 if the entry is "null".
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.
getNextEvictable() - Method in class com.google.common.cache.LocalCache.Segment
 
getNextInAccessQueue() - Method in class com.google.common.cache.LocalCache.AbstractReferenceEntry
 
getNextInAccessQueue() - Method in enum class com.google.common.cache.LocalCache.NullEntry
 
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
 
getNextInAccessQueue() - Method in interface com.google.common.cache.ReferenceEntry
Returns the next entry in the access queue.
getNextInKeyBucket() - Method in class com.google.common.collect.ImmutableMapEntry
 
getNextInKeyBucket() - Method in class com.google.common.collect.ImmutableMapEntry.NonTerminalImmutableMapEntry
 
getNextInValueBucket() - Method in class com.google.common.collect.ImmutableMapEntry
 
getNextInValueBucket() - Method in class com.google.common.collect.ImmutableMapEntry.NonTerminalImmutableBiMapEntry
 
getNextInWriteQueue() - Method in class com.google.common.cache.LocalCache.AbstractReferenceEntry
 
getNextInWriteQueue() - Method in enum class com.google.common.cache.LocalCache.NullEntry
 
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
 
getNextInWriteQueue() - Method in interface com.google.common.cache.ReferenceEntry
Returns the next entry in the write queue.
getNextSchedule() - Method in class com.google.common.util.concurrent.AbstractScheduledService.CustomScheduler
Calculates the time at which to next invoke the task.
getNodeConnections(Graph<N>) - Static method in class com.google.common.graph.ImmutableGraph
 
getNodeConnections(Network<N, E>) - Static method in class com.google.common.graph.ImmutableNetwork
 
getNodeConnections(ValueGraph<N, V>) - Static method in class com.google.common.graph.ImmutableValueGraph
 
getNullLocation() - Method in class com.google.common.collect.testing.AbstractContainerTester
 
getNumElements() - Method in class com.google.common.collect.testing.AbstractContainerTester
 
getNumElements() - Method in enum class com.google.common.collect.testing.features.CollectionSize
 
getNumEntries() - Method in class com.google.common.collect.testing.AbstractMapTester
 
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<? 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(Iterable<T>) - Static method in class com.google.common.collect.Iterables
Returns the single element contained in iterable.
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.
getOnlyElement(Iterator<T>) - Static method in class com.google.common.collect.Iterators
Returns the single element contained in iterator.
getOptional() - Method in class com.google.common.collect.MoreCollectors.ToOptionalState
 
getOrCreate(R) - Method in class com.google.common.collect.StandardTable
 
getOrCreateCollection(K) - Method in class com.google.common.collect.AbstractMapBasedMultimap
 
getOrCreateNodes(Class<E>) - Static method in class com.google.common.util.concurrent.CycleDetectingLockFactory
 
getOrDefault(Object, V) - Method in class com.google.common.cache.LocalCache
 
getOrDefault(Object, V) - Method in class com.google.common.collect.ImmutableMap
 
getOrDefault(Object, V) - Method in class com.google.common.collect.Maps.AsMapView
 
getOrDefault(Object, V) - Method in class com.google.common.collect.Maps.NavigableAsMapView
 
getOrDefault(Object, V) - Method in class com.google.common.collect.Synchronized.SynchronizedMap
 
getOrDefault(Object, V2) - Method in class com.google.common.collect.Maps.TransformedEntriesMap
 
getOrderedElements() - Method in class com.google.common.collect.testing.AbstractContainerTester
getOrInitSeenExceptions() - Method in class com.google.common.util.concurrent.AggregateFutureState
 
getOrLoad(K) - Method in class com.google.common.cache.LocalCache
 
getOutput(int) - Method in class com.google.common.collect.CompactHashMap.Itr
 
getOwner() - Method in class com.google.common.util.concurrent.InterruptibleTask.Blocker
 
getOwnerType() - Method in class com.google.common.reflect.Invokable
Returns the type of T.
getOwnerType() - Method in class com.google.common.reflect.Types.ParameterizedTypeImpl
 
getOwnerType(Class<?>) - Method in enum class com.google.common.reflect.Types.ClassOwnership
 
getOwnerTypeIfPresent() - Method in class com.google.common.reflect.TypeToken
Returns the owner type of a ParameterizedType or enclosing class of a Class, or null otherwise.
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.
getParameterValues(Method) - Static method in class com.google.common.testing.ForwardingWrapperTester
 
getParentIndex(int) - Method in class com.google.common.collect.MinMaxPriorityQueue.Heap
 
getParentPath(Path) - Static method in class com.google.common.io.MoreFiles
Returns a path to the parent directory of the given path.
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.
getPredecessor(int) - Method in class com.google.common.collect.CompactLinkedHashMap
 
getPredecessor(int) - Method in class com.google.common.collect.CompactLinkedHashSet
 
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
 
getPresentFeatures() - Method in class com.google.common.collect.testing.features.TesterRequirements
 
getPreviousInAccessQueue() - Method in class com.google.common.cache.LocalCache.AbstractReferenceEntry
 
getPreviousInAccessQueue() - Method in enum class com.google.common.cache.LocalCache.NullEntry
 
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
 
getPreviousInAccessQueue() - Method in interface com.google.common.cache.ReferenceEntry
Returns the previous entry in the access queue.
getPreviousInWriteQueue() - Method in class com.google.common.cache.LocalCache.AbstractReferenceEntry
 
getPreviousInWriteQueue() - Method in enum class com.google.common.cache.LocalCache.NullEntry
 
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
 
getPreviousInWriteQueue() - Method in interface com.google.common.cache.ReferenceEntry
Returns the previous entry in the write queue.
getPutAllNullKeyUnsupportedMethod() - Static method in class com.google.common.collect.testing.testers.MapPutAllTester
Returns the Method instance for MapPutAllTester.testPutAll_nullKeyUnsupported() so that tests can suppress it with FeatureSpecificTestSuiteBuilder.suppressing() until Sun bug 5045147 is fixed.
getPutNullKeyUnsupportedMethod() - Static method in class com.google.common.collect.testing.testers.MapPutTester
Returns the Method instance for MapPutTester.testPut_nullKeyUnsupported() so that tests of TreeMap can suppress it with FeatureSpecificTestSuiteBuilder.suppressing() until Sun bug 5045147 is fixed.
getQueue() - Method in class com.google.common.collect.testing.testers.AbstractQueueTester
 
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(K) - Method in class com.google.common.reflect.TypeToken.TypeCollector.ForwardingTypeCollector
 
getRawType(K) - Method in class com.google.common.reflect.TypeToken.TypeCollector
 
getRawTypes() - Method in class com.google.common.reflect.TypeToken
 
getReference(Reference<T>) - Static method in class com.google.common.graph.DirectedMultiNetworkConnections
 
getReference(Reference<T>) - Static method in class com.google.common.graph.UndirectedMultiNetworkConnections
 
getRefreshNanos() - Method in class com.google.common.cache.CacheBuilder
 
getRemovalListener() - Method in class com.google.common.cache.CacheBuilder
 
getRemoveDuplicateInitializingMethods() - Static method in class com.google.common.collect.testing.google.MultisetRemoveTester
Returns Method instances for the remove tests that assume multisets support duplicates so that the test of Multisets.forSet() can suppress them.
getReplacementArray() - Method in class com.google.common.escape.ArrayBasedEscaperMap
 
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.
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.
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.
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.TableCollectors.MutableCell
 
getRowKey() - Method in class com.google.common.collect.Tables.ImmutableCell
 
getSampleElements() - Method in class com.google.common.collect.testing.AbstractContainerTester
 
getSampleElements(int) - Method in class com.google.common.collect.testing.AbstractContainerTester
 
getSampleElements(int) - Method in class com.google.common.collect.testing.OneSizeGenerator
 
getSampleElements(int) - Method in interface com.google.common.collect.testing.OneSizeTestContainerGenerator
 
getSampleEntries() - Method in class com.google.common.collect.testing.AbstractMapTester
 
getSampleEntries(int) - Method in class com.google.common.collect.testing.AbstractMapTester
 
getServer() - Method in class com.google.common.net.InetAddresses.TeredoInfo
 
getSet() - Method in class com.google.common.collect.testing.testers.AbstractSetTester
 
getSetCountDuplicateInitializingMethods() - Static method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
Returns Method instances for the setCount() tests that assume multisets support duplicates so that the test of Multisets.forSet() can suppress them.
getSetNullSupportedMethod() - Static method in class com.google.common.collect.testing.testers.ListSetTester
Returns the Method instance for ListSetTester.testSet_null() so that tests of Collections.checkedCollection(java.util.Collection, Class) can suppress it with FeatureSpecificTestSuiteBuilder.suppressing() until Sun bug 6409434 is fixed.
getSetUp() - Method in class com.google.common.collect.testing.FeatureSpecificTestSuiteBuilder
 
getSetValueMethod() - Static method in class com.google.common.collect.testing.testers.MapEntrySetTester
 
getSetValueWithNullValuesAbsentMethod() - Static method in class com.google.common.collect.testing.testers.MapEntrySetTester
 
getSetValueWithNullValuesPresentMethod() - Static method in class com.google.common.collect.testing.testers.MapEntrySetTester
 
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.
getSizeMethod(Object) - Static method in class com.google.common.base.Throwables
Returns the Method that can be used to return the size of a stack, or null if that method cannot be found (it is only to be found in fairly recent JDKs).
getSortedSetDelegate() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedNavigableSet
 
getSortedSetDelegate() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedSortedSet
 
getSource() - Method in exception class com.google.common.collect.testing.features.ConflictingRequirementsException
 
getSource() - Method in class com.google.common.eventbus.DeadEvent
Returns the object that originated this event (not the object that originated the wrapped event).
getSpliteratorNotImmutableCollectionAllowsAddMethod() - Static method in class com.google.common.collect.testing.testers.CollectionSpliteratorTester
 
getSpliteratorNotImmutableCollectionAllowsRemoveMethod() - Static method in class com.google.common.collect.testing.testers.CollectionSpliteratorTester
 
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.
getStackTraceDepthMethod - Static variable in class com.google.common.base.Throwables
The "getStackTraceDepth" method, only available on some JDKs so we use reflection to find it when available.
getStackTraceElementMethod - Static variable in class com.google.common.base.Throwables
The "getStackTraceElementMethod" method, only available on some JDKs so we use reflection to find it when available.
getStartFinalizer(Class<?>) - Static method in class com.google.common.base.FinalizableReferenceQueue
Looks up Finalizer.startFinalizer().
getStaticMethods(Class<?>) - Method in enum class com.google.common.testing.NullPointerTester.Visibility
 
getStatsCounterSupplier() - Method in class com.google.common.cache.CacheBuilder
 
getStimulusValues() - Method in class com.google.common.collect.testing.AbstractIteratorTester
I'd like to make this a parameter to the constructor, but I can't because the stimulus instances refer to this.
getStimulusValues() - Method in class com.google.common.collect.testing.IteratorTester
 
getStimulusValues() - Method in class com.google.common.collect.testing.ListIteratorTester
 
getStoredLogRecords() - Method in class com.google.common.testing.TestLogHandler
Returns a snapshot of the logged records.
getSubjectGenerator() - Method in class com.google.common.collect.testing.AbstractTester
 
getSubjectGenerator() - Method in class com.google.common.collect.testing.FeatureSpecificTestSuiteBuilder
 
getSubListOriginalListSetAffectsSubListLargeListMethod() - Static method in class com.google.common.collect.testing.testers.ListSubListTester
Returns the Method instance for ListSubListTester.testSubList_originalListSetAffectsSubListLargeList() so that tests of CopyOnWriteArrayList can suppress them with FeatureSpecificTestSuiteBuilder.suppressing() until Sun bug 6570631 is fixed.
getSubListOriginalListSetAffectsSubListMethod() - Static method in class com.google.common.collect.testing.testers.ListSubListTester
Returns the Method instance for ListSubListTester.testSubList_originalListSetAffectsSubList() so that tests of CopyOnWriteArrayList can suppress them with FeatureSpecificTestSuiteBuilder.suppressing() until Sun bug 6570631 is fixed.
getSubListSubListRemoveAffectsOriginalLargeListMethod() - Static method in class com.google.common.collect.testing.testers.ListSubListTester
Returns the Method instance for ListSubListTester.testSubList_subListRemoveAffectsOriginalLargeList() so that tests of CopyOnWriteArrayList can suppress it with FeatureSpecificTestSuiteBuilder.suppressing() until Sun bug 6570575 is fixed.
getSubMap(int, int) - Method in class com.google.common.collect.ImmutableSortedMap
 
getSubMultiset(int, int) - Method in class com.google.common.collect.RegularImmutableSortedMultiset
 
getSubscriber() - Method in class com.google.common.eventbus.SubscriberExceptionContext
 
getSubscriberMethod() - Method in class com.google.common.eventbus.SubscriberExceptionContext
 
getSubscribers(Object) - Method in class com.google.common.eventbus.SubscriberRegistry
Gets an iterator representing an immutable snapshot of all subscribers to the given event at the time this method is called.
getSubscribersForTesting(Class<?>) - Method in class com.google.common.eventbus.SubscriberRegistry
 
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
 
getSuccessor(int) - Method in class com.google.common.collect.CompactHashMap
 
getSuccessor(int) - Method in class com.google.common.collect.CompactHashSet
 
getSuccessor(int) - Method in class com.google.common.collect.CompactLinkedHashMap
 
getSuccessor(int) - Method in class com.google.common.collect.CompactLinkedHashSet
 
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
 
getSuppressedTests() - Method in class com.google.common.collect.testing.FeatureSpecificTestSuiteBuilder
 
getTearDown() - Method in class com.google.common.collect.testing.FeatureSpecificTestSuiteBuilder
 
getTeredoInfo(Inet6Address) - Static method in class com.google.common.net.InetAddresses
Returns the Teredo information embedded in a Teredo address.
getTesterAnnotations(AnnotatedElement) - Static method in class com.google.common.collect.testing.features.FeatureUtil
Find all the tester annotations declared on a tester class or method.
getTesterRequirements(Class<?>) - Static method in class com.google.common.collect.testing.features.FeatureUtil
Get the full set of requirements for a tester class.
getTesterRequirements(Method) - Static method in class com.google.common.collect.testing.features.FeatureUtil
Get the full set of requirements for a tester class.
getTesters() - Method in class com.google.common.collect.testing.AbstractCollectionTestSuiteBuilder
 
getTesters() - Method in class com.google.common.collect.testing.ConcurrentMapTestSuiteBuilder
 
getTesters() - Method in class com.google.common.collect.testing.ConcurrentNavigableMapTestSuiteBuilder
 
getTesters() - Method in class com.google.common.collect.testing.FeatureSpecificTestSuiteBuilder
 
getTesters() - Method in class com.google.common.collect.testing.google.BiMapTestSuiteBuilder
 
getTesters() - Method in class com.google.common.collect.testing.google.ListMultimapTestSuiteBuilder
 
getTesters() - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder
 
getTesters() - Method in class com.google.common.collect.testing.google.MultisetTestSuiteBuilder
 
getTesters() - Method in class com.google.common.collect.testing.google.SetMultimapTestSuiteBuilder
 
getTesters() - Method in class com.google.common.collect.testing.google.SortedMultisetTestSuiteBuilder
 
getTesters() - Method in class com.google.common.collect.testing.google.SortedSetMultimapTestSuiteBuilder
 
getTesters() - Method in class com.google.common.collect.testing.ListTestSuiteBuilder
 
getTesters() - Method in class com.google.common.collect.testing.MapTestSuiteBuilder
 
getTesters() - Method in class com.google.common.collect.testing.NavigableMapTestSuiteBuilder
 
getTesters() - Method in class com.google.common.collect.testing.NavigableSetTestSuiteBuilder
 
getTesters() - Method in class com.google.common.collect.testing.PerCollectionSizeTestSuiteBuilder.OneSizeTestSuiteBuilder
 
getTesters() - Method in class com.google.common.collect.testing.QueueTestSuiteBuilder
 
getTesters() - Method in class com.google.common.collect.testing.SetTestSuiteBuilder
 
getTesters() - Method in class com.google.common.collect.testing.SortedMapTestSuiteBuilder
 
getTesters() - Method in class com.google.common.collect.testing.SortedSetTestSuiteBuilder
 
getTestMethodName() - Method in class com.google.common.collect.testing.AbstractTester
Returns the name of the test method invoked by this test instance.
getTicker(boolean) - Method in class com.google.common.cache.CacheBuilder
 
getTo() - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.SortedMapSubmapTestMapGenerator
 
getTo() - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.SortedSetSubsetTestSetGenerator
 
getToArrayIsPlainObjectArrayMethod() - Static method in class com.google.common.collect.testing.testers.CollectionToArrayTester
Returns the Method instance for CollectionToArrayTester.testToArray_isPlainObjectArray() so that tests of Arrays.asList(Object[]) can suppress it with FeatureSpecificTestSuiteBuilder.suppressing() until Sun bug 6260652 is fixed.
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 '.'.
getTopMetaIterator() - Method in class com.google.common.collect.Iterators.ConcatenatedIterator
 
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.
getTypeName() - Method in class com.google.common.reflect.Types.TypeVariableImpl
 
getTypeParameters() - Method in class com.google.common.reflect.Invokable.ConstructorInvokable
getTypeParameters() - Method in class com.google.common.reflect.Invokable
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.
getUid(Object) - Method in class com.google.common.collect.Ordering.ArbitraryOrdering
 
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.
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
 
getUninterruptibly(Future<V>) - Static method in class com.google.common.util.concurrent.AbstractFuture
An inlined private copy of Uninterruptibles.getUninterruptibly(java.util.concurrent.Future<V>) used to break an internal dependency on other /util/concurrent classes.
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.
getUninterruptibly(Future<V>, Duration) - 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 class com.google.common.hash.LittleEndianByteArray.UnsafeByteArray
Returns an Unsafe.
getUnsafe() - Static method in class com.google.common.hash.Striped64
Returns a sun.misc.Unsafe.
getUnsafe() - Static method in enum class 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
 
getUsername() - Static method in class com.google.common.io.TempFileCreator.JavaNioCreator
 
getValue() - Method in class com.google.common.cache.LocalCache.WriteThroughEntry
 
getValue() - Method in class com.google.common.collect.AbstractMapEntry
 
getValue() - Method in class com.google.common.collect.CompactHashMap.MapEntry
 
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.DummyInternalEntry
 
getValue() - Method in interface com.google.common.collect.MapMakerInternalMap.InternalEntry
Gets the value for the entry.
getValue() - Method in class com.google.common.collect.MapMakerInternalMap.StrongKeyDummyValueEntry
 
getValue() - Method in class com.google.common.collect.MapMakerInternalMap.StrongKeyStrongValueEntry
 
getValue() - Method in class com.google.common.collect.MapMakerInternalMap.StrongKeyWeakValueEntry
 
getValue() - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyDummyValueEntry
 
getValue() - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyStrongValueEntry
 
getValue() - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyWeakValueEntry
 
getValue() - Method in class com.google.common.collect.MapMakerInternalMap.WriteThroughEntry
 
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.TableCollectors.MutableCell
 
getValue() - Method in class com.google.common.collect.Tables.ImmutableCell
 
getValue() - Method in class com.google.common.collect.TreeRangeMap.RangeMapEntry
 
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
 
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(int) - Method in class com.google.common.collect.RegularImmutableTable
 
getValue(int) - Method in class com.google.common.collect.SparseImmutableTable
 
getValueEquivalence() - Method in class com.google.common.cache.CacheBuilder
 
getValueForNullKey() - Method in class com.google.common.collect.testing.AbstractMapTester
 
getValueForNullKey() - Method in class com.google.common.collect.testing.google.AbstractMultimapTester
 
getValueNotInPopulatedMap() - Method in class com.google.common.collect.testing.MapInterfaceTest
Creates a new value that is not expected to be found in MapInterfaceTest.makePopulatedMap().
getValueReference() - Method in class com.google.common.cache.LocalCache.AbstractReferenceEntry
 
getValueReference() - Method in enum class com.google.common.cache.LocalCache.NullEntry
 
getValueReference() - Method in class com.google.common.cache.LocalCache.StrongEntry
 
getValueReference() - Method in class com.google.common.cache.LocalCache.WeakEntry
 
getValueReference() - Method in interface com.google.common.cache.ReferenceEntry
Returns the value reference from this entry.
getValueReference() - Method in class com.google.common.collect.MapMakerInternalMap.StrongKeyWeakValueEntry
 
getValueReference() - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyWeakValueEntry
 
getValueReference() - Method in interface com.google.common.collect.MapMakerInternalMap.WeakValueEntry
Gets the weak value reference held by entry.
getValueReferenceQueueForTesting() - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Unsafely extracts the value reference queue used by this segment.
getValueReferenceQueueForTesting() - Method in class com.google.common.collect.MapMakerInternalMap.StrongKeyWeakValueSegment
 
getValueReferenceQueueForTesting() - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyWeakValueSegment
 
getValueStrength() - Method in class com.google.common.cache.CacheBuilder
 
getValueStrength() - Method in class com.google.common.collect.MapMaker
 
getVisibleMethods(Class<?>) - Method in enum class com.google.common.testing.NullPointerTester.Visibility
 
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.
getWeakValueReferenceForTesting(MapMakerInternalMap.InternalEntry<K, V, ?>) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Unsafely extracts the weak value reference inside of the given entry.
getWeakValueReferenceForTesting(MapMakerInternalMap.InternalEntry<K, V, ?>) - Method in class com.google.common.collect.MapMakerInternalMap.StrongKeyWeakValueSegment
 
getWeakValueReferenceForTesting(MapMakerInternalMap.InternalEntry<K, V, ?>) - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyWeakValueSegment
 
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
 
getWithoutCaching(Object) - Method in class com.google.common.graph.MapIteratorCache
 
getWriteTime() - Method in class com.google.common.cache.LocalCache.AbstractReferenceEntry
 
getWriteTime() - Method in enum class com.google.common.cache.LocalCache.NullEntry
 
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
 
getWriteTime() - Method in interface com.google.common.cache.ReferenceEntry
 
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_128 - Static variable in class com.google.common.hash.Murmur3_128HashFunction
 
GOOD_FAST_HASH_32 - Static variable in class com.google.common.hash.Murmur3_32HashFunction
 
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.
GoogleHelpers - Class in com.google.common.collect.testing.google
Helper methods/assertions for use with com.google.common.collect types.
GoogleHelpers() - Constructor for class com.google.common.collect.testing.google.GoogleHelpers
 
graph - Variable in class com.google.common.graph.EndpointPairIterator
 
graph - Variable in class com.google.common.graph.Graphs.TransposedGraph
 
graph - Variable in class com.google.common.graph.Graphs.TransposedValueGraph
 
graph - Variable in class com.google.common.graph.IncidentEdgeSet
 
Graph<N> - Interface in com.google.common.graph
An interface for graph-structured data, whose edges are anonymous entities with no identity or information of their own.
GraphBuilder<N> - Class in com.google.common.graph
A builder for constructing instances of MutableGraph or ImmutableGraph with user-defined properties.
GraphBuilder(boolean) - Constructor for class com.google.common.graph.GraphBuilder
Creates a new instance with the specified edge directionality.
GraphConnections<N,V> - Interface in com.google.common.graph
An interface for representing and manipulating an origin node's adjacent nodes and edge values in a Graph.
GraphConstants - Class in com.google.common.graph
A utility class to hold various constants used by the Guava Graph library.
GraphConstants() - Constructor for class com.google.common.graph.GraphConstants
 
GraphConstants.Presence - Enum Class in com.google.common.graph
Singleton edge value for Graph implementations backed by ValueGraphs.
Graphs - Class in com.google.common.graph
Static utility methods for Graph, ValueGraph, and Network instances.
Graphs() - Constructor for class com.google.common.graph.Graphs
 
Graphs.NodeAndRemainingSuccessors<N> - Class in com.google.common.graph
 
Graphs.NodeVisitState - Enum Class in com.google.common.graph
An enum representing the state of a node during DFS.
Graphs.TransposedGraph<N> - Class in com.google.common.graph
 
Graphs.TransposedNetwork<N,E> - Class in com.google.common.graph
 
Graphs.TransposedValueGraph<N,V> - Class in com.google.common.graph
 
GraphsBridgeMethods - Class in com.google.common.graph
Supertype for Graphs, containing the old signatures of methods whose signatures we've changed.
GraphsBridgeMethods() - Constructor for class com.google.common.graph.GraphsBridgeMethods
 
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.
greatest(int) - Static method in class com.google.common.collect.TopKSelector
Returns a TopKSelector that collects the greatest k elements added to it, relative to the natural ordering of the elements, and returns them via TopKSelector.topK() in descending order.
greatest(int, Comparator<? super T>) - Static method in class com.google.common.collect.Comparators
Returns a Collector that returns the k greatest (relative to the specified Comparator) input elements, in descending order, as an unmodifiable List.
greatest(int, Comparator<? super T>) - Static method in class com.google.common.collect.TopKSelector
Returns a TopKSelector that collects the greatest k elements added to it, relative to the specified comparator, and returns them via TopKSelector.topK() in descending order.
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<C>) - Method in class com.google.common.collect.Cut.AboveValue
 
greatestValueBelow(DiscreteDomain<C>) - Method in class com.google.common.collect.Cut.BelowValue
 
greatestValueBelow(DiscreteDomain<C>) - Method in class com.google.common.collect.Cut
 
greatestValueBelow(DiscreteDomain<Comparable<?>>) - Method in class com.google.common.collect.Cut.AboveAll
 
greatestValueBelow(DiscreteDomain<Comparable<?>>) - Method in class com.google.common.collect.Cut.BelowAll
 
groupNumber - Variable in class com.google.common.testing.RelationshipTester.Item
 
groups - Variable in class com.google.common.testing.RelationshipTester
 
grow(CharBuffer) - Static method in class com.google.common.io.ReaderInputStream
Returns a new CharBuffer identical to buf, except twice the capacity.
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.
Guarantees - Search tag in class com.google.common.collect.ImmutableCollection
Section
Guard(Monitor) - Constructor for class com.google.common.util.concurrent.Monitor.Guard
 
GwtCompatible - Annotation Interface 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).
gwtCompatibleToArray(Iterable<? extends ListenableFuture<? extends T>>) - Static method in class com.google.common.util.concurrent.Futures
Can't use Iterables.toArray because it's not gwt compatible
GwtFluentFutureCatchingSpecialization<V> - Class in com.google.common.util.concurrent
Hidden superclass of FluentFuture that provides us a place to declare special GWT versions of the
invalid reference
FluentFuture.catching
family of methods.
GwtFluentFutureCatchingSpecialization() - Constructor for class com.google.common.util.concurrent.GwtFluentFutureCatchingSpecialization
 
GwtFuturesCatchingSpecialization - Class in com.google.common.util.concurrent
Hidden superclass of Futures that provides us a place to declare special GWT versions of the Futures.catching family of methods.
GwtFuturesCatchingSpecialization() - Constructor for class com.google.common.util.concurrent.GwtFuturesCatchingSpecialization
 
GwtIncompatible - Annotation Interface in com.google.common.annotations
The presence of this annotation on an API indicates that the method may not be used with the Google Web Toolkit (GWT).
GwtTransient - Annotation Interface in com.google.common.collect
Private replacement for
invalid reference
com.google.gwt.user.client.rpc.GwtTransient
to work around build-system quirks.
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
 
HAL_JSON - Static variable in class com.google.common.net.MediaType
halfPowersOf10 - Static variable in class com.google.common.math.IntMath
 
halfPowersOf10 - Static variable in class com.google.common.math.LongMath
 
handleAllCompleted() - Method in class com.google.common.util.concurrent.AggregateFuture
 
handleAllCompleted() - Method in class com.google.common.util.concurrent.CollectionFuture
 
handleAllCompleted() - Method in class com.google.common.util.concurrent.CombinedFuture
 
handleException(Throwable) - Method in class com.google.common.util.concurrent.AggregateFuture
Fails this future with the given Throwable if AggregateFuture.allMustSucceed is true.
handleException(Throwable, SubscriberExceptionContext) - Method in class com.google.common.eventbus.EventBus.LoggingHandler
 
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
handleInvocation(Object, Method, Object[]) - Method in class com.google.common.testing.DummyProxy.DummyHandler
 
handleInvocation(Object, Method, Object[]) - Method in class com.google.common.testing.ForwardingWrapperTester.InteractionTester
 
handleInvocation(Object, Method, Object[]) - Method in class com.google.common.testing.FreshValueGenerator.FreshInvocationHandler
 
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.
handleSubscriberException(Throwable, SubscriberExceptionContext) - Method in class com.google.common.eventbus.EventBus
Handles the given exception thrown by a subscriber with the given context.
Handling of non-finite values - Search tag in class com.google.common.math.Quantiles
Section
hasBracketlessColons - Variable in class com.google.common.net.HostAndPort
True if the parsed host has colons, but no surrounding brackets.
hasCharacteristics(int) - Method in class com.google.common.collect.testing.SpliteratorTester.GeneralSpliterator
 
hasConstructorUsableByGetChecked(Class<? extends Exception>) - Static method in class com.google.common.util.concurrent.FuturesGetChecked
 
hasCycle(Graph<N>) - Static method in class com.google.common.graph.Graphs
Returns true if graph has at least one cycle.
hasCycle(Network<?, ?>) - Static method in class com.google.common.graph.Graphs
Returns true if network has at least one cycle.
hasEdgeConnecting(EndpointPair<N>) - Method in class com.google.common.graph.AbstractBaseGraph
 
hasEdgeConnecting(EndpointPair<N>) - Method in class com.google.common.graph.AbstractNetwork
 
hasEdgeConnecting(EndpointPair<N>) - Method in interface com.google.common.graph.BaseGraph
Returns true if there is an edge that directly connects endpoints (in the order, if any, specified by endpoints).
hasEdgeConnecting(EndpointPair<N>) - Method in class com.google.common.graph.ForwardingGraph
 
hasEdgeConnecting(EndpointPair<N>) - Method in class com.google.common.graph.ForwardingNetwork
 
hasEdgeConnecting(EndpointPair<N>) - Method in class com.google.common.graph.ForwardingValueGraph
 
hasEdgeConnecting(EndpointPair<N>) - Method in interface com.google.common.graph.Graph
Returns true if there is an edge that directly connects endpoints (in the order, if any, specified by endpoints).
hasEdgeConnecting(EndpointPair<N>) - Method in class com.google.common.graph.Graphs.TransposedGraph
 
hasEdgeConnecting(EndpointPair<N>) - Method in class com.google.common.graph.Graphs.TransposedNetwork
 
hasEdgeConnecting(EndpointPair<N>) - Method in class com.google.common.graph.Graphs.TransposedValueGraph
 
hasEdgeConnecting(EndpointPair<N>) - Method in interface com.google.common.graph.Network
Returns true if there is an edge that directly connects endpoints (in the order, if any, specified by endpoints).
hasEdgeConnecting(EndpointPair<N>) - Method in class com.google.common.graph.StandardValueGraph
 
hasEdgeConnecting(EndpointPair<N>) - Method in interface com.google.common.graph.ValueGraph
Returns true if there is an edge that directly connects endpoints (in the order, if any, specified by endpoints).
hasEdgeConnecting(N, N) - Method in class com.google.common.graph.AbstractBaseGraph
 
hasEdgeConnecting(N, N) - Method in class com.google.common.graph.AbstractNetwork
 
hasEdgeConnecting(N, N) - Method in interface com.google.common.graph.BaseGraph
Returns true if there is an edge that directly connects nodeU to nodeV.
hasEdgeConnecting(N, N) - Method in class com.google.common.graph.ForwardingGraph
 
hasEdgeConnecting(N, N) - Method in class com.google.common.graph.ForwardingNetwork
 
hasEdgeConnecting(N, N) - Method in class com.google.common.graph.ForwardingValueGraph
 
hasEdgeConnecting(N, N) - Method in interface com.google.common.graph.Graph
Returns true if there is an edge that directly connects nodeU to nodeV.
hasEdgeConnecting(N, N) - Method in class com.google.common.graph.Graphs.TransposedGraph
 
hasEdgeConnecting(N, N) - Method in class com.google.common.graph.Graphs.TransposedNetwork
 
hasEdgeConnecting(N, N) - Method in class com.google.common.graph.Graphs.TransposedValueGraph
 
hasEdgeConnecting(N, N) - Method in interface com.google.common.graph.Network
Returns true if there is an edge that directly connects nodeU to nodeV.
hasEdgeConnecting(N, N) - Method in class com.google.common.graph.StandardValueGraph
 
hasEdgeConnecting(N, N) - Method in interface com.google.common.graph.ValueGraph
Returns true if there is an edge that directly connects nodeU to nodeV.
hasEdgeConnectingInternal(N, N) - Method in class com.google.common.graph.StandardValueGraph
 
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.
hash - Variable in class com.google.common.cache.LocalCache.StrongEntry
 
hash - Variable in class com.google.common.cache.LocalCache.WeakEntry
 
hash - Variable in class com.google.common.collect.MapMakerInternalMap.AbstractStrongKeyEntry
 
hash - Variable in class com.google.common.collect.MapMakerInternalMap.AbstractWeakKeyEntry
 
hash - Variable in class com.google.common.hash.HashCode.IntHashCode
 
hash - Variable in class com.google.common.hash.HashCode.LongHashCode
 
hash() - Method in class com.google.common.hash.AbstractNonStreamingHashFunction.BufferingHasher
 
hash() - Method in class com.google.common.hash.AbstractStreamingHasher
 
hash() - Method in class com.google.common.hash.ChecksumHashFunction.ChecksumHasher
 
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.MacHashFunction.MacHasher
 
hash() - Method in class com.google.common.hash.MessageDigestHashFunction.MessageDigestHasher
 
hash() - Method in class com.google.common.hash.Murmur3_32HashFunction.Murmur3_32Hasher
 
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
Deprecated.
Prefer asByteSource(file).hash(hashFunction).
hash(Object) - Method in class com.google.common.cache.LocalCache
 
hash(Object) - Method in class com.google.common.collect.MapMakerInternalMap
 
hash(Map.Entry<?, ?>) - Static method in class com.google.common.collect.testing.testers.MapHashCodeTester
 
hash(T) - Method in class com.google.common.base.Equivalence
Returns a hash code for t.
HASH_FLOODING_FPP - Static variable in class com.google.common.collect.CompactHashMap
Maximum allowed false positive probability of detecting a hash flooding attack given random input.
HASH_FLOODING_FPP - Static variable in class com.google.common.collect.CompactHashSet
Maximum allowed false positive probability of detecting a hash flooding attack given random input.
HASH_FLOODING_FPP - Static variable in class com.google.common.collect.RegularImmutableMap
Maximum allowed false positive probability of detecting a hash flooding attack given random input.
HASH_FLOODING_FPP - Static variable in class com.google.common.collect.RegularImmutableMultiset
Maximum allowed false positive probability of detecting a hash flooding attack given random input.
HASH_FUNCTION - Static variable in enum class com.google.common.hash.Hashing.Crc32CSupplier
 
HASH_TABLE_BITS_MASK - Static variable in class com.google.common.collect.CompactHashing
Bitmask that selects the low bits of metadata to get hashTableBits.
HASH_TABLE_BITS_MAX_BITS - Static variable in class com.google.common.collect.CompactHashing
Number of bits used to store the numbers of hash table bits (max 30).
hash128to64(long, long) - Static method in class com.google.common.hash.Fingerprint2011
Implementation of Hash128to64 from util/hash/hash128to64.h
HashBasedTable<R,C,V> - Class in com.google.common.collect
Implementation of Table using linked 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.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.AbstractHashFunction
 
hashBytes(byte[]) - Method in interface com.google.common.hash.HashFunction
Shortcut for newHasher().putBytes(input).hash().
hashBytes(byte[], int, int) - Method in class com.google.common.hash.AbstractHashFunction
 
hashBytes(byte[], int, int) - Method in class com.google.common.hash.AbstractNonStreamingHashFunction
 
hashBytes(byte[], int, int) - Method in class com.google.common.hash.FarmHashFingerprint64
 
hashBytes(byte[], int, int) - Method in class com.google.common.hash.Fingerprint2011
 
hashBytes(byte[], int, int) - Method in interface com.google.common.hash.HashFunction
Shortcut for newHasher().putBytes(input, off, len).hash().
hashBytes(byte[], int, int) - Method in class com.google.common.hash.Murmur3_32HashFunction
 
hashBytes(ByteBuffer) - Method in class com.google.common.hash.AbstractHashFunction
 
hashBytes(ByteBuffer) - Method in class com.google.common.hash.AbstractNonStreamingHashFunction
 
hashBytes(ByteBuffer) - Method in interface com.google.common.hash.HashFunction
Shortcut for newHasher().putBytes(input).hash().
hashCode - Variable in class com.google.common.collect.ImmutableEnumSet
 
hashCode - Variable in class com.google.common.collect.ImmutableSet.RegularSetBuilderImpl
 
hashCode - Variable in class com.google.common.collect.RegularImmutableBiMap
 
hashCode - Variable in class com.google.common.collect.RegularImmutableMultiset
 
hashCode - Variable in class com.google.common.collect.RegularImmutableSet
 
hashCode - Variable in class com.google.common.net.MediaType
 
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() - 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.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.Predicates.SubtypeOfPredicate
 
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.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.AboveAll
 
hashCode() - Method in class com.google.common.collect.Cut.AboveValue
 
hashCode() - Method in class com.google.common.collect.Cut.BelowAll
 
hashCode() - Method in class com.google.common.collect.Cut.BelowValue
 
hashCode() - Method in class com.google.common.collect.Cut
 
hashCode() - Method in class com.google.common.collect.EmptyContiguousSet
 
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() - 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.ImmutableMap.MapViewOfValuesAsSingletonSets
 
hashCode() - Method in class com.google.common.collect.ImmutableMapEntrySet
 
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 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() - Method 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() - 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.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 class com.google.common.collect.Synchronized.SynchronizedTable
 
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.testing.BaseComparable
 
hashCode() - Method in class com.google.common.collect.testing.features.TesterRequirements
 
hashCode() - Method in class com.google.common.collect.testing.Helpers.NullsBefore
 
hashCode() - Method in class com.google.common.collect.testing.MinimalSet
 
hashCode() - Method in class com.google.common.collect.testing.SafeTreeMap
 
hashCode() - Method in class com.google.common.collect.testing.SafeTreeSet
 
hashCode() - Method in class com.google.common.collect.testing.SampleElements.Collider
 
hashCode() - Method in class com.google.common.collect.testing.UnhashableObject
 
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.Subscriber
 
hashCode() - Method in class com.google.common.eventbus.SubscriberRegistry.MethodIdentifier
 
hashCode() - Method in class com.google.common.graph.AbstractGraph
 
hashCode() - Method in class com.google.common.graph.AbstractNetwork
 
hashCode() - Method in class com.google.common.graph.AbstractValueGraph
 
hashCode() - Method in class com.google.common.graph.DirectedGraphConnections.NodeConnection.Pred
 
hashCode() - Method in class com.google.common.graph.DirectedGraphConnections.NodeConnection.Succ
 
hashCode() - Method in class com.google.common.graph.ElementOrder
 
hashCode() - Method in class com.google.common.graph.EndpointPair
The hashcode of an ordered EndpointPair is equal to Objects.hashCode(source(), target()).
hashCode() - Method in class com.google.common.graph.EndpointPair.Ordered
 
hashCode() - Method in class com.google.common.graph.EndpointPair.Unordered
 
hashCode() - Method in interface com.google.common.graph.Graph
Returns the hash code for this graph.
hashCode() - Method in class com.google.common.graph.InvalidatableSet
 
hashCode() - Method in interface com.google.common.graph.Network
Returns the hash code for this network.
hashCode() - Method in interface com.google.common.graph.ValueGraph
Returns the hash code for this graph.
hashCode() - Method in class com.google.common.hash.BloomFilter
 
hashCode() - Method in class com.google.common.hash.BloomFilterStrategies.LockFreeBitArray
 
hashCode() - Method in class com.google.common.hash.Funnels.SequentialFunnel
 
hashCode() - Method in class com.google.common.hash.Funnels.StringCharsetFunnel
 
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 interface com.google.common.hash.Hasher
Deprecated.
This returns Object.hashCode(); you almost certainly mean to call hash().asInt().
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.io.BaseEncoding.Alphabet
 
hashCode() - Method in class com.google.common.io.BaseEncoding.StandardBaseEncoding
 
hashCode() - Method in class com.google.common.math.PairedStats
hashCode() - Method in class com.google.common.math.Stats
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() - Method in class com.google.common.primitives.Bytes.ByteArrayAsList
 
hashCode() - Method in class com.google.common.primitives.Chars.CharArrayAsList
 
hashCode() - Method in class com.google.common.primitives.Doubles.DoubleArrayAsList
 
hashCode() - Method in class com.google.common.primitives.Floats.FloatArrayAsList
 
hashCode() - Method in class com.google.common.primitives.ImmutableDoubleArray.AsList
 
hashCode() - Method in class com.google.common.primitives.ImmutableDoubleArray
Returns an unspecified hash code for the contents of this immutable array.
hashCode() - Method in class com.google.common.primitives.ImmutableIntArray.AsList
 
hashCode() - Method in class com.google.common.primitives.ImmutableIntArray
Returns an unspecified hash code for the contents of this immutable array.
hashCode() - Method in class com.google.common.primitives.ImmutableLongArray.AsList
 
hashCode() - Method in class com.google.common.primitives.ImmutableLongArray
Returns an unspecified hash code for the contents of this immutable array.
hashCode() - Method in class com.google.common.primitives.Ints.IntArrayAsList
 
hashCode() - Method in class com.google.common.primitives.Longs.LongArrayAsList
 
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.LocationInfo
 
hashCode() - Method in class com.google.common.reflect.ClassPath.ResourceInfo
 
hashCode() - Method in class com.google.common.reflect.Invokable
 
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() - Method in class com.google.common.testing.ClassSanityTester.SerializableDummyProxy
 
hashCode() - Method in class com.google.common.testing.DummyProxy.DummyHandler
 
hashCode() - Method in class com.google.common.testing.FreshValueGenerator.FreshInvocationHandler
 
hashCode() - Method in class com.google.common.testing.NullPointerTester.Signature
 
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(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(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(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(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(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(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(Object...) - Static method in class com.google.common.base.Objects
Generates a hash code for multiple values.
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.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().
hashCodeInsensitiveToArgReference(Invokable<?, ?>, List<Object>, int, Object) - Static method in class com.google.common.testing.ClassSanityTester
 
hasher - Variable in class com.google.common.hash.HashingInputStream
 
hasher - Variable in class com.google.common.hash.HashingOutputStream
 
Hasher - Interface in com.google.common.hash
A PrimitiveSink that can compute a hash code after reading the input.
hashFloodingDetected(Multisets.ImmutableEntry<?>[]) - Static method in class com.google.common.collect.RegularImmutableMultiset
 
hashFloodingDetected(Object[]) - Static method in class com.google.common.collect.ImmutableSet.RegularSetBuilderImpl
Checks the whole hash table for poor hash distribution.
hashFunction - Variable in enum class com.google.common.hash.Hashing.ChecksumType
 
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 - 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.collect.Hashing
 
Hashing() - Constructor for class com.google.common.hash.Hashing
 
Hashing.ChecksumType - Enum Class in com.google.common.hash
 
Hashing.ConcatenatedHashFunction - Class in com.google.common.hash
 
Hashing.Crc32cMethodHandles - Class in com.google.common.hash
 
Hashing.Crc32CSupplier - Enum 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.Sha1Holder - Class in com.google.common.hash
 
Hashing.Sha256Holder - Class in com.google.common.hash
 
Hashing.Sha384Holder - Class in com.google.common.hash
 
Hashing.Sha512Holder - 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.AbstractHashFunction
 
hashInt(int) - Method in class com.google.common.hash.AbstractNonStreamingHashFunction
 
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 hash table to map keys to value collections.
hashKeys(int) - Static method in class com.google.common.collect.MultimapBuilder
Uses a hash table to map keys to value collections, initialized to expect the specified number of keys.
hashLength0to16(byte[], int, int) - Static method in class com.google.common.hash.FarmHashFingerprint64
 
hashLength16(long, long, long) - Static method in class com.google.common.hash.FarmHashFingerprint64
 
hashLength17to32(byte[], int, int) - Static method in class com.google.common.hash.FarmHashFingerprint64
 
hashLength33To64(byte[], int, int) - Static method in class com.google.common.hash.FarmHashFingerprint64
 
hashLength33To64(byte[], int, int) - Static method in class com.google.common.hash.Fingerprint2011
 
hashLength65Plus(byte[], int, int) - Static method in class com.google.common.hash.FarmHashFingerprint64
 
hashLong(long) - Method in class com.google.common.hash.AbstractHashFunction
 
hashLong(long) - Method in class com.google.common.hash.AbstractNonStreamingHashFunction
 
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
 
HashMultimapGwtSerializationDependencies<K,V> - Class in com.google.common.collect
A dummy superclass to support GWT serialization of the element types of a HashMultimap.
HashMultimapGwtSerializationDependencies(Map<K, Collection<V>>) - Constructor for class com.google.common.collect.HashMultimapGwtSerializationDependencies
 
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
 
hashName - Variable in class com.google.common.testing.RelationshipTester
 
hashObject(T, Funnel<? super T>) - Method in class com.google.common.hash.AbstractHashFunction
 
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 hash-based Set to store value collections.
hashSetValues(int) - Method in class com.google.common.collect.MultimapBuilder.MultimapBuilderWithKeys
Uses a hash-based Set to store value collections, initialized to expect the specified number of values per key.
hashString(CharSequence, Charset) - Method in class com.google.common.hash.AbstractHashFunction
 
hashString(CharSequence, Charset) - Method in class com.google.common.hash.AbstractNonStreamingHashFunction
 
hashString(CharSequence, Charset) - Method in interface com.google.common.hash.HashFunction
Shortcut for newHasher().putString(input, charset).hash().
hashString(CharSequence, Charset) - Method in class com.google.common.hash.Murmur3_32HashFunction
 
hashTable - Variable in class com.google.common.collect.ImmutableSet.RegularSetBuilderImpl
 
hashTable - Variable in class com.google.common.collect.LinkedHashMultimap.ValueSet
 
hashTable - Variable in class com.google.common.collect.RegularImmutableMultiset
 
hashTableKToV - Variable in class com.google.common.collect.HashBiMap
 
hashTableMask() - Method in class com.google.common.collect.CompactHashMap
Gets the hash table mask using the stored number of hash table bits.
hashTableMask() - Method in class com.google.common.collect.CompactHashSet
Gets the hash table mask using the stored number of hash table bits.
hashTableVToK - Variable in class com.google.common.collect.HashBiMap
 
hashUnencodedChars(CharSequence) - Method in class com.google.common.hash.AbstractHashFunction
 
hashUnencodedChars(CharSequence) - Method in class com.google.common.hash.AbstractNonStreamingHashFunction
 
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
 
hasInstanceMethodToTestNulls(Class<?>, NullPointerTester.Visibility) - Method in class com.google.common.testing.ClassSanityTester
 
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 - Variable in class com.google.common.collect.testing.AbstractIteratorTester
 
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.CompactHashMap.Itr
 
hasNext() - Method in class com.google.common.collect.EnumMultiset.Itr
 
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.Iterators.ConcatenatedIterator
 
hasNext() - Method in enum class com.google.common.collect.Iterators.EmptyModifiableIterator
 
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.Iterators.SingletonIterator
 
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.testing.AbstractIteratorTester.MultiExceptionListIterator
 
hasNext() - Method in class com.google.common.collect.TransformedIterator
 
hasNext() - Method in class com.google.common.collect.TreeTraverser.BreadthFirstIterator
Deprecated.
 
hasNext() - Method in class com.google.common.collect.TreeTraverser.PreOrderIterator
Deprecated.
 
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 - Variable in class com.google.common.collect.testing.AbstractIteratorTester
 
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.testing.AbstractIteratorTester.MultiExceptionListIterator
 
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
 
HasReachedRunningGuard() - Constructor for class com.google.common.util.concurrent.AbstractService.HasReachedRunningGuard
 
hasRegistrySuffix() - Method in class com.google.common.net.InternetDomainName
Indicates whether this domain name ends in a registry suffix, including if it is a registry suffix itself.
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.
hasTest(Class<?>, Iterable<String>) - Static method in class com.google.common.testing.AbstractPackageSanityTests
 
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_CLOSED - Enum constant in enum class com.google.common.collect.testing.google.MultisetNavigationTester.SubMultisetSpec
 
HEAD_OPEN - Enum constant in enum class com.google.common.collect.testing.google.MultisetNavigationTester.SubMultisetSpec
 
header - Variable in class com.google.common.collect.TreeMultiset
 
headIndex(E, boolean) - Method in class com.google.common.collect.RegularImmutableSortedSet
 
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
 
headMap(K) - 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) - 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) - Method in class com.google.common.collect.Maps.DescendingMap
 
headMap(K) - Method in class com.google.common.collect.Maps.FilteredEntrySortedMap
 
headMap(K) - Method in class com.google.common.collect.Maps.SortedAsMapView
 
headMap(K) - 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) - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableMap
 
headMap(K) - Method in class com.google.common.collect.Synchronized.SynchronizedSortedMap
 
headMap(K) - Method in class com.google.common.collect.testing.SafeTreeMap
 
headMap(K, boolean) - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableAsMap
 
headMap(K, boolean) - Method in class com.google.common.collect.ForwardingNavigableMap
 
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, boolean) - Method in class com.google.common.collect.Maps.FilteredEntryNavigableMap
 
headMap(K, boolean) - Method in class com.google.common.collect.Maps.NavigableAsMapView
 
headMap(K, boolean) - Method in class com.google.common.collect.Maps.TransformedEntriesNavigableMap
 
headMap(K, boolean) - Method in class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
headMap(K, boolean) - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableMap
 
headMap(K, boolean) - Method in class com.google.common.collect.testing.SafeTreeMap
 
headMap(R) - Method in class com.google.common.collect.StandardRowSortedTable.RowSortedMap
 
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.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(C) - Method in class com.google.common.collect.ContiguousSet
 
headSet(C, boolean) - Method in class com.google.common.collect.ContiguousSet
 
headSet(E) - Method in class com.google.common.collect.ForwardingSortedSet
 
headSet(E) - Method in class com.google.common.collect.ImmutableSortedSet
headSet(E) - Method in class com.google.common.collect.Sets.DescendingSet
 
headSet(E) - Method in class com.google.common.collect.Sets.FilteredSortedSet
 
headSet(E) - Method in class com.google.common.collect.SortedMultisets.ElementSet
 
headSet(E) - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableSet
 
headSet(E) - Method in class com.google.common.collect.Synchronized.SynchronizedSortedSet
 
headSet(E) - Method in class com.google.common.collect.testing.SafeTreeSet
 
headSet(E, boolean) - Method in class com.google.common.collect.ForwardingNavigableSet
 
headSet(E, boolean) - Method in class com.google.common.collect.ImmutableSortedSet
 
headSet(E, boolean) - Method in class com.google.common.collect.Sets.DescendingSet
 
headSet(E, boolean) - Method in class com.google.common.collect.Sets.FilteredNavigableSet
 
headSet(E, boolean) - Method in class com.google.common.collect.Sets.UnmodifiableNavigableSet
 
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, boolean) - Method in class com.google.common.collect.testing.SafeTreeSet
 
headSet(K) - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableKeySet
 
headSet(K) - Method in class com.google.common.collect.AbstractMapBasedMultimap.SortedKeySet
 
headSet(K) - Method in class com.google.common.collect.Maps.FilteredEntrySortedMap.SortedKeySet
 
headSet(K) - Method in class com.google.common.collect.Maps.NavigableKeySet
 
headSet(K) - Method in class com.google.common.collect.Maps.SortedKeySet
 
headSet(K, boolean) - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableKeySet
 
headSet(K, boolean) - Method in class com.google.common.collect.Maps.NavigableKeySet
 
headSet(V) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedSortedSet
 
headSet(V, boolean) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedNavigableSet
 
headSetImpl(C, boolean) - Method in class com.google.common.collect.ContiguousSet
 
headSetImpl(C, boolean) - Method in class com.google.common.collect.EmptyContiguousSet
 
headSetImpl(C, boolean) - Method in class com.google.common.collect.ImmutableRangeSet.AsSet
 
headSetImpl(C, boolean) - Method in class com.google.common.collect.RegularContiguousSet
 
headSetImpl(E, boolean) - Method in class com.google.common.collect.DescendingImmutableSortedSet
 
headSetImpl(E, boolean) - Method in class com.google.common.collect.ImmutableSortedSet
 
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_EVENT - 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
 
HEIF - Static variable in class com.google.common.net.MediaType
height - Variable in class com.google.common.collect.TreeMultiset.AvlNode
 
height(TreeMultiset.AvlNode<?>) - Static method in class com.google.common.collect.TreeMultiset.AvlNode
 
Helper() - Constructor for class com.google.common.collect.MapMakerInternalMap.StrongKeyDummyValueEntry.Helper
 
Helper() - Constructor for class com.google.common.collect.MapMakerInternalMap.StrongKeyStrongValueEntry.Helper
 
Helper() - Constructor for class com.google.common.collect.MapMakerInternalMap.StrongKeyWeakValueEntry.Helper
 
Helper() - Constructor for class com.google.common.collect.MapMakerInternalMap.WeakKeyDummyValueEntry.Helper
 
Helper() - Constructor for class com.google.common.collect.MapMakerInternalMap.WeakKeyStrongValueEntry.Helper
 
Helper() - Constructor for class com.google.common.collect.MapMakerInternalMap.WeakKeyWeakValueEntry.Helper
 
Helpers - Class in com.google.common.collect.testing
 
Helpers() - Constructor for class com.google.common.collect.testing.Helpers
 
Helpers.EntryComparator<K,V> - Class in com.google.common.collect.testing
 
Helpers.GwtTransient - Annotation Interface in com.google.common.collect.testing
Private replacement for
invalid reference
com.google.gwt.user.client.rpc.GwtTransient
to work around build-system quirks.
Helpers.NullsBefore - Class in com.google.common.collect.testing
Compares strings in natural order except that null comes immediately before a given value.
Helpers.NullsBeforeB - Class in com.google.common.collect.testing
 
Helpers.NullsBeforeTwo - Class in com.google.common.collect.testing
 
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(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(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
 
higher(E) - Method in class com.google.common.collect.testing.SafeTreeSet
 
higher(K) - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableKeySet
 
higher(K) - Method in class com.google.common.collect.Maps.NavigableKeySet
 
higher(V) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedNavigableSet
 
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
 
higherEntry(K) - Method in class com.google.common.collect.testing.SafeTreeMap
 
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
 
higherKey(K) - Method in class com.google.common.collect.testing.SafeTreeMap
 
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.
hmacMd5(byte[]) - Static method in class com.google.common.hash.Hashing
Returns a hash function implementing the Message Authentication Code (MAC) algorithm, using the MD5 (128 hash bits) hash function and a SecretKeySpec created from the given byte array and the MD5 algorithm.
hmacMd5(Key) - Static method in class com.google.common.hash.Hashing
Returns a hash function implementing the Message Authentication Code (MAC) algorithm, using the MD5 (128 hash bits) hash function and the given secret key.
hmacSha1(byte[]) - Static method in class com.google.common.hash.Hashing
Returns a hash function implementing the Message Authentication Code (MAC) algorithm, using the SHA-1 (160 hash bits) hash function and a SecretKeySpec created from the given byte array and the SHA-1 algorithm.
hmacSha1(Key) - Static method in class com.google.common.hash.Hashing
Returns a hash function implementing the Message Authentication Code (MAC) algorithm, using the SHA-1 (160 hash bits) hash function and the given secret key.
hmacSha256(byte[]) - Static method in class com.google.common.hash.Hashing
Returns a hash function implementing the Message Authentication Code (MAC) algorithm, using the SHA-256 (256 hash bits) hash function and a SecretKeySpec created from the given byte array and the SHA-256 algorithm.
hmacSha256(Key) - Static method in class com.google.common.hash.Hashing
Returns a hash function implementing the Message Authentication Code (MAC) algorithm, using the SHA-256 (256 hash bits) hash function and the given secret key.
hmacSha512(byte[]) - Static method in class com.google.common.hash.Hashing
Returns a hash function implementing the Message Authentication Code (MAC) algorithm, using the SHA-512 (512 hash bits) hash function and a SecretKeySpec created from the given byte array and the SHA-512 algorithm.
hmacSha512(Key) - Static method in class com.google.common.hash.Hashing
Returns a hash function implementing the Message Authentication Code (MAC) algorithm, using the SHA-512 (512 hash bits) hash function and the given secret key.
hmacToString(String, Key) - Static method in class com.google.common.hash.Hashing
 
holderHead - Variable in class com.google.common.base.MoreObjects.ToStringHelper
 
holderTail - Variable in class com.google.common.base.MoreObjects.ToStringHelper
 
home - Variable in class com.google.common.reflect.ClassPath.LocationInfo
 
horizontal(double) - Static method in class com.google.common.math.LinearTransformation
Builds an instance representing a horizontal transformation with a constant value of y.
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
 
How to get an instance - Search tag in interface com.google.common.util.concurrent.ListenableFuture
Section
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
 
HTTP2_SETTINGS - Static variable in class com.google.common.net.HttpHeaders
The HTTP HTTP2-Settings header field name.
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
 
HttpHeaders.ReferrerPolicyValues - Class in com.google.common.net
Values for the Referrer-Policy header.

I

"Interfaces", not implementations - Search tag in class com.google.common.collect.ImmutableCollection
Section
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
 
identifier - Variable in class com.google.common.eventbus.EventBus
 
identifier() - Method in class com.google.common.eventbus.EventBus
Returns the identifier for this event bus.
identity - Variable in class com.google.common.testing.FreshValueGenerator.FreshInvocationHandler
 
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() - Static method in class com.google.common.base.Functions
Returns the identity function.
identity() - Method in class com.google.common.testing.DummyProxy.DummyHandler
 
Identity() - Constructor for class com.google.common.base.Equivalence.Identity
 
IdentityConverter() - Constructor for class com.google.common.base.Converter.IdentityConverter
 
IdentityFunction() - Constructor for enum class com.google.common.base.Functions.IdentityFunction
 
identityHashCode(Object) - Method in class com.google.common.collect.Ordering.ArbitraryOrdering
 
IDLE - Enum constant in enum class com.google.common.util.concurrent.SequentialExecutor.WorkerRunningState
Runnable is not running and not queued for execution
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.
ignore(Constructor<?>) - Method in class com.google.common.testing.NullPointerTester
Ignore constructor in the tests that follow.
ignore(Method) - Method in class com.google.common.testing.NullPointerTester
Ignore method in the tests that follow.
IGNORE_TYPE_VARIABLE_OR_WILDCARD - Enum constant in enum class com.google.common.reflect.TypeToken.TypeFilter
 
ignoreCase - Variable in class com.google.common.io.BaseEncoding.Alphabet
 
ignoreCase - Variable in class com.google.common.io.BaseEncoding.StandardBaseEncoding
 
ignoreCase() - Method in class com.google.common.io.BaseEncoding.Alphabet
Returns an equivalent Alphabet except it ignores case.
ignoreCase() - Method in class com.google.common.io.BaseEncoding
Returns an encoding that behaves equivalently to this encoding, but decodes letters without regard to case.
ignoreCase() - Method in class com.google.common.io.BaseEncoding.SeparatedBaseEncoding
 
ignoreCase() - Method in class com.google.common.io.BaseEncoding.StandardBaseEncoding
 
ignoreClasses(Predicate<? super Class<?>>) - Method in class com.google.common.testing.AbstractPackageSanityTests
Specifies that classes that satisfy the given predicate aren't tested for sanity.
ignoredMembers - Variable in class com.google.common.testing.NullPointerTester
 
IgnoreJRERequirement - Annotation Interface in com.google.common.base
Disables Animal Sniffer's checking of compatibility with older versions of Java/Android.
IgnoreJRERequirement - Annotation Interface in com.google.common.cache
Disables Animal Sniffer's checking of compatibility with older versions of Java/Android.
IgnoreJRERequirement - Annotation Interface in com.google.common.collect
Disables Animal Sniffer's checking of compatibility with older versions of Java/Android.
IgnoreJRERequirement - Annotation Interface in com.google.common.hash
Disables Animal Sniffer's checking of compatibility with older versions of Java/Android.
IgnoreJRERequirement - Annotation Interface in com.google.common.io
Disables Animal Sniffer's checking of compatibility with older versions of Java/Android.
IgnoreJRERequirement - Annotation Interface in com.google.common.reflect
Disables Animal Sniffer's checking of compatibility with older versions of Java/Android.
IgnoreJRERequirement - Annotation Interface in com.google.common.testing
Disables Animal Sniffer's checking of compatibility with older versions of Java/Android.
ignoringReader(Reader, String) - Static method in class com.google.common.io.BaseEncoding
 
IMAGE_TYPE - Static variable in class com.google.common.net.MediaType
 
immediate() - Static method in class com.google.common.eventbus.Dispatcher
Returns a dispatcher that dispatches events to subscribers immediately as they're posted without using an intermediate queue to change the dispatch order.
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.ImmediateFuture.ImmediateCancelledFuture
 
ImmediateDispatcher() - Constructor for class com.google.common.eventbus.Dispatcher.ImmediateDispatcher
 
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.ImmediateFuture.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<V> - Class in com.google.common.util.concurrent
Implementation of Futures.immediateFuture(V).
ImmediateFuture(V) - Constructor for class com.google.common.util.concurrent.ImmediateFuture
 
ImmediateFuture.ImmediateCancelledFuture<V> - Class in com.google.common.util.concurrent
 
ImmediateFuture.ImmediateFailedFuture<V> - Class in com.google.common.util.concurrent
 
ImmediateScheduledFuture(ListenableFuture<V>) - Constructor for class com.google.common.util.concurrent.testing.SameThreadScheduledExecutorService.ImmediateScheduledFuture
 
immediateVoidFuture() - Static method in class com.google.common.util.concurrent.Futures
Returns a successful ListenableFuture<Void>.
immutable() - Method in class com.google.common.graph.GraphBuilder
Returns an ImmutableGraph.Builder with the properties of this GraphBuilder.
immutable() - Method in class com.google.common.graph.NetworkBuilder
Returns an ImmutableNetwork.Builder with the properties of this NetworkBuilder.
immutable() - Method in class com.google.common.graph.ValueGraphBuilder
Returns an ImmutableValueGraph.Builder with the properties of this ValueGraphBuilder.
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
A BiMap whose contents will never change, with many other important properties detailed at ImmutableCollection.
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<K,V> - Class in com.google.common.collect
Serialized type for all ImmutableBiMap instances.
ImmutableBiMapCopyOfEntriesGenerator() - Constructor for class com.google.common.collect.testing.google.BiMapGenerators.ImmutableBiMapCopyOfEntriesGenerator
 
ImmutableBiMapCopyOfGenerator() - Constructor for class com.google.common.collect.testing.google.BiMapGenerators.ImmutableBiMapCopyOfGenerator
 
ImmutableBiMapGenerator() - Constructor for class com.google.common.collect.testing.google.BiMapGenerators.ImmutableBiMapGenerator
 
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 ClassToInstanceMap whose contents will never change, with many other important properties detailed at ImmutableCollection.
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
A Collection whose contents will never change, and which offers a few additional guarantees detailed below.
ImmutableCollection() - Constructor for class com.google.common.collect.ImmutableCollection
 
ImmutableCollection.Builder<E> - Class in com.google.common.collect
Abstract base class for builders of ImmutableCollection types.
Immutable collections - Search tag in package com.google.common.collect
Section
immutableCopy() - Method in class com.google.common.collect.Sets.SetView
Returns an immutable copy of the current contents of this set view.
ImmutableDoubleArray - Class in com.google.common.primitives
An immutable array of double values, with an API resembling List.
ImmutableDoubleArray(double[]) - Constructor for class com.google.common.primitives.ImmutableDoubleArray
 
ImmutableDoubleArray(double[], int, int) - Constructor for class com.google.common.primitives.ImmutableDoubleArray
 
ImmutableDoubleArray.AsList - Class in com.google.common.primitives
 
ImmutableDoubleArray.Builder - Class in com.google.common.primitives
A builder for ImmutableDoubleArray instances; obtained using ImmutableDoubleArray.builder(int).
immutableEntry(E, int) - Static method in class com.google.common.collect.Multisets
Returns an immutable multiset entry with the specified element and count.
immutableEntry(K, V) - Static method in class com.google.common.collect.Maps
Returns an immutable map entry with the specified key and value.
ImmutableEntry<K,V> - Class in com.google.common.collect
An immutable Map.Entry, used both by Maps.immutableEntry(Object, Object) and by other parts of common.collect as a superclass.
ImmutableEntry(E, int) - Constructor for class com.google.common.collect.Multisets.ImmutableEntry
 
ImmutableEntry(K, V) - Constructor for class com.google.common.collect.ImmutableEntry
 
immutableEnumMap(Map<K, ? extends V>) - Static method in class com.google.common.collect.Maps
Returns an immutable map instance containing the given entries.
ImmutableEnumMap<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.EnumSerializedForm<K,V> - Class in com.google.common.collect
 
ImmutableEnumMapGenerator() - Constructor for class com.google.common.collect.testing.google.MapGenerators.ImmutableEnumMapGenerator
 
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<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.EnumSerializedForm<E> - Class in com.google.common.collect
 
ImmutableGraph<N> - Class in com.google.common.graph
A Graph whose elements and structural relationships will never change.
ImmutableGraph(BaseGraph<N>) - Constructor for class com.google.common.graph.ImmutableGraph
 
ImmutableGraph.Builder<N> - Class in com.google.common.graph
A builder for creating ImmutableGraph instances, especially static final graphs.
ImmutableIntArray - Class in com.google.common.primitives
An immutable array of int values, with an API resembling List.
ImmutableIntArray(int[]) - Constructor for class com.google.common.primitives.ImmutableIntArray
 
ImmutableIntArray(int[], int, int) - Constructor for class com.google.common.primitives.ImmutableIntArray
 
ImmutableIntArray.AsList - Class in com.google.common.primitives
 
ImmutableIntArray.Builder - Class in com.google.common.primitives
A builder for ImmutableIntArray instances; obtained using ImmutableIntArray.builder(int).
ImmutableList<E> - Class in com.google.common.collect
A List whose contents will never change, with many other important properties detailed at ImmutableCollection.
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
 
ImmutableListHeadSubListGenerator() - Constructor for class com.google.common.collect.testing.google.ListGenerators.ImmutableListHeadSubListGenerator
 
ImmutableListMiddleSubListGenerator() - Constructor for class com.google.common.collect.testing.google.ListGenerators.ImmutableListMiddleSubListGenerator
 
ImmutableListMultimap<K,V> - Class in com.google.common.collect
A ListMultimap whose contents will never change, with many other important properties detailed at ImmutableCollection.
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").
ImmutableListOfGenerator() - Constructor for class com.google.common.collect.testing.google.ListGenerators.ImmutableListOfGenerator
 
ImmutableListTailSubListGenerator() - Constructor for class com.google.common.collect.testing.google.ListGenerators.ImmutableListTailSubListGenerator
 
ImmutableLongArray - Class in com.google.common.primitives
An immutable array of long values, with an API resembling List.
ImmutableLongArray(long[]) - Constructor for class com.google.common.primitives.ImmutableLongArray
 
ImmutableLongArray(long[], int, int) - Constructor for class com.google.common.primitives.ImmutableLongArray
 
ImmutableLongArray.AsList - Class in com.google.common.primitives
 
ImmutableLongArray.Builder - Class in com.google.common.primitives
A builder for ImmutableLongArray instances; obtained using ImmutableLongArray.builder(int).
ImmutableMap<K,V> - Class in com.google.common.collect
A Map whose contents will never change, with many other important properties detailed at ImmutableCollection.
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.IteratorBasedImmutableMap<K,V> - Class in com.google.common.collect
 
ImmutableMap.MapViewOfValuesAsSingletonSets - Class in com.google.common.collect
 
ImmutableMap.SerializedForm<K,V> - Class in com.google.common.collect
Serialized type for all ImmutableMap instances.
ImmutableMapCopyOfEntriesGenerator() - Constructor for class com.google.common.collect.testing.google.MapGenerators.ImmutableMapCopyOfEntriesGenerator
 
ImmutableMapCopyOfEnumMapGenerator() - Constructor for class com.google.common.collect.testing.google.MapGenerators.ImmutableMapCopyOfEnumMapGenerator
 
ImmutableMapCopyOfGenerator() - Constructor for class com.google.common.collect.testing.google.MapGenerators.ImmutableMapCopyOfGenerator
 
ImmutableMapEntry<K,V> - Class in com.google.common.collect
Implementation of Entry for ImmutableMap that adds extra methods to traverse hash buckets for the key and the value.
ImmutableMapEntry(ImmutableMapEntry<K, V>) - Constructor for class com.google.common.collect.ImmutableMapEntry
 
ImmutableMapEntry(K, V) - Constructor for class com.google.common.collect.ImmutableMapEntry
 
ImmutableMapEntry.NonTerminalImmutableBiMapEntry<K,V> - Class in com.google.common.collect
 
ImmutableMapEntry.NonTerminalImmutableMapEntry<K,V> - Class in com.google.common.collect
 
ImmutableMapEntryListGenerator() - Constructor for class com.google.common.collect.testing.google.MapGenerators.ImmutableMapEntryListGenerator
 
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
 
ImmutableMapEntrySet.RegularEntrySet<K,V> - Class in com.google.common.collect
 
ImmutableMapGenerator() - Constructor for class com.google.common.collect.testing.google.MapGenerators.ImmutableMapGenerator
 
ImmutableMapKeyListGenerator() - Constructor for class com.google.common.collect.testing.google.MapGenerators.ImmutableMapKeyListGenerator
 
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
 
ImmutableMapUnhashableValuesGenerator() - Constructor for class com.google.common.collect.testing.google.MapGenerators.ImmutableMapUnhashableValuesGenerator
 
ImmutableMapValueListGenerator() - Constructor for class com.google.common.collect.testing.google.MapGenerators.ImmutableMapValueListGenerator
 
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
 
ImmutableMapValuesAsSingletonSetGenerator() - Constructor for class com.google.common.collect.testing.google.MapGenerators.ImmutableMapValuesAsSingletonSetGenerator
 
ImmutableMultimap<K,V> - Class in com.google.common.collect
A Multimap whose contents will never change, with many other important properties detailed at ImmutableCollection.
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.EntryCollection<K,V> - Class in com.google.common.collect
 
ImmutableMultimap.FieldSettersHolder - Class in com.google.common.collect
 
ImmutableMultimap.Keys - Class in com.google.common.collect
 
ImmutableMultimap.KeysSerializedForm - Class in com.google.common.collect
 
ImmutableMultimap.Values<K,V> - Class in com.google.common.collect
 
ImmutableMultiset<E> - Class in com.google.common.collect
A Multiset whose contents will never change, with many other important properties detailed at ImmutableCollection.
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.ElementSet<E> - Class in com.google.common.collect
 
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
 
ImmutableMultisetGwtSerializationDependencies<E> - Class in com.google.common.collect
A dummy superclass to support GWT serialization of the element type of an ImmutableMultiset.
ImmutableMultisetGwtSerializationDependencies() - Constructor for class com.google.common.collect.ImmutableMultisetGwtSerializationDependencies
 
ImmutableNetwork<N,E> - Class in com.google.common.graph
A Network whose elements and structural relationships will never change.
ImmutableNetwork(Network<N, E>) - Constructor for class com.google.common.graph.ImmutableNetwork
 
ImmutableNetwork.Builder<N,E> - Class in com.google.common.graph
A builder for creating ImmutableNetwork instances, especially static final networks.
ImmutableRangeMap<K,V> - Class in com.google.common.collect
A RangeMap whose contents will never change, with many other important properties detailed at ImmutableCollection.
ImmutableRangeMap(ImmutableList<Range<K>>, ImmutableList<V>) - Constructor for class com.google.common.collect.ImmutableRangeMap
 
ImmutableRangeMap.Builder<K,V> - Class in com.google.common.collect
A builder for immutable range maps.
ImmutableRangeMap.SerializedForm<K,V> - Class in com.google.common.collect
This class is used to serialize ImmutableRangeMap instances.
ImmutableRangeSet<C> - Class in com.google.common.collect
A RangeSet whose contents will never change, with many other important properties detailed at ImmutableCollection.
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> - Class in com.google.common.collect
 
ImmutableRangeSet.Builder<C> - Class in com.google.common.collect
A builder for immutable range sets.
ImmutableRangeSet.ComplementRanges - Class in com.google.common.collect
 
ImmutableRangeSet.SerializedForm<C> - Class in com.google.common.collect
 
ImmutableSet<E> - Class in com.google.common.collect
A Set whose contents will never change, with many other important properties detailed at ImmutableCollection.
ImmutableSet() - Constructor for class com.google.common.collect.ImmutableSet
 
ImmutableSet.Builder<E> - Class in com.google.common.collect
A builder for creating ImmutableSet instances.
ImmutableSet.CachingAsList<E> - Class in com.google.common.collect
 
ImmutableSet.EmptySetBuilderImpl<E> - Class in com.google.common.collect
 
ImmutableSet.Indexed<E> - Class in com.google.common.collect
 
ImmutableSet.JdkBackedSetBuilderImpl<E> - Class in com.google.common.collect
SetBuilderImpl version that uses a JDK HashSet, which has built in hash flooding protection.
ImmutableSet.RegularSetBuilderImpl<E> - Class in com.google.common.collect
Default implementation of the guts of ImmutableSet.Builder, creating an open-addressed hash table and deduplicating elements as they come, so it only allocates O(max(distinct, expectedCapacity)) rather than O(calls to add).
ImmutableSet.SerializedForm - Class in com.google.common.collect
 
ImmutableSet.SetBuilderImpl<E> - Class in com.google.common.collect
Swappable internal implementation of an ImmutableSet.Builder.
ImmutableSetAsListGenerator() - Constructor for class com.google.common.collect.testing.google.SetGenerators.ImmutableSetAsListGenerator
 
ImmutableSetCopyOfGenerator() - Constructor for class com.google.common.collect.testing.google.SetGenerators.ImmutableSetCopyOfGenerator
 
ImmutableSetMultimap<K,V> - Class in com.google.common.collect
A SetMultimap whose contents will never change, with many other important properties detailed at ImmutableCollection.
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.EntrySet<K,V> - Class in com.google.common.collect
 
ImmutableSetMultimap.SetFieldSettersHolder - Class in com.google.common.collect
 
ImmutableSetSizedBuilderGenerator() - Constructor for class com.google.common.collect.testing.google.SetGenerators.ImmutableSetSizedBuilderGenerator
 
ImmutableSetTooBigBuilderGenerator() - Constructor for class com.google.common.collect.testing.google.SetGenerators.ImmutableSetTooBigBuilderGenerator
 
ImmutableSetTooSmallBuilderGenerator() - Constructor for class com.google.common.collect.testing.google.SetGenerators.ImmutableSetTooSmallBuilderGenerator
 
ImmutableSetUnsizedBuilderGenerator() - Constructor for class com.google.common.collect.testing.google.SetGenerators.ImmutableSetUnsizedBuilderGenerator
 
ImmutableSetWithBadHashesGenerator() - Constructor for class com.google.common.collect.testing.google.SetGenerators.ImmutableSetWithBadHashesGenerator
 
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
A NavigableMap whose contents will never change, with many other important properties detailed at ImmutableCollection.
ImmutableSortedMap(RegularImmutableSortedSet<K>, ImmutableList<V>) - Constructor for class com.google.common.collect.ImmutableSortedMap
 
ImmutableSortedMap(RegularImmutableSortedSet<K>, ImmutableList<V>, 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<K,V> - Class in com.google.common.collect
Serialized type for all ImmutableSortedMap instances.
ImmutableSortedMapCopyOfEntriesGenerator() - Constructor for class com.google.common.collect.testing.google.SortedMapGenerators.ImmutableSortedMapCopyOfEntriesGenerator
 
ImmutableSortedMapEntryListGenerator() - Constructor for class com.google.common.collect.testing.google.SortedMapGenerators.ImmutableSortedMapEntryListGenerator
 
ImmutableSortedMapGenerator() - Constructor for class com.google.common.collect.testing.google.SortedMapGenerators.ImmutableSortedMapGenerator
 
ImmutableSortedMapKeyListGenerator() - Constructor for class com.google.common.collect.testing.google.SortedMapGenerators.ImmutableSortedMapKeyListGenerator
 
ImmutableSortedMapValueListGenerator() - Constructor for class com.google.common.collect.testing.google.SortedMapGenerators.ImmutableSortedMapValueListGenerator
 
ImmutableSortedMultiset<E> - Class in com.google.common.collect
A SortedMultiset whose contents will never change, with many other important properties detailed at ImmutableCollection.
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
 
ImmutableSortedSet<E> - Class in com.google.common.collect
A NavigableSet whose contents will never change, with many other important properties detailed at ImmutableCollection.
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
 
ImmutableSortedSetAsListGenerator() - Constructor for class com.google.common.collect.testing.google.SetGenerators.ImmutableSortedSetAsListGenerator
 
ImmutableSortedSetAsListSubListGenerator() - Constructor for class com.google.common.collect.testing.google.SetGenerators.ImmutableSortedSetAsListSubListGenerator
 
ImmutableSortedSetCopyOfGenerator() - Constructor for class com.google.common.collect.testing.google.SetGenerators.ImmutableSortedSetCopyOfGenerator
 
ImmutableSortedSetDescendingAsListGenerator() - Constructor for class com.google.common.collect.testing.google.SetGenerators.ImmutableSortedSetDescendingAsListGenerator
 
ImmutableSortedSetDescendingGenerator() - Constructor for class com.google.common.collect.testing.google.SetGenerators.ImmutableSortedSetDescendingGenerator
 
ImmutableSortedSetExplicitComparator() - Constructor for class com.google.common.collect.testing.google.SetGenerators.ImmutableSortedSetExplicitComparator
 
ImmutableSortedSetExplicitSuperclassComparatorGenerator() - Constructor for class com.google.common.collect.testing.google.SetGenerators.ImmutableSortedSetExplicitSuperclassComparatorGenerator
 
ImmutableSortedSetHeadsetGenerator() - Constructor for class com.google.common.collect.testing.google.SetGenerators.ImmutableSortedSetHeadsetGenerator
 
ImmutableSortedSetReversedOrderGenerator() - Constructor for class com.google.common.collect.testing.google.SetGenerators.ImmutableSortedSetReversedOrderGenerator
 
ImmutableSortedSetSubsetAsListGenerator() - Constructor for class com.google.common.collect.testing.google.SetGenerators.ImmutableSortedSetSubsetAsListGenerator
 
ImmutableSortedSetSubsetAsListSubListGenerator() - Constructor for class com.google.common.collect.testing.google.SetGenerators.ImmutableSortedSetSubsetAsListSubListGenerator
 
ImmutableSortedSetSubsetGenerator() - Constructor for class com.google.common.collect.testing.google.SetGenerators.ImmutableSortedSetSubsetGenerator
 
ImmutableSortedSetTailsetGenerator() - Constructor for class com.google.common.collect.testing.google.SetGenerators.ImmutableSortedSetTailsetGenerator
 
ImmutableSortedSetUnhashableGenerator() - Constructor for class com.google.common.collect.testing.google.SetGenerators.ImmutableSortedSetUnhashableGenerator
 
ImmutableSupplier<T> - Interface in com.google.common.hash
Explicitly named subinterface of Supplier that can be marked @
invalid reference
Immutable
.
ImmutableTable<R,C,V> - Class in com.google.common.collect
A Table whose contents will never change, with many other important properties detailed at ImmutableCollection.
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").
ImmutableTable.SerializedForm - Class in com.google.common.collect
Serialized type for all ImmutableTable instances.
ImmutableTableCollectorState() - Constructor for class com.google.common.collect.TableCollectors.ImmutableTableCollectorState
 
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.
ImmutableValueGraph<N,V> - Class in com.google.common.graph
A ValueGraph whose elements and structural relationships will never change.
ImmutableValueGraph(ValueGraph<N, V>) - Constructor for class com.google.common.graph.ImmutableValueGraph
 
ImmutableValueGraph.Builder<N,V> - Class in com.google.common.graph
A builder for creating ImmutableValueGraph instances, especially static final graphs.
impl - Variable in class com.google.common.collect.ImmutableSet.Builder
 
implementations - Static variable in class com.google.common.testing.ArbitraryInstances
type → implementation.
Implementations - Search tag in interface com.google.common.collect.BiMap
Section
Implementations - Search tag in interface com.google.common.collect.ClassToInstanceMap
Section
Implementations - Search tag in interface com.google.common.collect.Multimap
Section
Implementations - Search tag in interface com.google.common.collect.Multiset
Section
Implementations - Search tag in interface com.google.common.collect.Table
Section
IMPLICIT_BIT - Static variable in class com.google.common.math.DoubleUtils
The implicit 1 bit that is omitted in significands of normal doubles.
implied - Variable in enum class com.google.common.collect.testing.features.CollectionFeature
 
implied - Variable in enum class com.google.common.collect.testing.features.CollectionSize
 
implied - Variable in enum class com.google.common.collect.testing.features.ListFeature
 
implied - Variable in enum class com.google.common.collect.testing.features.MapFeature
 
implied - Variable in enum class com.google.common.collect.testing.features.SetFeature
 
implied - Variable in enum class com.google.common.collect.testing.google.MultimapFeature
 
impliedFeatures(Set<Feature<?>>) - Static method in class com.google.common.collect.testing.features.FeatureUtil
Given a set of features, return a new set of all features directly or indirectly implied by any of them.
ImprovedAbstractSet() - Constructor for class com.google.common.collect.Sets.ImprovedAbstractSet
 
in - Variable in class com.google.common.io.MultiInputStream
 
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.
InactiveComparisonChain(int) - Constructor for class com.google.common.collect.ComparisonChain.InactiveComparisonChain
 
incidentEdgeIterator(N) - Method in class com.google.common.graph.DirectedGraphConnections
 
incidentEdgeIterator(N) - Method in interface com.google.common.graph.GraphConnections
Returns an iterator over the incident edges.
incidentEdgeIterator(N) - Method in class com.google.common.graph.UndirectedGraphConnections
 
incidentEdgeMap - Variable in class com.google.common.graph.AbstractUndirectedNetworkConnections
Keys are edges incident to the origin node, values are the node at the other end.
incidentEdgeOrder - Variable in class com.google.common.graph.AbstractGraphBuilder
 
incidentEdgeOrder - Variable in class com.google.common.graph.StandardMutableValueGraph
 
incidentEdgeOrder() - Method in class com.google.common.graph.AbstractBaseGraph
 
incidentEdgeOrder() - Method in interface com.google.common.graph.BaseGraph
incidentEdgeOrder() - Method in class com.google.common.graph.ForwardingGraph
 
incidentEdgeOrder() - Method in class com.google.common.graph.ForwardingValueGraph
 
incidentEdgeOrder() - Method in interface com.google.common.graph.Graph
incidentEdgeOrder() - Method in class com.google.common.graph.ImmutableGraph
 
incidentEdgeOrder() - Method in class com.google.common.graph.ImmutableValueGraph
 
incidentEdgeOrder() - Method in class com.google.common.graph.StandardMutableValueGraph
 
incidentEdgeOrder() - Method in interface com.google.common.graph.ValueGraph
incidentEdgeOrder(ElementOrder<N1>) - Method in class com.google.common.graph.GraphBuilder
incidentEdgeOrder(ElementOrder<N1>) - Method in class com.google.common.graph.ValueGraphBuilder
incidentEdges() - Method in class com.google.common.graph.AbstractDirectedNetworkConnections
 
incidentEdges() - Method in class com.google.common.graph.AbstractUndirectedNetworkConnections
 
incidentEdges() - Method in interface com.google.common.graph.NetworkConnections
 
incidentEdges(N) - Method in class com.google.common.graph.AbstractBaseGraph
 
incidentEdges(N) - Method in interface com.google.common.graph.BaseGraph
Returns a live view of the edges in this graph whose endpoints include node.
incidentEdges(N) - Method in class com.google.common.graph.ForwardingGraph
 
incidentEdges(N) - Method in class com.google.common.graph.ForwardingNetwork
 
incidentEdges(N) - Method in interface com.google.common.graph.Graph
Returns a live view of the edges in this graph whose endpoints include node.
incidentEdges(N) - Method in class com.google.common.graph.Graphs.TransposedGraph
 
incidentEdges(N) - Method in interface com.google.common.graph.Network
Returns a live view of the edges whose incident nodes in this network include node.
incidentEdges(N) - Method in class com.google.common.graph.StandardNetwork
 
incidentEdges(N) - Method in class com.google.common.graph.StandardValueGraph
 
incidentEdges(N) - Method in interface com.google.common.graph.ValueGraph
Returns a live view of the edges in this graph whose endpoints include node.
IncidentEdgeSet<N> - Class in com.google.common.graph
Abstract base class for an incident edges set that allows different implementations of AbstractCollection.iterator().
IncidentEdgeSet(BaseGraph<N>, N) - Constructor for class com.google.common.graph.IncidentEdgeSet
 
incidentNodes(E) - Method in class com.google.common.graph.ForwardingNetwork
 
incidentNodes(E) - Method in class com.google.common.graph.Graphs.TransposedNetwork
 
incidentNodes(E) - Method in interface com.google.common.graph.Network
Returns the nodes which are the endpoints of edge in this network.
incidentNodes(E) - Method in class com.google.common.graph.StandardNetwork
 
includingEquals() - Method in class com.google.common.testing.ForwardingWrapperTester
inclusive - Variable in enum class com.google.common.collect.BoundType
 
INCLUSIVE - Enum constant in enum class com.google.common.collect.testing.DerivedCollectionGenerators.Bound
 
INCLUSIVE - Enum constant in enum class com.google.common.collect.testing.google.SortedMultisetTestSuiteBuilder.Bound
 
In combination with incidentEdgeOrder - Search tag in com.google.common.graph.ElementOrder.stable()
Section
IncomparableType() - Constructor for enum class com.google.common.collect.testing.testers.MapEntrySetTester.IncomparableType
 
IncomparableValueException(Object) - Constructor for exception class com.google.common.collect.Ordering.IncomparableValueException
 
IncompatibleKeyType() - Constructor for class com.google.common.collect.testing.MapInterfaceTest.IncompatibleKeyType
 
incompleteOutputCount - Variable in class com.google.common.util.concurrent.Futures.InCompletionOrderState
 
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.
InCompletionOrderFuture(Futures.InCompletionOrderState<T>) - Constructor for class com.google.common.util.concurrent.Futures.InCompletionOrderFuture
 
InCompletionOrderState(ListenableFuture<? extends T>[]) - Constructor for class com.google.common.util.concurrent.Futures.InCompletionOrderState
 
incorporateRequirements(TesterRequirements, TesterRequirements, Object) - Static method in class com.google.common.collect.testing.features.FeatureUtil
Incorporate additional requirements into an existing requirements object.
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() - Method in interface com.google.common.hash.LongAddable
 
increment() - Method in class com.google.common.hash.LongAddables.PureJavaLongAddable
 
increment() - Method in class com.google.common.hash.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.
incrementExpectedModCount() - Method in class com.google.common.collect.CompactHashMap.Itr
 
incrementModCount() - Method in class com.google.common.collect.CompactHashMap
 
incrementModCount() - Method in class com.google.common.collect.CompactHashSet
 
inDegree(N) - Method in class com.google.common.graph.AbstractBaseGraph
 
inDegree(N) - Method in class com.google.common.graph.AbstractNetwork
 
inDegree(N) - Method in interface com.google.common.graph.BaseGraph
Returns the count of node's incoming edges (equal to predecessors(node).size()) in a directed graph.
inDegree(N) - Method in class com.google.common.graph.ForwardingGraph
 
inDegree(N) - Method in class com.google.common.graph.ForwardingNetwork
 
inDegree(N) - Method in class com.google.common.graph.ForwardingValueGraph
 
inDegree(N) - Method in interface com.google.common.graph.Graph
Returns the count of node's incoming edges (equal to predecessors(node).size()) in a directed graph.
inDegree(N) - Method in class com.google.common.graph.Graphs.TransposedGraph
 
inDegree(N) - Method in class com.google.common.graph.Graphs.TransposedNetwork
 
inDegree(N) - Method in class com.google.common.graph.Graphs.TransposedValueGraph
 
inDegree(N) - Method in interface com.google.common.graph.Network
Returns the count of node's incoming edges in a directed network.
inDegree(N) - Method in interface com.google.common.graph.ValueGraph
Returns the count of node's incoming edges (equal to predecessors(node).size()) in a directed graph.
index - Variable in class com.google.common.collect.EnumMultiset.Itr
 
index - Variable in class com.google.common.collect.Streams.MapWithIndexSpliterator
 
index - Variable in class com.google.common.math.Quantiles.ScaleAndIndex
 
index - Variable in class com.google.common.util.concurrent.Striped.SmallLazyStriped.ArrayReference
 
index(int) - Method in class com.google.common.math.Quantiles.Scale
Specifies a single quantile index to be calculated, i.e.
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.
indexed(int, int, IntFunction<T>) - Static method in class com.google.common.collect.CollectSpliterators
 
indexed(int, int, IntFunction<T>, Comparator<? super T>) - Static method in class com.google.common.collect.CollectSpliterators
 
Indexed() - Constructor for class com.google.common.collect.ImmutableSet.Indexed
 
IndexedImmutableSet<E> - Class in com.google.common.collect
 
IndexedImmutableSet() - Constructor for class com.google.common.collect.IndexedImmutableSet
 
indexes - Variable in class com.google.common.math.Quantiles.ScaleAndIndexes
 
indexes(int...) - Method in class com.google.common.math.Quantiles.Scale
Specifies multiple quantile indexes to be calculated, each index being the k in the kth q-quantile.
indexes(Collection<Integer>) - Method in class com.google.common.math.Quantiles.Scale
Specifies multiple quantile indexes to be calculated, each index being the k in the kth q-quantile.
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.Any
 
indexIn(CharSequence) - Method in class com.google.common.base.CharMatcher
Returns the index of the first matching BMP character in a character sequence, or -1 if no matching character is present.
indexIn(CharSequence) - Method in class com.google.common.base.CharMatcher.None
 
indexIn(CharSequence, int) - Method in class com.google.common.base.CharMatcher.Any
 
indexIn(CharSequence, int) - Method in class com.google.common.base.CharMatcher
Returns the index of the first matching BMP character in a character sequence, starting from a given position, or -1 if no character matches after that position.
indexIn(CharSequence, int) - Method in class com.google.common.base.CharMatcher.None
 
indexMap(Collection<E>) - Static method in class com.google.common.collect.Maps
Returns a map from the ith element of list to i.
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[]) - 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(boolean[], boolean, int, int) - Static method in class com.google.common.primitives.Booleans
 
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[]) - 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(byte[], byte, int, int) - Static method in class com.google.common.primitives.Bytes
 
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[]) - 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(char[], char, int, int) - Static method in class com.google.common.primitives.Chars
 
indexOf(double) - Method in class com.google.common.primitives.ImmutableDoubleArray
Returns the smallest index for which ImmutableDoubleArray.get(int) returns target, or -1 if no such index exists.
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[]) - 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(double[], double, int, int) - Static method in class com.google.common.primitives.Doubles
 
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[]) - 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(float[], float, int, int) - Static method in class com.google.common.primitives.Floats
 
indexOf(int) - Method in class com.google.common.primitives.ImmutableIntArray
Returns the smallest index for which ImmutableIntArray.get(int) returns target, or -1 if no such index exists.
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[]) - 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(int[], int, int, int) - Static method in class com.google.common.primitives.Ints
 
indexOf(long) - Method in class com.google.common.primitives.ImmutableLongArray
Returns the smallest index for which ImmutableLongArray.get(int) returns target, or -1 if no such index exists.
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[]) - 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(long[], long, int, int) - Static method in class com.google.common.primitives.Longs
 
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[]) - 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(short[], short, int, int) - Static method in class com.google.common.primitives.Shorts
 
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(Object) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedList
 
indexOf(Object) - Method in class com.google.common.collect.CartesianList
 
indexOf(Object) - Method in class com.google.common.collect.CompactHashMap
 
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.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(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.RegularImmutableSortedSet
 
indexOf(Object) - Method in class com.google.common.collect.Synchronized.SynchronizedList
 
indexOf(Object) - Method in class com.google.common.primitives.Booleans.BooleanArrayAsList
 
indexOf(Object) - Method in class com.google.common.primitives.Bytes.ByteArrayAsList
 
indexOf(Object) - Method in class com.google.common.primitives.Chars.CharArrayAsList
 
indexOf(Object) - Method in class com.google.common.primitives.Doubles.DoubleArrayAsList
 
indexOf(Object) - Method in class com.google.common.primitives.Floats.FloatArrayAsList
 
indexOf(Object) - Method in class com.google.common.primitives.ImmutableDoubleArray.AsList
 
indexOf(Object) - Method in class com.google.common.primitives.ImmutableIntArray.AsList
 
indexOf(Object) - Method in class com.google.common.primitives.ImmutableLongArray.AsList
 
indexOf(Object) - Method in class com.google.common.primitives.Ints.IntArrayAsList
 
indexOf(Object) - Method in class com.google.common.primitives.Longs.LongArrayAsList
 
indexOf(Object) - Method in class com.google.common.primitives.Shorts.ShortArrayAsList
 
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.
indexOfImpl(List<?>, Object) - Static method in class com.google.common.collect.Lists
An implementation of List.indexOf(Object).
indexOfRandomAccess(List<?>, Object) - Static method in class com.google.common.collect.Lists
 
indexToRemove - Variable in class com.google.common.collect.CompactHashMap.Itr
 
inducedSubgraph(Graph<N>, Iterable<? extends N>) - Static method in class com.google.common.graph.Graphs
Returns the subgraph of graph induced by nodes.
inducedSubgraph(Network<N, E>, Iterable<? extends N>) - Static method in class com.google.common.graph.Graphs
Returns the subgraph of network induced by nodes.
inducedSubgraph(ValueGraph<N, V>, Iterable<? extends N>) - Static method in class com.google.common.graph.Graphs
Returns the subgraph of graph induced by nodes.
inEdgeMap - Variable in class com.google.common.graph.AbstractDirectedNetworkConnections
Keys are edges incoming to the origin node, values are the source node.
inEdges() - Method in class com.google.common.graph.AbstractDirectedNetworkConnections
 
inEdges() - Method in class com.google.common.graph.AbstractUndirectedNetworkConnections
 
inEdges() - Method in interface com.google.common.graph.NetworkConnections
 
inEdges(N) - Method in class com.google.common.graph.ForwardingNetwork
 
inEdges(N) - Method in class com.google.common.graph.Graphs.TransposedNetwork
 
inEdges(N) - Method in interface com.google.common.graph.Network
Returns a live view of all edges in this network which can be traversed in the direction (if any) of the edge to end at node.
inEdges(N) - Method in class com.google.common.graph.StandardNetwork
 
InetAddresses - Class in com.google.common.net
Static utility methods pertaining to InetAddress instances.
InetAddresses() - Constructor for class com.google.common.net.InetAddresses
 
InetAddresses.Scope - Class in com.google.common.net
 
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.
inferKeyTypeOrObjectUnderJ2cl(Map<K, ?>) - Static method in class com.google.common.collect.EnumBiMap
 
inferValueTypeOrObjectUnderJ2cl(Map<?, V>) - Static method in class com.google.common.collect.EnumBiMap
 
inGraph(SuccessorsFunction<N>) - Static method in class com.google.common.graph.Traverser.Traversal
 
inheritableThreadLocals - Static variable in class com.google.common.base.internal.Finalizer
 
init() - Method in class com.google.common.util.concurrent.AggregateFuture
Must be called at the end of each subclass's constructor.
init(int) - Method in class com.google.common.collect.CompactHashMap
Pseudoconstructor for serialization support.
init(int) - Method in class com.google.common.collect.CompactHashSet
Pseudoconstructor for serialization support.
init(int) - Method in class com.google.common.collect.CompactLinkedHashMap
 
init(int) - Method in class com.google.common.collect.CompactLinkedHashSet
 
init(int) - Method in class com.google.common.collect.HashBiMap
 
init(G, String) - Method in class com.google.common.collect.testing.AbstractTester
 
init(G, String, Runnable, Runnable) - Method in class com.google.common.collect.testing.AbstractTester
 
initAnnotatedTypeExists() - Static method in class com.google.common.reflect.Invokable
 
initCollectionWithNullElement() - Method in class com.google.common.collect.testing.AbstractCollectionTester
 
initialCapacity - Variable in class com.google.common.cache.CacheBuilder
 
initialCapacity - Variable in class com.google.common.cache.CacheBuilderSpec
 
initialCapacity - Variable in class com.google.common.collect.MapMaker
 
initialCapacity(int) - Method in class com.google.common.cache.CacheBuilder
Sets the minimum total size for the internal hash tables.
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
 
initializeOrUpdateCancellationDelegate(AbstractScheduledService.CustomScheduler.Schedule) - Method in class com.google.common.util.concurrent.AbstractScheduledService.CustomScheduler.ReschedulableCallable
 
initialQueueSize(int, int, Iterable<?>) - Static method in class com.google.common.collect.MinMaxPriorityQueue
 
initMapWithNullKey() - Method in class com.google.common.collect.testing.AbstractMapTester
 
initMapWithNullValue() - Method in class com.google.common.collect.testing.AbstractMapTester
 
initMultimapWithNullKey() - Method in class com.google.common.collect.testing.google.AbstractMultimapTester
 
initMultimapWithNullKeyAndValue() - Method in class com.google.common.collect.testing.google.AbstractMultimapTester
 
initMultimapWithNullValue() - Method in class com.google.common.collect.testing.google.AbstractMultimapTester
 
initNanoTime(long) - Static method in class com.google.common.util.concurrent.Monitor
Returns System.nanoTime() unless the timeout has already elapsed.
initTable(AtomicReferenceArray<ReferenceEntry<K, V>>) - Method in class com.google.common.cache.LocalCache.Segment
 
initTable(AtomicReferenceArray<E>) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
 
initThreeCopies() - Method in class com.google.common.collect.testing.google.AbstractMultisetTester
 
InMemoryPrintStream() - Constructor for class com.google.common.testing.ArbitraryInstances.Dummies.InMemoryPrintStream
 
InMemoryPrintWriter() - Constructor for class com.google.common.testing.ArbitraryInstances.Dummies.InMemoryPrintWriter
 
INNER_CAPACITY - Static variable in class com.google.common.graph.GraphConstants
 
INNER_LOAD_FACTOR - Static variable in class com.google.common.graph.GraphConstants
 
innerNodeCode - Variable in enum class com.google.thirdparty.publicsuffix.PublicSuffixType
The character used for an inner node in the trie encoding
inOrder() - Method in interface com.google.common.collect.testing.SpliteratorTester.Ordered
Attests that the expected values must not just be present but must be present in the order they were given.
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.AbstractCatchingFuture
 
inputFuture - Variable in class com.google.common.util.concurrent.AbstractTransformFuture
 
inputFutures - Variable in class com.google.common.util.concurrent.Futures.InCompletionOrderState
 
inputFutures() - Method in class com.google.common.util.concurrent.ClosingFuture.Combiner
 
inputList - Variable in class com.google.common.collect.Collections2.OrderedPermutationCollection
 
inputList - Variable in class com.google.common.collect.Collections2.PermutationCollection
 
inputs - Variable in class com.google.common.util.concurrent.ClosingFuture.Combiner
 
inputSet - Variable in class com.google.common.collect.Sets.PowerSet
 
inputSet - Variable in class com.google.common.collect.Sets.SubSet
 
inRange(char, char) - Static method in class com.google.common.base.CharMatcher
Returns a char matcher that matches any character in a given BMP range (both endpoints are inclusive).
InRange(char, char) - Constructor for class com.google.common.base.CharMatcher.InRange
 
InsecureRecursiveDeleteException - Exception Class in com.google.common.io
Exception indicating that a recursive delete can't be performed because the file system does not have the support necessary to guarantee that it is not vulnerable to race conditions that would allow it to delete files and directories outside of the directory being deleted (i.e., SecureDirectoryStream is not supported).
InsecureRecursiveDeleteException(String) - Constructor for exception class com.google.common.io.InsecureRecursiveDeleteException
 
insert(HashBiMap.BiEntry<K, V>, HashBiMap.BiEntry<K, V>) - Method in class com.google.common.collect.HashBiMap
 
insertEntry(int, E, int, int) - Method in class com.google.common.collect.CompactHashSet
Creates a fresh entry with the specified object at the specified position in the entry arrays.
insertEntry(int, E, int, int) - Method in class com.google.common.collect.CompactLinkedHashSet
 
insertEntry(int, K, V, int, int) - Method in class com.google.common.collect.CompactHashMap
Creates a fresh entry with the specified object at the specified position in the entry arrays.
insertEntry(int, K, V, int, int) - Method in class com.google.common.collect.CompactLinkedHashMap
 
insertInHashTable(E) - Method in class com.google.common.collect.ImmutableSet.RegularSetBuilderImpl
 
insertInto(Deque<T>, T) - Method in enum class com.google.common.graph.Traverser.InsertionOrder
 
insertion() - Static method in class com.google.common.graph.ElementOrder
Returns an instance which specifies that insertion ordering is guaranteed.
INSERTION - Enum constant in enum class com.google.common.graph.ElementOrder.Type
 
insertionOrder - Variable in class com.google.common.collect.TableCollectors.ImmutableTableCollectorState
 
InsertionOrder() - Constructor for enum class com.google.common.graph.Traverser.InsertionOrder
 
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 - Variable in class com.google.common.base.Suppliers.SupplierOfInstance
 
instance() - Static method in class com.google.common.collect.ImmutableSet.EmptySetBuilderImpl
 
instance() - Static method in class com.google.common.collect.MapMakerInternalMap.StrongKeyDummyValueEntry.Helper
 
instance() - Static method in class com.google.common.collect.MapMakerInternalMap.StrongKeyStrongValueEntry.Helper
 
instance() - Static method in class com.google.common.collect.MapMakerInternalMap.StrongKeyWeakValueEntry.Helper
 
instance() - Static method in class com.google.common.collect.MapMakerInternalMap.WeakKeyDummyValueEntry.Helper
 
instance() - Static method in class com.google.common.collect.MapMakerInternalMap.WeakKeyStrongValueEntry.Helper
 
instance() - Static method in class com.google.common.collect.MapMakerInternalMap.WeakKeyWeakValueEntry.Helper
 
instance() - Static method in enum class com.google.common.collect.MultimapBuilder.LinkedListSupplier
 
INSTANCE - Enum constant in enum class com.google.common.base.Functions.IdentityFunction
 
INSTANCE - Enum constant in enum class com.google.common.base.Functions.ToStringFunction
 
INSTANCE - Enum constant in enum class com.google.common.base.Suppliers.SupplierFunctionImpl
 
INSTANCE - Enum constant in enum class com.google.common.cache.CacheBuilder.NullListener
 
INSTANCE - Enum constant in enum class com.google.common.cache.CacheBuilder.OneWeigher
 
INSTANCE - Enum constant in enum class com.google.common.cache.LocalCache.NullEntry
 
INSTANCE - Enum constant in enum class com.google.common.collect.Iterators.EmptyModifiableIterator
 
INSTANCE - Enum constant in enum class com.google.common.collect.MultimapBuilder.LinkedListSupplier
 
INSTANCE - Enum constant in enum class com.google.common.collect.testing.testers.MapEntrySetTester.IncomparableType
 
INSTANCE - Enum constant in enum class com.google.common.hash.Funnels.ByteArrayFunnel
 
INSTANCE - Enum constant in enum class com.google.common.hash.Funnels.IntegerFunnel
 
INSTANCE - Enum constant in enum class com.google.common.hash.Funnels.LongFunnel
 
INSTANCE - Enum constant in enum class com.google.common.hash.Funnels.UnencodedCharsFunnel
 
INSTANCE - Enum constant in enum class com.google.common.hash.LittleEndianByteArray.JavaLittleEndianBytes
 
INSTANCE - Enum constant in enum class com.google.common.primitives.Booleans.LexicographicalComparator
 
INSTANCE - Enum constant in enum class com.google.common.primitives.Chars.LexicographicalComparator
 
INSTANCE - Enum constant in enum class com.google.common.primitives.Doubles.LexicographicalComparator
 
INSTANCE - Enum constant in enum class com.google.common.primitives.Floats.LexicographicalComparator
 
INSTANCE - Enum constant in enum class com.google.common.primitives.Ints.LexicographicalComparator
 
INSTANCE - Enum constant in enum class com.google.common.primitives.Longs.LexicographicalComparator
 
INSTANCE - Enum constant in enum class com.google.common.primitives.Shorts.LexicographicalComparator
 
INSTANCE - Enum constant in enum class com.google.common.primitives.SignedBytes.LexicographicalComparator
 
INSTANCE - Enum constant in enum class com.google.common.primitives.UnsignedBytes.LexicographicalComparatorHolder.PureJavaComparator
 
INSTANCE - Enum constant in enum class com.google.common.primitives.UnsignedBytes.LexicographicalComparatorHolder.UnsafeComparator
 
INSTANCE - Enum constant in enum class com.google.common.primitives.UnsignedInts.LexicographicalComparator
 
INSTANCE - Enum constant in enum class com.google.common.primitives.UnsignedLongs.LexicographicalComparator
 
INSTANCE - Enum constant in enum class com.google.common.util.concurrent.DirectExecutor
 
INSTANCE - Enum constant in enum class com.google.common.util.concurrent.FuturesGetChecked.GetCheckedTypeValidatorHolder.ClassValueValidator
 
INSTANCE - Enum constant in enum class com.google.common.util.concurrent.FuturesGetChecked.GetCheckedTypeValidatorHolder.WeakSetValidator
 
INSTANCE - Static variable in class com.google.common.base.Absent
 
INSTANCE - Static variable in class com.google.common.base.CharMatcher.Any
 
INSTANCE - Static variable in class com.google.common.base.CharMatcher.Ascii
 
INSTANCE - Static variable in class com.google.common.base.CharMatcher.BreakingWhitespace
 
INSTANCE - Static variable in class com.google.common.base.CharMatcher.Digit
 
INSTANCE - Static variable in class com.google.common.base.CharMatcher.Invisible
 
INSTANCE - Static variable in class com.google.common.base.CharMatcher.JavaDigit
 
INSTANCE - Static variable in class com.google.common.base.CharMatcher.JavaIsoControl
 
INSTANCE - Static variable in class com.google.common.base.CharMatcher.JavaLetter
 
INSTANCE - Static variable in class com.google.common.base.CharMatcher.JavaLetterOrDigit
 
INSTANCE - Static variable in class com.google.common.base.CharMatcher.JavaLowerCase
 
INSTANCE - Static variable in class com.google.common.base.CharMatcher.JavaUpperCase
 
INSTANCE - Static variable in class com.google.common.base.CharMatcher.None
 
INSTANCE - Static variable in class com.google.common.base.CharMatcher.SingleWidth
 
INSTANCE - Static variable in class com.google.common.base.CharMatcher.Whitespace
 
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 - 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.EmptyImmutableListMultimap
 
INSTANCE - Static variable in class com.google.common.collect.EmptyImmutableSetMultimap
 
INSTANCE - Static variable in class com.google.common.collect.ImmutableSet.EmptySetBuilderImpl
 
INSTANCE - Static variable in class com.google.common.collect.MapMakerInternalMap.StrongKeyDummyValueEntry.Helper
 
INSTANCE - Static variable in class com.google.common.collect.MapMakerInternalMap.StrongKeyStrongValueEntry.Helper
 
INSTANCE - Static variable in class com.google.common.collect.MapMakerInternalMap.StrongKeyWeakValueEntry.Helper
 
INSTANCE - Static variable in class com.google.common.collect.MapMakerInternalMap.WeakKeyDummyValueEntry.Helper
 
INSTANCE - Static variable in class com.google.common.collect.MapMakerInternalMap.WeakKeyStrongValueEntry.Helper
 
INSTANCE - Static variable in class com.google.common.collect.MapMakerInternalMap.WeakKeyWeakValueEntry.Helper
 
INSTANCE - Static variable in class com.google.common.collect.Multisets.DecreasingCount
 
INSTANCE - Static variable in class com.google.common.collect.NaturalOrdering
 
INSTANCE - Static variable in class com.google.common.collect.Range.RangeLexOrdering
 
INSTANCE - Static variable in class com.google.common.collect.ReverseNaturalOrdering
 
INSTANCE - Static variable in class com.google.common.collect.testing.Helpers.NullsBeforeB
 
INSTANCE - Static variable in class com.google.common.collect.testing.Helpers.NullsBeforeTwo
 
INSTANCE - Static variable in class com.google.common.collect.UsingToStringOrdering
 
INSTANCE - Static variable in class com.google.common.eventbus.Dispatcher.ImmediateDispatcher
 
INSTANCE - Static variable in class com.google.common.eventbus.EventBus.LoggingHandler
 
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.TempFileCreator
 
INSTANCE - Static variable in class com.google.common.math.BigDecimalMath.BigDecimalToDoubleRounder
 
INSTANCE - Static variable in class com.google.common.math.BigIntegerMath.BigIntegerToDoubleRounder
 
INSTANCE - Static variable in class com.google.common.math.LinearTransformation.NaNLinearTransformation
 
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
 
INSTANCE - Static variable in class com.google.common.reflect.TypeResolver.WildcardCapturer
 
INSTANCE - Static variable in class com.google.common.testing.ArbitraryInstances.AlwaysEqual
 
INSTANCE - Static variable in class com.google.common.testing.ArbitraryInstances.ByToString
 
INSTANCE - Static variable in class com.google.common.testing.ArbitraryInstances.NullByteSink
 
INSTANCE - Static variable in class com.google.common.util.concurrent.ImmediateFuture.ImmediateCancelledFuture
 
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
 
instantiate(Invokable<?, ? extends T>) - Method in class com.google.common.testing.ClassSanityTester
Instantiates using factory.
instantiate(Class<T>) - Method in class com.google.common.testing.ClassSanityTester
Instantiates cls by invoking one of its non-private constructors or non-private static factory methods with the parameters automatically provided using dummy values.
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 class 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.
InteractionTester(Class<T>, Method) - Constructor for class com.google.common.testing.ForwardingWrapperTester.InteractionTester
 
INTERFACE_ONLY - Enum constant in enum class com.google.common.reflect.TypeToken.TypeFilter
 
interfaceMethodCalled(Class<?>, Method) - Method in class com.google.common.testing.FreshValueGenerator
Subclasses can override to provide different return value for proxied interface methods.
interfaces - Variable in class com.google.common.reflect.TypeToken.InterfaceSet
 
interfaces() - Method in class com.google.common.reflect.TypeToken.ClassSet
 
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.TypeSet) - Constructor for class com.google.common.reflect.TypeToken.InterfaceSet
 
interfaceType - Variable in class com.google.common.testing.DummyProxy.DummyHandler
 
interfaceType - Variable in class com.google.common.testing.ForwardingWrapperTester.InteractionTester
 
interfaceType - Variable in class com.google.common.testing.FreshValueGenerator.FreshInvocationHandler
 
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.InternerImpl
 
Internal - Class in com.google.common.base
This class is for com.google.common.base use only!
Internal - Class in com.google.common.util.concurrent
This class is for com.google.common.util.concurrent use only!
Internal() - Constructor for class com.google.common.base.Internal
 
Internal() - Constructor for class com.google.common.util.concurrent.Internal
 
internalArray() - Method in class com.google.common.collect.ImmutableCollection
If this collection is backed by an array of its elements in insertion order, returns it.
internalArray() - Method in class com.google.common.collect.RegularImmutableAsList
 
internalArray() - Method in class com.google.common.collect.RegularImmutableList
 
internalArray() - Method in class com.google.common.collect.RegularImmutableSet
 
internalArray() - Method in class com.google.common.collect.RegularImmutableSortedSet
 
internalArrayEnd() - Method in class com.google.common.collect.ImmutableCollection
If this collection is backed by an array of its elements in insertion order, returns the offset where this collection's elements end.
internalArrayEnd() - Method in class com.google.common.collect.RegularImmutableAsList
 
internalArrayEnd() - Method in class com.google.common.collect.RegularImmutableList
 
internalArrayEnd() - Method in class com.google.common.collect.RegularImmutableSet
 
internalArrayEnd() - Method in class com.google.common.collect.RegularImmutableSortedSet
 
internalArrayStart() - Method in class com.google.common.collect.ImmutableCollection
If this collection is backed by an array of its elements in insertion order, returns the offset where this collection's elements start.
internalArrayStart() - Method in class com.google.common.collect.RegularImmutableAsList
 
internalArrayStart() - Method in class com.google.common.collect.RegularImmutableList
 
internalArrayStart() - Method in class com.google.common.collect.RegularImmutableSet
 
internalArrayStart() - Method in class com.google.common.collect.RegularImmutableSortedSet
 
internalExecuteAndCompare(T, T, AbstractIteratorTester.IteratorOperation) - Method in class com.google.common.collect.testing.AbstractIteratorTester
Apply this method to both iterators and return normally only if both produce the same response.
InternalFutureFailureAccess - Class in com.google.common.util.concurrent.internal
A future that, if it fails, may optionally provide access to the cause of the failure.
InternalFutureFailureAccess() - Constructor for class com.google.common.util.concurrent.internal.InternalFutureFailureAccess
Constructor for use by subclasses.
InternalFutures - Class in com.google.common.util.concurrent.internal
Static utilities for InternalFutureFailureAccess.
InternalFutures() - Constructor for class com.google.common.util.concurrent.internal.InternalFutures
 
internalReset(long) - Method in class com.google.common.cache.Striped64
Sets base and all cells to the given value.
internalReset(long) - Method in class com.google.common.hash.Striped64
Sets base and all cells to the given value.
interner - Variable in class com.google.common.collect.Interners.InternerFunction
 
Interner<E> - Interface in com.google.common.collect
Provides similar behavior to String.intern() for any immutable type.
InternerBuilder() - Constructor for class com.google.common.collect.Interners.InternerBuilder
 
InternerFunction(Interner<E>) - Constructor for class com.google.common.collect.Interners.InternerFunction
 
InternerImpl(MapMaker) - Constructor for class com.google.common.collect.Interners.InternerImpl
 
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.InternerBuilder - Class in com.google.common.collect
Builder for Interner instances.
Interners.InternerFunction<E> - Class in com.google.common.collect
 
Interners.InternerImpl<E> - Class 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.
InternetDomainName(String, ImmutableList<String>) - Constructor for class com.google.common.net.InternetDomainName
Internal constructor that skips validations when creating an instance from parts of an already-validated InternetDomainName, as in InternetDomainName.ancestor(int).
interpolate(double, double, double, double) - Static method in class com.google.common.math.Quantiles
Returns a value a fraction (remainder / scale) of the way between lower and upper.
InterruptibleTask<T> - Class in com.google.common.util.concurrent
 
InterruptibleTask() - Constructor for class com.google.common.util.concurrent.InterruptibleTask
 
InterruptibleTask.Blocker - Class in com.google.common.util.concurrent
Using this as the blocker object allows introspection and debugging tools to see that the currentRunner thread is blocked on the progress of the interruptor thread, which can help identify deadlocks.
InterruptibleTask.DoNothingRunnable - Class in com.google.common.util.concurrent
 
interruptTask() - Method in class com.google.common.util.concurrent.AbstractFuture
Subclasses can override this method to implement interruption of the future's computation.
interruptTask() - Method in class com.google.common.util.concurrent.CombinedFuture
 
interruptTask() - Method in class com.google.common.util.concurrent.InterruptibleTask
Interrupts the running task.
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.
intersect(Set<?>, Set<?>) - Static method in class com.google.common.collect.testing.FeatureSpecificTestSuiteBuilder
 
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(ContiguousSet<C>) - Method in class com.google.common.collect.RegularContiguousSet
 
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(RangeSet<C>) - Method in class com.google.common.collect.ImmutableRangeSet
Returns a new range set consisting of the intersection of this range set and other.
intersection(Set<? extends T>, Set<? extends T>) - Static method in class com.google.common.collect.testing.features.FeatureUtil
Construct a new Set that is the intersection of the given sets.
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.
intersects(Range<C>) - Method in class com.google.common.collect.AbstractRangeSet
 
intersects(Range<C>) - Method in class com.google.common.collect.ImmutableRangeSet
 
intersects(Range<C>) - Method in interface com.google.common.collect.RangeSet
Returns true if there exists a non-empty range enclosed by both a member range in this range set and the specified range.
intersects(Range<C>) - Method in class com.google.common.collect.TreeRangeSet
 
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
 
inTree(SuccessorsFunction<N>) - Static method in class com.google.common.graph.Traverser.Traversal
 
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.collect.testing.SampleElements.Ints
 
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 Class in com.google.common.primitives
 
IntsMethodsForWeb - Class in com.google.common.primitives
Holder for web specializations of methods of Ints.
IntsMethodsForWeb() - Constructor for class com.google.common.primitives.IntsMethodsForWeb
 
intsToDoubles(int[]) - Static method in class com.google.common.math.Quantiles
 
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.hash.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
 
InvalidatableSet<E> - Class in com.google.common.graph
A subclass of `ForwardingSet` that throws `IllegalStateException` on invocation of any method (except `hashCode` and `equals`) if the provided `Supplier` returns false.
InvalidatableSet(Set<E>, Supplier<Boolean>, Supplier<String>) - Constructor for class com.google.common.graph.InvalidatableSet
 
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() - Method in class com.google.common.cache.AbstractCache
 
invalidateAll() - Method in interface com.google.common.cache.Cache
Discards all entries in the cache.
invalidateAll() - Method in class com.google.common.cache.ForwardingCache
 
invalidateAll() - Method in class com.google.common.cache.LocalCache.LocalManualCache
 
invalidateAll(Iterable<?>) - Method in class com.google.common.cache.LocalCache
 
invalidateAll(Iterable<?>) - Method in class com.google.common.cache.LocalCache.LocalManualCache
 
invalidateAll(Iterable<? extends Object>) - Method in class com.google.common.cache.AbstractCache
 
invalidateAll(Iterable<? extends Object>) - Method in interface com.google.common.cache.Cache
Discards any cached values for keys keys.
invalidateAll(Iterable<? extends Object>) - Method in class com.google.common.cache.ForwardingCache
 
InvalidCacheLoadException(String) - Constructor for exception class com.google.common.cache.CacheLoader.InvalidCacheLoadException
 
invariantly(Type) - Static method in class com.google.common.reflect.TypeResolver
Returns a resolver that resolves types "invariantly".
invariantTypeResolver - Variable in class com.google.common.reflect.TypeToken
Resolver for resolving parameter and field types with TypeToken.runtimeType as context.
inverse - Variable in class com.google.common.collect.AbstractBiMap
 
inverse - Variable in class com.google.common.collect.HashBiMap
 
inverse - Variable in class com.google.common.collect.ImmutableListMultimap
 
inverse - Variable in class com.google.common.collect.ImmutableSetMultimap
 
inverse - Variable in class com.google.common.collect.JdkBackedImmutableBiMap
 
inverse - Variable in class com.google.common.collect.Maps.FilteredEntryBiMap
 
inverse - Variable in class com.google.common.collect.Maps.UnmodifiableBiMap
 
inverse - Variable in class com.google.common.collect.RegularImmutableBiMap
 
inverse - Variable in class com.google.common.collect.SingletonImmutableBiMap
 
inverse - Variable in class com.google.common.collect.Synchronized.SynchronizedBiMap
 
inverse - Variable in class com.google.common.math.LinearTransformation.RegularLinearTransformation
 
inverse - Variable in class com.google.common.math.LinearTransformation.VerticalLinearTransformation
 
inverse() - Method in class com.google.common.collect.AbstractBiMap
 
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.HashBiMap
 
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() - 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() - Method in class com.google.common.collect.ImmutableSetMultimap
Returns an immutable multimap which is the inverse of this one.
inverse() - Method in class com.google.common.collect.JdkBackedImmutableBiMap
 
inverse() - Method in class com.google.common.collect.Maps.FilteredEntryBiMap
 
inverse() - Method in class com.google.common.collect.Maps.UnmodifiableBiMap
 
inverse() - Method in class com.google.common.collect.RegularImmutableBiMap
 
inverse() - Method in class com.google.common.collect.RegularImmutableBiMap.Inverse
 
inverse() - Method in class com.google.common.collect.SingletonImmutableBiMap
 
inverse() - Method in class com.google.common.collect.Synchronized.SynchronizedBiMap
 
inverse() - Method in class com.google.common.math.LinearTransformation
Returns the inverse linear transformation.
inverse() - Method in class com.google.common.math.LinearTransformation.NaNLinearTransformation
 
inverse() - Method in class com.google.common.math.LinearTransformation.RegularLinearTransformation
 
inverse() - Method in class com.google.common.math.LinearTransformation.VerticalLinearTransformation
 
Inverse() - Constructor for class com.google.common.collect.HashBiMap.Inverse
 
Inverse() - Constructor for class com.google.common.collect.RegularImmutableBiMap.Inverse
 
Inverse(Map<K, V>, AbstractBiMap<V, K>) - Constructor for class com.google.common.collect.AbstractBiMap.Inverse
 
INVERSE - Enum constant in enum class com.google.common.collect.testing.google.BiMapTestSuiteBuilder.NoRecurse
 
INVERSE_COMPUTE_FOR_WORD_OF_ALL_1S - Static variable in class com.google.common.hash.Crc32cHashFunction.Crc32cHasher
 
InverseBiMapGenerator(OneSizeTestContainerGenerator<BiMap<K, V>, Map.Entry<K, V>>) - Constructor for class com.google.common.collect.testing.google.DerivedGoogleCollectionGenerators.InverseBiMapGenerator
 
InverseEntries() - Constructor for class com.google.common.collect.JdkBackedImmutableBiMap.InverseEntries
 
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
 
INVERTED_INSERTION_INDEX - Enum constant in enum class com.google.common.collect.SortedLists.KeyAbsentBehavior
Return ~insertionIndex, where insertionIndex is defined as the point at which the key would be inserted into the list: the index of the next higher element in the list, or list.size() if there is no such element.
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.
Invertibility - Search tag in class com.google.common.base.Converter
Section
invisible() - Static method in class com.google.common.base.CharMatcher
Deprecated.
Most invisible characters are supplementary characters; see the class documentation.
Invisible() - Constructor for class com.google.common.base.CharMatcher.Invisible
 
invokable(Object, Method) - Static method in class com.google.common.testing.NullPointerTester
 
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(Invokable<?, ? extends T>, List<?>) - Static method in class com.google.common.testing.ClassSanityTester
 
invoke(Object, Method, Object[]) - Method in class com.google.common.reflect.AbstractInvocationHandler
proxy.hashCode() delegates to AbstractInvocationHandler.hashCode() proxy.toString() delegates to AbstractInvocationHandler.toString() proxy.equals(argument) returns true if: proxy and argument are of the same type and AbstractInvocationHandler.equals(java.lang.Object) returns true for the InvocationHandler of argument other method calls are dispatched to AbstractInvocationHandler.handleInvocation(java.lang.Object, java.lang.reflect.Method, java.lang.Object[]).
invoke(Object, Method, Object[]) - Method in class com.google.common.reflect.Types.TypeVariableInvocationHandler
 
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.
invokeAccessibleNonThrowingMethod(Method, Object, Object...) - Static method in class com.google.common.base.Throwables
 
invokeAll(Collection<? extends Callable<T>>) - 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>>) - Method in class com.google.common.util.concurrent.testing.SameThreadScheduledExecutorService
 
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.ForwardingExecutorService
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in interface com.google.common.util.concurrent.ListeningExecutorService
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.google.common.util.concurrent.testing.SameThreadScheduledExecutorService
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.google.common.util.concurrent.WrappingExecutorService
 
invokeAll(Collection<? extends Callable<T>>, Duration) - Method in interface com.google.common.util.concurrent.ListeningExecutorService
invokeAny(Collection<? extends Callable<T>>) - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
invokeAny(Collection<? extends Callable<T>>) - Method in class com.google.common.util.concurrent.testing.SameThreadScheduledExecutorService
 
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.ForwardingExecutorService
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.google.common.util.concurrent.testing.SameThreadScheduledExecutorService
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.google.common.util.concurrent.WrappingExecutorService
 
invokeAny(Collection<? extends Callable<T>>, Duration) - Method in interface com.google.common.util.concurrent.ListeningExecutorService
invokeAnyImpl(ListeningExecutorService, Collection<? extends Callable<T>>, boolean, long, TimeUnit) - Static method in class com.google.common.util.concurrent.MoreExecutors
invokeAnyImpl(ListeningExecutorService, Collection<? extends Callable<T>>, boolean, Duration) - Static method in class com.google.common.util.concurrent.MoreExecutors
invokeGeneratorMethod(Method, Object...) - Method in class com.google.common.testing.FreshValueGenerator
 
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
 
invokeSubscriberMethod(Object) - Method in class com.google.common.eventbus.Subscriber
Invokes the subscriber method.
invokeSubscriberMethod(Object) - Method in class com.google.common.eventbus.Subscriber.SynchronizedSubscriber
 
ipStringToBytes(String, InetAddresses.Scope) - Static method in class com.google.common.net.InetAddresses
Returns null if unable to parse into a byte[].
IPV4_DELIMITER - Static variable in class com.google.common.net.InetAddresses
 
IPV4_DELIMITER_MATCHER - Static variable in class com.google.common.net.InetAddresses
 
IPV4_PART_COUNT - Static variable in class com.google.common.net.InetAddresses
 
IPV6_DELIMITER - Static variable in class com.google.common.net.InetAddresses
 
IPV6_DELIMITER_MATCHER - 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 BMP 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.
is(Type, TypeVariable<?>) - Method in class com.google.common.reflect.TypeToken
A.is(B) is defined as Foo<A>.isSubtypeOf(Foo<B>).
Is(char) - Constructor for class com.google.common.base.CharMatcher.Is
 
IS_DIRECTORY - Enum constant in enum class com.google.common.io.Files.FilePredicate
 
IS_FILE - Enum constant in enum class com.google.common.io.Files.FilePredicate
 
IS_NULL - Enum constant in enum class com.google.common.base.Predicates.ObjectPredicate
 
is6to4Address(Inet6Address) - Static method in class com.google.common.net.InetAddresses
Evaluates whether the argument is a 6to4 address.
isAbstract() - Method in class com.google.common.reflect.Invokable
Returns true if the method is abstract.
isAccessible() - Method in class com.google.common.reflect.Invokable
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
 
isActuallyE(Object) - Method in class com.google.common.collect.EnumMultiset
 
isAnnotationPresent(Class<? extends Annotation>) - Method in class com.google.common.reflect.Invokable
 
isAnnotationPresent(Class<? extends Annotation>) - Method in class com.google.common.reflect.Parameter
 
isAppEngineWithApiClasses() - 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.
isCancelled() - Method in class com.google.common.util.concurrent.AbstractFuture
 
isCancelled() - Method in class com.google.common.util.concurrent.AbstractFuture.TrustedFuture
 
isCancelled() - Method in interface com.google.common.util.concurrent.AbstractScheduledService.Cancellable
 
isCancelled() - Method in class com.google.common.util.concurrent.AbstractScheduledService.CustomScheduler.SupplantableFuture
 
isCancelled() - Method in class com.google.common.util.concurrent.AbstractScheduledService.FutureAsCancellable
 
isCancelled() - Method in class com.google.common.util.concurrent.FluentFuture.TrustedFuture
 
isCancelled() - Method in class com.google.common.util.concurrent.ForwardingFluentFuture
 
isCancelled() - Method in class com.google.common.util.concurrent.ForwardingFuture
 
isCancelled() - Method in class com.google.common.util.concurrent.ImmediateFuture
 
isCheckedException(Class<? extends Exception>) - Static method in class com.google.common.util.concurrent.FuturesGetChecked
 
isCollected(E) - Static method in class com.google.common.collect.MapMakerInternalMap.Segment
Returns true if the value has been partially collected, meaning that the value is null.
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.
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.
isDeclaredThreadSafe(Method) - Static method in class com.google.common.eventbus.Subscriber
Checks whether method is thread-safe, as indicated by the presence of the AllowConcurrentEvents annotation.
isDirected - Variable in class com.google.common.graph.StandardNetwork
 
isDirected - Variable in class com.google.common.graph.StandardValueGraph
 
isDirected() - Method in interface com.google.common.graph.BaseGraph
Returns true if the edges in this graph are directed.
isDirected() - Method in class com.google.common.graph.ForwardingGraph
 
isDirected() - Method in class com.google.common.graph.ForwardingNetwork
 
isDirected() - Method in class com.google.common.graph.ForwardingValueGraph
 
isDirected() - Method in interface com.google.common.graph.Graph
Returns true if the edges in this graph are directed.
isDirected() - Method in interface com.google.common.graph.Network
Returns true if the edges in this network are directed.
isDirected() - Method in class com.google.common.graph.StandardNetwork
 
isDirected() - Method in class com.google.common.graph.StandardValueGraph
 
isDirected() - Method in interface com.google.common.graph.ValueGraph
Returns true if the edges in this graph are directed.
isDirectory() - Static method in class com.google.common.io.Files
Returns a predicate that returns the result of File.isDirectory() on input files.
isDirectory(LinkOption...) - Static method in class com.google.common.io.MoreFiles
Returns a predicate that returns the result of Files.isDirectory(Path, LinkOption...) on input paths with the given link options.
isDirectory(SecureDirectoryStream<Path>, Path, LinkOption...) - Static method in class com.google.common.io.MoreFiles
Returns whether or not the file with the given name in the given dir is a directory.
isDone - Variable in class com.google.common.hash.Murmur3_32HashFunction.Murmur3_32Hasher
 
isDone() - Method in interface com.google.common.testing.GcFinalization.FinalizationPredicate
 
isDone() - Method in class com.google.common.util.concurrent.AbstractFuture
 
isDone() - Method in class com.google.common.util.concurrent.AbstractFuture.TrustedFuture
 
isDone() - Method in class com.google.common.util.concurrent.CombinedFuture.CombinedFutureInterruptibleTask
 
isDone() - Method in class com.google.common.util.concurrent.FluentFuture.TrustedFuture
 
isDone() - Method in class com.google.common.util.concurrent.ForwardingFluentFuture
 
isDone() - Method in class com.google.common.util.concurrent.ForwardingFuture
 
isDone() - Method in class com.google.common.util.concurrent.ImmediateFuture
 
isDone() - Method in class com.google.common.util.concurrent.InterruptibleTask
Called before runInterruptibly - if true, runInterruptibly and afterRanInterruptibly will not be called.
isDone() - Method in class com.google.common.util.concurrent.TrustedListenableFutureTask.TrustedFutureInterruptibleAsyncTask
 
isDone() - Method in class com.google.common.util.concurrent.TrustedListenableFutureTask.TrustedFutureInterruptibleTask
 
ISE - Static variable in exception class com.google.common.collect.testing.AbstractIteratorTester.PermittedMetaException
 
isEither(char, char) - Static method in class com.google.common.base.CharMatcher
 
IsEither(char, char) - Constructor for class com.google.common.base.CharMatcher.IsEither
 
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
Returns true if rowKeyList().size == 0 or columnKeyList().size() == 0.
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.CompactHashMap
 
isEmpty() - Method in class com.google.common.collect.CompactHashSet
 
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.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() - 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.Lists.TransformingSequentialList
 
isEmpty() - Method in class com.google.common.collect.MapMakerInternalMap.EntrySet
 
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.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.Sets.PowerSet
 
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 class com.google.common.collect.Synchronized.SynchronizedTable
 
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.testing.SafeTreeMap
 
isEmpty() - Method in class com.google.common.collect.testing.SafeTreeSet
 
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.ImmutableDoubleArray
Returns true if there are no values in this array (ImmutableDoubleArray.length() is zero).
isEmpty() - Method in class com.google.common.primitives.ImmutableIntArray
Returns true if there are no values in this array (ImmutableIntArray.length() is zero).
isEmpty() - Method in class com.google.common.primitives.ImmutableLongArray
Returns true if there are no values in this array (ImmutableLongArray.length() is zero).
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.
isEmpty(Iterable<?>) - Static method in class com.google.common.collect.Iterables
Determines if the given iterable contains no elements.
isEmpty(Iterable<?>) - Static method in class com.google.common.collect.testing.Helpers
 
isEmpty(Object) - Static method in class com.google.common.base.MoreObjects.ToStringHelper
 
isEquals(Member) - Static method in class com.google.common.testing.NullPointerTester
Returns true if the given member is a method that overrides Object.equals(Object).
isEqualsDefined(Class<?>) - Static method in class com.google.common.testing.AbstractPackageSanityTests
 
IsEqualToPredicate(Object) - Constructor for class com.google.common.base.Predicates.IsEqualToPredicate
 
isEvenLevel(int) - Static method in class com.google.common.collect.MinMaxPriorityQueue
 
isExpectedType(Throwable) - Method in enum class com.google.common.testing.NullPointerTester.ExceptionTypePolicy
 
isExpired(ReferenceEntry<K, V>, long) - Method in class com.google.common.cache.LocalCache
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.Invokable
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.EmptyContiguousSet
 
isHashCodeFast() - Method in class com.google.common.collect.ImmutableEnumSet
 
isHashCodeFast() - Method in class com.google.common.collect.ImmutableMap
 
isHashCodeFast() - Method in class com.google.common.collect.ImmutableMap.MapViewOfValuesAsSingletonSets
 
isHashCodeFast() - Method in class com.google.common.collect.ImmutableMapEntrySet
 
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.RegularImmutableBiMap
 
isHashCodeFast() - Method in class com.google.common.collect.RegularImmutableSet
 
isHealthy() - Method in class com.google.common.util.concurrent.ServiceManager
Returns true if all services are currently in the running state.
isHorizontal() - Method in class com.google.common.math.LinearTransformation
Returns whether this is a horizontal transformation.
isHorizontal() - Method in class com.google.common.math.LinearTransformation.NaNLinearTransformation
 
isHorizontal() - Method in class com.google.common.math.LinearTransformation.RegularLinearTransformation
 
isHorizontal() - Method in class com.google.common.math.LinearTransformation.VerticalLinearTransformation
 
isIgnored(Member) - Method in class com.google.common.testing.NullPointerTester
 
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.
isInOrder(Iterable<? extends T>, Comparator<T>) - Static method in class com.google.common.collect.Comparators
Returns true if each element in iterable after the first is greater than or equal to the element that preceded it, according to the specified comparator.
isInstanceOfThrowableClass(Throwable, Class<? extends Throwable>) - Static method in class com.google.common.util.concurrent.Platform
 
isInStrictOrder(Iterable<? extends T>, Comparator<T>) - Static method in class com.google.common.collect.Comparators
Returns true if each element in iterable after the first is strictly greater than the element that preceded it, according to the specified comparator.
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(C) - Method in class com.google.common.collect.Cut.AboveValue
 
isLessThan(C) - Method in class com.google.common.collect.Cut.BelowValue
 
isLessThan(C) - Method in class com.google.common.collect.Cut
 
isLessThan(Comparable<?>) - Method in class com.google.common.collect.Cut.AboveAll
 
isLessThan(Comparable<?>) - Method in class com.google.common.collect.Cut.BelowAll
 
isLive(ReferenceEntry<K, V>, long) - Method in class com.google.common.cache.LocalCache
This method is a convenience for testing.
isLiveForTesting(MapMakerInternalMap.InternalEntry<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.ComputingValueReference
 
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 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.Invokable
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 BMP character specified.
IsNot(char) - Constructor for class com.google.common.base.CharMatcher.IsNot
 
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.
isNullable(Invokable<?, ?>) - Static method in class com.google.common.testing.NullPointerTester
 
isNullable(Invokable<?, ?>) - Method in enum class com.google.common.testing.NullPointerTester.NullnessAnnotationReader
 
isNullable(Parameter) - Static method in class com.google.common.testing.NullPointerTester
 
isNullable(Parameter) - Method in enum class com.google.common.testing.NullPointerTester.NullnessAnnotationReader
 
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() - Method in class com.google.common.graph.EndpointPair
Returns true if this EndpointPair is an ordered pair (i.e.
isOrdered() - Method in class com.google.common.graph.EndpointPair.Ordered
 
isOrdered() - Method in class com.google.common.graph.EndpointPair.Unordered
 
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.
isOrderingCompatible(EndpointPair<?>) - Method in class com.google.common.graph.AbstractBaseGraph
Returns true iff endpoints' ordering is compatible with the directionality of this graph.
isOrderingCompatible(EndpointPair<?>) - Method in class com.google.common.graph.AbstractNetwork
 
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
 
isOwnedBySubtypeOf(Type) - Method in class com.google.common.reflect.TypeToken
 
isPackagePrivate() - Method in class com.google.common.reflect.Invokable
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.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.ElementSet
 
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.JdkBackedImmutableBiMap.InverseEntries
 
isPartialView() - Method in class com.google.common.collect.JdkBackedImmutableBiMap
 
isPartialView() - Method in class com.google.common.collect.JdkBackedImmutableMap
 
isPartialView() - Method in class com.google.common.collect.JdkBackedImmutableMultiset
 
isPartialView() - Method in class com.google.common.collect.JdkBackedImmutableSet
 
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.RegularImmutableMap.KeySet
 
isPartialView() - Method in class com.google.common.collect.RegularImmutableMap.Values
 
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
 
isPartialView() - Method in class com.google.common.primitives.ImmutableDoubleArray
 
isPartialView() - Method in class com.google.common.primitives.ImmutableIntArray
 
isPartialView() - Method in class com.google.common.primitives.ImmutableLongArray
 
isPcreLike() - Static method in class com.google.common.base.CommonPattern
 
isPcreLike() - Method in interface com.google.common.base.PatternCompiler
Returns true if the regex implementation behaves like Perl -- notably, by supporting possessive quantifiers but also being susceptible to catastrophic backtracking.
isPcreLike() - Method in class com.google.common.base.Platform.JdkPatternCompiler
 
isPermitted(Exception) - Method in exception class com.google.common.collect.testing.AbstractIteratorTester.PermittedMetaException
 
isPermutation(List<?>, List<?>) - Static method in class com.google.common.collect.Collections2
Returns true if the second list is a permutation of the first.
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.
isPowerOfTwo(BigInteger) - Static method in class com.google.common.math.BigIntegerMath
Returns true if x represents a power of two.
isPredecessor(Object) - Static method in class com.google.common.graph.DirectedGraphConnections
 
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
 
isPrime(int) - Static method in class com.google.common.math.IntMath
Returns true if n is a prime number: an integer greater than one that cannot be factored into a product of smaller positive integers.
isPrime(long) - Static method in class com.google.common.math.LongMath
Returns true if n is a prime number: an integer greater than one that cannot be factored into a product of smaller positive integers.
isPrimitive() - Method in class com.google.common.reflect.TypeToken
Returns true if this type is one of the nine primitive types (including void).
isPrimitiveOrNullable(Parameter) - Static method in class com.google.common.testing.NullPointerTester
 
isPrivate() - Method in class com.google.common.reflect.Invokable
Returns true if the element is private.
isProtected() - Method in class com.google.common.reflect.Invokable
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.Invokable
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
 
isRegistrySuffix() - Method in class com.google.common.net.InternetDomainName
Indicates whether this domain name represents a registry suffix, as defined by a subset of the Mozilla Foundation's Public Suffix List (PSL).
isRegularFile(LinkOption...) - Static method in class com.google.common.io.MoreFiles
Returns a predicate that returns the result of Files.isRegularFile(Path, LinkOption...) on input paths with the given link options.
isReusable() - Method in class com.google.common.collect.ImmutableMapEntry
Returns true if this entry has no bucket links and can safely be reused as a terminal entry in a bucket in another map.
isReusable() - Method in class com.google.common.collect.ImmutableMapEntry.NonTerminalImmutableMapEntry
 
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.AbstractService.HasReachedRunningGuard
 
isSatisfied() - Method in class com.google.common.util.concurrent.AbstractService.IsStartableGuard
 
isSatisfied() - Method in class com.google.common.util.concurrent.AbstractService.IsStoppableGuard
 
isSatisfied() - Method in class com.google.common.util.concurrent.AbstractService.IsStoppedGuard
 
isSatisfied() - Method in class com.google.common.util.concurrent.Monitor.Guard
Evaluates this guard's boolean condition.
isSatisfied() - Method in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState.AwaitHealthGuard
 
isSatisfied() - Method in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState.StoppedGuard
 
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.
isShutdown() - Method in class com.google.common.util.concurrent.DirectExecutorService
 
isShutdown() - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
isShutdown() - Method in class com.google.common.util.concurrent.MoreExecutors.ListeningDecorator
 
isShutdown() - Method in class com.google.common.util.concurrent.testing.SameThreadScheduledExecutorService
 
isShutdown() - Method in class com.google.common.util.concurrent.testing.TestingExecutors.NoOpScheduledExecutorService
 
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
 
IsStartableGuard() - Constructor for class com.google.common.util.concurrent.AbstractService.IsStartableGuard
 
isStatic() - Method in class com.google.common.reflect.Invokable
Returns true if the element is static.
isStoppable - Variable in class com.google.common.util.concurrent.AbstractService
 
IsStoppableGuard() - Constructor for class com.google.common.util.concurrent.AbstractService.IsStoppableGuard
 
isStopped - Variable in class com.google.common.util.concurrent.AbstractService
 
IsStoppedGuard() - Constructor for class com.google.common.util.concurrent.AbstractService.IsStoppedGuard
 
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.
isSubtypeOf(TypeToken<?>) - Method in class com.google.common.reflect.TypeToken
Returns true if this type is a subtype of the given type.
isSubtypeOf(Type) - Method in class com.google.common.reflect.TypeToken.Bounds
 
isSubtypeOf(Type) - Method in class com.google.common.reflect.TypeToken
Returns true if this type is a subtype of the given type.
isSubtypeOfArrayType(GenericArrayType) - Method in class com.google.common.reflect.TypeToken
 
isSubtypeOfParameterizedType(ParameterizedType) - Method in class com.google.common.reflect.TypeToken
 
isSuccessor(Object) - Static method in class com.google.common.graph.DirectedGraphConnections
 
isSupertypeOf(TypeToken<?>) - Method in class com.google.common.reflect.TypeToken
Returns true if this type is a supertype of the given type.
isSupertypeOf(Type) - Method in class com.google.common.reflect.TypeToken.Bounds
 
isSupertypeOf(Type) - Method in class com.google.common.reflect.TypeToken
Returns true if this type is a supertype of the given type.
isSupertypeOfArray(GenericArrayType) - Method in class com.google.common.reflect.TypeToken
 
isSynchronized() - Method in class com.google.common.reflect.Invokable
Returns true if the method is synchronized.
isSynthetic() - Method in class com.google.common.reflect.Invokable
 
isTeredoAddress(Inet6Address) - Static method in class com.google.common.net.InetAddresses
Evaluates whether the argument is a Teredo address.
isTerminated() - Method in class com.google.common.util.concurrent.DirectExecutorService
 
isTerminated() - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
isTerminated() - Method in class com.google.common.util.concurrent.MoreExecutors.ListeningDecorator
 
isTerminated() - Method in class com.google.common.util.concurrent.testing.SameThreadScheduledExecutorService
 
isTerminated() - Method in class com.google.common.util.concurrent.testing.TestingExecutors.NoOpScheduledExecutorService
 
isTerminated() - Method in class com.google.common.util.concurrent.WrappingExecutorService
 
isThreadScheduled - Variable in class com.google.common.util.concurrent.ListenerCallQueue.PerListenerQueue
 
isTopDomainUnderRegistrySuffix() - Method in class com.google.common.net.InternetDomainName
Indicates whether this domain name is composed of exactly one subdomain component followed by a registry suffix.
isTopLevel() - Method in class com.google.common.reflect.ClassPath.ClassInfo
Returns true if the class name "looks to be" top level (not nested), that is, it includes no '$' in the name.
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.Invokable
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.
isUnderRegistrySuffix() - Method in class com.google.common.net.InternetDomainName
Indicates whether this domain name ends in a registry suffix, while not being a registry 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.
isUsingHashFloodingResistance() - Method in class com.google.common.collect.CompactHashSet
 
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.
isValidClass - Static variable in enum class com.google.common.util.concurrent.FuturesGetChecked.GetCheckedTypeValidatorHolder.ClassValueValidator
 
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
 
isVertical() - Method in class com.google.common.math.LinearTransformation
Returns whether this is a vertical transformation.
isVertical() - Method in class com.google.common.math.LinearTransformation.NaNLinearTransformation
 
isVertical() - Method in class com.google.common.math.LinearTransformation.RegularLinearTransformation
 
isVertical() - Method in class com.google.common.math.LinearTransformation.VerticalLinearTransformation
 
isVisible(int) - Method in enum class com.google.common.testing.NullPointerTester.Visibility
 
isVisible(Member) - Method in enum class com.google.common.testing.NullPointerTester.Visibility
Returns true if member is visible under this visibility.
isVolatile() - Method in class com.google.common.reflect.Invokable
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
 
Item(T, int, int) - Constructor for class com.google.common.testing.RelationshipTester.Item
 
itemNumber - Variable in class com.google.common.testing.RelationshipTester.Item
 
itemReporter - Variable in class com.google.common.testing.EqualsTester
 
itemReporter - Variable in class com.google.common.testing.RelationshipTester
 
ItemReporter() - Constructor for class com.google.common.testing.RelationshipTester.ItemReporter
 
items - Variable in class com.google.common.testing.EquivalenceTester
 
iterable - Variable in class com.google.common.collect.Iterables.UnmodifiableIterable
 
iterable(Object, Object, Object[]) - Static method in class com.google.common.base.Joiner
 
iterableDelegate - Variable in class com.google.common.collect.FluentIterable
 
Iterables - Class in com.google.common.collect
An assortment of mainly legacy static utility methods that operate on or return objects of type Iterable.
Iterables() - Constructor for class com.google.common.collect.Iterables
 
Iterables.UnmodifiableIterable<T> - Class in com.google.common.collect
 
iterator - Variable in class com.google.common.collect.Iterators.ConcatenatedIterator
 
iterator - Variable in class com.google.common.collect.Iterators.PeekingImpl
 
iterator - Variable in class com.google.common.collect.StandardTable.Column.EntrySetIterator
 
iterator - Variable in class com.google.common.collect.testing.MinimalIterable
 
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.ElementSet
 
iterator() - Method in class com.google.common.collect.AbstractMultiset.EntrySet
 
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.CompactHashMap.EntrySetView
 
iterator() - Method in class com.google.common.collect.CompactHashMap.KeySetView
 
iterator() - Method in class com.google.common.collect.CompactHashMap.ValuesView
 
iterator() - Method in class com.google.common.collect.CompactHashSet
 
iterator() - Method in class com.google.common.collect.ConcurrentHashMultiset
 
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.EnumMultiset
 
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.ForwardingMultiset.StandardElementSet
 
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.ImmutableMapEntrySet.RegularEntrySet
 
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
 
iterator() - Method in class com.google.common.collect.ImmutableRangeSet.AsSet
 
iterator() - Method in class com.google.common.collect.ImmutableSet.Indexed
 
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.IndexedImmutableSet
 
iterator() - Method in class com.google.common.collect.Iterables.UnmodifiableIterable
 
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.MapMakerInternalMap.EntrySet
 
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 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.Multisets.ViewMultiset
 
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.RegularImmutableSet
 
iterator() - Method in class com.google.common.collect.RegularImmutableSortedSet
 
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.SetView
Scope the return type to UnmodifiableIterator to ensure this is an unmodifiable view.
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.SortedMultisets.ElementSet
 
iterator() - Method in class com.google.common.collect.StandardTable.Column.EntrySet
 
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.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.testing.MinimalCollection
 
iterator() - Method in class com.google.common.collect.testing.MinimalIterable
 
iterator() - Method in class com.google.common.collect.testing.SafeTreeSet
 
iterator() - Method in class com.google.common.collect.testing.SampleElements
 
iterator() - Method in class com.google.common.collect.TreeMultiset
 
iterator() - Method in class com.google.common.graph.EdgesConnecting
 
iterator() - Method in class com.google.common.graph.EndpointPair
iterator() - Method in class com.google.common.graph.MultiEdgesConnecting
 
iterator(Splitter, CharSequence) - Method in interface com.google.common.base.Splitter.Strategy
 
IteratorBasedAbstractMap() - Constructor for class com.google.common.collect.Maps.IteratorBasedAbstractMap
 
IteratorBasedImmutableMap() - Constructor for class com.google.common.collect.ImmutableMap.IteratorBasedImmutableMap
 
IteratorFeature - Enum Class in com.google.common.collect.testing
A method supported by implementations of the Iterator or ListIterator interface.
IteratorFeature() - Constructor for enum class com.google.common.collect.testing.IteratorFeature
 
iteratorImpl(Multiset<E>) - Static method in class com.google.common.collect.Multisets
An implementation of Multiset.iterator().
iteratorOrListIterator(Collection<E>) - Static method in class com.google.common.collect.AbstractMapBasedMultimap
 
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.ArrayItr<T> - Class in com.google.common.collect
 
Iterators.ConcatenatedIterator<T> - Class in com.google.common.collect
 
Iterators.EmptyModifiableIterator - Enum Class in com.google.common.collect
This is an enum singleton rather than an anonymous class so ProGuard can figure out it's only referenced by emptyModifiableIterator().
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.
Iterators.SingletonIterator<T> - Class in com.google.common.collect
 
iteratorStimuli() - Method in class com.google.common.collect.testing.AbstractIteratorTester
 
IteratorTester<E> - Class in com.google.common.collect.testing
A utility for testing an Iterator implementation by comparing its behavior to that of a "known good" reference implementation.
IteratorTester(int, Iterable<? extends IteratorFeature>, Iterable<E>, AbstractIteratorTester.KnownOrder) - Constructor for class com.google.common.collect.testing.IteratorTester
Creates an IteratorTester.
Itr() - Constructor for class com.google.common.collect.AbstractMapBasedMultimap.Itr
 
Itr() - Constructor for class com.google.common.collect.CompactHashMap.Itr
 
Itr() - Constructor for class com.google.common.collect.EnumMultiset.Itr
 
Itr() - Constructor for class com.google.common.collect.HashBiMap.Itr
 

J

j - Variable in class com.google.common.collect.Collections2.PermutationIterator
 
J2ktIncompatible - Annotation Interface in com.google.common.annotations
The presence of this annotation on an API indicates that the method may not be used with J2kt.
JAVA_CLASS_PATH - Enum constant in enum class com.google.common.base.StandardSystemProperty
Java class path.
JAVA_CLASS_VERSION - Enum constant in enum class com.google.common.base.StandardSystemProperty
Java class format version number.
JAVA_COMPILER - Enum constant in enum class com.google.common.base.StandardSystemProperty
Name of JIT compiler to use.
JAVA_EXT_DIRS - Enum constant in enum class com.google.common.base.StandardSystemProperty
Deprecated.
This property was deprecated in Java 8 and removed in Java 9. We do not plan to remove this API from Guava, but if you are using it, it is probably not doing what you want.
JAVA_HOME - Enum constant in enum class com.google.common.base.StandardSystemProperty
Java installation directory.
JAVA_IO_TMPDIR - Enum constant in enum class com.google.common.base.StandardSystemProperty
Default temp file path.
JAVA_LANG_ACCESS_CLASSNAME - Static variable in class com.google.common.base.Throwables
JavaLangAccess class name to load using reflection
JAVA_LIBRARY_PATH - Enum constant in enum class com.google.common.base.StandardSystemProperty
List of paths to search when loading libraries.
JAVA_SPECIFICATION_NAME - Enum constant in enum class com.google.common.base.StandardSystemProperty
Java Runtime Environment specification name.
JAVA_SPECIFICATION_VENDOR - Enum constant in enum class com.google.common.base.StandardSystemProperty
Java Runtime Environment specification vendor.
JAVA_SPECIFICATION_VERSION - Enum constant in enum class com.google.common.base.StandardSystemProperty
Java Runtime Environment specification version.
JAVA_UTIL_ZIP - Enum constant in enum class com.google.common.hash.Hashing.Crc32CSupplier
 
JAVA_VENDOR - Enum constant in enum class com.google.common.base.StandardSystemProperty
Java Runtime Environment vendor.
JAVA_VENDOR_URL - Enum constant in enum class com.google.common.base.StandardSystemProperty
Java vendor URL.
JAVA_VERSION - Enum constant in enum class com.google.common.base.StandardSystemProperty
Java Runtime Environment version.
JAVA_VM_NAME - Enum constant in enum class com.google.common.base.StandardSystemProperty
Java Virtual Machine implementation name.
JAVA_VM_SPECIFICATION_NAME - Enum constant in enum class com.google.common.base.StandardSystemProperty
Java Virtual Machine specification name.
JAVA_VM_SPECIFICATION_VENDOR - Enum constant in enum class com.google.common.base.StandardSystemProperty
Java Virtual Machine specification vendor.
JAVA_VM_SPECIFICATION_VERSION - Enum constant in enum class com.google.common.base.StandardSystemProperty
Java Virtual Machine specification version.
JAVA_VM_VENDOR - Enum constant in enum class com.google.common.base.StandardSystemProperty
Java Virtual Machine implementation vendor.
JAVA_VM_VERSION - Enum constant in enum class com.google.common.base.StandardSystemProperty
Java Virtual Machine implementation version.
java.util.concurrent.CompletableFuture / java.util.concurrent.CompletionStage - Search tag in class com.google.common.util.concurrent.FluentFuture
Section
java.util.Objects.requireNonNull() - Search tag in class com.google.common.base.Preconditions
Section
JAVA6 - Enum constant in enum class com.google.common.reflect.Types.JavaVersion
 
JAVA7 - Enum constant in enum class com.google.common.reflect.Types.JavaVersion
 
JAVA8 - Enum constant in enum class com.google.common.reflect.Types.JavaVersion
 
Java 8+ equivalents - Search tag in class com.google.common.collect.ComparisonChain
Section
Java 8+ users - Search tag in class com.google.common.collect.Ordering
Section
Java8Compatibility - Class in com.google.common.base
Wrappers around Buffer methods that are covariantly overridden in Java 9+.
Java8Compatibility - Class in com.google.common.hash
Wrappers around Buffer methods that are covariantly overridden in Java 9+.
Java8Compatibility - Class in com.google.common.io
Wrappers around Buffer methods that are covariantly overridden in Java 9+.
Java8Compatibility() - Constructor for class com.google.common.base.Java8Compatibility
 
Java8Compatibility() - Constructor for class com.google.common.hash.Java8Compatibility
 
Java8Compatibility() - Constructor for class com.google.common.io.Java8Compatibility
 
JAVA9 - Enum constant in enum class com.google.common.reflect.Types.JavaVersion
 
javaDigit() - Static method in class com.google.common.base.CharMatcher
Deprecated.
Many digits are supplementary characters; see the class documentation.
JavaDigit() - Constructor for class com.google.common.base.CharMatcher.JavaDigit
 
JavaIoCreator() - Constructor for class com.google.common.io.TempFileCreator.JavaIoCreator
 
javaIsoControl() - Static method in class com.google.common.base.CharMatcher
Determines whether a character is an ISO control character as specified by Character.isISOControl(char).
JavaIsoControl() - Constructor for class com.google.common.base.CharMatcher.JavaIsoControl
 
javaLetter() - Static method in class com.google.common.base.CharMatcher
Deprecated.
Most letters are supplementary characters; see the class documentation.
JavaLetter() - Constructor for class com.google.common.base.CharMatcher.JavaLetter
 
javaLetterOrDigit() - Static method in class com.google.common.base.CharMatcher
Deprecated.
Most letters and digits are supplementary characters; see the class documentation.
JavaLetterOrDigit() - Constructor for class com.google.common.base.CharMatcher.JavaLetterOrDigit
 
JavaLittleEndianBytes() - Constructor for enum class com.google.common.hash.LittleEndianByteArray.JavaLittleEndianBytes
 
javaLowerCase() - Static method in class com.google.common.base.CharMatcher
Deprecated.
Some lowercase characters are supplementary characters; see the class documentation.
JavaLowerCase() - Constructor for class com.google.common.base.CharMatcher.JavaLowerCase
 
JavaNioCreator() - Constructor for class com.google.common.io.TempFileCreator.JavaNioCreator
 
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.
javaUpperCase() - Static method in class com.google.common.base.CharMatcher
Deprecated.
Some uppercase characters are supplementary characters; see the class documentation.
JavaUpperCase() - Constructor for class com.google.common.base.CharMatcher.JavaUpperCase
 
JavaVersion() - Constructor for enum class com.google.common.reflect.Types.JavaVersion
 
JdkBackedImmutableBiMap<K,V> - Class in com.google.common.collect
Implementation of ImmutableBiMap backed by a pair of JDK HashMaps, which have smartness protecting against hash flooding.
JdkBackedImmutableBiMap(ImmutableList<Map.Entry<K, V>>, Map<K, V>, Map<V, K>) - Constructor for class com.google.common.collect.JdkBackedImmutableBiMap
 
JdkBackedImmutableBiMap.InverseEntries - Class in com.google.common.collect
 
JdkBackedImmutableMap<K,V> - Class in com.google.common.collect
Implementation of ImmutableMap backed by a JDK HashMap, which has smartness protecting against hash flooding.
JdkBackedImmutableMap(Map<K, V>, ImmutableList<Map.Entry<K, V>>) - Constructor for class com.google.common.collect.JdkBackedImmutableMap
 
JdkBackedImmutableMultiset<E> - Class in com.google.common.collect
An implementation of ImmutableMultiset backed by a JDK Map and a list of entries.
JdkBackedImmutableMultiset(Map<E, Integer>, ImmutableList<Multiset.Entry<E>>, long) - Constructor for class com.google.common.collect.JdkBackedImmutableMultiset
 
JdkBackedImmutableSet<E> - Class in com.google.common.collect
ImmutableSet implementation backed by a JDK HashSet, used to defend against apparent hash flooding.
JdkBackedImmutableSet(Set<?>, ImmutableList<E>) - Constructor for class com.google.common.collect.JdkBackedImmutableSet
 
JdkBackedSetBuilderImpl(ImmutableSet.SetBuilderImpl<E>) - Constructor for class com.google.common.collect.ImmutableSet.JdkBackedSetBuilderImpl
 
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.
JdkMatcher(Matcher) - Constructor for class com.google.common.base.JdkPattern.JdkMatcher
 
JdkPattern - Class in com.google.common.base
A regex pattern implementation which is backed by the Pattern.
JdkPattern(Pattern) - Constructor for class com.google.common.base.JdkPattern
 
JdkPattern.JdkMatcher - Class in com.google.common.base
 
JdkPatternCompiler() - Constructor for class com.google.common.base.Platform.JdkPatternCompiler
 
jdkTypeDuplicatesOwnerName() - Method in enum class com.google.common.reflect.Types.JavaVersion
 
jla - Static variable in class com.google.common.base.Throwables
Access to some fancy internal JVM internals.
jlaStackTrace(Throwable) - Static method in class com.google.common.base.Throwables
 
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(Iterable<? extends 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(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(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(String, boolean...) - Static method in class com.google.common.primitives.Booleans
Returns a string containing the supplied boolean 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, 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, 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.Longs
Returns a string containing the supplied long 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.
join(String, short...) - Static method in class com.google.common.primitives.Shorts
Returns a string containing the supplied short values separated by separator.
join(Iterator<? extends 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(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(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.
joiner - Variable in class com.google.common.base.Joiner.MapJoiner
 
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(Joiner) - Constructor for class com.google.common.base.Joiner
 
Joiner(String) - Constructor for class com.google.common.base.Joiner
 
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.
joinUninterruptibly(Thread, Duration) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes unit.timedJoin(toJoin, timeout) uninterruptibly.
JOSE - Static variable in class com.google.common.net.MediaType
JOSE_JSON - Static variable in class com.google.common.net.MediaType
JP2K - Static variable in class com.google.common.net.MediaType
JPEG - Static variable in class com.google.common.net.MediaType
 
JSON_UTF_8 - Static variable in class com.google.common.net.MediaType
 
justAfterNull - Variable in class com.google.common.collect.testing.Helpers.NullsBefore
 
JVM_BEHAVIOR - Static variable in enum class com.google.common.reflect.Types.ClassOwnership
 
JWT - Static variable in class com.google.common.net.MediaType

K

k - Variable in class com.google.common.collect.TopKSelector
 
k0 - Variable in class com.google.common.hash.SipHashFunction
 
k0() - Method in class com.google.common.collect.testing.AbstractMapTester
 
k0() - Method in class com.google.common.collect.testing.google.AbstractMultimapTester
 
K0 - Static variable in class com.google.common.hash.FarmHashFingerprint64
 
K0 - Static variable in class com.google.common.hash.Fingerprint2011
 
k1 - Variable in class com.google.common.hash.SipHashFunction
 
k1() - Method in class com.google.common.collect.testing.AbstractMapTester
 
k1() - Method in class com.google.common.collect.testing.google.AbstractMultimapTester
 
K1 - Static variable in class com.google.common.hash.FarmHashFingerprint64
 
K1 - Static variable in class com.google.common.hash.Fingerprint2011
 
k2() - Method in class com.google.common.collect.testing.AbstractMapTester
 
k2() - Method in class com.google.common.collect.testing.google.AbstractMultimapTester
 
K2 - Static variable in class com.google.common.hash.FarmHashFingerprint64
 
K2 - Static variable in class com.google.common.hash.Fingerprint2011
 
k3() - Method in class com.google.common.collect.testing.AbstractMapTester
 
k3() - Method in class com.google.common.collect.testing.google.AbstractMultimapTester
 
K3 - Static variable in class com.google.common.hash.Fingerprint2011
 
k4() - Method in class com.google.common.collect.testing.AbstractMapTester
 
k4() - Method in class com.google.common.collect.testing.google.AbstractMultimapTester
 
KEEP_ALIVE - Static variable in class com.google.common.net.HttpHeaders
The HTTP Keep-Alive header field name.
key - Variable in enum class com.google.common.base.StandardSystemProperty
 
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.collect.AbstractMapBasedMultimap.Itr
 
key - Variable in class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection
 
key - Variable in class com.google.common.collect.CompactHashMap.MapEntry
 
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.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.AbstractStrongKeyEntry
 
key - Variable in class com.google.common.collect.MapMakerInternalMap.WriteThroughEntry
 
key - Variable in class com.google.common.graph.MapRetrievalCache.CacheEntry
 
key - Variable in class com.google.common.hash.MacHashFunction
 
key() - Method in enum class com.google.common.base.StandardSystemProperty
Returns the key used to look up this system property.
key(int) - Method in class com.google.common.collect.CompactHashMap
 
KEY - Enum constant in enum class com.google.common.collect.Maps.EntryFunction
 
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 class com.google.common.collect.SortedLists.KeyAbsentBehavior
 
keyComparator - Variable in class com.google.common.collect.ImmutableMultimap.Builder
 
keyComparator - Variable in class com.google.common.collect.testing.Helpers.EntryComparator
 
keyComparator - Variable in class com.google.common.collect.TreeMultimap
 
keyComparator() - Method in class com.google.common.collect.TreeMultimap
Deprecated.
Use ((NavigableSet<K>) multimap.keySet()).comparator() instead.
keyEquivalence - Variable in class com.google.common.cache.CacheBuilder
 
keyEquivalence - Variable in class com.google.common.cache.LocalCache
Strategy for comparing keys.
keyEquivalence - Variable in class com.google.common.cache.LocalCache.ManualSerializationProxy
 
keyEquivalence - Variable in class com.google.common.collect.MapMaker
 
keyEquivalence - Variable in class com.google.common.collect.MapMakerInternalMap.AbstractSerializationProxy
 
keyEquivalence - Variable in class com.google.common.collect.MapMakerInternalMap
Strategy for comparing keys.
keyEquivalence(Equivalence<Object>) - Method in class com.google.common.cache.CacheBuilder
Sets a custom Equivalence strategy for comparing keys.
keyEquivalence(Equivalence<Object>) - Method in class com.google.common.collect.MapMaker
Sets a custom Equivalence 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 - Variable in class com.google.common.collect.AbstractMapBasedMultimap.Itr
 
keyIterator() - Method in class com.google.common.collect.ImmutableEnumMap
 
keyIterator() - Method in class com.google.common.collect.ImmutableMap
 
keyIterator(Iterator<Map.Entry<K, V>>) - Static method in class com.google.common.collect.Maps
 
KeyIterator() - Constructor for class com.google.common.cache.LocalCache.KeyIterator
 
KeyIterator() - Constructor for class com.google.common.collect.MapMakerInternalMap.KeyIterator
 
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 class com.google.common.collect.SortedLists.KeyPresentBehavior
 
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.
keys - Variable in class com.google.common.collect.AbstractMultimap
 
keys - Variable in class com.google.common.collect.CompactHashMap
The keys of the entries in the map, in the range of [0, size()).
keys - Variable in class com.google.common.collect.ImmutableMap.SerializedForm
 
keys - Variable in class com.google.common.collect.Multimaps.UnmodifiableMultimap
 
keys - Variable in class com.google.common.collect.Synchronized.SynchronizedMultimap
 
keys - Variable in class com.google.common.collect.testing.TestMapEntrySetGenerator
 
keys() - Method in class com.google.common.collect.AbstractMultimap
 
keys() - Method in class com.google.common.collect.ForwardingMultimap
 
keys() - Method in class com.google.common.collect.ImmutableMultimap
Returns an immutable multiset containing all the keys in this multimap, in the same order and with the same frequencies as they appear in this multimap; to get only a single occurrence of each key, use ImmutableMultimap.keySet().
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() - Method in class com.google.common.collect.Multimaps.UnmodifiableMultimap
 
keys() - Method in class com.google.common.collect.Synchronized.SynchronizedMultimap
 
keys() - Method in class com.google.common.collect.testing.testers.MapReplaceAllTester
 
Keys() - Constructor for class com.google.common.collect.FilteredEntryMultimap.Keys
 
Keys() - Constructor for class com.google.common.collect.ImmutableMultimap.Keys
 
Keys(Multimap<K, V>) - Constructor for class com.google.common.collect.Multimaps.Keys
 
KEYS_SPLITTER - Static variable in class com.google.common.cache.CacheBuilderSpec
Splits each key-value pair.
keySet - Variable in class com.google.common.cache.LocalCache
 
keySet - Variable in class com.google.common.collect.AbstractBiMap
 
keySet - Variable in class com.google.common.collect.AbstractMultimap
 
keySet - Variable in class com.google.common.collect.ImmutableMap
 
keySet - Variable in class com.google.common.collect.ImmutableSortedMap
 
keySet - Variable in class com.google.common.collect.MapMakerInternalMap
 
keySet - Variable in class com.google.common.collect.Maps.ViewCachingAbstractMap
 
keySet - Variable in class com.google.common.collect.Multimaps.UnmodifiableMultimap
 
keySet - Variable 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.cache.LocalCache
 
keySet() - Method in class com.google.common.collect.AbstractBiMap
 
keySet() - Method in class com.google.common.collect.AbstractMapBasedMultimap.AsMap
 
keySet() - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableAsMap
 
keySet() - Method in class com.google.common.collect.AbstractMapBasedMultimap.SortedAsMap
 
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.CompactHashMap
 
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() - Method in class com.google.common.collect.ImmutableMap
Returns an immutable set of the keys in this map, in the same order that they appear in ImmutableMap.entrySet.
keySet() - Method in class com.google.common.collect.ImmutableMultimap
Returns an immutable set of the distinct keys in this multimap, in the same order as they appear in this multimap.
keySet() - Method in class com.google.common.collect.ImmutableSortedMap
Returns an immutable sorted set of the keys in this map.
keySet() - Method in class com.google.common.collect.LinkedHashMultimap
Returns a view collection of all distinct keys contained in this multimap.
keySet() - Method in class com.google.common.collect.MapMakerInternalMap
 
keySet() - Method in class com.google.common.collect.Maps.DescendingMap
 
keySet() - Method in class com.google.common.collect.Maps.FilteredEntrySortedMap
 
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 class com.google.common.collect.Maps.ViewCachingAbstractMap
 
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.UnmodifiableMultimap
 
keySet() - Method in class com.google.common.collect.StandardRowSortedTable.RowSortedMap
 
keySet() - Method in class com.google.common.collect.StandardTable.ColumnMap
 
keySet() - Method in class com.google.common.collect.Synchronized.SynchronizedMap
 
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.testing.SafeTreeMap
 
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
 
KeySet() - Constructor for class com.google.common.cache.LocalCache.KeySet
 
KeySet() - Constructor for class com.google.common.collect.AbstractBiMap.KeySet
 
KeySet() - Constructor for class com.google.common.collect.HashBiMap.KeySet
 
KeySet() - Constructor for class com.google.common.collect.MapMakerInternalMap.KeySet
 
KeySet() - Constructor for class com.google.common.collect.Maps.FilteredEntryMap.KeySet
 
KeySet() - Constructor for class com.google.common.collect.StandardTable.Column.KeySet
 
KeySet(RegularImmutableMap<K, ?>) - Constructor for class com.google.common.collect.RegularImmutableMap.KeySet
 
KeySet(Map<K, Collection<V>>) - Constructor for class com.google.common.collect.AbstractMapBasedMultimap.KeySet
 
KeySet(Map<K, V>) - Constructor for class com.google.common.collect.Maps.KeySet
 
keySetGenerator(OneSizeTestContainerGenerator<Map<K, V>, Map.Entry<K, V>>) - Static method in class com.google.common.collect.testing.DerivedCollectionGenerators
 
keySetIterator() - Method in class com.google.common.collect.CompactHashMap
 
KeySetSerializedForm(ImmutableMap<K, ?>) - Constructor for class com.google.common.collect.ImmutableMapKeySet.KeySetSerializedForm
 
keySetView - Variable in class com.google.common.collect.CompactHashMap
 
KeySetView() - Constructor for class com.google.common.collect.CompactHashMap.KeySetView
 
KeysGenerator(OneSizeTestContainerGenerator<M, Map.Entry<K, V>>) - Constructor for class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.KeysGenerator
 
keySpliterator() - Method in class com.google.common.collect.ImmutableEnumMap
 
keySpliterator() - Method in class com.google.common.collect.ImmutableMap
 
KeysSerializedForm(ImmutableMultimap<?, ?>) - Constructor for class com.google.common.collect.ImmutableMultimap.KeysSerializedForm
 
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() - Method in interface com.google.common.collect.MapMakerInternalMap.InternalEntryHelper
The strength of the key type in each entry.
keyStrength() - Method in class com.google.common.collect.MapMakerInternalMap
 
keyStrength() - Method in class com.google.common.collect.MapMakerInternalMap.StrongKeyDummyValueEntry.Helper
 
keyStrength() - Method in class com.google.common.collect.MapMakerInternalMap.StrongKeyStrongValueEntry.Helper
 
keyStrength() - Method in class com.google.common.collect.MapMakerInternalMap.StrongKeyWeakValueEntry.Helper
 
keyStrength() - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyDummyValueEntry.Helper
 
keyStrength() - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyStrongValueEntry.Helper
 
keyStrength() - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyWeakValueEntry.Helper
 
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() - Method in class com.google.common.collect.EnumBiMap
Returns the associated key type.
keyType() - Method in class com.google.common.collect.EnumHashBiMap
Returns the associated key type.
keyTypeOrObjectUnderJ2cl - Variable in class com.google.common.collect.EnumBiMap
 
keyTypeOrObjectUnderJ2cl - Variable in class com.google.common.collect.EnumHashBiMap
 
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
OGC KML (Keyhole Markup Language), compressed using the ZIP format into KMZ archives.
KNOWN_ORDER - Enum constant in enum class com.google.common.collect.testing.AbstractIteratorTester.KnownOrder
 
KNOWN_ORDER - Enum constant in enum class com.google.common.collect.testing.features.CollectionFeature
Indicates that a collection has a well-defined ordering of its elements.
KNOWN_TYPES - Static variable in class com.google.common.net.MediaType
 
knownOrder - Variable in class com.google.common.collect.testing.AbstractIteratorTester
 
KnownOrder() - Constructor for enum class com.google.common.collect.testing.AbstractIteratorTester.KnownOrder
 

L

L16_AUDIO - Static variable in class com.google.common.net.MediaType
L16 audio, as defined by RFC 2586.
L24_AUDIO - Static variable in class com.google.common.net.MediaType
L24 audio, as defined by RFC 3190.
labelQueue - Variable in class com.google.common.util.concurrent.ListenerCallQueue.PerListenerQueue
 
LARGE - Enum constant in enum class com.google.common.math.LongMath.MillerRabinTester
Works for all nonnegative signed longs.
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.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() - Method in class com.google.common.collect.testing.SafeTreeSet
 
LAST_BEFORE - Enum constant in enum class com.google.common.collect.SortedLists.KeyPresentBehavior
Return the index of the last list element that compares as less than the key, or -1 if there is no such element.
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.
LAST_PRESENT - Enum constant in enum class com.google.common.collect.SortedLists.KeyPresentBehavior
Return the index of the last list element that compares as equal to the key.
lastEntry - Variable in class com.google.common.collect.CompactLinkedHashMap
Pointer to the last node in the linked list, or ENDPOINT if there are no entries.
lastEntry - Variable in class com.google.common.collect.CompactLinkedHashSet
Pointer to the last node in the linked list, or ENDPOINT if there are no entries.
lastEntry - Variable in class com.google.common.collect.LinkedHashMultimap.ValueSet
 
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.ForwardingNavigableMap
 
lastEntry() - Method in class com.google.common.collect.ForwardingSortedMultiset
 
lastEntry() - Method in class com.google.common.collect.ImmutableSortedMap
 
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.testing.SafeTreeMap
 
lastEntry() - Method in class com.google.common.collect.UnmodifiableSortedMultiset
 
lastEntryForEachKey(Map.Entry<K, V>[], int) - Static method in class com.google.common.collect.ImmutableMap.Builder
Scans the first size elements of entries looking for duplicate keys.
lastFromForgetMeNot - Variable in class com.google.common.collect.MinMaxPriorityQueue.QueueIterator
 
lastInclusive - Variable in class com.google.common.collect.testing.DerivedCollectionGenerators.SortedMapSubmapTestMapGenerator
 
lastInclusive - Variable in class com.google.common.collect.testing.DerivedCollectionGenerators.SortedSetSubsetTestSetGenerator
 
lastIndexIn(CharSequence) - Method in class com.google.common.base.CharMatcher.Any
 
lastIndexIn(CharSequence) - Method in class com.google.common.base.CharMatcher
Returns the index of the last matching BMP character in a character sequence, or -1 if no matching character is present.
lastIndexIn(CharSequence) - Method in class com.google.common.base.CharMatcher.None
 
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(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(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(double) - Method in class com.google.common.primitives.ImmutableDoubleArray
Returns the largest index for which ImmutableDoubleArray.get(int) returns target, or -1 if no such index exists.
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(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(int) - Method in class com.google.common.primitives.ImmutableIntArray
Returns the largest index for which ImmutableIntArray.get(int) returns target, or -1 if no such index exists.
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) - Method in class com.google.common.primitives.ImmutableLongArray
Returns the largest index for which ImmutableLongArray.get(int) returns target, or -1 if no such index exists.
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(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.collect.AbstractMapBasedMultimap.WrappedList
 
lastIndexOf(Object) - Method in class com.google.common.collect.CartesianList
 
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.Synchronized.SynchronizedList
 
lastIndexOf(Object) - Method in class com.google.common.primitives.Booleans.BooleanArrayAsList
 
lastIndexOf(Object) - Method in class com.google.common.primitives.Bytes.ByteArrayAsList
 
lastIndexOf(Object) - Method in class com.google.common.primitives.Chars.CharArrayAsList
 
lastIndexOf(Object) - Method in class com.google.common.primitives.Doubles.DoubleArrayAsList
 
lastIndexOf(Object) - Method in class com.google.common.primitives.Floats.FloatArrayAsList
 
lastIndexOf(Object) - Method in class com.google.common.primitives.ImmutableDoubleArray.AsList
 
lastIndexOf(Object) - Method in class com.google.common.primitives.ImmutableIntArray.AsList
 
lastIndexOf(Object) - Method in class com.google.common.primitives.ImmutableLongArray.AsList
 
lastIndexOf(Object) - Method in class com.google.common.primitives.Ints.IntArrayAsList
 
lastIndexOf(Object) - Method in class com.google.common.primitives.Longs.LongArrayAsList
 
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).
lastIndexOfRandomAccess(List<?>, Object) - Static method in class com.google.common.collect.Lists
 
lastInKeyInsertionOrder - Variable in class com.google.common.collect.HashBiMap
 
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.testing.SafeTreeMap
 
lastKey() - Method in class com.google.common.collect.TreeBasedTable.TreeRow
 
lastKnownIndex - Variable in class com.google.common.collect.CompactHashMap.MapEntry
 
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
 
latch - Variable in class com.google.common.util.concurrent.testing.AbstractListenableFutureTest
 
laterCount - Variable in class com.google.common.collect.Multisets.MultisetIteratorImpl
Count of subsequent elements equal to current element
latestTaskQueue - Variable in class com.google.common.util.concurrent.ExecutionSequencer
 
lazyInverse - Variable in class com.google.common.collect.SingletonImmutableBiMap
 
LazyLogger - Class in com.google.common.util.concurrent
A holder for a Logger that is initialized only when requested.
LazyLogger(Class<?>) - Constructor for class com.google.common.util.concurrent.LazyLogger
 
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.
lazyStackTrace(Throwable) - Static method in class com.google.common.base.Throwables
Deprecated.
This method is equivalent to Throwable.getStackTrace() on JDK versions past JDK 8 and on all Android versions. Use Throwable.getStackTrace() directly, or where possible use the java.lang.StackWalker.walk method introduced in JDK 9.
lazyStackTraceIsLazy() - Static method in class com.google.common.base.Throwables
Deprecated.
This method always returns false on JDK versions past JDK 8 and on all Android versions.
lazyTransform(Future<I>, Function<? super I, ? extends O>) - Static method in class com.google.common.util.concurrent.Futures
Like Futures.transform(ListenableFuture, Function, Executor) except that the transformation function is invoked on each call to get() on the returned future.
lazyWeakCustom(int, Supplier<L>) - Static method in class com.google.common.util.concurrent.Striped
Creates a Striped<L> with lazily initialized, weakly referenced locks.
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 class com.google.thirdparty.publicsuffix.PublicSuffixType
The character used for a leaf node in the trie encoding
least(int) - Static method in class com.google.common.collect.TopKSelector
Returns a TopKSelector that collects the lowest k elements added to it, relative to the natural ordering of the elements, and returns them via TopKSelector.topK() in ascending order.
least(int, Comparator<? super T>) - Static method in class com.google.common.collect.Comparators
Returns a Collector that returns the k smallest (relative to the specified Comparator) input elements, in ascending order, as an unmodifiable List.
least(int, Comparator<? super T>) - Static method in class com.google.common.collect.TopKSelector
Returns a TopKSelector that collects the lowest k elements added to it, relative to the specified comparator, and returns them via TopKSelector.topK() in ascending order.
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.
leastSquaresFit() - Method in class com.google.common.math.PairedStats
Returns a linear transformation giving the best fit to the data according to Ordinary Least Squares linear regression of y as a function of x.
leastSquaresFit() - Method in class com.google.common.math.PairedStatsAccumulator
Returns a linear transformation giving the best fit to the data according to Ordinary Least Squares linear regression of y as a function of x.
leastValueAbove(DiscreteDomain<C>) - Method in class com.google.common.collect.Cut.AboveValue
 
leastValueAbove(DiscreteDomain<C>) - Method in class com.google.common.collect.Cut.BelowValue
 
leastValueAbove(DiscreteDomain<C>) - Method in class com.google.common.collect.Cut
 
leastValueAbove(DiscreteDomain<Comparable<?>>) - Method in class com.google.common.collect.Cut.AboveAll
 
leastValueAbove(DiscreteDomain<Comparable<?>>) - Method in class com.google.common.collect.Cut.BelowAll
 
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
 
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
 
legacyAsync() - Static method in class com.google.common.eventbus.Dispatcher
Returns a dispatcher that queues events that are posted in a single global queue.
LegacyAsyncDispatcher() - Constructor for class com.google.common.eventbus.Dispatcher.LegacyAsyncDispatcher
 
legacyReadResolve() - Method in class com.google.common.collect.ImmutableMap.SerializedForm
 
length - Variable in class com.google.common.collect.ImmutableList.SubList
 
length - Variable in class com.google.common.collect.RegularImmutableSortedMultiset
 
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.ByteArrayByteSource
 
length - Variable in class com.google.common.io.ByteSource.SlicedByteSource
 
length() - Method in class com.google.common.hash.AbstractNonStreamingHashFunction.ExposedByteArrayOutputStream
 
length() - Method in class com.google.common.io.CharSource.CharSequenceCharSource
 
length() - Method in class com.google.common.io.CharSource.ConcatenatedCharSource
 
length() - Method in class com.google.common.io.CharSource
Returns the length of this source in chars, even if doing so requires opening and traversing an entire stream.
length() - Method in class com.google.common.primitives.ImmutableDoubleArray
Returns the number of values in this array.
length() - Method in class com.google.common.primitives.ImmutableIntArray
Returns the number of values in this array.
length() - Method in class com.google.common.primitives.ImmutableLongArray
Returns the number of values in this array.
length() - Method in class com.google.common.util.concurrent.AtomicDoubleArray
Returns the length of the array.
lengthIfKnown() - Method in class com.google.common.io.CharSource.CharSequenceCharSource
 
lengthIfKnown() - Method in class com.google.common.io.CharSource.ConcatenatedCharSource
 
lengthIfKnown() - Method in class com.google.common.io.CharSource
Returns the size of this source in chars, if the size can be easily determined without actually opening the data stream.
lenientFormat(String, Object...) - Static method in class com.google.common.base.Strings
Returns the given template string with each occurrence of "%s" replaced with the corresponding argument value from args; or, if the placeholder and argument counts do not match, returns a best-effort form of that string.
lenientParsing() - Method in class com.google.common.cache.CacheBuilder
Enables lenient parsing.
lenientToString(Object) - Static method in class com.google.common.base.Strings
 
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.
LETTER_MATCHER - Static variable in class com.google.common.net.InternetDomainName
 
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".
lexicographical(Comparator<T>) - Static method in class com.google.common.collect.Comparators
Returns a new comparator which sorts iterables by comparing corresponding elements pairwise until a nonzero result is found; imposes "dictionary order." If the end of one iterable is reached, but not the other, the shorter iterable is considered to be less than the longer one.
lexicographicalComparator() - Static method in class com.google.common.primitives.Booleans
Returns a comparator that compares two boolean arrays lexicographically.
lexicographicalComparator() - Static method in class com.google.common.primitives.Chars
Returns a comparator that compares two char arrays lexicographically; not advisable for sorting user-visible strings as the ordering may not match the conventions of the user's locale.
lexicographicalComparator() - Static method in class com.google.common.primitives.Doubles
Returns a comparator that compares two double arrays lexicographically.
lexicographicalComparator() - Static method in class com.google.common.primitives.Floats
Returns a comparator that compares two float arrays lexicographically.
lexicographicalComparator() - Static method in class com.google.common.primitives.Ints
Returns a comparator that compares two int arrays lexicographically.
lexicographicalComparator() - Static method in class com.google.common.primitives.Longs
Returns a comparator that compares two long arrays lexicographically.
lexicographicalComparator() - Static method in class com.google.common.primitives.Shorts
Returns a comparator that compares two short arrays lexicographically.
lexicographicalComparator() - Static method in class com.google.common.primitives.SignedBytes
Returns a comparator that compares two byte arrays lexicographically.
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() - 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 class com.google.common.primitives.Booleans.LexicographicalComparator
 
LexicographicalComparator() - Constructor for enum class com.google.common.primitives.Chars.LexicographicalComparator
 
LexicographicalComparator() - Constructor for enum class com.google.common.primitives.Doubles.LexicographicalComparator
 
LexicographicalComparator() - Constructor for enum class com.google.common.primitives.Floats.LexicographicalComparator
 
LexicographicalComparator() - Constructor for enum class com.google.common.primitives.Ints.LexicographicalComparator
 
LexicographicalComparator() - Constructor for enum class com.google.common.primitives.Longs.LexicographicalComparator
 
LexicographicalComparator() - Constructor for enum class com.google.common.primitives.Shorts.LexicographicalComparator
 
LexicographicalComparator() - Constructor for enum class com.google.common.primitives.SignedBytes.LexicographicalComparator
 
LexicographicalComparator() - Constructor for enum class com.google.common.primitives.UnsignedInts.LexicographicalComparator
 
LexicographicalComparator() - Constructor for enum class 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(Comparator<? 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 - Variable in class com.google.common.base.Splitter.SplittingIterator
 
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(int) - Method in class com.google.common.collect.FluentIterable
Creates a fluent iterable with the first size elements of this fluent iterable.
limit(InputStream, long) - Static method in class com.google.common.io.ByteStreams
Wraps a InputStream, limiting the number of bytes which can be read.
limit(Iterable<T>, int) - Static method in class com.google.common.collect.Iterables
Returns a view of iterable containing its first limitSize elements.
limit(Buffer, int) - Static method in class com.google.common.base.Java8Compatibility
 
limit(Buffer, int) - Static method in class com.google.common.hash.Java8Compatibility
 
limit(Buffer, int) - Static method in class com.google.common.io.Java8Compatibility
 
limit(Iterator<T>, int) - Static method in class com.google.common.collect.Iterators
Returns a view containing the first limitSize elements of iterator.
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_SEPARATOR - Enum constant in enum class com.google.common.base.StandardSystemProperty
Line separator ("\n" on UNIX).
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
 
linearTimeSizeImpl(Multiset<?>) - Static method in class com.google.common.collect.Multisets
An implementation of Multiset.size().
LinearTransformation - Class in com.google.common.math
The representation of a linear transformation between real numbers x and y.
LinearTransformation() - Constructor for class com.google.common.math.LinearTransformation
 
LinearTransformation.LinearTransformationBuilder - Class in com.google.common.math
This is an intermediate stage in the construction process.
LinearTransformation.NaNLinearTransformation - Class in com.google.common.math
 
LinearTransformation.RegularLinearTransformation - Class in com.google.common.math
 
LinearTransformation.VerticalLinearTransformation - Class in com.google.common.math
 
LinearTransformationBuilder(double, double) - Constructor for class com.google.common.math.LinearTransformation.LinearTransformationBuilder
 
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 - Variable in class com.google.common.io.LineReader
 
lines() - Method in class com.google.common.io.CharSource.CharSequenceCharSource
 
lines() - Method in class com.google.common.io.CharSource
Opens a new Stream for reading text one line at a time from this source.
linesIterator() - Method in class com.google.common.io.CharSource.CharSequenceCharSource
Returns an iterator over the lines in the string.
link(int) - Method in class com.google.common.collect.CompactLinkedHashMap
 
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 hash table to map keys to value collections.
linkedHashKeys(int) - Static method in class com.google.common.collect.MultimapBuilder
Uses an hash table 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<V> associated with a key, the linked list of insertion-ordered entries in that Set<V>, 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
 
LinkedHashMultimapGwtSerializationDependencies<K,V> - Class in com.google.common.collect
A dummy superclass to support GWT serialization of the element types of a LinkedHashMultimap.
LinkedHashMultimapGwtSerializationDependencies(Map<K, Collection<V>>) - Constructor for class com.google.common.collect.LinkedHashMultimapGwtSerializationDependencies
 
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 an insertion-ordered hash-based Set to store value collections.
linkedHashSetValues(int) - Method in class com.google.common.collect.MultimapBuilder.MultimapBuilderWithKeys
Uses an insertion-ordered hash-based Set 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 class com.google.common.collect.MultimapBuilder.LinkedListSupplier
 
linkedListValues() - Method in class com.google.common.collect.MultimapBuilder.MultimapBuilderWithKeys
Uses a LinkedList to store value collections.
LinkedStrongKeyDummyValueEntry(K, int, MapMakerInternalMap.StrongKeyDummyValueEntry<K>) - Constructor for class com.google.common.collect.MapMakerInternalMap.StrongKeyDummyValueEntry.LinkedStrongKeyDummyValueEntry
 
LinkedStrongKeyStrongValueEntry(K, int, MapMakerInternalMap.StrongKeyStrongValueEntry<K, V>) - Constructor for class com.google.common.collect.MapMakerInternalMap.StrongKeyStrongValueEntry.LinkedStrongKeyStrongValueEntry
 
LinkedStrongKeyWeakValueEntry(K, int, MapMakerInternalMap.StrongKeyWeakValueEntry<K, V>) - Constructor for class com.google.common.collect.MapMakerInternalMap.StrongKeyWeakValueEntry.LinkedStrongKeyWeakValueEntry
 
LinkedWeakKeyDummyValueEntry(ReferenceQueue<K>, K, int, MapMakerInternalMap.WeakKeyDummyValueEntry<K>) - Constructor for class com.google.common.collect.MapMakerInternalMap.WeakKeyDummyValueEntry.LinkedWeakKeyDummyValueEntry
 
LinkedWeakKeyStrongValueEntry(ReferenceQueue<K>, K, int, MapMakerInternalMap.WeakKeyStrongValueEntry<K, V>) - Constructor for class com.google.common.collect.MapMakerInternalMap.WeakKeyStrongValueEntry.LinkedWeakKeyStrongValueEntry
 
LinkedWeakKeyWeakValueEntry(ReferenceQueue<K>, K, int, MapMakerInternalMap.WeakKeyWeakValueEntry<K, V>) - Constructor for class com.google.common.collect.MapMakerInternalMap.WeakKeyWeakValueEntry.LinkedWeakKeyWeakValueEntry
 
links - Variable in class com.google.common.collect.CompactLinkedHashMap
Contains the link pointers corresponding with the entries, in the range of [0, size()).
list - Variable in class com.google.common.collect.Collections2.PermutationIterator
 
list - Variable in class com.google.common.collect.Lists.Partition
 
list - Variable in class com.google.common.testing.TestLogHandler
We will keep a private list of all logged records
list - Variable in class com.google.common.util.concurrent.ClosingFuture.DeferredCloser
 
list(List<E>, Object) - Static method in class com.google.common.collect.Synchronized
 
ListAddAllAtIndexTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests addAll(int, Collection) operations on a list.
ListAddAllAtIndexTester() - Constructor for class com.google.common.collect.testing.testers.ListAddAllAtIndexTester
 
ListAddAllTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests addAll(Collection) operations on a list.
ListAddAllTester() - Constructor for class com.google.common.collect.testing.testers.ListAddAllTester
 
ListAddAtIndexTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests add(int, Object) operations on a list.
ListAddAtIndexTester() - Constructor for class com.google.common.collect.testing.testers.ListAddAtIndexTester
 
ListAddTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests add(Object) operations on a list.
ListAddTester() - Constructor for class com.google.common.collect.testing.testers.ListAddTester
 
ListCreationTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests creation (typically through a constructor or static factory method) of a list.
ListCreationTester() - Constructor for class com.google.common.collect.testing.testers.ListCreationTester
 
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(Runnable, V) - Constructor for class com.google.common.util.concurrent.ListenableFutureTask
 
ListenableFutureTask(Callable<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.PerListenerQueue
 
Listener() - Constructor for class com.google.common.util.concurrent.AbstractFuture.Listener
 
Listener() - Constructor for class com.google.common.util.concurrent.Service.Listener
 
Listener() - Constructor for class com.google.common.util.concurrent.ServiceManager.Listener
 
Listener(Runnable, Executor) - Constructor for class com.google.common.util.concurrent.AbstractFuture.Listener
 
ListenerCallQueue<L> - Class in com.google.common.util.concurrent
A list of listeners for implementing a concurrency friendly observable object.
ListenerCallQueue() - Constructor for class com.google.common.util.concurrent.ListenerCallQueue
 
ListenerCallQueue.Event<L> - Interface in com.google.common.util.concurrent
Method reference-compatible listener event.
ListenerCallQueue.PerListenerQueue<L> - Class in com.google.common.util.concurrent
A special purpose queue/executor that dispatches listener events serially on a configured executor.
listenerExecutor - Variable in class com.google.common.util.concurrent.CombinedFuture.CombinedFutureInterruptibleTask
 
listeners - Variable in class com.google.common.util.concurrent.AbstractFuture
All listeners.
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.ListenerCallQueue
 
listeners - Variable in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState
The listeners to notify during a state transition.
LISTENERS_OFFSET - Static variable in class com.google.common.util.concurrent.AbstractFuture.UnsafeAtomicHelper
 
listenersUpdater - Variable in class com.google.common.util.concurrent.AbstractFuture.SafeAtomicHelper
 
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.
ListEqualsTester<E> - Class in com.google.common.collect.testing.testers
ListEqualsTester() - Constructor for class com.google.common.collect.testing.testers.ListEqualsTester
 
ListFeature - Enum Class in com.google.common.collect.testing.features
Optional features of classes derived from List.
ListFeature(Feature<? super List>...) - Constructor for enum class com.google.common.collect.testing.features.ListFeature
 
ListFeature.Require - Annotation Interface in com.google.common.collect.testing.features
 
listFiles(Path) - Static method in class com.google.common.io.MoreFiles
Returns an immutable list of paths to the files contained in the given directory.
ListFuture(ImmutableCollection<? extends ListenableFuture<? extends V>>, boolean) - Constructor for class com.google.common.util.concurrent.CollectionFuture.ListFuture
 
ListGenerators - Class in com.google.common.collect.testing.google
Common generators of different types of lists.
ListGenerators() - Constructor for class com.google.common.collect.testing.google.ListGenerators
 
ListGenerators.BuilderAddAllListGenerator - Class in com.google.common.collect.testing.google
 
ListGenerators.BuilderAddListGenerator - Class in com.google.common.collect.testing.google
 
ListGenerators.BuilderReversedListGenerator - Class in com.google.common.collect.testing.google
 
ListGenerators.CharactersOfCharSequenceGenerator - Class in com.google.common.collect.testing.google
 
ListGenerators.CharactersOfStringGenerator - Class in com.google.common.collect.testing.google
 
ListGenerators.ImmutableListHeadSubListGenerator - Class in com.google.common.collect.testing.google
 
ListGenerators.ImmutableListMiddleSubListGenerator - Class in com.google.common.collect.testing.google
 
ListGenerators.ImmutableListOfGenerator - Class in com.google.common.collect.testing.google
 
ListGenerators.ImmutableListTailSubListGenerator - Class in com.google.common.collect.testing.google
 
ListGenerators.TestUnhashableListGenerator - Class in com.google.common.collect.testing.google
 
ListGenerators.UnhashableElementsImmutableListGenerator - Class in com.google.common.collect.testing.google
 
ListGetTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests get() operations on a list.
ListGetTester() - Constructor for class com.google.common.collect.testing.testers.ListGetTester
 
ListHashCodeTester<E> - Class in com.google.common.collect.testing.testers
ListHashCodeTester() - Constructor for class com.google.common.collect.testing.testers.ListHashCodeTester
 
ListIndexOfTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests indexOf() operations on a list.
ListIndexOfTester() - Constructor for class com.google.common.collect.testing.testers.ListIndexOfTester
 
listIterator() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedList
 
listIterator() - Method in class com.google.common.collect.ForwardingList
 
listIterator() - Method in class com.google.common.collect.ImmutableList
 
listIterator() - Method in class com.google.common.collect.Synchronized.SynchronizedList
 
listIterator(int) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedList
 
listIterator(int) - Method in class com.google.common.collect.ForwardingList
 
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(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).
listIteratorStimuli() - Method in class com.google.common.collect.testing.AbstractIteratorTester
 
ListIteratorTester<E> - Class in com.google.common.collect.testing
A utility similar to IteratorTester for testing a ListIterator against a known good reference implementation.
ListIteratorTester(int, Iterable<E>, Iterable<? extends IteratorFeature>, Iterable<E>, int) - Constructor for class com.google.common.collect.testing.ListIteratorTester
 
ListLastIndexOfTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests lastIndexOf() operations on a list.
ListLastIndexOfTester() - Constructor for class com.google.common.collect.testing.testers.ListLastIndexOfTester
 
ListListIteratorTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests listIterator operations on a list.
ListListIteratorTester() - Constructor for class com.google.common.collect.testing.testers.ListListIteratorTester
 
listListIteratorTesterNumIterations() - Static method in class com.google.common.collect.testing.testers.Platform
listMultimap(ListMultimap<K, V>, Object) - Static method in class com.google.common.collect.Synchronized
 
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.
ListMultimapAsMapTester<K,V> - Class in com.google.common.collect.testing.google
ListMultimapAsMapTester() - Constructor for class com.google.common.collect.testing.google.ListMultimapAsMapTester
 
ListMultimapBuilder() - Constructor for class com.google.common.collect.MultimapBuilder.ListMultimapBuilder
 
ListMultimapEqualsTester<K,V> - Class in com.google.common.collect.testing.google
ListMultimapEqualsTester() - Constructor for class com.google.common.collect.testing.google.ListMultimapEqualsTester
 
ListMultimapPutAllTester<K,V> - Class in com.google.common.collect.testing.google
ListMultimapPutAllTester() - Constructor for class com.google.common.collect.testing.google.ListMultimapPutAllTester
 
ListMultimapPutTester<K,V> - Class in com.google.common.collect.testing.google
ListMultimapPutTester() - Constructor for class com.google.common.collect.testing.google.ListMultimapPutTester
 
ListMultimapRemoveTester<K,V> - Class in com.google.common.collect.testing.google
ListMultimapRemoveTester() - Constructor for class com.google.common.collect.testing.google.ListMultimapRemoveTester
 
ListMultimapReplaceValuesTester<K,V> - Class in com.google.common.collect.testing.google
ListMultimapReplaceValuesTester() - Constructor for class com.google.common.collect.testing.google.ListMultimapReplaceValuesTester
 
ListMultimapTestSuiteBuilder<K,V> - Class in com.google.common.collect.testing.google
Creates, based on your criteria, a JUnit test suite that exhaustively tests a ListMultimap implementation.
ListMultimapTestSuiteBuilder() - Constructor for class com.google.common.collect.testing.google.ListMultimapTestSuiteBuilder
 
ListMultimapTestSuiteBuilder.MultimapAsMapGetGenerator<K,V> - Class in com.google.common.collect.testing.google
 
ListMultimapTestSuiteBuilder.MultimapGetGenerator<K,V> - Class in com.google.common.collect.testing.google
 
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
 
ListRemoveAllTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests removeAll operations on a list.
ListRemoveAllTester() - Constructor for class com.google.common.collect.testing.testers.ListRemoveAllTester
 
ListRemoveAtIndexTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests remove(int) operations on a list.
ListRemoveAtIndexTester() - Constructor for class com.google.common.collect.testing.testers.ListRemoveAtIndexTester
 
ListRemoveTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests remove(Object) operations on a list.
ListRemoveTester() - Constructor for class com.google.common.collect.testing.testers.ListRemoveTester
 
ListReplaceAllTester<E> - Class in com.google.common.collect.testing.testers
ListReplaceAllTester() - Constructor for class com.google.common.collect.testing.testers.ListReplaceAllTester
 
ListRetainAllTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests retainAll operations on a list.
ListRetainAllTester() - Constructor for class com.google.common.collect.testing.testers.ListRetainAllTester
 
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
 
ListSetTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests set() operations on a list.
ListSetTester() - Constructor for class com.google.common.collect.testing.testers.ListSetTester
 
ListSubListTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests subList() operations on a list.
ListSubListTester() - Constructor for class com.google.common.collect.testing.testers.ListSubListTester
 
ListTestSuiteBuilder<E> - Class in com.google.common.collect.testing
Creates, based on your criteria, a JUnit test suite that exhaustively tests a List implementation.
ListTestSuiteBuilder() - Constructor for class com.google.common.collect.testing.ListTestSuiteBuilder
 
ListTestSuiteBuilder.ReserializedListGenerator<E> - Class in com.google.common.collect.testing
 
ListToArrayTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests toArray() operations on a list.
ListToArrayTester() - Constructor for class com.google.common.collect.testing.testers.ListToArrayTester
 
LittleEndianByteArray - Class in com.google.common.hash
Utility functions for loading and storing values from a byte array.
LittleEndianByteArray() - Constructor for class com.google.common.hash.LittleEndianByteArray
Deter instantiation of this class.
LittleEndianByteArray.JavaLittleEndianBytes - Enum Class in com.google.common.hash
Fallback implementation for when Unsafe is not available in our current environment.
LittleEndianByteArray.LittleEndianBytes - Interface in com.google.common.hash
Common interface for retrieving a 64-bit long from a little-endian byte array.
LittleEndianByteArray.UnsafeByteArray - Enum Class in com.google.common.hash
The only reference to Unsafe is in this nested class.
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() - Method in class com.google.common.reflect.ClassPath.ClassInfo
Loads (but doesn't link or initialize) the class.
load(Object) - Method in class com.google.common.cache.CacheLoader.SupplierToCacheLoader
 
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_FACTOR - Static variable in class com.google.common.collect.HashBiMap
 
load32(byte[], int) - Static method in class com.google.common.hash.LittleEndianByteArray
Load 4 bytes from the provided array at the indicated offset.
load64(byte[], int) - Static method in class com.google.common.hash.LittleEndianByteArray
Load 8 bytes into long in a little endian manner, from the substring between position and position + 8.
load64Safely(byte[], int, int) - Static method in class com.google.common.hash.LittleEndianByteArray
Similar to load64, but allows offset + 8 > input.length, padding the result with zeroes.
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
 
loadClassesInPackage() - Method in class com.google.common.testing.AbstractPackageSanityTests
 
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() - Method in class com.google.common.base.FinalizableReferenceQueue.SystemLoader
 
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.
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
 
loadPatternCompiler() - Static method in class com.google.common.base.Platform
 
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
 
LOCAL_CLASS_HAS_NO_OWNER - Enum constant in enum class com.google.common.reflect.Types.ClassOwnership
 
localCache - Variable in class com.google.common.cache.LocalCache.LocalManualCache
 
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.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.ComputingValueReference<K,V> - Class in com.google.common.cache
 
LocalCache.EntryFactory - Enum Class 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, reconstituting 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, reconstituting it as a Cache using CacheBuilder upon deserialization.
LocalCache.NullEntry - Enum Class in com.google.common.cache
 
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 Class 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.
LocationInfo(File, ClassLoader) - Constructor for class com.google.common.reflect.ClassPath.LocationInfo
 
locationsFrom(ClassLoader) - Static method in class com.google.common.reflect.ClassPath
Returns all locations that classloader and parent loaders load classes and resources from.
lock - Variable in class com.google.common.base.Suppliers.ExpiringMemoizingSupplier
 
lock - Variable in class com.google.common.base.Suppliers.MemoizingSupplier
 
lock - Variable in class com.google.common.base.Suppliers.NonSerializableMemoizingSupplier
 
lock - Variable in class com.google.common.testing.TearDownStack
 
lock - Variable in class com.google.common.testing.TestLogHandler
 
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 - Variable in class com.google.common.util.concurrent.AbstractScheduledService.CustomScheduler.SupplantableFuture
 
lock - Variable in class com.google.common.util.concurrent.AbstractScheduledService.ServiceDelegate
 
lock - Variable in class com.google.common.util.concurrent.DirectExecutorService
Lock used whenever accessing the state variables (runningTasks, shutdown) of the executor
lock - Variable in class com.google.common.util.concurrent.LazyLogger
 
lock - Variable in class com.google.common.util.concurrent.Monitor
The lock underlying this monitor.
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() - Method in class com.google.common.util.concurrent.ForwardingLock
 
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
 
LockFreeBitArray(long) - Constructor for class com.google.common.hash.BloomFilterStrategies.LockFreeBitArray
 
LockFreeBitArray(long[]) - Constructor for class com.google.common.hash.BloomFilterStrategies.LockFreeBitArray
 
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
 
lockInterruptibly() - Method in class com.google.common.util.concurrent.ForwardingLock
 
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) - Static 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.AbstractFuture
 
log - Static variable in class com.google.common.util.concurrent.AggregateFutureState
 
log - Static variable in class com.google.common.util.concurrent.ExecutionList
Logger to log exceptions caught when running runnables.
log - Static variable in class com.google.common.util.concurrent.ImmediateFuture
 
log - Static variable in class com.google.common.util.concurrent.SequentialExecutor
 
log(Throwable) - Static method in class com.google.common.util.concurrent.AggregateFuture
 
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.
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.
log10Floor(int) - Static method in class com.google.common.math.IntMath
 
log10Floor(long) - Static method in class com.google.common.math.LongMath
 
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.
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.
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.base.Platform
 
logger - Static variable in class com.google.common.cache.CacheBuilder.LoggerHolder
 
logger - Static variable in class com.google.common.cache.LocalCache
 
logger - Static variable in class com.google.common.collect.testing.FeatureSpecificTestSuiteBuilder
 
logger - Static variable in class com.google.common.collect.testing.PerCollectionSizeTestSuiteBuilder
 
logger - Static variable in class com.google.common.eventbus.EventBus
 
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 - Variable in class com.google.common.testing.AbstractPackageSanityTests
 
logger - Static variable in class com.google.common.testing.ArbitraryInstances
 
logger - Static variable in class com.google.common.testing.SloppyTearDown
 
logger - Static variable in class com.google.common.testing.TearDownStack
 
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.AggregateFuture
 
logger - Static variable in class com.google.common.util.concurrent.ClosingFuture
 
logger - Static variable in class com.google.common.util.concurrent.CycleDetectingLockFactory
 
logger - Variable in class com.google.common.util.concurrent.LazyLogger
 
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
 
logger(SubscriberExceptionContext) - Static method in class com.google.common.eventbus.EventBus.LoggingHandler
 
LoggerHolder() - Constructor for class com.google.common.cache.CacheBuilder.LoggerHolder
 
loggerName - Variable in class com.google.common.util.concurrent.LazyLogger
 
LoggingHandler() - Constructor for class com.google.common.eventbus.EventBus.LoggingHandler
 
logPatternCompilerError(ServiceConfigurationError) - Static method in class com.google.common.base.Platform
 
LONG_ADDRESSABLE_BITS - Static variable in class com.google.common.hash.BloomFilterStrategies.LockFreeBitArray
 
LongAddable - Interface in com.google.common.cache
Abstract interface for objects that can concurrently add longs.
LongAddable - Interface in com.google.common.hash
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 - Class in com.google.common.hash
Source of LongAddable objects that deals with GWT, Unsafe, and all that.
LongAddables() - Constructor for class com.google.common.cache.LongAddables
 
LongAddables() - Constructor for class com.google.common.hash.LongAddables
 
LongAddables.PureJavaLongAddable - Class in com.google.common.cache
 
LongAddables.PureJavaLongAddable - Class in com.google.common.hash
 
LongAdder - Class in com.google.common.cache
One or more variables that together maintain an initially zero long sum.
LongAdder - Class in com.google.common.hash
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.
LongAdder() - Constructor for class com.google.common.hash.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 class 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
 
LongMath.MillerRabinTester - Enum Class in com.google.common.math
 
LongParser() - Constructor for class com.google.common.cache.CacheBuilderSpec.LongParser
 
longs - Variable in class com.google.common.util.concurrent.AtomicDoubleArray
 
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.AsciiDigits - Class in com.google.common.primitives
 
Longs.LexicographicalComparator - Enum Class 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
 
longsToDoubles(long[]) - Static method in class com.google.common.math.Quantiles
 
longValue() - Method in class com.google.common.cache.LongAdder
Equivalent to LongAdder.sum().
longValue() - Method in class com.google.common.hash.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(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(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(E) - Method in class com.google.common.collect.testing.SafeTreeSet
 
lower(K) - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableKeySet
 
lower(K) - Method in class com.google.common.collect.Maps.NavigableKeySet
 
lower(V) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedNavigableSet
 
LOWER_CAMEL - Enum constant in enum class com.google.common.base.CaseFormat
Java variable naming convention, e.g., "lowerCamel".
LOWER_HYPHEN - Enum constant in enum class com.google.common.base.CaseFormat
Hyphenated variable naming convention, e.g., "lower-hyphen".
LOWER_UNDERSCORE - Enum constant in enum class com.google.common.base.CaseFormat
C++ variable naming convention, e.g., "lower_underscore".
lowerBound - Variable in class com.google.common.collect.Range
 
lowerBound - Variable in class com.google.common.collect.TreeBasedTable.TreeRow
 
lowerBound() - 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 - Variable in class com.google.common.io.BaseEncoding.StandardBaseEncoding
 
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() - 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
 
lowerEntry(K) - Method in class com.google.common.collect.testing.SafeTreeMap
 
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
 
lowerKey(K) - Method in class com.google.common.collect.testing.SafeTreeMap
 

M

mac - Variable in class com.google.common.hash.MacHashFunction.MacHasher
 
MacHasher(Mac) - Constructor for class com.google.common.hash.MacHashFunction.MacHasher
 
MacHashFunction - Class in com.google.common.hash
HashFunction adapter for Mac instances.
MacHashFunction(String, Key, String) - Constructor for class com.google.common.hash.MacHashFunction
 
MacHashFunction.MacHasher - Class in com.google.common.hash
Hasher that updates a Mac (message authentication code).
maintainEmptyInvariant() - Method in class com.google.common.collect.StandardTable.Row
 
maintainEmptyInvariant() - Method in class com.google.common.collect.TreeBasedTable.TreeRow
 
makeBuilder(int) - Method in class com.google.common.collect.ImmutableBiMap.SerializedForm
 
makeBuilder(int) - Method in class com.google.common.collect.ImmutableMap.SerializedForm
Returns a builder that builds the unserialized type.
makeBuilder(int) - Method in class com.google.common.collect.ImmutableSortedMap.SerializedForm
 
makeComplementByHand(Collection<E>, Class<E>) - Static method in class com.google.common.collect.Sets
 
makeEitherMap() - Method in class com.google.common.collect.testing.MapInterfaceTest
Used by tests that require a map, but don't care whether it's populated or not.
makeEitherMap() - Method in class com.google.common.collect.testing.SortedMapInterfaceTest
 
makeEmptyMap() - Method in class com.google.common.collect.testing.MapInterfaceTest
Creates a new, empty instance of the class under test.
makeEmptyMap() - Method in class com.google.common.collect.testing.SortedMapInterfaceTest
 
makeHash() - Method in class com.google.common.hash.AbstractStreamingHasher
Computes a hash code based on the data that have been provided to this hasher.
makeHash() - Method in class com.google.common.hash.Crc32cHashFunction.Crc32cHasher
 
makeHash() - Method in class com.google.common.hash.Murmur3_128HashFunction.Murmur3_128Hasher
 
makeHash() - Method in class com.google.common.hash.SipHashFunction.SipHasher
 
makeHash(Hasher[]) - Method in class com.google.common.hash.AbstractCompositeHashFunction
Constructs a HashCode from the Hasher objects of the functions.
makeHash(Hasher[]) - Method in class com.google.common.hash.Hashing.ConcatenatedHashFunction
 
makeImmutable(Map.Entry<K, V>) - Static method in class com.google.common.collect.RegularImmutableMap
Makes an entry usable internally by a new ImmutableMap.
makeImmutable(Map.Entry<K, V>, K, V) - Static method in class com.google.common.collect.RegularImmutableMap
Makes an entry usable internally by a new ImmutableMap without rereading its contents.
makeInverse(Map<V, K>) - Method in class com.google.common.collect.AbstractBiMap
 
makeMap() - Method in class com.google.common.collect.MapMaker
Builds a thread-safe map.
makePopulatedMap() - Method in class com.google.common.collect.testing.MapInterfaceTest
Creates a new, non-empty instance of the class under test.
makePopulatedMap() - Method in class com.google.common.collect.testing.SortedMapInterfaceTest
 
makeSuiteForTesterClass(Class<? extends AbstractTester<?>>) - Method in class com.google.common.collect.testing.FeatureSpecificTestSuiteBuilder
 
MANIFEST_JSON_UTF_8 - Static variable in class com.google.common.net.MediaType
Manually closing - Search tag in class com.google.common.util.concurrent.ClosingFuture
Section
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
 
ManualSerializationProxy(LocalCache<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.Segment
 
map - Variable in class com.google.common.collect.AbstractMapBasedMultimap
 
map - Variable in class com.google.common.collect.CollectCollectors.EnumMapAccumulator
 
map - Variable in class com.google.common.collect.ImmutableMapEntrySet.EntrySetSerializedForm
 
map - Variable in class com.google.common.collect.ImmutableMapEntrySet.RegularEntrySet
 
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.InternerImpl
 
map - Variable in class com.google.common.collect.MapMakerInternalMap.Segment
 
map - Variable in class com.google.common.collect.Maps.KeySet
 
map - Variable in class com.google.common.collect.Maps.Values
 
map - Variable in class com.google.common.collect.Multimaps.MapMultimap
 
map - Variable in class com.google.common.collect.Multimaps.UnmodifiableMultimap
 
map - Variable in class com.google.common.collect.RegularImmutableMap.KeySet
 
map - Variable in class com.google.common.collect.RegularImmutableMap.KeySet.SerializedForm
 
map - Variable in class com.google.common.collect.RegularImmutableMap.Values
 
map - Variable in class com.google.common.collect.RegularImmutableMap.Values.SerializedForm
 
map - Variable in class com.google.common.escape.CharEscaperBuilder
 
map - Variable in class com.google.common.reflect.TypeResolver.TypeTable
 
map - Variable in class com.google.common.util.concurrent.AtomicLongMap
 
map() - Method in class com.google.common.collect.AbstractMapBasedMultimap.AsMap.AsMapEntries
 
map() - Method in class com.google.common.collect.CompactHashMap.EntrySetView
 
map() - Method in class com.google.common.collect.ForwardingMap.StandardEntrySet
 
map() - Method in class com.google.common.collect.ImmutableMapEntrySet
 
map() - Method in class com.google.common.collect.ImmutableMapEntrySet.RegularEntrySet
 
map() - Method in class com.google.common.collect.Maps.EntrySet
 
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() - Method in class com.google.common.collect.Maps.Values
 
map() - Method in class com.google.common.collect.Multimaps.AsMap.EntrySet
 
map() - Method in class com.google.common.collect.RegularImmutableBiMap.Inverse.InverseEntrySet
 
map(TypeResolver.TypeVariableKey, Type) - Method in class com.google.common.reflect.TypeResolver.TypeMappingIntrospector
 
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
map(Map<K, V>, Object) - Static method in class com.google.common.collect.Synchronized
 
map(Spliterator<InElementT>, Function<? super InElementT, ? extends OutElementT>) - Static method in class com.google.common.collect.CollectSpliterators
Returns a Spliterator over the elements of fromSpliterator mapped by function.
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
 
MapClearTester<K,V> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests clear() operations on a map.
MapClearTester() - Constructor for class com.google.common.collect.testing.testers.MapClearTester
 
MapComputeIfAbsentTester<K,V> - Class in com.google.common.collect.testing.testers
MapComputeIfAbsentTester() - Constructor for class com.google.common.collect.testing.testers.MapComputeIfAbsentTester
 
MapComputeIfAbsentTester.ExpectedException - Exception Class in com.google.common.collect.testing.testers
 
MapComputeIfPresentTester<K,V> - Class in com.google.common.collect.testing.testers
MapComputeIfPresentTester() - Constructor for class com.google.common.collect.testing.testers.MapComputeIfPresentTester
 
MapComputeIfPresentTester.ExpectedException - Exception Class in com.google.common.collect.testing.testers
 
MapComputeTester<K,V> - Class in com.google.common.collect.testing.testers
MapComputeTester() - Constructor for class com.google.common.collect.testing.testers.MapComputeTester
 
MapComputeTester.ExpectedException - Exception Class in com.google.common.collect.testing.testers
 
MapContainsKeyTester<K,V> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests containsKey() operations on a map.
MapContainsKeyTester() - Constructor for class com.google.common.collect.testing.testers.MapContainsKeyTester
 
MapContainsValueTester<K,V> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests containsValue() operations on a map.
MapContainsValueTester() - Constructor for class com.google.common.collect.testing.testers.MapContainsValueTester
 
MapCreationTester<K,V> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests creation (typically through a constructor or static factory method) of a map.
MapCreationTester() - Constructor for class com.google.common.collect.testing.testers.MapCreationTester
 
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
 
mapEntries(SampleElements<K>, SampleElements<V>) - Static method in class com.google.common.collect.testing.SampleElements
 
mapEntry(K, V) - Static method in class com.google.common.collect.testing.Helpers
 
mapEntry(K, V) - Static method in class com.google.common.collect.testing.MapInterfaceTest
 
MapEntry(int) - Constructor for class com.google.common.collect.CompactHashMap.MapEntry
 
MapEntrySetGenerator(OneSizeTestContainerGenerator<Map<K, V>, Map.Entry<K, V>>) - Constructor for class com.google.common.collect.testing.DerivedCollectionGenerators.MapEntrySetGenerator
 
MapEntrySetTester<K,V> - Class in com.google.common.collect.testing.testers
MapEntrySetTester() - Constructor for class com.google.common.collect.testing.testers.MapEntrySetTester
 
MapEntrySetTester.IncomparableType - Enum Class in com.google.common.collect.testing.testers
 
MapEqualsTester<K,V> - Class in com.google.common.collect.testing.testers
MapEqualsTester() - Constructor for class com.google.common.collect.testing.testers.MapEqualsTester
 
MapFeature - Enum Class in com.google.common.collect.testing.features
Optional features of classes derived from Map.
MapFeature(Feature<? super Map>...) - Constructor for enum class com.google.common.collect.testing.features.MapFeature
 
MapFeature.Require - Annotation Interface in com.google.common.collect.testing.features
 
MapForEachTester<K,V> - Class in com.google.common.collect.testing.testers
MapForEachTester() - Constructor for class com.google.common.collect.testing.testers.MapForEachTester
 
mapGenerator - Variable in class com.google.common.collect.testing.DerivedCollectionGenerators.MapEntrySetGenerator
 
mapGenerator - Variable in class com.google.common.collect.testing.DerivedCollectionGenerators.MapKeySetGenerator
 
mapGenerator - Variable in class com.google.common.collect.testing.DerivedCollectionGenerators.MapValueCollectionGenerator
 
mapGenerator - Variable in class com.google.common.collect.testing.google.DerivedGoogleCollectionGenerators.BiMapValueSetGenerator
 
mapGenerator - Variable in class com.google.common.collect.testing.MapTestSuiteBuilder.ReserializedMapGenerator
 
MapGenerator(OneSizeTestContainerGenerator<BiMap<K, V>, Map.Entry<K, V>>) - Constructor for class com.google.common.collect.testing.google.DerivedGoogleCollectionGenerators.MapGenerator
 
MapGenerators - Class in com.google.common.collect.testing.google
Generators of different types of map and related collections, such as keys, entries and values.
MapGenerators() - Constructor for class com.google.common.collect.testing.google.MapGenerators
 
MapGenerators.ImmutableEnumMapGenerator - Class in com.google.common.collect.testing.google
 
MapGenerators.ImmutableMapCopyOfEntriesGenerator - Class in com.google.common.collect.testing.google
 
MapGenerators.ImmutableMapCopyOfEnumMapGenerator - Class in com.google.common.collect.testing.google
 
MapGenerators.ImmutableMapCopyOfGenerator - Class in com.google.common.collect.testing.google
 
MapGenerators.ImmutableMapEntryListGenerator - Class in com.google.common.collect.testing.google
 
MapGenerators.ImmutableMapGenerator - Class in com.google.common.collect.testing.google
 
MapGenerators.ImmutableMapKeyListGenerator - Class in com.google.common.collect.testing.google
 
MapGenerators.ImmutableMapUnhashableValuesGenerator - Class in com.google.common.collect.testing.google
 
MapGenerators.ImmutableMapValueListGenerator - Class in com.google.common.collect.testing.google
 
MapGenerators.ImmutableMapValuesAsSingletonSetGenerator - Class in com.google.common.collect.testing.google
 
MapGetOrDefaultTester<K,V> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests Map.getOrDefault(java.lang.Object, V).
MapGetOrDefaultTester() - Constructor for class com.google.common.collect.testing.testers.MapGetOrDefaultTester
 
MapGetTester<K,V> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests get operations on a map.
MapGetTester() - Constructor for class com.google.common.collect.testing.testers.MapGetTester
 
MapHashCodeTester<K,V> - Class in com.google.common.collect.testing.testers
MapHashCodeTester() - Constructor for class com.google.common.collect.testing.testers.MapHashCodeTester
 
MapInterfaceTest<K,V> - Class in com.google.common.collect.testing
Tests representing the contract of Map.
MapInterfaceTest(boolean, boolean, boolean, boolean, boolean) - Constructor for class com.google.common.collect.testing.MapInterfaceTest
Constructor that assigns supportsIteratorRemove the same value as supportsRemove.
MapInterfaceTest(boolean, boolean, boolean, boolean, boolean, boolean) - Constructor for class com.google.common.collect.testing.MapInterfaceTest
Constructor with an explicit supportsIteratorRemove parameter.
MapInterfaceTest.IncompatibleKeyType - Class in com.google.common.collect.testing
A key type that is not assignable to any classes but Object.
mapInternal(File, FileChannel.MapMode, long) - Static method in class com.google.common.io.Files
 
MapIsEmptyTester<K,V> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests isEmpty() operations on a map.
MapIsEmptyTester() - Constructor for class com.google.common.collect.testing.testers.MapIsEmptyTester
 
mapIterator - Variable in class com.google.common.collect.StandardTable.ColumnKeyIterator
 
MapIteratorCache<K,V> - Class in com.google.common.graph
A map-like data structure that wraps a backing map and caches values while iterating through MapIteratorCache.unmodifiableKeySet().
MapIteratorCache(Map<K, V>) - Constructor for class com.google.common.graph.MapIteratorCache
 
MapJoiner(Joiner, String) - Constructor for class com.google.common.base.Joiner.MapJoiner
 
MapKeySetGenerator(OneSizeTestContainerGenerator<Map<K, V>, Map.Entry<K, V>>) - Constructor for class com.google.common.collect.testing.DerivedCollectionGenerators.MapKeySetGenerator
 
mapMaker - Variable in class com.google.common.collect.Interners.InternerBuilder
 
MapMaker - Class in com.google.common.collect
A builder of ConcurrentMap instances that can have keys or values automatically wrapped in weak references.
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.Dummy - Enum Class in com.google.common.collect
A dummy singleton value type used by Interners.
MapMakerInternalMap<K,V,E,S> - Class in com.google.common.collect
The concurrent hash map implementation built by MapMaker.
MapMakerInternalMap(MapMaker, MapMakerInternalMap.InternalEntryHelper<K, V, E, S>) - Constructor for class com.google.common.collect.MapMakerInternalMap
Creates a new, empty map with the specified strategy, initial capacity and concurrency level.
MapMakerInternalMap.AbstractSerializationProxy<K,V> - Class in com.google.common.collect
The actual object that gets serialized.
MapMakerInternalMap.AbstractStrongKeyEntry<K,V,E> - Class in com.google.common.collect
Base class for MapMakerInternalMap.InternalEntry implementations for strong keys.
MapMakerInternalMap.AbstractWeakKeyEntry<K,V,E> - Class in com.google.common.collect
Base class for MapMakerInternalMap.InternalEntry implementations for weak keys.
MapMakerInternalMap.CleanupMapTask - Class in com.google.common.collect
 
MapMakerInternalMap.DummyInternalEntry - Class in com.google.common.collect
A dummy implementation of MapMakerInternalMap.InternalEntry, solely for use in the type signature of MapMakerInternalMap.UNSET_WEAK_VALUE_REFERENCE below.
MapMakerInternalMap.EntryIterator - Class in com.google.common.collect
 
MapMakerInternalMap.EntrySet - Class in com.google.common.collect
 
MapMakerInternalMap.HashIterator<T> - Class in com.google.common.collect
 
MapMakerInternalMap.InternalEntry<K,V,E> - Interface in com.google.common.collect
An entry in a hash table of a MapMakerInternalMap.Segment.
MapMakerInternalMap.InternalEntryHelper<K,V,E,S> - Interface in com.google.common.collect
A helper object for operating on MapMakerInternalMap.InternalEntry instances in a type-safe and efficient manner.
MapMakerInternalMap.KeyIterator - Class in com.google.common.collect
 
MapMakerInternalMap.KeySet - Class in com.google.common.collect
 
MapMakerInternalMap.Segment<K,V,E,S> - 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.Strength - Enum Class in com.google.common.collect
 
MapMakerInternalMap.StrongKeyDummyValueEntry<K> - Class in com.google.common.collect
Concrete implementation of MapMakerInternalMap.InternalEntry for strong keys and MapMaker.Dummy values.
MapMakerInternalMap.StrongKeyDummyValueEntry.Helper<K> - Class in com.google.common.collect
Concrete implementation of MapMakerInternalMap.InternalEntryHelper for strong keys and MapMaker.Dummy values.
MapMakerInternalMap.StrongKeyDummyValueEntry.LinkedStrongKeyDummyValueEntry<K> - Class in com.google.common.collect
 
MapMakerInternalMap.StrongKeyDummyValueSegment<K> - Class in com.google.common.collect
Concrete implementation of MapMakerInternalMap.Segment for strong keys and MapMaker.Dummy values.
MapMakerInternalMap.StrongKeyStrongValueEntry<K,V> - Class in com.google.common.collect
Concrete implementation of MapMakerInternalMap.InternalEntry for strong keys and strong values.
MapMakerInternalMap.StrongKeyStrongValueEntry.Helper<K,V> - Class in com.google.common.collect
Concrete implementation of MapMakerInternalMap.InternalEntryHelper for strong keys and strong values.
MapMakerInternalMap.StrongKeyStrongValueEntry.LinkedStrongKeyStrongValueEntry<K,V> - Class in com.google.common.collect
 
MapMakerInternalMap.StrongKeyStrongValueSegment<K,V> - Class in com.google.common.collect
Concrete implementation of MapMakerInternalMap.Segment for strong keys and strong values.
MapMakerInternalMap.StrongKeyWeakValueEntry<K,V> - Class in com.google.common.collect
Concrete implementation of MapMakerInternalMap.InternalEntry for strong keys and weak values.
MapMakerInternalMap.StrongKeyWeakValueEntry.Helper<K,V> - Class in com.google.common.collect
Concrete implementation of MapMakerInternalMap.InternalEntryHelper for strong keys and weak values.
MapMakerInternalMap.StrongKeyWeakValueEntry.LinkedStrongKeyWeakValueEntry<K,V> - Class in com.google.common.collect
 
MapMakerInternalMap.StrongKeyWeakValueSegment<K,V> - Class in com.google.common.collect
Concrete implementation of MapMakerInternalMap.Segment for strong keys and weak values.
MapMakerInternalMap.StrongValueEntry<K,V,E> - Interface in com.google.common.collect
Marker interface for MapMakerInternalMap.InternalEntry implementations for strong values.
MapMakerInternalMap.ValueIterator - Class in com.google.common.collect
 
MapMakerInternalMap.Values - Class in com.google.common.collect
 
MapMakerInternalMap.WeakKeyDummyValueEntry<K> - Class in com.google.common.collect
Concrete implementation of MapMakerInternalMap.InternalEntry for weak keys and MapMaker.Dummy values.
MapMakerInternalMap.WeakKeyDummyValueEntry.Helper<K> - Class in com.google.common.collect
Concrete implementation of MapMakerInternalMap.InternalEntryHelper for weak keys and MapMaker.Dummy values.
MapMakerInternalMap.WeakKeyDummyValueEntry.LinkedWeakKeyDummyValueEntry<K> - Class in com.google.common.collect
 
MapMakerInternalMap.WeakKeyDummyValueSegment<K> - Class in com.google.common.collect
Concrete implementation of MapMakerInternalMap.Segment for weak keys and MapMaker.Dummy values.
MapMakerInternalMap.WeakKeyStrongValueEntry<K,V> - Class in com.google.common.collect
Concrete implementation of MapMakerInternalMap.InternalEntry for weak keys and strong values.
MapMakerInternalMap.WeakKeyStrongValueEntry.Helper<K,V> - Class in com.google.common.collect
Concrete implementation of MapMakerInternalMap.InternalEntryHelper for weak keys and strong values.
MapMakerInternalMap.WeakKeyStrongValueEntry.LinkedWeakKeyStrongValueEntry<K,V> - Class in com.google.common.collect
 
MapMakerInternalMap.WeakKeyStrongValueSegment<K,V> - Class in com.google.common.collect
Concrete implementation of MapMakerInternalMap.Segment for weak keys and strong values.
MapMakerInternalMap.WeakKeyWeakValueEntry<K,V> - Class in com.google.common.collect
Concrete implementation of MapMakerInternalMap.InternalEntry for weak keys and weak values.
MapMakerInternalMap.WeakKeyWeakValueEntry.Helper<K,V> - Class in com.google.common.collect
Concrete implementation of MapMakerInternalMap.InternalEntryHelper for weak keys and weak values.
MapMakerInternalMap.WeakKeyWeakValueEntry.LinkedWeakKeyWeakValueEntry<K,V> - Class in com.google.common.collect
 
MapMakerInternalMap.WeakKeyWeakValueSegment<K,V> - Class in com.google.common.collect
Concrete implementation of MapMakerInternalMap.Segment for weak keys and weak values.
MapMakerInternalMap.WeakValueEntry<K,V,E> - Interface in com.google.common.collect
Marker interface for MapMakerInternalMap.InternalEntry implementations for weak values.
MapMakerInternalMap.WeakValueReference<K,V,E> - Interface in com.google.common.collect
A weakly referenced value that also has a reference to its containing entry.
MapMakerInternalMap.WeakValueReferenceImpl<K,V,E> - Class in com.google.common.collect
Concrete implementation of MapMakerInternalMap.WeakValueReference.
MapMakerInternalMap.WriteThroughEntry - Class in com.google.common.collect
Custom Entry class used by EntryIterator.next(), that relays setValue changes to the underlying map.
MapMergeTester<K,V> - Class in com.google.common.collect.testing.testers
MapMergeTester() - Constructor for class com.google.common.collect.testing.testers.MapMergeTester
 
MapMergeTester.ExpectedException - Exception Class in com.google.common.collect.testing.testers
 
MapMultimap(Map<K, V>) - Constructor for class com.google.common.collect.Multimaps.MapMultimap
 
mapOfRanges - Variable in class com.google.common.collect.ImmutableRangeMap.SerializedForm
 
mapping(double, double) - Static method in class com.google.common.math.LinearTransformation
Start building an instance which maps x = x1 to y = y1.
mappings - Variable in class com.google.common.reflect.TypeResolver.TypeMappingIntrospector
 
MapPutAllTester<K,V> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests putAll operations on a map.
MapPutAllTester() - Constructor for class com.google.common.collect.testing.testers.MapPutAllTester
 
MapPutIfAbsentTester<K,V> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests Map.putIfAbsent(K, V).
MapPutIfAbsentTester() - Constructor for class com.google.common.collect.testing.testers.MapPutIfAbsentTester
 
MapPutTester<K,V> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests put operations on a map.
MapPutTester() - Constructor for class com.google.common.collect.testing.testers.MapPutTester
 
mapReference - Variable in class com.google.common.collect.MapMakerInternalMap.CleanupMapTask
 
MapRemoveEntryTester<K,V> - Class in com.google.common.collect.testing.testers
MapRemoveEntryTester() - Constructor for class com.google.common.collect.testing.testers.MapRemoveEntryTester
 
MapRemoveTester<K,V> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests remove operations on a map.
MapRemoveTester() - Constructor for class com.google.common.collect.testing.testers.MapRemoveTester
 
MapReplaceAllTester<K,V> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests replaceAll() operations on a map.
MapReplaceAllTester() - Constructor for class com.google.common.collect.testing.testers.MapReplaceAllTester
 
MapReplaceEntryTester<K,V> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests Map.replace(Object, Object, Object).
MapReplaceEntryTester() - Constructor for class com.google.common.collect.testing.testers.MapReplaceEntryTester
 
MapReplaceTester<K,V> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests Map.replace(Object, Object).
MapReplaceTester() - Constructor for class com.google.common.collect.testing.testers.MapReplaceTester
 
MapRetrievalCache<K,V> - Class in com.google.common.graph
A MapIteratorCache that adds additional caching.
MapRetrievalCache(Map<K, V>) - Constructor for class com.google.common.graph.MapRetrievalCache
 
MapRetrievalCache.CacheEntry<K,V> - Class in com.google.common.graph
 
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 Class 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.IteratorBasedAbstractMap<K,V> - Class in com.google.common.collect
 
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
The implementation of Maps.unmodifiableEntrySet(Set).
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
 
Maps.ViewCachingAbstractMap<K,V> - Class in com.google.common.collect
AbstractMap extension that makes it easy to cache customized keySet, values, and entrySet views.
MapSerializationTester<K,V> - Class in com.google.common.collect.testing.testers
Basic serialization test for maps.
MapSerializationTester() - Constructor for class com.google.common.collect.testing.testers.MapSerializationTester
 
MapSizeTester<K,V> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests size() operations on a map.
MapSizeTester() - Constructor for class com.google.common.collect.testing.testers.MapSizeTester
 
MapSortedKeySetGenerator(OneSizeTestContainerGenerator<Map<K, V>, Map.Entry<K, V>>) - Constructor for class com.google.common.collect.testing.DerivedCollectionGenerators.MapSortedKeySetGenerator
 
MapSplitter(Splitter, Splitter) - Constructor for class com.google.common.base.Splitter.MapSplitter
 
MapTestSuiteBuilder<K,V> - Class in com.google.common.collect.testing
Creates, based on your criteria, a JUnit test suite that exhaustively tests a Map implementation.
MapTestSuiteBuilder() - Constructor for class com.google.common.collect.testing.MapTestSuiteBuilder
 
MapTestSuiteBuilder.ReserializedMapGenerator<K,V> - Class in com.google.common.collect.testing
 
MapToStringTester<K,V> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests toString() operations on a map.
MapToStringTester() - Constructor for class com.google.common.collect.testing.testers.MapToStringTester
 
MapValueCollectionGenerator(OneSizeTestContainerGenerator<Map<K, V>, Map.Entry<K, V>>) - Constructor for class com.google.common.collect.testing.DerivedCollectionGenerators.MapValueCollectionGenerator
 
MapViewOfValuesAsSingletonSets() - Constructor for class com.google.common.collect.ImmutableMap.MapViewOfValuesAsSingletonSets
 
mapWithIndex(DoubleStream, Streams.DoubleFunctionWithIndex<R>) - Static method in class com.google.common.collect.Streams
Returns a stream consisting of the results of applying the given function to the elements of stream and their indexes in the stream.
mapWithIndex(IntStream, Streams.IntFunctionWithIndex<R>) - Static method in class com.google.common.collect.Streams
Returns a stream consisting of the results of applying the given function to the elements of stream and their indexes in the stream.
mapWithIndex(LongStream, Streams.LongFunctionWithIndex<R>) - Static method in class com.google.common.collect.Streams
Returns a stream consisting of the results of applying the given function to the elements of stream and their indexes in the stream.
mapWithIndex(Stream<T>, Streams.FunctionWithIndex<? super T, ? extends R>) - Static method in class com.google.common.collect.Streams
Returns a stream consisting of the results of applying the given function to the elements of stream and their indices in the stream.
MapWithIndexSpliterator(F, long) - Constructor for class com.google.common.collect.Streams.MapWithIndexSpliterator
 
mark - Variable in class com.google.common.io.ByteStreams.LimitedInputStream
 
mark - Variable in class com.google.common.io.CharSequenceReader
 
mark - Variable in class com.google.common.io.CountingInputStream
 
mark(int) - Method in class com.google.common.hash.HashingInputStream
mark() is not supported for HashingInputStream
mark(int) - Method in class com.google.common.io.ByteStreams.LimitedInputStream
 
mark(int) - Method in class com.google.common.io.CharSequenceReader
 
mark(int) - Method in class com.google.common.io.CountingInputStream
 
mark(Buffer) - Static method in class com.google.common.io.Java8Compatibility
 
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 - 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
mask() - Method in class com.google.common.collect.LinkedHashMultimap.ValueSet
 
maskCombine(int, int, int) - Static method in class com.google.common.collect.CompactHashing
Returns a new value combining the prefix and suffix using the given mask.
match - Variable in class com.google.common.base.CharMatcher.Is
 
match - Variable in class com.google.common.base.CharMatcher.IsNot
 
match1 - Variable in class com.google.common.base.CharMatcher.IsEither
 
match2 - Variable in class com.google.common.base.CharMatcher.IsEither
 
matcher - Variable in class com.google.common.base.JdkPattern.JdkMatcher
 
matcher(CharSequence) - Method in class com.google.common.base.CommonPattern
 
matcher(CharSequence) - Method in class com.google.common.base.JdkPattern
 
matches() - Method in class com.google.common.base.CommonMatcher
 
matches() - Method in class com.google.common.base.JdkPattern.JdkMatcher
 
matches(char) - Method in class com.google.common.base.CharMatcher.And
 
matches(char) - Method in class com.google.common.base.CharMatcher.Any
 
matches(char) - Method in class com.google.common.base.CharMatcher.AnyOf
 
matches(char) - Method in class com.google.common.base.CharMatcher.Ascii
 
matches(char) - Method in class com.google.common.base.CharMatcher.BitSetMatcher
 
matches(char) - Method in class com.google.common.base.CharMatcher.BreakingWhitespace
 
matches(char) - Method in class com.google.common.base.CharMatcher.ForPredicate
 
matches(char) - Method in class com.google.common.base.CharMatcher.InRange
 
matches(char) - Method in class com.google.common.base.CharMatcher.Is
 
matches(char) - Method in class com.google.common.base.CharMatcher.IsEither
 
matches(char) - Method in class com.google.common.base.CharMatcher.IsNot
 
matches(char) - Method in class com.google.common.base.CharMatcher.JavaDigit
 
matches(char) - Method in class com.google.common.base.CharMatcher.JavaIsoControl
 
matches(char) - Method in class com.google.common.base.CharMatcher.JavaLetter
 
matches(char) - Method in class com.google.common.base.CharMatcher.JavaLetterOrDigit
 
matches(char) - Method in class com.google.common.base.CharMatcher.JavaLowerCase
 
matches(char) - Method in class com.google.common.base.CharMatcher.JavaUpperCase
 
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.Negated
 
matches(char) - Method in class com.google.common.base.CharMatcher.None
 
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.CharMatcher.Whitespace
 
matches(char) - Method in class com.google.common.base.SmallCharMatcher
 
matches(char) - Method in class com.google.common.io.BaseEncoding.Alphabet
 
matches(Test) - Method in class com.google.common.collect.testing.FeatureSpecificTestSuiteBuilder
 
matchesAllOf(CharSequence) - Method in class com.google.common.base.CharMatcher.Any
 
matchesAllOf(CharSequence) - Method in class com.google.common.base.CharMatcher
Returns true if a character sequence contains only matching BMP characters.
matchesAllOf(CharSequence) - Method in class com.google.common.base.CharMatcher.Negated
 
matchesAllOf(CharSequence) - Method in class com.google.common.base.CharMatcher.None
 
matchesAnyOf(CharSequence) - Method in class com.google.common.base.CharMatcher
Returns true if a character sequence contains at least one matching BMP character.
matchesNoneOf(CharSequence) - Method in class com.google.common.base.CharMatcher.Any
 
matchesNoneOf(CharSequence) - Method in class com.google.common.base.CharMatcher
Returns true if a character sequence contains no matching BMP characters.
matchesNoneOf(CharSequence) - Method in class com.google.common.base.CharMatcher.Negated
 
matchesNoneOf(CharSequence) - Method in class com.google.common.base.CharMatcher.None
 
matchesType(Optional<PublicSuffixType>, Optional<PublicSuffixType>) - Static method in class com.google.common.net.InternetDomainName
If a desiredType is specified, returns true only if the actualType is identical.
matchesValue(Object, int) - Method in class com.google.common.collect.LinkedHashMultimap.ValueEntry
 
MathPreconditions - Class in com.google.common.math
A collection of preconditions for math functions.
MathPreconditions() - Constructor for class com.google.common.math.MathPreconditions
 
max - Variable in class com.google.common.escape.CharEscaperBuilder
 
max - Variable in class com.google.common.math.Stats
 
max - Variable in class com.google.common.math.StatsAccumulator
 
max() - Method in class com.google.common.math.Stats
Returns the highest value in the dataset.
max() - Method in class com.google.common.math.StatsAccumulator
Returns the highest value in the dataset.
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, treating values as unsigned.
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.max(float, float).
max(int...) - Static method in class com.google.common.primitives.Ints
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.Longs
Returns the greatest value present in array.
max(long...) - Static method in class com.google.common.primitives.UnsignedLongs
Returns the greatest value present in array, treating values as unsigned.
max(short...) - Static method in class com.google.common.primitives.Shorts
Returns the greatest value present in array.
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) - 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.Ordering
Returns the greatest of the specified values according to this ordering.
max(E, E, E, E...) - Method in class com.google.common.collect.ReverseNaturalOrdering
 
max(E, E, E, E...) - Method in class com.google.common.collect.ReverseOrdering
 
max(Iterable<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.ReverseNaturalOrdering
 
max(Iterable<E>) - Method in class com.google.common.collect.ReverseOrdering
 
max(Iterator<E>) - Method in class com.google.common.collect.Ordering
Returns the greatest of the specified values according to this ordering.
max(Iterator<E>) - Method in class com.google.common.collect.ReverseNaturalOrdering
 
max(Iterator<E>) - Method in class com.google.common.collect.ReverseOrdering
 
max(T, T) - Static method in class com.google.common.collect.Comparators
Returns the maximum of the two values.
max(T, T, Comparator<? super T>) - Static method in class com.google.common.collect.Comparators
Returns the maximum of the two values, according to the given comparator.
MAX - Static variable in class com.google.common.base.Ascii
The maximum value of an ASCII character.
MAX_ARRAY_LEN - Static variable in class com.google.common.io.ByteStreams
Max array length on JVM.
MAX_ASCII_CONTROL_CHAR - Static variable in class com.google.common.xml.XmlEscapers
 
MAX_BUSY_WAIT_SPINS - Static variable in class com.google.common.util.concurrent.InterruptibleTask
 
MAX_DOMAIN_PART_LENGTH - Static variable in class com.google.common.net.InternetDomainName
Maximum size of a single part of a domain name.
MAX_EXTRAS - Static variable in class com.google.common.collect.MoreCollectors.ToOptionalState
 
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_HASH_BUCKET_LENGTH - Static variable in class com.google.common.collect.CompactHashMap
Maximum allowed length of a hash table bucket before falling back to a j.u.LinkedHashMap-based implementation.
MAX_HASH_BUCKET_LENGTH - Static variable in class com.google.common.collect.CompactHashSet
Maximum allowed length of a hash table bucket before falling back to a j.u.LinkedHashSet based implementation.
MAX_HASH_BUCKET_LENGTH - Static variable in class com.google.common.collect.RegularImmutableMap
Maximum allowed length of a hash table bucket before falling back to a j.u.HashMap based implementation.
MAX_HASH_BUCKET_LENGTH - Static variable in class com.google.common.collect.RegularImmutableMultiset
Maximum allowed length of a hash table bucket before falling back to a j.u.HashMap based implementation.
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_LOAD_FACTOR - Static variable in class com.google.common.collect.RegularImmutableMultiset
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_NANOSECONDS_THRESHOLD - Static variable in class com.google.common.util.concurrent.OverflowAvoidingLockSupport
 
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_RUN_MULTIPLIER - Static variable in class com.google.common.collect.ImmutableSet.RegularSetBuilderImpl
We attempt to detect deliberate hash flooding attempts.
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_SIGNED_POWER_OF_TWO - Static variable in class com.google.common.math.IntMath
 
MAX_SIGNED_POWER_OF_TWO - Static variable in class com.google.common.math.LongMath
 
MAX_SIZE - Static variable in class com.google.common.base.SmallCharMatcher
 
MAX_SIZE - Static variable in class com.google.common.collect.CompactHashing
Maximum size of a compact hash-based collection (2^30 - 1 because 0 is UNSET).
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.
MAXIMUM_SPLIT - Enum constant in enum class com.google.common.collect.testing.SpliteratorTester.SpliteratorDecompositionStrategy
 
maximumSize - Variable in class com.google.common.cache.CacheBuilder
 
maximumSize - Variable in class com.google.common.cache.CacheBuilderSpec
 
maximumSize - Variable in class com.google.common.collect.MinMaxPriorityQueue.Builder
 
maximumSize - Variable in class com.google.common.collect.MinMaxPriorityQueue
 
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(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.
maximumSize(long) - Method in class com.google.common.cache.CacheBuilder
Specifies the maximum number of entries the cache may contain.
MaximumSizeParser() - Constructor for class com.google.common.cache.CacheBuilderSpec.MaximumSizeParser
 
maximumWeight - Variable in class com.google.common.cache.CacheBuilder
 
maximumWeight - Variable in class com.google.common.cache.CacheBuilderSpec
 
maximumWeight(long) - Method in class com.google.common.cache.CacheBuilder
Specifies the maximum weight of entries the cache may contain.
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.
maxRunBeforeFallback - Variable in class com.google.common.collect.ImmutableSet.RegularSetBuilderImpl
 
maxRunBeforeFallback(int) - Static method in class com.google.common.collect.ImmutableSet.RegularSetBuilderImpl
If more than this many consecutive positions are filled in a table of the specified size, report probable hash flooding.
maxSafeDigits - Static variable in class com.google.common.primitives.UnsignedLongs.ParseOverflowDetection
 
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.ParseOverflowDetection
 
maxValueMods - Static variable in class com.google.common.primitives.UnsignedLongs.ParseOverflowDetection
 
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.
maybeClearReferenceQueues() - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Clears the reference queues used by this segment, if any.
maybeClearReferenceQueues() - Method in class com.google.common.collect.MapMakerInternalMap.StrongKeyWeakValueSegment
 
maybeClearReferenceQueues() - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyDummyValueSegment
 
maybeClearReferenceQueues() - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyStrongValueSegment
 
maybeClearReferenceQueues() - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyWeakValueSegment
 
maybeDrainReferenceQueues() - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Drains the reference queues used by this segment, if any.
maybeDrainReferenceQueues() - Method in class com.google.common.collect.MapMakerInternalMap.StrongKeyWeakValueSegment
 
maybeDrainReferenceQueues() - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyDummyValueSegment
 
maybeDrainReferenceQueues() - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyStrongValueSegment
 
maybeDrainReferenceQueues() - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyWeakValueSegment
 
maybePropagateCancellationTo(Future<?>) - Method in class com.google.common.util.concurrent.AbstractFuture
If this future has been cancelled (and possibly interrupted), cancels (and possibly interrupts) the given future (if available).
mayNeedHiddenThis() - Method in class com.google.common.reflect.Invokable.ConstructorInvokable
 
MBOX - Static variable in class com.google.common.net.MediaType
MD_UTF_8 - Static variable in class com.google.common.net.MediaType
As described in RFC 7763, this constant (text/markdown) is used for Markdown documents.
md5() - Static method in class com.google.common.hash.Hashing
Deprecated.
If you must interoperate with a system that requires MD5, then use this method, despite its deprecation. But if you can choose your hash function, avoid MD5, which is neither fast nor secure. As of January 2017, we suggest:
MD5 - Static variable in class com.google.common.hash.Hashing.Md5Holder
 
Md5Holder() - Constructor for class com.google.common.hash.Hashing.Md5Holder
 
mean - Variable in class com.google.common.math.Stats
 
mean - Variable in class com.google.common.math.StatsAccumulator
 
mean() - Method in class com.google.common.math.Stats
Returns the arithmetic mean of the values.
mean() - Method in class com.google.common.math.StatsAccumulator
Returns the arithmetic mean of the values.
mean(double...) - Static method in class com.google.common.math.DoubleMath
Deprecated.
Use Stats.meanOf(java.lang.Iterable<? extends java.lang.Number>) instead, noting the less strict handling of non-finite values.
mean(int...) - Static method in class com.google.common.math.DoubleMath
Deprecated.
Use Stats.meanOf(java.lang.Iterable<? extends java.lang.Number>) instead, noting the less strict handling of non-finite values.
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...) - Static method in class com.google.common.math.DoubleMath
Deprecated.
Use Stats.meanOf(java.lang.Iterable<? extends java.lang.Number>) instead, noting the less strict handling of non-finite values.
mean(long, long) - Static method in class com.google.common.math.LongMath
Returns the arithmetic mean of x and y, rounded toward negative infinity.
mean(Iterable<? extends Number>) - Static method in class com.google.common.math.DoubleMath
Deprecated.
Use Stats.meanOf(java.lang.Iterable<? extends java.lang.Number>) instead, noting the less strict handling of non-finite values.
mean(Iterator<? extends Number>) - Static method in class com.google.common.math.DoubleMath
Deprecated.
Use Stats.meanOf(java.lang.Iterable<? extends java.lang.Number>) instead, noting the less strict handling of non-finite values.
meanOf(double...) - Static method in class com.google.common.math.Stats
Returns the arithmetic mean of the values.
meanOf(int...) - Static method in class com.google.common.math.Stats
Returns the arithmetic mean of the values.
meanOf(long...) - Static method in class com.google.common.math.Stats
Returns the arithmetic mean of the values.
meanOf(Iterable<? extends Number>) - Static method in class com.google.common.math.Stats
Returns the arithmetic mean of the values.
meanOf(Iterator<? extends Number>) - Static method in class com.google.common.math.Stats
Returns the arithmetic mean of the values.
MEDIA_PRESENTATION_DESCRIPTION - Static variable in class com.google.common.net.MediaType
median() - Static method in class com.google.common.math.Quantiles
Specifies the computation of a median (i.e.
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.Invokable
 
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.
memoizeWithExpiration(Supplier<T>, Duration) - 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
 
merge(long, double, double, double, double) - Method in class com.google.common.math.StatsAccumulator
 
merge(Range<K>, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class com.google.common.collect.ImmutableRangeMap
Deprecated.
Unsupported operation.
merge(Range<K>, V, BiFunction<? super V, ? super V, ? extends V>) - Method in interface com.google.common.collect.RangeMap
Merges a value into a part of the map by applying a remapping function.
merge(Range<K>, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class com.google.common.collect.TreeRangeMap
 
merge(Range<K>, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class com.google.common.collect.TreeRangeMap.SubRangeMap
 
merge(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class com.google.common.cache.LocalCache
 
merge(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class com.google.common.collect.ImmutableMap
Deprecated.
Unsupported operation.
merge(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class com.google.common.collect.Maps.UnmodifiableBiMap
 
merge(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
merge(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class com.google.common.collect.Synchronized.SynchronizedMap
 
merge(V, BinaryOperator<V>) - Method in class com.google.common.collect.TableCollectors.MutableCell
 
MERGE_LEFT_ASSOCIATIVE - Enum constant in enum class com.google.common.testing.CollectorTester.CollectStrategy
Get one accumulator for each element and merge the accumulators left-to-right.
MERGE_RIGHT_ASSOCIATIVE - Enum constant in enum class com.google.common.testing.CollectorTester.CollectStrategy
Get one accumulator for each element and merge the accumulators right-to-left.
mergeFunction - Variable in class com.google.common.collect.CollectCollectors.EnumMapAccumulator
 
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.
mergeTables(Table<R, C, V>, R, C, V, BinaryOperator<V>) - Static method in class com.google.common.collect.TableCollectors
 
MergingIterator(Iterable<? extends Iterator<? extends T>>, Comparator<? super T>) - Constructor for class com.google.common.collect.Iterators.MergingIterator
 
message(SubscriberExceptionContext) - Static method in class com.google.common.eventbus.EventBus.LoggingHandler
 
MESSAGE - Static variable in class com.google.common.io.TempFileCreator.ThrowingCreator
 
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, int, String) - Constructor for class com.google.common.hash.MessageDigestHashFunction
 
MessageDigestHashFunction(String, 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
 
metadata - Variable in class com.google.common.collect.CompactHashMap
Keeps track of metadata like the number of hash table bits and modifications of this data structure (to make it possible to throw ConcurrentModificationException in the iterator).
metadata - Variable in class com.google.common.collect.CompactHashSet
Keeps track of metadata like the number of hash table bits and modifications of this data structure (to make it possible to throw ConcurrentModificationException in the iterator).
metaIterators - Variable in class com.google.common.collect.Iterators.ConcatenatedIterator
 
method - Variable in class com.google.common.eventbus.Subscriber
Subscriber method.
method - Variable in class com.google.common.reflect.Invokable.MethodInvokable
 
method - Variable in class com.google.common.testing.ForwardingWrapperTester.InteractionTester
 
method(Method) - Method in class com.google.common.reflect.TypeToken
Returns the Invokable for method, which must be a member of T.
MethodIdentifier(Method) - Constructor for class com.google.common.eventbus.SubscriberRegistry.MethodIdentifier
 
MethodInvokable(Method) - Constructor for class com.google.common.reflect.Invokable.MethodInvokable
 
methodTesterRequirementsCache - Static variable in class com.google.common.collect.testing.features.FeatureUtil
 
MICROSOFT_EXCEL - Static variable in class com.google.common.net.MediaType
Microsoft Excel spreadsheets.
MICROSOFT_OUTLOOK - Static variable in class com.google.common.net.MediaType
MICROSOFT_POWERPOINT - Static variable in class com.google.common.net.MediaType
Microsoft Powerpoint presentations.
MICROSOFT_WORD - Static variable in class com.google.common.net.MediaType
Microsoft Word documents.
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.LockFreeBitArray) - 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.
millerRabinBaseSets - Static variable in class com.google.common.math.LongMath
 
MillerRabinTester() - Constructor for enum class com.google.common.math.LongMath.MillerRabinTester
 
min - Variable in class com.google.common.math.Stats
 
min - Variable in class com.google.common.math.StatsAccumulator
 
min() - Method in class com.google.common.math.Stats
Returns the lowest value in the dataset.
min() - Method in class com.google.common.math.StatsAccumulator
Returns the lowest value in the dataset.
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, treating values as unsigned.
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(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.Longs
Returns the least value present in array.
min(long...) - Static method in class com.google.common.primitives.UnsignedLongs
Returns the least value present in array, treating values as unsigned.
min(short...) - Static method in class com.google.common.primitives.Shorts
Returns the least value present in array.
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) - 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.Ordering
Returns the least of the specified values according to this ordering.
min(E, E, E, E...) - Method in class com.google.common.collect.ReverseNaturalOrdering
 
min(E, E, E, E...) - Method in class com.google.common.collect.ReverseOrdering
 
min(Iterable<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.ReverseNaturalOrdering
 
min(Iterable<E>) - Method in class com.google.common.collect.ReverseOrdering
 
min(Iterator<E>) - Method in class com.google.common.collect.Ordering
Returns the least of the specified values according to this ordering.
min(Iterator<E>) - Method in class com.google.common.collect.ReverseNaturalOrdering
 
min(Iterator<E>) - Method in class com.google.common.collect.ReverseOrdering
 
min(T, T) - Static method in class com.google.common.collect.Comparators
Returns the minimum of the two values.
min(T, T, Comparator<? super T>) - Static method in class com.google.common.collect.Comparators
Returns the minimum of the two values, according to the given comparator.
MIN - Static variable in class com.google.common.base.Ascii
The minimum value of an ASCII character.
MIN_ASCII_CONTROL_CHAR - Static variable in class com.google.common.xml.XmlEscapers
 
MIN_ELEMENT - Static variable in class com.google.common.collect.testing.SampleElements.Strings
 
MIN_HASH_TABLE_SIZE - Static variable in class com.google.common.collect.CompactHashing
Minimum size of the hash table of a compact hash-based collection.
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
 
MinimalCollection<E> - Class in com.google.common.collect.testing
A simplistic collection which implements only the bare minimum allowed by the spec, and throws exceptions whenever it can.
MinimalCollection(Class<? super E>, boolean, E...) - Constructor for class com.google.common.collect.testing.MinimalCollection
 
MinimalIterable<E> - Class in com.google.common.collect.testing
An implementation of Iterable which throws an exception on all invocations of the MinimalIterable.iterator() method after the first, and whose iterator is always unmodifiable.
MinimalIterable(Iterator<E>) - Constructor for class com.google.common.collect.testing.MinimalIterable
 
MinimalSet<E> - Class in com.google.common.collect.testing
A simplistic set which implements the bare minimum so that it can be used in tests without relying on any specific Set implementations.
MinimalSet(Class<? super E>, E...) - Constructor for class com.google.common.collect.testing.MinimalSet
 
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 MinMaxPriorityQueue 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.
minus(BigDecimal, BigDecimal) - Method in class com.google.common.math.BigDecimalMath.BigDecimalToDoubleRounder
 
minus(BigInteger, BigInteger) - Method in class com.google.common.math.BigIntegerMath.BigIntegerToDoubleRounder
 
minus(X, X) - Method in class com.google.common.math.ToDoubleRounder
Returns a - b, guaranteed that both arguments are nonnegative.
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.
misleadingSizeCollection(int) - Static method in class com.google.common.collect.testing.Helpers
Returns a collection that simulates concurrent modification by having its size method return incorrect values.
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(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
 
mixK2(long) - Static method in class com.google.common.hash.Murmur3_128HashFunction.Murmur3_128Hasher
 
MockFutureListener - Class in com.google.common.util.concurrent.testing
A simple mock implementation of Runnable that can be used for testing ListenableFutures.
MockFutureListener(ListenableFuture<?>) - Constructor for class com.google.common.util.concurrent.testing.MockFutureListener
 
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
 
MODIFIABLE - Static variable in enum class com.google.common.collect.testing.IteratorFeature
A set containing all of the optional features of the Iterator and ListIterator interfaces.
MODIFICATION_COUNT_INCREMENT - Static variable in class com.google.common.collect.CompactHashing
Use high bits of metadata for modification count.
monitor - Variable in class com.google.common.util.concurrent.AbstractService
 
monitor - Variable in class com.google.common.util.concurrent.Monitor.Guard
 
monitor - Variable in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState
 
Monitor - Search tag in class com.google.common.util.concurrent.Monitor
Section
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.Guard - Class in com.google.common.util.concurrent
A boolean condition for which a thread may wait.
MoreCollectors - Class in com.google.common.collect
Collectors not present in java.util.stream.Collectors that are not otherwise associated with a com.google.common type.
MoreCollectors() - Constructor for class com.google.common.collect.MoreCollectors
 
MoreCollectors.ToOptionalState - Class in com.google.common.collect
This atrocity is here to let us report several of the elements in the stream if there were more than one, not just two.
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.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
 
MoreFiles - Class in com.google.common.io
Static utilities for use with Path instances, intended to complement Files.
MoreFiles() - Constructor for class com.google.common.io.MoreFiles
 
MoreFiles.PathByteSink - Class in com.google.common.io
 
MoreFiles.PathByteSource - Class in com.google.common.io
 
More information - Search tag in class com.google.common.base.Preconditions
Section
More information - Search tag in class com.google.common.base.Verify
Section
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.UnconditionalValueHolder - Class in com.google.common.base
Holder object for values that cannot be null or empty (will be printed unconditionally).
MoreObjects.ToStringHelper.ValueHolder - Class in com.google.common.base
 
More on CacheBuilder - Search tag in class com.google.common.cache.CacheBuilder
Section
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
 
moveLastEntry(int, int) - Method in class com.google.common.collect.CompactHashMap
Moves the last entry in the entry array into dstIndex, and nulls out its old position.
moveLastEntry(int, int) - Method in class com.google.common.collect.CompactHashSet
Moves the last entry in the entry array into dstIndex, and nulls out its old position.
moveLastEntry(int, int) - Method in class com.google.common.collect.CompactLinkedHashMap
 
moveLastEntry(int, int) - Method in class com.google.common.collect.CompactLinkedHashSet
 
movePivotToStartOfSlice(double[], int, int) - Static method in class com.google.common.math.Quantiles
Selects the pivot to use, namely the median of the values at from, to, and halfway between the two (rounded down), from array, and ensure (by swapping elements if necessary) that that pivot value appears at the start of the slice i.e.
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
 
mulMod(long, long, long) - Method in enum class com.google.common.math.LongMath.MillerRabinTester
Returns a * b mod m.
MultiEdgesConnecting<E> - Class in com.google.common.graph
A class to represent the set of edges connecting an (implicit) origin node to a target node.
MultiEdgesConnecting(Map<E, ?>, Object) - Constructor for class com.google.common.graph.MultiEdgesConnecting
 
MultiExceptionListIterator(List<E>) - Constructor for class com.google.common.collect.testing.AbstractIteratorTester.MultiExceptionListIterator
 
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 - 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.KeysSerializedForm
 
multimap - Variable in class com.google.common.collect.ImmutableMultimap.Values
 
multimap - Variable in class com.google.common.collect.ImmutableSetMultimap.EntrySet
 
multimap - Variable in class com.google.common.collect.Multimaps.AsMap
 
multimap - Variable in class com.google.common.collect.Multimaps.Keys
 
multimap - Variable in class com.google.common.collect.testing.google.AbstractMultimapTester
 
multimap() - Method in class com.google.common.collect.AbstractMultimap.Entries
 
multimap() - Method in class com.google.common.collect.Multimaps.Entries
 
multimap() - Method in class com.google.common.collect.testing.google.AbstractMultimapTester
 
multimap(Multimap<K, V>, Object) - Static method in class com.google.common.collect.Synchronized
 
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.
MultimapAsMapGetGenerator(OneSizeTestContainerGenerator<ListMultimap<K, V>, Map.Entry<K, V>>) - Constructor for class com.google.common.collect.testing.google.ListMultimapTestSuiteBuilder.MultimapAsMapGetGenerator
 
MultimapAsMapGetGenerator(OneSizeTestContainerGenerator<SetMultimap<K, V>, Map.Entry<K, V>>) - Constructor for class com.google.common.collect.testing.google.SetMultimapTestSuiteBuilder.MultimapAsMapGetGenerator
 
MultimapAsMapGetGenerator(OneSizeTestContainerGenerator<M, Map.Entry<K, V>>) - Constructor for class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.MultimapAsMapGetGenerator
 
MultimapAsMapGetTester<K,V> - Class in com.google.common.collect.testing.google
Tests for Multimap.asMap().get(Object).
MultimapAsMapGetTester() - Constructor for class com.google.common.collect.testing.google.MultimapAsMapGetTester
 
MultimapAsMapTester<K,V> - Class in com.google.common.collect.testing.google
Tests for Multimap.asMap().
MultimapAsMapTester() - Constructor for class com.google.common.collect.testing.google.MultimapAsMapTester
 
MultimapBuilder<K0,V0> - Class in com.google.common.collect
An immutable builder for Multimap instances, letting you independently select the desired behaviors (for example, ordering) of the backing map and value-collections.
MultimapBuilder() - Constructor for class com.google.common.collect.MultimapBuilder
 
MultimapBuilder.ArrayListSupplier<V> - Class in com.google.common.collect
 
MultimapBuilder.EnumSetSupplier<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 Class 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
 
MultimapClearTester<K,V> - Class in com.google.common.collect.testing.google
Tests for Multimap.clear().
MultimapClearTester() - Constructor for class com.google.common.collect.testing.google.MultimapClearTester
 
MultimapContainsEntryTester<K,V> - Class in com.google.common.collect.testing.google
MultimapContainsEntryTester() - Constructor for class com.google.common.collect.testing.google.MultimapContainsEntryTester
 
MultimapContainsKeyTester<K,V> - Class in com.google.common.collect.testing.google
Tester for the containsKey methods of Multimap and its asMap() view.
MultimapContainsKeyTester() - Constructor for class com.google.common.collect.testing.google.MultimapContainsKeyTester
 
MultimapContainsValueTester<K,V> - Class in com.google.common.collect.testing.google
MultimapContainsValueTester() - Constructor for class com.google.common.collect.testing.google.MultimapContainsValueTester
 
MultimapEntriesTester<K,V> - Class in com.google.common.collect.testing.google
Tester for Multimap.entries.
MultimapEntriesTester() - Constructor for class com.google.common.collect.testing.google.MultimapEntriesTester
 
MultimapEqualsTester<K,V> - Class in com.google.common.collect.testing.google
Tester for Multimap.equals.
MultimapEqualsTester() - Constructor for class com.google.common.collect.testing.google.MultimapEqualsTester
 
MultimapFeature - Enum Class in com.google.common.collect.testing.google
Optional features of classes derived from Multimap.
MultimapFeature(Feature<? super Multimap>...) - Constructor for enum class com.google.common.collect.testing.google.MultimapFeature
 
MultimapFeature.Require - Annotation Interface in com.google.common.collect.testing.google
 
MultimapForEachTester<K,V> - Class in com.google.common.collect.testing.google
MultimapForEachTester() - Constructor for class com.google.common.collect.testing.google.MultimapForEachTester
 
multimapGenerator - Variable in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.AsMapGenerator
 
multimapGenerator - Variable in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.EntriesGenerator
 
multimapGenerator - Variable in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.KeysGenerator
 
multimapGenerator - Variable in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.MultimapGetGenerator
 
multimapGenerator - Variable in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.ReserializedMultimapGenerator
 
multimapGenerator - Variable in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.ValuesGenerator
 
MultimapGetGenerator(OneSizeTestContainerGenerator<ListMultimap<K, V>, Map.Entry<K, V>>) - Constructor for class com.google.common.collect.testing.google.ListMultimapTestSuiteBuilder.MultimapGetGenerator
 
MultimapGetGenerator(OneSizeTestContainerGenerator<SetMultimap<K, V>, Map.Entry<K, V>>) - Constructor for class com.google.common.collect.testing.google.SetMultimapTestSuiteBuilder.MultimapGetGenerator
 
MultimapGetGenerator(OneSizeTestContainerGenerator<M, Map.Entry<K, V>>) - Constructor for class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.MultimapGetGenerator
 
MultimapGetTester<K,V> - Class in com.google.common.collect.testing.google
MultimapGetTester() - Constructor for class com.google.common.collect.testing.google.MultimapGetTester
 
multimapHeaderEntry - Variable in class com.google.common.collect.LinkedHashMultimap
 
MultimapKeySetTester<K,V> - Class in com.google.common.collect.testing.google
Tester for Multimap.keySet.
MultimapKeySetTester() - Constructor for class com.google.common.collect.testing.google.MultimapKeySetTester
 
MultimapKeysTester<K,V> - Class in com.google.common.collect.testing.google
Tester for Multimap.entries.
MultimapKeysTester() - Constructor for class com.google.common.collect.testing.google.MultimapKeysTester
 
MultimapPutAllMultimapTester<K,V> - Class in com.google.common.collect.testing.google
MultimapPutAllMultimapTester() - Constructor for class com.google.common.collect.testing.google.MultimapPutAllMultimapTester
 
MultimapPutIterableTester<K,V> - Class in com.google.common.collect.testing.google
MultimapPutIterableTester() - Constructor for class com.google.common.collect.testing.google.MultimapPutIterableTester
 
MultimapPutTester<K,V> - Class in com.google.common.collect.testing.google
Tester for Multimap.put(K, V).
MultimapPutTester() - Constructor for class com.google.common.collect.testing.google.MultimapPutTester
 
MultimapRemoveAllTester<K,V> - Class in com.google.common.collect.testing.google
MultimapRemoveAllTester() - Constructor for class com.google.common.collect.testing.google.MultimapRemoveAllTester
 
MultimapRemoveEntryTester<K,V> - Class in com.google.common.collect.testing.google
MultimapRemoveEntryTester() - Constructor for class com.google.common.collect.testing.google.MultimapRemoveEntryTester
 
MultimapReplaceValuesTester<K,V> - Class in com.google.common.collect.testing.google
MultimapReplaceValuesTester() - Constructor for class com.google.common.collect.testing.google.MultimapReplaceValuesTester
 
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.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
 
MultimapSizeTester<K,V> - Class in com.google.common.collect.testing.google
Tester for the size methods of Multimap and its views.
MultimapSizeTester() - Constructor for class com.google.common.collect.testing.google.MultimapSizeTester
 
MultimapTestSuiteBuilder<K,V,M> - Class in com.google.common.collect.testing.google
Creates, based on your criteria, a JUnit test suite that exhaustively tests a Multimap implementation.
MultimapTestSuiteBuilder() - Constructor for class com.google.common.collect.testing.google.MultimapTestSuiteBuilder
 
MultimapTestSuiteBuilder.AsMapGenerator<K,V,M> - Class in com.google.common.collect.testing.google
 
MultimapTestSuiteBuilder.EntriesGenerator<K,V,M> - Class in com.google.common.collect.testing.google
 
MultimapTestSuiteBuilder.KeysGenerator<K,V,M> - Class in com.google.common.collect.testing.google
 
MultimapTestSuiteBuilder.MultimapAsMapGetGenerator<K,V,M> - Class in com.google.common.collect.testing.google
 
MultimapTestSuiteBuilder.MultimapGetGenerator<K,V,M> - Class in com.google.common.collect.testing.google
 
MultimapTestSuiteBuilder.ReserializedMultimapGenerator<K,V,M> - Class in com.google.common.collect.testing.google
 
MultimapTestSuiteBuilder.ValuesGenerator<K,V,M> - Class in com.google.common.collect.testing.google
 
MultimapToStringTester<K,V> - Class in com.google.common.collect.testing.google
Tester for Multimap.toString().
MultimapToStringTester() - Constructor for class com.google.common.collect.testing.google.MultimapToStringTester
 
MultimapValuesTester<K,V> - Class in com.google.common.collect.testing.google
Tester for Multimap.values.
MultimapValuesTester() - Constructor for class com.google.common.collect.testing.google.MultimapValuesTester
 
multimapView - Variable in class com.google.common.collect.ImmutableMap
 
MULTIPLE_EDGES_CONNECTING - Static variable in class com.google.common.graph.GraphConstants
 
multiples(boolean) - Method in class com.google.common.collect.MoreCollectors.ToOptionalState
 
MULTIPLIER - Static variable in class com.google.common.base.CharMatcher.Whitespace
 
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 - Variable in class com.google.common.collect.ImmutableMultiset.EntrySetSerializedForm
 
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.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() - Method in class com.google.common.collect.Multisets.ElementSet
 
multiset() - Method in class com.google.common.collect.Multisets.EntrySet
 
multiset() - Method in class com.google.common.collect.SortedMultisets.ElementSet
 
multiset(Multiset<E>, Object) - Static method in class com.google.common.collect.Synchronized
 
Multiset<E> - Interface in com.google.common.collect
A collection that supports order-independent equality, like Set, but may have duplicate elements.
Multiset.Entry<E> - Interface in com.google.common.collect
An unmodifiable element-count pair for a multiset.
MultisetAddTester<E> - Class in com.google.common.collect.testing.google
Tests for Multiset.add.
MultisetAddTester() - Constructor for class com.google.common.collect.testing.google.MultisetAddTester
 
MultisetContainsTester<E> - Class in com.google.common.collect.testing.google
Tests for Multiset.containsAll not already addressed by CollectionContainsTester.
MultisetContainsTester() - Constructor for class com.google.common.collect.testing.google.MultisetContainsTester
 
MultisetCountTester<E> - Class in com.google.common.collect.testing.google
Tests for Multiset#count.
MultisetCountTester() - Constructor for class com.google.common.collect.testing.google.MultisetCountTester
 
MultisetElementSetTester<E> - Class in com.google.common.collect.testing.google
Tests for Multiset.elementSet() not covered by the derived SetTestSuiteBuilder.
MultisetElementSetTester() - Constructor for class com.google.common.collect.testing.google.MultisetElementSetTester
 
MultisetEntrySetTester<E> - Class in com.google.common.collect.testing.google
Tests for Multiset.entrySet.
MultisetEntrySetTester() - Constructor for class com.google.common.collect.testing.google.MultisetEntrySetTester
 
MultisetEqualsTester<E> - Class in com.google.common.collect.testing.google
Tests for Multiset.equals and Multiset.hashCode.
MultisetEqualsTester() - Constructor for class com.google.common.collect.testing.google.MultisetEqualsTester
 
MultisetFeature - Enum Class in com.google.common.collect.testing.google
Optional features of classes derived from Multiset.
MultisetFeature() - Constructor for enum class com.google.common.collect.testing.google.MultisetFeature
 
MultisetFeature.Require - Annotation Interface in com.google.common.collect.testing.google
 
MultisetForEachEntryTester<E> - Class in com.google.common.collect.testing.google
Tests for Multiset#forEachEntry.
MultisetForEachEntryTester() - Constructor for class com.google.common.collect.testing.google.MultisetForEachEntryTester
 
MultisetIteratorImpl(Multiset<E>, Iterator<Multiset.Entry<E>>) - Constructor for class com.google.common.collect.Multisets.MultisetIteratorImpl
 
MultisetIteratorTester<E> - Class in com.google.common.collect.testing.google
Tester to make sure the iterator().remove() implementation of Multiset works when there are multiple occurrences of elements.
MultisetIteratorTester() - Constructor for class com.google.common.collect.testing.google.MultisetIteratorTester
 
MultisetNavigationTester<E> - Class in com.google.common.collect.testing.google
Tester for navigation of SortedMultisets.
MultisetNavigationTester() - Constructor for class com.google.common.collect.testing.google.MultisetNavigationTester
 
MultisetNavigationTester.SubMultisetSpec - Enum Class in com.google.common.collect.testing.google
 
MultisetReadsTester<E> - Class in com.google.common.collect.testing.google
A generic JUnit test which tests multiset-specific read operations.
MultisetReadsTester() - Constructor for class com.google.common.collect.testing.google.MultisetReadsTester
 
MultisetRemoveTester<E> - Class in com.google.common.collect.testing.google
Tests for Multiset#remove, Multiset.removeAll, and Multiset.retainAll not already covered by the corresponding Collection testers.
MultisetRemoveTester() - Constructor for class com.google.common.collect.testing.google.MultisetRemoveTester
 
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.DecreasingCount - Class in com.google.common.collect
 
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
 
Multisets.ViewMultiset<E> - Class in com.google.common.collect
An AbstractMultiset with additional default implementations, some of them linear-time implementations in terms of elementSet and entrySet.
MultisetSerializationTester<E> - Class in com.google.common.collect.testing.google
A generic JUnit test which tests multiset-specific serialization.
MultisetSerializationTester() - Constructor for class com.google.common.collect.testing.google.MultisetSerializationTester
 
MultisetSetCountConditionallyTester<E> - Class in com.google.common.collect.testing.google
A generic JUnit test which tests conditional setCount() operations on a multiset.
MultisetSetCountConditionallyTester() - Constructor for class com.google.common.collect.testing.google.MultisetSetCountConditionallyTester
 
MultisetSetCountUnconditionallyTester<E> - Class in com.google.common.collect.testing.google
A generic JUnit test which tests unconditional setCount() operations on a multiset.
MultisetSetCountUnconditionallyTester() - Constructor for class com.google.common.collect.testing.google.MultisetSetCountUnconditionallyTester
 
MultisetTestSuiteBuilder<E> - Class in com.google.common.collect.testing.google
Creates, based on your criteria, a JUnit test suite that exhaustively tests a Multiset implementation.
MultisetTestSuiteBuilder() - Constructor for class com.google.common.collect.testing.google.MultisetTestSuiteBuilder
 
MultisetTestSuiteBuilder.ElementSetGenerator<E> - Class in com.google.common.collect.testing.google
 
MultisetTestSuiteBuilder.EntrySetGenerator<E> - Class in com.google.common.collect.testing.google
 
MultisetTestSuiteBuilder.NoRecurse - Enum Class in com.google.common.collect.testing.google
 
MultisetTestSuiteBuilder.ReserializedMultisetGenerator<E> - Class in com.google.common.collect.testing.google
 
munch() - Method in class com.google.common.hash.AbstractStreamingHasher
 
munchIfFull() - Method in class com.google.common.hash.AbstractStreamingHasher
 
MURMUR128_MITZ_32 - Enum constant in enum class com.google.common.hash.BloomFilterStrategies
See "Less Hashing, Same Performance: Building a Better Bloom Filter" by Adam Kirsch and Michael Mitzenmacher.
MURMUR128_MITZ_64 - Enum constant in enum class com.google.common.hash.BloomFilterStrategies
This strategy uses all 128 bits of Hashing.murmur3_128(int) when hashing.
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(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 variable in class com.google.common.hash.Murmur3_128HashFunction
 
Murmur3_128Hasher(int) - Constructor for class com.google.common.hash.Murmur3_128HashFunction.Murmur3_128Hasher
 
Murmur3_128HashFunction - Class in com.google.common.hash
See MurmurHash3_x64_128 in the C++ implementation.
Murmur3_128HashFunction(int) - Constructor for class com.google.common.hash.Murmur3_128HashFunction
 
Murmur3_128HashFunction.Murmur3_128Hasher - Class in com.google.common.hash
 
murmur3_32() - Static method in class com.google.common.hash.Hashing
Deprecated.
This implementation produces incorrect hash values from the HashFunction.hashString(java.lang.CharSequence, java.nio.charset.Charset) method if the string contains non-BMP characters. Use Hashing.murmur3_32_fixed() instead.
murmur3_32(int) - Static method in class com.google.common.hash.Hashing
Deprecated.
This implementation produces incorrect hash values from the HashFunction.hashString(java.lang.CharSequence, java.nio.charset.Charset) method if the string contains non-BMP characters. Use Hashing.murmur3_32_fixed(int) instead.
MURMUR3_32 - Static variable in class com.google.common.hash.Murmur3_32HashFunction
 
murmur3_32_fixed() - 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_fixed(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_FIXED - Static variable in class com.google.common.hash.Murmur3_32HashFunction
 
Murmur3_32Hasher(int) - Constructor for class com.google.common.hash.Murmur3_32HashFunction.Murmur3_32Hasher
 
Murmur3_32HashFunction - Class in com.google.common.hash
See MurmurHash3_x86_32 in the C++ implementation.
Murmur3_32HashFunction(int, boolean) - Constructor for class com.google.common.hash.Murmur3_32HashFunction
 
Murmur3_32HashFunction.Murmur3_32Hasher - Class in com.google.common.hash
 
murmurHash64WithSeed(byte[], int, int, long) - Static method in class com.google.common.hash.Fingerprint2011
 
MutableCell(R, C, V) - Constructor for class com.google.common.collect.TableCollectors.MutableCell
 
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
 
MutableClassToInstanceMap.SerializedForm<B> - Class in com.google.common.collect
Serialized form of the map, to avoid serializing the constraint.
mutableGraph - Variable in class com.google.common.graph.ImmutableGraph.Builder
 
MutableGraph<N> - Interface in com.google.common.graph
A subinterface of Graph which adds mutation methods.
mutableNetwork - Variable in class com.google.common.graph.ImmutableNetwork.Builder
 
MutableNetwork<N,E> - Interface in com.google.common.graph
A subinterface of Network which adds mutation methods.
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
 
mutableValueGraph - Variable in class com.google.common.graph.ImmutableValueGraph.Builder
 
MutableValueGraph<N,V> - Interface in com.google.common.graph
A subinterface of ValueGraph which adds mutation methods.
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

n - Variable in class com.google.common.collect.ImmutableSortedSet.Builder
 
NACL_APPLICATION - Static variable in class com.google.common.net.MediaType
NaCl applications.
NACL_PORTABLE_APPLICATION - Static variable in class com.google.common.net.MediaType
NaCl portable applications.
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.collect.testing.FeatureSpecificTestSuiteBuilder
 
name - Variable in class com.google.common.eventbus.SubscriberRegistry.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
 
name - Variable in class com.google.common.testing.NullPointerTester.Signature
 
named(String) - Method in class com.google.common.collect.testing.FeatureSpecificTestSuiteBuilder
Configures this builder produce a TestSuite with the given name.
NamedFastMatcher(String) - Constructor for class com.google.common.base.CharMatcher.NamedFastMatcher
 
nameFormat - Variable in class com.google.common.util.concurrent.ThreadFactoryBuilder
 
NaNLinearTransformation() - Constructor for class com.google.common.math.LinearTransformation.NaNLinearTransformation
 
nanos - Variable in class com.google.common.testing.FakeTicker
 
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() - Static method in class com.google.common.graph.ElementOrder
Returns an instance which specifies that the natural ordering of the elements is guaranteed.
NATURAL_EMPTY_MAP - Static variable in class com.google.common.collect.ImmutableSortedMap
 
NATURAL_EMPTY_MULTISET - Static variable in class com.google.common.collect.RegularImmutableSortedMultiset
 
NATURAL_EMPTY_SET - Static variable in class com.google.common.collect.RegularImmutableSortedSet
 
NATURAL_ORDER - Static variable in class com.google.common.collect.ImmutableSortedMap
 
NATURAL_ORDER - Static variable in class com.google.common.collect.testing.SafeTreeMap
 
NATURAL_ORDER - Static variable in class com.google.common.collect.testing.SafeTreeSet
 
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 - Variable in class com.google.common.collect.Maps.DescendingMap
 
navigableKeySet - Variable in class com.google.common.collect.Synchronized.SynchronizedNavigableMap
 
navigableKeySet() - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableAsMap
 
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() - 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() - Method in class com.google.common.collect.Maps.TransformedEntriesNavigableMap
 
navigableKeySet() - Method in class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
navigableKeySet() - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableMap
 
navigableKeySet() - Method in class com.google.common.collect.testing.SafeTreeMap
 
NavigableKeySet(NavigableMap<K, Collection<V>>) - Constructor for class com.google.common.collect.AbstractMapBasedMultimap.NavigableKeySet
 
NavigableKeySet(NavigableMap<K, V>) - Constructor for class com.google.common.collect.Maps.NavigableKeySet
 
navigableMap - Variable in class com.google.common.collect.testing.testers.NavigableMapNavigationTester
 
navigableMap - Variable in class com.google.common.collect.testing.testers.SortedMapNavigationTester
 
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
 
NavigableMapNavigationTester<K,V> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests operations on a NavigableMap.
NavigableMapNavigationTester() - Constructor for class com.google.common.collect.testing.testers.NavigableMapNavigationTester
 
NavigableMapSubmapTestMapGenerator(TestSortedMapGenerator<K, V>, DerivedCollectionGenerators.Bound, DerivedCollectionGenerators.Bound) - Constructor for class com.google.common.collect.testing.NavigableMapTestSuiteBuilder.NavigableMapSubmapTestMapGenerator
 
NavigableMapTestSuiteBuilder<K,V> - Class in com.google.common.collect.testing
Creates, based on your criteria, a JUnit test suite that exhaustively tests a NavigableMap implementation.
NavigableMapTestSuiteBuilder() - Constructor for class com.google.common.collect.testing.NavigableMapTestSuiteBuilder
 
NavigableMapTestSuiteBuilder.DescendingTestMapGenerator<K,V> - Class in com.google.common.collect.testing
 
NavigableMapTestSuiteBuilder.NavigableMapSubmapTestMapGenerator<K,V> - Class in com.google.common.collect.testing
 
navigableSet - Variable in class com.google.common.collect.testing.testers.NavigableSetNavigationTester
 
navigableSet(NavigableSet<E>) - Static method in class com.google.common.collect.Synchronized
 
navigableSet(NavigableSet<E>, Object) - Static method in class com.google.common.collect.Synchronized
 
NavigableSetNavigationTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests operations on a NavigableSet.
NavigableSetNavigationTester() - Constructor for class com.google.common.collect.testing.testers.NavigableSetNavigationTester
 
NavigableSetSubsetTestSetGenerator(TestSortedSetGenerator<E>, DerivedCollectionGenerators.Bound, DerivedCollectionGenerators.Bound) - Constructor for class com.google.common.collect.testing.NavigableSetTestSuiteBuilder.NavigableSetSubsetTestSetGenerator
 
NavigableSetTestSuiteBuilder<E> - Class in com.google.common.collect.testing
Creates, based on your criteria, a JUnit test suite that exhaustively tests a NavigableSet implementation.
NavigableSetTestSuiteBuilder() - Constructor for class com.google.common.collect.testing.NavigableSetTestSuiteBuilder
 
NavigableSetTestSuiteBuilder.NavigableSetSubsetTestSetGenerator<E> - Class in com.google.common.collect.testing
 
NCPU - Static variable in class com.google.common.cache.Striped64
Number of CPUS, to place bound on table size
NCPU - Static variable in class com.google.common.hash.Striped64
Number of CPUS, to place bound on table size
needsAllocArrays() - Method in class com.google.common.collect.CompactHashMap
Returns whether arrays need to be allocated.
needsAllocArrays() - Method in class com.google.common.collect.CompactHashSet
Returns whether arrays need to be allocated.
needsResizing(int, int, double) - Static method in class com.google.common.collect.Hashing
 
nefariousMapEntry(K, V) - Static method in class com.google.common.collect.testing.Helpers
Returns a "nefarious" map entry with the specified key and value, meaning an entry that is suitable for testing that map entries cannot be modified via a nefarious implementation of equals.
negate() - Method in class com.google.common.base.CharMatcher.Any
 
negate() - Method in class com.google.common.base.CharMatcher.FastMatcher
 
negate() - Method in class com.google.common.base.CharMatcher.Is
 
negate() - Method in class com.google.common.base.CharMatcher.IsNot
 
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.Negated
 
negate() - Method in class com.google.common.base.CharMatcher.None
 
Negated(CharMatcher) - Constructor for class com.google.common.base.CharMatcher.Negated
 
NegatedFastMatcher(CharMatcher) - Constructor for class com.google.common.base.CharMatcher.NegatedFastMatcher
 
negativeToMaxValue(long) - Static method in class com.google.common.cache.AbstractCache.SimpleStatsCounter
Returns value, if non-negative.
network - Variable in class com.google.common.graph.Graphs.TransposedNetwork
 
Network<N,E> - Interface in com.google.common.graph
An interface for graph-structured data, whose edges are unique objects.
NetworkBuilder<N,E> - Class in com.google.common.graph
A builder for constructing instances of MutableNetwork or ImmutableNetwork with user-defined properties.
NetworkBuilder(boolean) - Constructor for class com.google.common.graph.NetworkBuilder
Creates a new instance with the specified edge directionality.
NetworkConnections<N,E> - Interface in com.google.common.graph
An interface for representing and manipulating an origin node's adjacent nodes and incident edges in a Network.
NeverScheduledFuture() - Constructor for class com.google.common.util.concurrent.testing.TestingExecutors.NoOpScheduledExecutorService.NeverScheduledFuture
 
NeverSuccessfulListenableFutureTask(Runnable) - Constructor for class com.google.common.util.concurrent.MoreExecutors.ScheduledListeningDecorator.NeverSuccessfulListenableFutureTask
 
NEW - Enum constant in enum class com.google.common.util.concurrent.Service.State
A service in this state is inactive.
newAddMethod() - Method in class com.google.common.collect.testing.AbstractIteratorTester
 
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(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 class 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.
newBuilder() - Static method in class com.google.common.collect.Interners
Returns a fresh Interners.InternerBuilder instance.
newBuilderUsing(TestSortedMapGenerator<K, V>, DerivedCollectionGenerators.Bound, DerivedCollectionGenerators.Bound) - Method in class com.google.common.collect.testing.NavigableMapTestSuiteBuilder
 
newBuilderUsing(TestSortedMapGenerator<K, V>, DerivedCollectionGenerators.Bound, DerivedCollectionGenerators.Bound) - Method in class com.google.common.collect.testing.SortedMapTestSuiteBuilder
Like using() but overrideable by NavigableMapTestSuiteBuilder.
newBuilderUsing(TestSortedSetGenerator<E>, DerivedCollectionGenerators.Bound, DerivedCollectionGenerators.Bound) - Method in class com.google.common.collect.testing.NavigableSetTestSuiteBuilder
 
newBuilderUsing(TestSortedSetGenerator<E>, DerivedCollectionGenerators.Bound, DerivedCollectionGenerators.Bound) - Method in class com.google.common.collect.testing.SortedSetTestSuiteBuilder
Like using() but overrideable by NavigableSetTestSuiteBuilder.
newCapacity(int) - Static method in class com.google.common.collect.CompactHashing
Returns a larger power of 2 hashtable size given the current mask.
newConcurrentHashSet() - Static method in class com.google.common.collect.Platform
Returns the platform preferred implementation of a thread-safe hash set.
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
Creates a new empty ConcurrentHashMap instance.
newCondition() - Method in class com.google.common.util.concurrent.ForwardingLock
 
newCondition() - Method in class com.google.common.util.concurrent.Striped.WeakSafeLock
 
newConnections() - Method in class com.google.common.graph.StandardMutableNetwork
 
newConnections() - Method in class com.google.common.graph.StandardMutableValueGraph
 
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.
newCrc32c() - Static method in class com.google.common.hash.Hashing.Crc32cMethodHandles
 
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.
newDefaultReturningProxy(TypeToken<T>) - Method in class com.google.common.testing.NullPointerTester
 
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.
newEntry(LocalCache.Segment<K, V>, K, int, ReferenceEntry<K, V>) - Method in enum class com.google.common.cache.LocalCache.EntryFactory
Creates a new entry.
newEntry(MapMakerInternalMap.StrongKeyDummyValueSegment<K>, K, int, MapMakerInternalMap.StrongKeyDummyValueEntry<K>) - Method in class com.google.common.collect.MapMakerInternalMap.StrongKeyDummyValueEntry.Helper
 
newEntry(MapMakerInternalMap.StrongKeyStrongValueSegment<K, V>, K, int, MapMakerInternalMap.StrongKeyStrongValueEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.StrongKeyStrongValueEntry.Helper
 
newEntry(MapMakerInternalMap.StrongKeyWeakValueSegment<K, V>, K, int, MapMakerInternalMap.StrongKeyWeakValueEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.StrongKeyWeakValueEntry.Helper
 
newEntry(MapMakerInternalMap.WeakKeyDummyValueSegment<K>, K, int, MapMakerInternalMap.WeakKeyDummyValueEntry<K>) - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyDummyValueEntry.Helper
 
newEntry(MapMakerInternalMap.WeakKeyStrongValueSegment<K, V>, K, int, MapMakerInternalMap.WeakKeyStrongValueEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyStrongValueEntry.Helper
 
newEntry(MapMakerInternalMap.WeakKeyWeakValueSegment<K, V>, K, int, MapMakerInternalMap.WeakKeyWeakValueEntry<K, V>) - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyWeakValueEntry.Helper
 
newEntry(K, int, ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache
This method is a convenience for testing.
newEntry(K, int, ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.Segment
 
newEntry(S, K, int, E) - Method in interface com.google.common.collect.MapMakerInternalMap.InternalEntryHelper
Returns a freshly created entry, typed at the E type, for the given segment.
newEntryArray(int) - Method in class com.google.common.cache.LocalCache.Segment
 
newEntryArray(int) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
 
newEntryForTesting(K, int, MapMakerInternalMap.InternalEntry<K, V, ?>) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Unsafely returns a fresh entry.
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, mutable EnumSet instance containing the given elements in their natural order.
newFixedDelaySchedule(long, long, TimeUnit) - Static method in class com.google.common.util.concurrent.AbstractScheduledService.Scheduler
newFixedDelaySchedule(Duration, Duration) - Static method in class com.google.common.util.concurrent.AbstractScheduledService.Scheduler
newFixedRateSchedule(long, long, TimeUnit) - Static method in class com.google.common.util.concurrent.AbstractScheduledService.Scheduler
newFixedRateSchedule(Duration, Duration) - Static method in class com.google.common.util.concurrent.AbstractScheduledService.Scheduler
newFlatMapSpliterator(OutSpliteratorT, Spliterator<InElementT>, Function<? super InElementT, OutSpliteratorT>, int, long) - Method in interface com.google.common.collect.CollectSpliterators.FlatMapSpliterator.Factory
 
newFreshProxy(Class<T>) - Method in class com.google.common.testing.FreshValueGenerator
 
newFreshValueGenerator() - Method in class com.google.common.testing.ClassSanityTester
 
newFromConstructor(Constructor<X>, Throwable) - Static method in class com.google.common.util.concurrent.FuturesGetChecked
 
newGuard(BooleanSupplier) - Method in class com.google.common.util.concurrent.Monitor
Creates a new guard for this monitor.
newHasher() - Method in class com.google.common.hash.AbstractCompositeHashFunction
 
newHasher() - Method in class com.google.common.hash.AbstractNonStreamingHashFunction
 
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() - Method in class com.google.common.hash.MacHashFunction
 
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
 
newHasher(int) - Method in class com.google.common.hash.AbstractCompositeHashFunction
 
newHasher(int) - Method in class com.google.common.hash.AbstractHashFunction
 
newHasher(int) - Method in class com.google.common.hash.AbstractNonStreamingHashFunction
 
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).
newHashMap() - Static method in class com.google.common.collect.Maps
Creates a mutable, empty HashMap instance.
newHashMap(Collection<? extends Map.Entry<? extends K, ? extends V>>) - Static method in class com.google.common.collect.testing.testers.MapEqualsTester
 
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.
newHashMapWithExpectedSize(int) - Static method in class com.google.common.collect.Platform
Returns the platform preferred implementation of a map based on a hash table.
newHashSet() - Static method in class com.google.common.collect.Sets
Creates a mutable, initially empty HashSet instance.
newHashSet(E...) - Static method in class com.google.common.collect.Sets
Creates a mutable HashSet instance initially containing the given elements.
newHashSet(Iterable<? extends E>) - Static method in class com.google.common.collect.Sets
Creates a mutable HashSet instance containing the given elements.
newHashSet(Iterator<? extends E>) - Static method in class com.google.common.collect.Sets
Creates a mutable HashSet instance containing the given elements.
newHashSetWithExpectedSize(int) - Static method in class com.google.common.collect.Platform
Returns the platform preferred implementation of a set based on a hash table.
newHashSetWithExpectedSize(int) - Static method in class com.google.common.collect.Sets
Returns a new hash set using the smallest initial table size that can hold expectedSize elements without resizing.
newHeader() - Static method in class com.google.common.collect.LinkedHashMultimap.ValueEntry
 
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(TestCollectionGenerator<E>) - Static method in class com.google.common.collect.testing.ReserializingTestCollectionGenerator
 
newInstance(TestSetGenerator<E>) - Static method in class com.google.common.collect.testing.ReserializingTestSetGenerator
 
newInstance(BaseEncoding.Alphabet, Character) - Method in class com.google.common.io.BaseEncoding.Base16Encoding
 
newInstance(BaseEncoding.Alphabet, Character) - Method in class com.google.common.io.BaseEncoding.Base64Encoding
 
newInstance(BaseEncoding.Alphabet, Character) - Method in class com.google.common.io.BaseEncoding.StandardBaseEncoding
 
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>.
newLinkageError(Throwable) - Static method in class com.google.common.hash.ChecksumHashFunction.ChecksumMethodHandles
 
newLinkageError(Throwable) - Static method in class com.google.common.hash.Hashing.Crc32cMethodHandles
 
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.
newLinkedHashMapWithExpectedSize(int) - Static method in class com.google.common.collect.Maps
Creates a LinkedHashMap instance, with a high enough "initial capacity" that it should hold expectedSize elements without growth.
newLinkedHashMapWithExpectedSize(int) - Static method in class com.google.common.collect.Platform
Returns the platform preferred implementation of an insertion ordered map based on a hash table.
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.Platform
Returns the platform preferred implementation of an insertion ordered set based on a hash table.
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(TypeToken<T>) - Method in class com.google.common.testing.DummyProxy
Returns a new proxy for interfaceType.
newProxy(Class<T>) - Method in class com.google.common.testing.FreshValueGenerator
 
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(Class<T>, InvocationHandler) - Static method in class com.google.common.util.concurrent.SimpleTimeLimiter
 
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(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.
newProxy(T, Class<T>, Duration) - 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(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.
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.
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.
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.
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.
newSegment(MapMakerInternalMap<K, MapMaker.Dummy, MapMakerInternalMap.StrongKeyDummyValueEntry<K>, MapMakerInternalMap.StrongKeyDummyValueSegment<K>>, int) - Method in class com.google.common.collect.MapMakerInternalMap.StrongKeyDummyValueEntry.Helper
 
newSegment(MapMakerInternalMap<K, MapMaker.Dummy, MapMakerInternalMap.WeakKeyDummyValueEntry<K>, MapMakerInternalMap.WeakKeyDummyValueSegment<K>>, int) - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyDummyValueEntry.Helper
 
newSegment(MapMakerInternalMap<K, V, MapMakerInternalMap.StrongKeyStrongValueEntry<K, V>, MapMakerInternalMap.StrongKeyStrongValueSegment<K, V>>, int) - Method in class com.google.common.collect.MapMakerInternalMap.StrongKeyStrongValueEntry.Helper
 
newSegment(MapMakerInternalMap<K, V, MapMakerInternalMap.StrongKeyWeakValueEntry<K, V>, MapMakerInternalMap.StrongKeyWeakValueSegment<K, V>>, int) - Method in class com.google.common.collect.MapMakerInternalMap.StrongKeyWeakValueEntry.Helper
 
newSegment(MapMakerInternalMap<K, V, MapMakerInternalMap.WeakKeyStrongValueEntry<K, V>, MapMakerInternalMap.WeakKeyStrongValueSegment<K, V>>, int) - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyStrongValueEntry.Helper
 
newSegment(MapMakerInternalMap<K, V, MapMakerInternalMap.WeakKeyWeakValueEntry<K, V>, MapMakerInternalMap.WeakKeyWeakValueSegment<K, V>>, int) - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyWeakValueEntry.Helper
 
newSegment(MapMakerInternalMap<K, V, E, S>, int) - Method in interface com.google.common.collect.MapMakerInternalMap.InternalEntryHelper
Returns a freshly created segment, typed at the S type.
newSegmentArray(int) - Method in class com.google.common.cache.LocalCache
 
newSegmentArray(int) - Method in class com.google.common.collect.MapMakerInternalMap
 
newSequentialExecutor(Executor) - Static method in class com.google.common.util.concurrent.MoreExecutors
Returns an Executor that runs each task executed sequentially, such that no two tasks are running concurrently.
newSetFromMap(Map<E, Boolean>) - Static method in class com.google.common.collect.Sets
newSetMethod() - Method in class com.google.common.collect.testing.AbstractIteratorTester
 
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.
newTargetIterator() - Method in class com.google.common.collect.testing.AbstractIteratorTester
Returns a new target iterator each time it's called.
newTargetIterator() - Method in class com.google.common.collect.testing.ListIteratorTester
 
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(Runnable) - Method in class com.google.common.testing.ArbitraryInstances.Dummies.DummyThreadFactory
 
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.
newTraversal() - Method in class com.google.common.graph.Traverser
 
newTreeMap() - Static method in class com.google.common.collect.Maps
Creates a mutable, empty TreeMap instance using the natural ordering of its elements.
newTreeMap(Comparator<C>) - Static method in class com.google.common.collect.Maps
Creates a mutable, empty TreeMap instance using the given comparator.
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.
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.
newTypeVariableImpl(D, String, Type[]) - Static method in class com.google.common.reflect.Types
 
newValueCollectionBuilderWithExpectedSize(int) - Method in class com.google.common.collect.ImmutableMultimap.Builder
 
newValueCollectionBuilderWithExpectedSize(int) - Method in class com.google.common.collect.ImmutableSetMultimap.Builder
 
newValueReference(ReferenceEntry<K, V>, V, int) - Method in class com.google.common.cache.LocalCache
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.
newWeakValueReferenceForTesting(MapMakerInternalMap.InternalEntry<K, V, ?>, V) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Unsafely creates of a fresh MapMakerInternalMap.WeakValueReference, referencing the given value, for the given entry
newWeakValueReferenceForTesting(MapMakerInternalMap.InternalEntry<K, V, ?>, V) - Method in class com.google.common.collect.MapMakerInternalMap.StrongKeyWeakValueSegment
 
newWeakValueReferenceForTesting(MapMakerInternalMap.InternalEntry<K, V, ?>, V) - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyWeakValueSegment
 
newWithCause(Class<X>, Throwable) - Static method in class com.google.common.util.concurrent.FuturesGetChecked
 
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 - Variable in class com.google.common.base.MoreObjects.ToStringHelper.ValueHolder
 
next - Variable in class com.google.common.cache.LocalCache.StrongEntry
 
next - Variable in class com.google.common.cache.LocalCache.WeakEntry
 
next - Variable in class com.google.common.collect.AbstractIterator
 
next - Variable in class com.google.common.collect.HashBiMap.Itr
 
next - Variable 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 - Variable in class com.google.common.collect.LinkedListMultimap.ValueForKeyIterator
 
next - Variable in class com.google.common.collect.MapMakerInternalMap.StrongKeyDummyValueEntry.LinkedStrongKeyDummyValueEntry
 
next - Variable in class com.google.common.collect.MapMakerInternalMap.StrongKeyStrongValueEntry.LinkedStrongKeyStrongValueEntry
 
next - Variable in class com.google.common.collect.MapMakerInternalMap.StrongKeyWeakValueEntry.LinkedStrongKeyWeakValueEntry
 
next - Variable in class com.google.common.collect.MapMakerInternalMap.WeakKeyDummyValueEntry.LinkedWeakKeyDummyValueEntry
 
next - Variable in class com.google.common.collect.MapMakerInternalMap.WeakKeyStrongValueEntry.LinkedWeakKeyStrongValueEntry
 
next - Variable in class com.google.common.collect.MapMakerInternalMap.WeakKeyWeakValueEntry.LinkedWeakKeyWeakValueEntry
 
next - Variable in class com.google.common.collect.testing.AbstractIteratorTester
 
next - Variable in class com.google.common.util.concurrent.AbstractFuture.Listener
 
next - Variable in class com.google.common.util.concurrent.AbstractFuture.Waiter
 
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
next() - Method in class com.google.common.base.AbstractIterator
 
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() - Method in class com.google.common.cache.LocalCache.ValueIterator
 
next() - Method in class com.google.common.collect.AbstractIndexedListIterator
 
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.CompactHashMap.Itr
 
next() - Method in class com.google.common.collect.EnumMultiset.Itr
 
next() - Method in class com.google.common.collect.ForwardingIterator
 
next() - Method in class com.google.common.collect.HashBiMap.Itr
 
next() - Method in class com.google.common.collect.Iterators.ConcatenatedIterator
 
next() - Method in enum class com.google.common.collect.Iterators.EmptyModifiableIterator
 
next() - Method in class com.google.common.collect.Iterators.MergingIterator
 
next() - Method in class com.google.common.collect.Iterators.PeekingImpl
 
next() - Method in class com.google.common.collect.Iterators.SingletonIterator
 
next() - Method in class com.google.common.collect.LinkedListMultimap.DistinctKeyIterator
 
next() - Method in class com.google.common.collect.LinkedListMultimap.NodeIterator
 
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() - Method in class com.google.common.collect.MapMakerInternalMap.ValueIterator
 
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.testing.AbstractIteratorTester.MultiExceptionListIterator
 
next() - Method in class com.google.common.collect.TransformedIterator
 
next() - Method in class com.google.common.collect.TreeTraverser.BreadthFirstIterator
Deprecated.
 
next() - Method in class com.google.common.collect.TreeTraverser.PreOrderIterator
Deprecated.
 
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(Integer) - Method in class com.google.common.collect.DiscreteDomain.IntegerDomain
 
next(Long) - Method in class com.google.common.collect.DiscreteDomain.LongDomain
 
next(BigInteger) - Method in class com.google.common.collect.DiscreteDomain.BigIntegerDomain
 
NEXT_HIGHER - Enum constant in enum class com.google.common.collect.SortedLists.KeyAbsentBehavior
Return the index of the next higher element in the list, or list.size() if there is no such element.
NEXT_LOWER - Enum constant in enum class com.google.common.collect.SortedLists.KeyAbsentBehavior
Return the index of the next lower element in the list, or -1 if there is no such element.
NEXT_METHOD - Static variable in class com.google.common.collect.testing.AbstractIteratorTester
 
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
 
nextCursor - Variable in class com.google.common.collect.MinMaxPriorityQueue.QueueIterator
 
nextDouble() - Method in class com.google.common.hash.Hashing.LinearCongruentialGenerator
 
nextDown(double) - Static method in class com.google.common.math.DoubleUtils
 
nextElements - Variable in class com.google.common.collect.testing.AbstractIteratorTester.MultiExceptionListIterator
The elements to be returned by future calls to next(), with the first at the top of the stack.
nextEntry - Variable 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.cache.LocalCache.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
 
nextExecutor - Variable in class com.google.common.util.concurrent.ExecutionSequencer.ThreadConfinedTaskQueue
Only used by the thread associated with this object
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.
nextInBucket - Variable in class com.google.common.collect.RegularImmutableMultiset.NonTerminalEntry
 
nextInBucket() - Method in class com.google.common.collect.Multisets.ImmutableEntry
 
nextInBucket() - Method in class com.google.common.collect.RegularImmutableMultiset.NonTerminalEntry
 
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 - Variable in class com.google.common.collect.LinkedListMultimap.NodeIterator
 
nextIndex - Variable in class com.google.common.collect.LinkedListMultimap.ValueForKeyIterator
 
nextIndex - Variable in class com.google.common.collect.testing.AbstractIteratorTester
 
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() - Method in class com.google.common.collect.LinkedListMultimap.NodeIterator
 
nextIndex() - Method in class com.google.common.collect.LinkedListMultimap.ValueForKeyIterator
 
nextIndex() - Method in class com.google.common.collect.testing.AbstractIteratorTester.MultiExceptionListIterator
 
nextIndex() - Method in class com.google.common.collect.TransformedListIterator
 
nextInKeyBucket - Variable in class com.google.common.collect.ImmutableMapEntry.NonTerminalImmutableMapEntry
 
nextInKeyInsertionOrder - Variable in class com.google.common.collect.HashBiMap.BiEntry
 
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.ImmutableMapEntry.NonTerminalImmutableBiMapEntry
 
nextInValueBucket - Variable in class com.google.common.collect.LinkedHashMultimap.ValueEntry
 
nextInVToKBucket - Variable in class com.google.common.collect.HashBiMap.BiEntry
 
nextNotInSkipMe(int) - Method in class com.google.common.collect.MinMaxPriorityQueue.QueueIterator
Advances nextCursor to 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
 
nextTask - Variable in class com.google.common.util.concurrent.ExecutionSequencer.ThreadConfinedTaskQueue
Only used by the thread associated with this object
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 method in class com.google.common.base.CharMatcher.Digit
 
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_BOUND - Enum constant in enum class com.google.common.collect.testing.DerivedCollectionGenerators.Bound
 
NO_BOUND - Enum constant in enum class com.google.common.collect.testing.google.SortedMultisetTestSuiteBuilder.Bound
 
NO_ENTRY_SET - Enum constant in enum class com.google.common.collect.testing.google.MultisetTestSuiteBuilder.NoRecurse
 
NO_PORT - Static variable in class com.google.common.net.HostAndPort
Magic value indicating the absence of a port number.
NO_REFERRER - Static variable in class com.google.common.net.HttpHeaders.ReferrerPolicyValues
 
NO_REFFERER_WHEN_DOWNGRADE - Static variable in class com.google.common.net.HttpHeaders.ReferrerPolicyValues
 
NO_SPLIT_FOR_EACH_REMAINING - Enum constant in enum class com.google.common.collect.testing.SpliteratorTester.SpliteratorDecompositionStrategy
 
NO_SPLIT_TRY_ADVANCE - Enum constant in enum class com.google.common.collect.testing.SpliteratorTester.SpliteratorDecompositionStrategy
 
NO_SUFFIX_FOUND - Static variable in class com.google.common.net.InternetDomainName
Value of InternetDomainName.publicSuffixIndex() or InternetDomainName.registrySuffixIndex() which indicates that no relevant suffix was found.
NO_VARY_SEARCH - Static variable in class com.google.common.net.HttpHeaders
The HTTP No-Vary-Seearch header field name.
node - Variable in class com.google.common.graph.DirectedGraphConnections.NodeConnection
 
node - Variable in class com.google.common.graph.EndpointPairIterator
 
node - Variable in class com.google.common.graph.Graphs.NodeAndRemainingSuccessors
 
node - Variable in class com.google.common.graph.IncidentEdgeSet
 
Node(K, V) - Constructor for class com.google.common.collect.LinkedListMultimap.Node
 
NODE_NOT_IN_GRAPH - Static variable in class com.google.common.graph.GraphConstants
 
NODE_PAIR_REMOVED_FROM_GRAPH - Static variable in class com.google.common.graph.GraphConstants
 
NODE_REMOVED_FROM_GRAPH - Static variable in class com.google.common.graph.GraphConstants
 
nodeAggregate(TreeMultiset.AvlNode<?>) - Method in enum class com.google.common.collect.TreeMultiset.Aggregate
 
NodeAndRemainingSuccessors(N) - Constructor for class com.google.common.graph.Graphs.NodeAndRemainingSuccessors
 
NodeConnection(N) - Constructor for class com.google.common.graph.DirectedGraphConnections.NodeConnection
 
nodeConnections - Variable in class com.google.common.graph.StandardNetwork
 
nodeConnections - Variable in class com.google.common.graph.StandardValueGraph
 
nodeInvalidatableSet(Set<T>, N) - Method in class com.google.common.graph.AbstractBaseGraph
 
nodeInvalidatableSet(Set<T>, N) - Method in class com.google.common.graph.AbstractNetwork
Returns a Set whose methods throw IllegalStateException when the given node is not present in this network.
nodeIterator - Variable in class com.google.common.graph.EndpointPairIterator
 
NodeIterator(int) - Constructor for class com.google.common.collect.LinkedListMultimap.NodeIterator
 
nodeOrder - Variable in class com.google.common.graph.AbstractGraphBuilder
 
nodeOrder - Variable in class com.google.common.graph.StandardNetwork
 
nodeOrder - Variable in class com.google.common.graph.StandardValueGraph
 
nodeOrder() - Method in interface com.google.common.graph.BaseGraph
Returns the order of iteration for the elements of BaseGraph.nodes().
nodeOrder() - Method in class com.google.common.graph.ForwardingGraph
 
nodeOrder() - Method in class com.google.common.graph.ForwardingNetwork
 
nodeOrder() - Method in class com.google.common.graph.ForwardingValueGraph
 
nodeOrder() - Method in interface com.google.common.graph.Graph
Returns the order of iteration for the elements of Graph.nodes().
nodeOrder() - Method in interface com.google.common.graph.Network
Returns the order of iteration for the elements of Network.nodes().
nodeOrder() - Method in class com.google.common.graph.StandardNetwork
 
nodeOrder() - Method in class com.google.common.graph.StandardValueGraph
 
nodeOrder() - Method in interface com.google.common.graph.ValueGraph
Returns the order of iteration for the elements of ValueGraph.nodes().
nodeOrder(ElementOrder<N1>) - Method in class com.google.common.graph.GraphBuilder
Specifies the order of iteration for the elements of Graph.nodes().
nodeOrder(ElementOrder<N1>) - Method in class com.google.common.graph.NetworkBuilder
Specifies the order of iteration for the elements of Network.nodes().
nodeOrder(ElementOrder<N1>) - Method in class com.google.common.graph.ValueGraphBuilder
Specifies the order of iteration for the elements of Graph.nodes().
nodePairInvalidatableSet(Set<T>, N, N) - Method in class com.google.common.graph.AbstractBaseGraph
 
nodePairInvalidatableSet(Set<T>, N, N) - Method in class com.google.common.graph.AbstractNetwork
Returns a Set whose methods throw IllegalStateException when either of the given nodes is not present in this network.
nodes() - Method in interface com.google.common.graph.BaseGraph
Returns all nodes in this graph, in the order specified by BaseGraph.nodeOrder().
nodes() - Method in class com.google.common.graph.ForwardingGraph
 
nodes() - Method in class com.google.common.graph.ForwardingNetwork
 
nodes() - Method in class com.google.common.graph.ForwardingValueGraph
 
nodes() - Method in interface com.google.common.graph.Graph
Returns all nodes in this graph, in the order specified by Graph.nodeOrder().
nodes() - Method in interface com.google.common.graph.Network
Returns all nodes in this network, in the order specified by Network.nodeOrder().
nodes() - Method in class com.google.common.graph.StandardNetwork
 
nodes() - Method in class com.google.common.graph.StandardValueGraph
 
nodes() - Method in interface com.google.common.graph.ValueGraph
Returns all nodes in this graph, in the order specified by ValueGraph.nodeOrder().
nodeToOutEdge - Variable in class com.google.common.graph.EdgesConnecting
 
nodeU - Variable in class com.google.common.graph.EndpointPair
 
nodeU() - Method in class com.google.common.graph.EndpointPair
If this EndpointPair EndpointPair.isOrdered() returns the EndpointPair.source(); otherwise, returns an arbitrary (but consistent) endpoint of the origin edge.
nodeV - Variable in class com.google.common.graph.EndpointPair
 
nodeV() - Method in class com.google.common.graph.EndpointPair
Returns the node adjacent to EndpointPair.nodeU() along the origin edge.
NodeVisitState() - Constructor for enum class com.google.common.graph.Graphs.NodeVisitState
 
NON_STANDARD_TOSTRING - Enum constant in enum class com.google.common.collect.testing.features.CollectionFeature
Indicates that a collection has a different Object.toString() representation than most collections.
nonCancellationPropagating(ListenableFuture<V>) - Static method in class com.google.common.util.concurrent.Futures
Returns a 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 method in class com.google.common.base.CharMatcher
Matches no characters.
None() - Constructor for class com.google.common.base.CharMatcher.None
 
NONE - Enum constant in enum class com.google.common.collect.testing.features.CollectionFeature
For documenting collections that support no optional features, such as Collections.emptySet()
nonEmptyProperSubset - Variable in class com.google.common.collect.testing.testers.CollectionRetainAllTester
 
noneOf(CharSequence) - Static method in class com.google.common.base.CharMatcher
Returns a char matcher that matches any BMP character not present in the given character sequence.
Non-finite values - Search tag in com.google.common.math.PairedStats.leastSquaresFit()
Section
Non-finite values - Search tag in com.google.common.math.PairedStats.pearsonsCorrelationCoefficient()
Section
Non-finite values - Search tag in com.google.common.math.PairedStats.populationCovariance()
Section
Non-finite values - Search tag in com.google.common.math.PairedStats.sampleCovariance()
Section
Non-finite values - Search tag in com.google.common.math.PairedStatsAccumulator.leastSquaresFit()
Section
Non-finite values - Search tag in com.google.common.math.PairedStatsAccumulator.pearsonsCorrelationCoefficient()
Section
Non-finite values - Search tag in com.google.common.math.PairedStatsAccumulator.populationCovariance()
Section
Non-finite values - Search tag in com.google.common.math.PairedStatsAccumulator.sampleCovariance()
Section
Non-finite values - Search tag in com.google.common.math.Stats.max()
Section
Non-finite values - Search tag in com.google.common.math.Stats.mean()
Section
Non-finite values - Search tag in com.google.common.math.Stats.min()
Section
Non-finite values - Search tag in com.google.common.math.Stats.populationStandardDeviation()
Section
Non-finite values - Search tag in com.google.common.math.Stats.populationVariance()
Section
Non-finite values - Search tag in com.google.common.math.Stats.sampleStandardDeviation()
Section
Non-finite values - Search tag in com.google.common.math.Stats.sampleVariance()
Section
Non-finite values - Search tag in com.google.common.math.Stats.sum()
Section
Non-finite values - Search tag in com.google.common.math.StatsAccumulator.max()
Section
Non-finite values - Search tag in com.google.common.math.StatsAccumulator.mean()
Section
Non-finite values - Search tag in com.google.common.math.StatsAccumulator.min()
Section
Non-finite values - Search tag in com.google.common.math.StatsAccumulator.populationStandardDeviation()
Section
Non-finite values - Search tag in com.google.common.math.StatsAccumulator.populationVariance()
Section
Non-finite values - Search tag in com.google.common.math.StatsAccumulator.sampleStandardDeviation()
Section
Non-finite values - Search tag in com.google.common.math.StatsAccumulator.sampleVariance()
Section
Non-finite values - Search tag in com.google.common.math.StatsAccumulator.sum()
Section
Non-preconditions - Search tag in class com.google.common.base.Preconditions
Section
NonSerializableMemoizingSupplier(Supplier<T>) - Constructor for class com.google.common.base.Suppliers.NonSerializableMemoizingSupplier
 
NonTerminalEntry(E, int, Multisets.ImmutableEntry<E>) - Constructor for class com.google.common.collect.RegularImmutableMultiset.NonTerminalEntry
 
NonTerminalImmutableBiMapEntry(K, V, ImmutableMapEntry<K, V>, ImmutableMapEntry<K, V>) - Constructor for class com.google.common.collect.ImmutableMapEntry.NonTerminalImmutableBiMapEntry
 
NonTerminalImmutableMapEntry(K, V, ImmutableMapEntry<K, V>) - Constructor for class com.google.common.collect.ImmutableMapEntry.NonTerminalImmutableMapEntry
 
noOpScheduledExecutor() - Static method in class com.google.common.util.concurrent.testing.TestingExecutors
Returns a ScheduledExecutorService that never executes anything.
NoOpScheduledExecutorService() - Constructor for class com.google.common.util.concurrent.testing.TestingExecutors.NoOpScheduledExecutorService
 
NoOpService() - Constructor for class com.google.common.util.concurrent.ServiceManager.NoOpService
 
NoRecurse() - Constructor for enum class com.google.common.collect.testing.google.BiMapTestSuiteBuilder.NoRecurse
 
NoRecurse() - Constructor for enum class com.google.common.collect.testing.google.MultisetTestSuiteBuilder.NoRecurse
 
NoRecurse() - Constructor for enum class com.google.common.collect.testing.google.SortedMultisetTestSuiteBuilder.NoRecurse
 
NoRecurse() - Constructor for enum class com.google.common.collect.testing.SortedMapTestSuiteBuilder.NoRecurse
 
normalizeFirstWord(String) - Method in enum class 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 class 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.
NOT_AVAILABLE_ON_UNDIRECTED - Static variable in class com.google.common.graph.GraphConstants
 
NOT_FOUND - Static variable in class com.google.common.collect.CompactHashMap
 
NOT_NULL - Enum constant in enum class com.google.common.base.Predicates.ObjectPredicate
 
NOT_READY - Enum constant in enum class com.google.common.base.AbstractIterator.State
 
NOT_READY - Enum constant in enum class com.google.common.collect.AbstractIterator.State
We haven't yet computed or have already returned the element.
NOT_RUN - Enum constant in enum class com.google.common.util.concurrent.ExecutionSequencer.RunningState
 
NotAnInstance() - Constructor for enum class com.google.common.testing.EqualsTester.NotAnInstance
 
notForTypeVariable() - Method in class com.google.common.reflect.TypeResolver.WildcardCapturer
 
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
Notify pending loads that a new value was set.
notifyNewValue(V) - Method in class com.google.common.cache.LocalCache.WeakValueReference
 
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.
NotPredicate(Predicate<T>) - Constructor for class com.google.common.base.Predicates.NotPredicate
 
NPE_IAE_OR_UOE - Enum constant in enum class com.google.common.testing.NullPointerTester.ExceptionTypePolicy
NPE_OR_UOE - Enum constant in enum class com.google.common.testing.NullPointerTester.ExceptionTypePolicy
NSEE - Static variable in exception class com.google.common.collect.testing.AbstractIteratorTester.PermittedMetaException
 
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 - Static variable in class com.google.common.util.concurrent.AbstractFuture
A special value to represent null.
NULL - Static variable in class com.google.common.util.concurrent.ImmediateFuture
 
NULL_ESCAPER - Static variable in class com.google.common.escape.Escapers
 
NULL_OUTPUT_STREAM - Static variable in class com.google.common.io.ByteStreams
 
NULL_PLACEHOLDER - Static variable in class com.google.common.collect.MoreCollectors
 
NULL_STATS_COUNTER - Static variable in class com.google.common.cache.CacheBuilder
 
NULL_TEST_METHOD_NAMES - Static variable in class com.google.common.testing.AbstractPackageSanityTests
 
NULL_TICKER - Static variable in class com.google.common.cache.CacheBuilder
 
Nullability - Search tag in class com.google.common.base.Converter
Section
NULLABLE_ANNOTATION_SIMPLE_NAMES - Static variable in class com.google.common.testing.NullPointerTester
 
nullableSynchronizedEntry(Map.Entry<K, V>, Object) - Static method in class com.google.common.collect.Synchronized
 
NullByteSink() - Constructor for class com.google.common.testing.ArbitraryInstances.NullByteSink
 
nullCheckedTreeSet(E[]) - Static method in class com.google.common.collect.testing.google.SetGenerators
 
nullEntry() - Static method in class com.google.common.cache.LocalCache
 
NullEntry() - Constructor for enum class com.google.common.cache.LocalCache.NullEntry
 
nullEscaper() - Static method in class com.google.common.escape.Escapers
Returns an Escaper that does no escaping, passing all character data through unchanged.
NullFriendlyComparator() - Constructor for class com.google.common.collect.testing.TestsForMapsInJavaUtil.NullFriendlyComparator
 
NullFriendlyComparator() - Constructor for class com.google.common.collect.testing.TestsForSetsInJavaUtil.NullFriendlyComparator
 
nullifyAccessOrder(ReferenceEntry<K, V>) - Static method in class com.google.common.cache.LocalCache
 
nullifyWriteOrder(ReferenceEntry<K, V>) - Static method in class com.google.common.cache.LocalCache
 
nullKeyEntry - Variable in class com.google.common.collect.testing.testers.MapPutTester
 
nullKeyValueEntry - Variable in class com.google.common.collect.testing.testers.MapPutTester
 
NullListener() - Constructor for enum class com.google.common.cache.CacheBuilder.NullListener
 
NULLNESS_ANNOTATION_READER - Static variable in class com.google.common.testing.NullPointerTester
 
NullnessAnnotationReader() - Constructor for enum class com.google.common.testing.NullPointerTester.NullnessAnnotationReader
 
NullnessCasts - Class in com.google.common.base
A utility method to perform unchecked casts to suppress errors produced by nullness analyses.
NullnessCasts - Class in com.google.common.collect
A utility method to perform unchecked casts to suppress errors produced by nullness analyses.
NullnessCasts - Class in com.google.common.util.concurrent
A utility method to perform unchecked casts to suppress errors produced by nullness analyses.
NullnessCasts() - Constructor for class com.google.common.base.NullnessCasts
 
NullnessCasts() - Constructor for class com.google.common.collect.NullnessCasts
 
NullnessCasts() - Constructor for class com.google.common.util.concurrent.NullnessCasts
 
nullOutputStream() - Static method in class com.google.common.io.ByteStreams
Returns an OutputStream that simply discards written bytes.
nullPointerTester - Variable in class com.google.common.testing.ClassSanityTester
 
NullPointerTester - Class in com.google.common.testing
A test utility that verifies that your methods and constructors throw NullPointerException or UnsupportedOperationException whenever null is passed to a parameter whose declaration or type isn't annotated with an annotation with the simple name Nullable, CheckForNull, NullableType, or NullableDecl.
NullPointerTester() - Constructor for class com.google.common.testing.NullPointerTester
 
NullPointerTester.ExceptionTypePolicy - Enum Class in com.google.common.testing
Strategy for exception type matching used by NullPointerTester.
NullPointerTester.NullnessAnnotationReader - Enum Class in com.google.common.testing
Looks for declaration nullness annotations and, if supported, type-use nullness annotations.
NullPointerTester.Signature - Class in com.google.common.testing
 
NullPointerTester.Visibility - Enum Class in com.google.common.testing
Visibility of any method or constructor.
NullsBefore(String) - Constructor for class com.google.common.collect.testing.Helpers.NullsBefore
 
NullsBeforeB() - Constructor for class com.google.common.collect.testing.Helpers.NullsBeforeB
 
NullsBeforeTwo() - Constructor for class com.google.common.collect.testing.Helpers.NullsBeforeTwo
 
nullsFirst - Variable in class com.google.common.collect.NaturalOrdering
 
nullsFirst() - Method in class com.google.common.collect.NaturalOrdering
 
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
 
nullSingleton - Variable in class com.google.common.collect.testing.testers.CollectionRetainAllTester
 
nullsLast - Variable in class com.google.common.collect.NaturalOrdering
 
nullsLast() - Method in class com.google.common.collect.NaturalOrdering
 
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.Platform
Returns the string if it is not null, or an empty string otherwise.
nullToEmpty(String) - Static method in class com.google.common.base.Strings
Returns the given string if it is non-null; the empty string otherwise.
nullValueEntry - Variable in class com.google.common.collect.testing.testers.MapPutTester
 
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
 
numElements - Variable in enum class com.google.common.collect.testing.features.CollectionSize
 
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 class 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
 
OBSERVE_BROWSING_TOPICS - Static variable in class com.google.common.net.HttpHeaders
The HTTP Observe-Browsing-Topics header field name.
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() - Static method in class com.google.common.collect.FluentIterable
Returns a fluent iterable containing no elements.
of() - Static method in class com.google.common.collect.ImmutableBiMap
Returns the empty bimap.
of() - Static method in class com.google.common.collect.ImmutableClassToInstanceMap
Returns an empty ImmutableClassToInstanceMap.
of() - Static method in class com.google.common.collect.ImmutableList
Returns the empty immutable list.
of() - Static method in class com.google.common.collect.ImmutableListMultimap
Returns the empty multimap.
of() - Static method in class com.google.common.collect.ImmutableMap
Returns the empty map.
of() - Static method in class com.google.common.collect.ImmutableMultimap
Returns an empty multimap.
of() - Static method in class com.google.common.collect.ImmutableMultiset
Returns the empty immutable multiset.
of() - Static method in class com.google.common.collect.ImmutableRangeMap
Returns an empty immutable range map.
of() - Static method in class com.google.common.collect.ImmutableRangeSet
Returns an empty immutable range set.
of() - Static method in class com.google.common.collect.ImmutableSet
Returns the empty immutable set.
of() - Static method in class com.google.common.collect.ImmutableSetMultimap
Returns the empty multimap.
of() - Static method in class com.google.common.collect.ImmutableSortedMap
Returns the empty sorted map.
of() - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns the empty immutable sorted multiset.
of() - Static method in class com.google.common.collect.ImmutableSortedSet
Returns the empty immutable sorted set.
of() - Static method in class com.google.common.collect.ImmutableTable
Returns an empty immutable table.
of() - Static method in class com.google.common.graph.DirectedMultiNetworkConnections
 
of() - Static method in class com.google.common.graph.DirectedNetworkConnections
 
of() - Static method in class com.google.common.graph.UndirectedMultiNetworkConnections
 
of() - Static method in class com.google.common.graph.UndirectedNetworkConnections
 
of() - Static method in class com.google.common.primitives.ImmutableDoubleArray
Returns the empty array.
of() - Static method in class com.google.common.primitives.ImmutableIntArray
Returns the empty array.
of() - Static method in class com.google.common.primitives.ImmutableLongArray
Returns the empty array.
of() - Static method in class com.google.common.reflect.ImmutableTypeToInstanceMap
Returns an empty type to instance map.
of(double) - Static method in class com.google.common.primitives.ImmutableDoubleArray
Returns an immutable array containing a single value.
of(double...) - Static method in class com.google.common.math.Stats
Returns statistics over a dataset containing the given values.
of(double, double) - Static method in class com.google.common.primitives.ImmutableDoubleArray
Returns an immutable array containing the given values, in order.
of(double, double...) - Static method in class com.google.common.primitives.ImmutableDoubleArray
Returns an immutable array containing the given values, in order.
of(double, double, double) - Static method in class com.google.common.primitives.ImmutableDoubleArray
Returns an immutable array containing the given values, in order.
of(double, double, double, double) - Static method in class com.google.common.primitives.ImmutableDoubleArray
Returns an immutable array containing the given values, in order.
of(double, double, double, double, double) - Static method in class com.google.common.primitives.ImmutableDoubleArray
Returns an immutable array containing the given values, in order.
of(double, double, double, double, double, double) - Static method in class com.google.common.primitives.ImmutableDoubleArray
Returns an immutable array containing the given values, in order.
of(int) - Static method in class com.google.common.primitives.ImmutableIntArray
Returns an immutable array containing a single value.
of(int...) - Static method in class com.google.common.math.Stats
Returns statistics over a dataset containing the given values.
of(int, int) - Static method in class com.google.common.primitives.ImmutableIntArray
Returns an immutable array containing the given values, in order.
of(int, int...) - Static method in class com.google.common.primitives.ImmutableIntArray
Returns an immutable array containing the given values, in order.
of(int, int, int) - Static method in class com.google.common.primitives.ImmutableIntArray
Returns an immutable array containing the given values, in order.
of(int, int, int, int) - Static method in class com.google.common.primitives.ImmutableIntArray
Returns an immutable array containing the given values, in order.
of(int, int, int, int, int) - Static method in class com.google.common.primitives.ImmutableIntArray
Returns an immutable array containing the given values, in order.
of(int, int, int, int, int, int) - Static method in class com.google.common.primitives.ImmutableIntArray
Returns an immutable array containing the given values, in order.
of(long) - Static method in class com.google.common.primitives.ImmutableLongArray
Returns an immutable array containing a single value.
of(long...) - Static method in class com.google.common.math.Stats
Returns statistics over a dataset containing the given values.
of(long, long) - Static method in class com.google.common.primitives.ImmutableLongArray
Returns an immutable array containing the given values, in order.
of(long, long...) - Static method in class com.google.common.primitives.ImmutableLongArray
Returns an immutable array containing the given values, in order.
of(long, long, long) - Static method in class com.google.common.primitives.ImmutableLongArray
Returns an immutable array containing the given values, in order.
of(long, long, long, long) - Static method in class com.google.common.primitives.ImmutableLongArray
Returns an immutable array containing the given values, in order.
of(long, long, long, long, long) - Static method in class com.google.common.primitives.ImmutableLongArray
Returns an immutable array containing the given values, in order.
of(long, long, long, long, long, long) - Static method in class com.google.common.primitives.ImmutableLongArray
Returns an immutable array containing the given values, in order.
of(Equivalence<? super T>) - Static method in class com.google.common.testing.EquivalenceTester
 
of(Range<C>) - Static method in class com.google.common.collect.ImmutableRangeSet
Returns an immutable range set containing the specified single range.
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(BaseGraph<N>) - Static method in class com.google.common.graph.EndpointPairIterator
 
of(ElementOrder<N>) - Static method in class com.google.common.graph.DirectedGraphConnections
 
of(ElementOrder<N>) - Static method in class com.google.common.graph.UndirectedGraphConnections
 
of(Graph<?>, N, N) - Static method in class com.google.common.graph.EndpointPair
Returns an EndpointPair representing the endpoints of an edge in graph.
of(Network<?, ?>, N, N) - Static method in class com.google.common.graph.EndpointPair
Returns an EndpointPair representing the endpoints of an edge in network.
of(E) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing a single element.
of(E) - Static method in class com.google.common.collect.ImmutableMultiset
Returns an immutable multiset containing a single element.
of(E) - Static method in class com.google.common.collect.ImmutableSet
Returns an immutable set containing the given element.
of(E) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns an immutable sorted multiset containing a single element.
of(E) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing a single element.
of(E...) - Static method in class com.google.common.collect.testing.MinimalCollection
 
of(E...) - Static method in class com.google.common.collect.testing.MinimalIterable
Returns an iterable whose iterator returns the given elements in order.
of(E...) - Static method in class com.google.common.collect.testing.MinimalSet
 
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) - Static method in class com.google.common.collect.ImmutableMultiset
Returns an immutable multiset containing the given elements, in order.
of(E, E) - Static method in class com.google.common.collect.ImmutableSet
Returns an immutable set containing the given elements, minus duplicates, in the order each was first specified.
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) - 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...) - Static method in class com.google.common.collect.FluentIterable
Returns a fluent iterable containing the specified 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) - Static method in class com.google.common.collect.ImmutableMultiset
Returns an immutable multiset containing the given elements, in the "grouped iteration order" described in the class documentation.
of(E, E, E) - Static method in class com.google.common.collect.ImmutableSet
Returns an immutable set containing the given elements, minus duplicates, in the order each was first specified.
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) - 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.ImmutableList
Returns an immutable list 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 the "grouped iteration order" described in the class documentation.
of(E, E, E, E) - Static method in class com.google.common.collect.ImmutableSet
Returns an immutable set containing the given elements, minus duplicates, in the order each was first specified.
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) - 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.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.ImmutableMultiset
Returns an immutable multiset containing the given elements, in the "grouped iteration order" described in the class documentation.
of(E, E, E, E, E) - Static method in class com.google.common.collect.ImmutableSet
Returns an immutable set containing the given elements, minus duplicates, in the order each was first specified.
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) - 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) - 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...) - Static method in class com.google.common.collect.ImmutableMultiset
Returns an immutable multiset containing the given elements, in the "grouped iteration order" described in the class documentation.
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, minus duplicates, in the order each was first specified.
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, 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, 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(File, String, ClassLoader) - Static method in class com.google.common.reflect.ClassPath.ResourceInfo
 
of(Class<T>) - Static method in class com.google.common.reflect.TypeToken
Returns an instance of type token that wraps type.
of(Class<T>, T) - Static method in class com.google.common.collect.ImmutableClassToInstanceMap
Returns an ImmutableClassToInstanceMap containing a single entry.
of(Iterable<? extends Number>) - Static method in class com.google.common.math.Stats
Returns statistics over a dataset containing the given values.
of(Type) - Static method in class com.google.common.reflect.TypeToken
Returns an instance of type token that wraps type.
of(Comparator<? super K>, K, V) - Static method in class com.google.common.collect.ImmutableSortedMap
Returns an immutable map containing a single entry.
of(Supplier<Spliterator<E>>) - Static method in class com.google.common.collect.testing.SpliteratorTester
 
of(Iterator<? extends Number>) - Static method in class com.google.common.math.Stats
Returns statistics over a dataset containing the given values.
of(Set<E>, Supplier<Boolean>, Supplier<String>) - Static method in class com.google.common.graph.InvalidatableSet
 
of(Collector<T, A, R>) - Static method in class com.google.common.testing.CollectorTester
Creates a CollectorTester for the specified Collector.
of(Collector<T, A, R>, BiPredicate<? super R, ? super R>) - Static method in class com.google.common.testing.CollectorTester
Creates a CollectorTester for the specified Collector.
of(DoubleStream) - Static method in class com.google.common.math.Stats
Returns statistics over a dataset containing the given values.
of(IntStream) - Static method in class com.google.common.math.Stats
Returns statistics over a dataset containing the given values.
of(LongStream) - Static method in class com.google.common.math.Stats
Returns statistics over a dataset containing the given values.
of(K, V) - Static method in class com.google.common.collect.ImmutableBiMap
Returns an immutable bimap containing a single entry.
of(K, V) - Static method in class com.google.common.collect.ImmutableListMultimap
Returns an immutable multimap containing a single entry.
of(K, V) - Static method in class com.google.common.collect.ImmutableMap
Returns an immutable map containing a single entry.
of(K, V) - Static method in class com.google.common.collect.ImmutableMultimap
Returns an immutable multimap containing a single entry.
of(K, V) - Static method in class com.google.common.collect.ImmutableSetMultimap
Returns an immutable multimap containing a single entry.
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.ImmutableBiMap
Returns an immutable map containing the given entries, in order.
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) - Static method in class com.google.common.collect.ImmutableMap
Returns an immutable map containing the given entries, in order.
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) - Static method in class com.google.common.collect.ImmutableSetMultimap
Returns an immutable multimap containing the given entries, in order.
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.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.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.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.ImmutableMultimap
Returns an immutable multimap containing the given entries, in the "key-grouped" insertion order described in the class documentation.
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) - 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.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.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.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.ImmutableMultimap
Returns an immutable multimap containing the given entries, in the "key-grouped" insertion order described in the class documentation.
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) - 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.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.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.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.ImmutableMultimap
Returns an immutable multimap containing the given entries, in the "key-grouped" insertion order described in the class documentation.
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(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, 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(K, V, 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(K, V, 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, K, V, 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(K, V, K, V, 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(K, V, K, V, 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, K, V, K, V, 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(K, V, K, V, K, V, 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(K, V, K, V, K, V, 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, K, V, K, V, K, V, 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(K, V, K, V, K, V, K, V, 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(K, V, K, V, K, V, K, V, 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, K, V, K, V, K, V, K, V, 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(K, V, K, V, K, V, K, V, K, V, 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(K, V, K, V, K, V, K, V, K, V, 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(R, C, V) - Static method in class com.google.common.collect.ImmutableTable
Returns an immutable table containing a single cell.
of(T) - Static method in class com.google.common.base.Optional
Returns an Optional instance containing the given non-null reference.
ofClassAndContents(Class<? super E>, E...) - Static method in class com.google.common.collect.testing.MinimalCollection
 
ofClassAndContents(Class<? super E>, E[], Iterable<? extends E>) - Static method in class com.google.common.collect.testing.MinimalSet
 
ofDouble(Supplier<Spliterator.OfDouble>) - Static method in class com.google.common.collect.testing.SpliteratorTester
 
ofEntries(Map.Entry<? extends K, ? extends V>...) - Static method in class com.google.common.collect.ImmutableBiMap
Returns an immutable map containing the given entries, in order.
ofEntries(Map.Entry<? extends K, ? extends V>...) - Static method in class com.google.common.collect.ImmutableMap
Returns an immutable map containing the given entries, in order.
ofEntries(Map.Entry<? extends K, ? extends V>...) - Static method in class com.google.common.collect.ImmutableSortedMap
Deprecated.
Use ImmutableSortedMap.copyOf(ImmutableMap.ofEntries(...)).
offer(ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.AccessQueue
 
offer(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) - Method in class com.google.common.collect.ForwardingQueue
 
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.collect.ForwardingBlockingDeque
Deprecated.
 
offer(E, long, TimeUnit) - Method in class com.google.common.util.concurrent.ForwardingBlockingDeque
 
offer(E, long, TimeUnit) - Method in class com.google.common.util.concurrent.ForwardingBlockingQueue
 
offer(T) - Method in class com.google.common.collect.TopKSelector
Adds elem as a candidate for the top k elements.
offerAll(Iterable<? extends T>) - Method in class com.google.common.collect.TopKSelector
Adds each member of elements as a candidate for the top k elements.
offerAll(Iterator<? extends T>) - Method in class com.google.common.collect.TopKSelector
Adds each member of elements as a candidate for the top k elements.
offerFirst(E) - Method in class com.google.common.collect.ForwardingDeque
 
offerFirst(E) - Method in class com.google.common.collect.Synchronized.SynchronizedDeque
 
offerFirst(E, long, TimeUnit) - Method in class com.google.common.collect.ForwardingBlockingDeque
Deprecated.
 
offerFirst(E, long, TimeUnit) - Method in class com.google.common.util.concurrent.ForwardingBlockingDeque
 
offerLast(E) - Method in class com.google.common.collect.ForwardingDeque
 
offerLast(E) - Method in class com.google.common.collect.Synchronized.SynchronizedDeque
 
offerLast(E, long, TimeUnit) - Method in class com.google.common.collect.ForwardingBlockingDeque
Deprecated.
 
offerLast(E, long, TimeUnit) - Method in class com.google.common.util.concurrent.ForwardingBlockingDeque
 
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.RegularImmutableSortedMultiset
 
offset - Variable in class com.google.common.io.ByteSource.ByteArrayByteSource
 
offset - Variable in class com.google.common.io.ByteSource.SlicedByteSource
 
offset(C, long) - Method in class com.google.common.collect.DiscreteDomain
Returns, conceptually, "origin + distance", or equivalently, the result of calling DiscreteDomain.next(C) on origin distance times.
offset(Integer, long) - Method in class com.google.common.collect.DiscreteDomain.IntegerDomain
 
offset(Long, long) - Method in class com.google.common.collect.DiscreteDomain.LongDomain
 
offset(BigInteger, long) - Method in class com.google.common.collect.DiscreteDomain.BigIntegerDomain
 
ofImmutable(Map<E, N>) - Static method in class com.google.common.graph.UndirectedMultiNetworkConnections
 
ofImmutable(Map<E, N>) - Static method in class com.google.common.graph.UndirectedNetworkConnections
 
ofImmutable(Map<E, N>, Map<E, N>, int) - Static method in class com.google.common.graph.DirectedMultiNetworkConnections
 
ofImmutable(Map<E, N>, Map<E, N>, int) - Static method in class com.google.common.graph.DirectedNetworkConnections
 
ofImmutable(Map<N, V>) - Static method in class com.google.common.graph.UndirectedGraphConnections
 
ofImmutable(N, Iterable<EndpointPair<N>>, Function<N, V>) - Static method in class com.google.common.graph.DirectedGraphConnections
 
ofInstance(T) - Static method in class com.google.common.base.Suppliers
Returns a supplier that always supplies instance.
ofInt(Supplier<Spliterator.OfInt>) - Static method in class com.google.common.collect.testing.SpliteratorTester
 
ofLong(Supplier<Spliterator.OfLong>) - Static method in class com.google.common.collect.testing.SpliteratorTester
 
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 - Variable in class com.google.common.base.Splitter.SplittingIterator
 
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.
omitEmptyValues - Variable in class com.google.common.base.MoreObjects.ToStringHelper
 
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.
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(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.Joiner
Returns a joiner which automatically places separator between consecutive elements.
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 - Enum constant in enum class com.google.common.collect.testing.features.CollectionSize
Test a one-element collection.
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
 
OneSizeGenerator<T,E> - Class in com.google.common.collect.testing
Generator for collection of a particular size.
OneSizeGenerator(TestContainerGenerator<T, E>, CollectionSize) - Constructor for class com.google.common.collect.testing.OneSizeGenerator
 
OneSizeTestContainerGenerator<T,E> - Interface in com.google.common.collect.testing
The subject-generator interface accepted by Collection testers, for testing a Collection at one particular CollectionSize.
OneSizeTestSuiteBuilder(List<Class<? extends AbstractTester>>) - Constructor for class com.google.common.collect.testing.PerCollectionSizeTestSuiteBuilder.OneSizeTestSuiteBuilder
 
OneWeigher() - Constructor for enum class 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
 
ONLY_ELEMENT - Static variable in class com.google.common.collect.MoreCollectors
 
Only %s is supported - Search tag in class com.google.common.base.Preconditions
Section
Only %s is supported - Search tag in class com.google.common.base.Verify
Section
onlyElement() - Static method in class com.google.common.collect.MoreCollectors
A collector that takes a stream containing exactly one element and returns that element.
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.
onPatternInternal(CommonPattern) - Static method in class com.google.common.base.Splitter
Internal utility; see Splitter.on(Pattern) instead.
onRemoval(RemovalNotification<Object, Object>) - Method in enum class 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.
onResultOf(Function<? super 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.
OPEN - Enum constant in enum class com.google.common.collect.BoundType
The endpoint value is not considered part of the set ("exclusive").
OPEN - Enum constant in enum class com.google.common.util.concurrent.ClosingFuture.State
The ClosingFuture.CloseableList has not been subsumed or closed.
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
 
OPENSEARCH_DESCRIPTION_UTF_8 - Static variable in class com.google.common.net.MediaType
OpenSearch Description files are XML files that describe how a website can be used as a search engine by consumers (e.g.
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.AsByteSource
 
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.CharSource.StringCharSource
 
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.MoreFiles.PathByteSink
 
openStream() - Method in class com.google.common.io.MoreFiles.PathByteSource
 
openStream() - Method in class com.google.common.io.Resources.UrlByteSource
 
openStream() - Method in class com.google.common.testing.ArbitraryInstances.NullByteSink
 
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
 
options - Variable in class com.google.common.io.MoreFiles.PathByteSink
 
options - Variable in class com.google.common.io.MoreFiles.PathByteSource
 
or(CharMatcher) - Method in class com.google.common.base.CharMatcher.Any
 
or(CharMatcher) - Method in class com.google.common.base.CharMatcher.Is
 
or(CharMatcher) - Method in class com.google.common.base.CharMatcher.IsNot
 
or(CharMatcher) - Method in class com.google.common.base.CharMatcher.None
 
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(Optional<? extends T>) - Method in class com.google.common.base.Absent
 
or(Optional<? extends T>) - Method in class com.google.common.base.Optional
Returns this Optional if it has a value present; secondChoice otherwise.
or(Optional<? extends T>) - Method in class com.google.common.base.Present
 
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(Supplier<? extends T>) - Method in class com.google.common.base.Absent
 
or(Supplier<? extends T>) - Method in class com.google.common.base.Optional
Returns the contained instance if it is present; supplier.get() otherwise.
or(Supplier<? extends T>) - Method in class com.google.common.base.Present
 
or(AbstractPackageSanityTests.Chopper) - Method in class com.google.common.testing.AbstractPackageSanityTests.Chopper
 
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(T) - Method in class com.google.common.base.Absent
 
or(T) - Method in class com.google.common.base.Optional
Returns the contained instance if it is present; defaultValue otherwise.
or(T) - Method in class com.google.common.base.Present
 
Or(CharMatcher, CharMatcher) - Constructor for class com.google.common.base.CharMatcher.Or
 
order(List<Multiset.Entry<E>>) - Method in class com.google.common.collect.testing.google.MultisetTestSuiteBuilder.EntrySetGenerator
 
order(List<AnEnum>) - Method in class com.google.common.collect.testing.google.TestEnumMultisetGenerator
Sorts the enums according to their natural ordering.
order(List<AnEnum>) - Method in class com.google.common.collect.testing.TestEnumSetGenerator
Sorts the enums according to their natural ordering.
order(List<UnhashableObject>) - Method in class com.google.common.collect.testing.TestUnhashableCollectionGenerator
 
order(List<E>) - Method in class com.google.common.collect.testing.CollectionTestSuiteBuilder.ReserializedCollectionGenerator
 
order(List<E>) - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.SortedSetSubsetTestSetGenerator
 
order(List<E>) - Method in class com.google.common.collect.testing.google.MultisetTestSuiteBuilder.ElementSetGenerator
 
order(List<E>) - Method in class com.google.common.collect.testing.google.MultisetTestSuiteBuilder.ReserializedMultisetGenerator
 
order(List<E>) - Method in class com.google.common.collect.testing.google.SortedMultisetTestSuiteBuilder.ForwardingTestMultisetGenerator
 
order(List<E>) - Method in class com.google.common.collect.testing.ListTestSuiteBuilder.ReserializedListGenerator
 
order(List<E>) - Method in class com.google.common.collect.testing.OneSizeGenerator
 
order(List<E>) - Method in class com.google.common.collect.testing.ReserializingTestCollectionGenerator
 
order(List<E>) - Method in class com.google.common.collect.testing.SetTestSuiteBuilder.ReserializedSetGenerator
 
order(List<E>) - Method in interface com.google.common.collect.testing.TestContainerGenerator
Returns the iteration ordering of elements, given the order in which they were added to the container.
order(List<Character>) - Method in class com.google.common.collect.testing.TestCharacterListGenerator
Returns the original element list, unchanged.
order(List<Integer>) - Method in class com.google.common.collect.testing.google.SetGenerators.ContiguousSetDescendingGenerator
Sorts the elements in reverse natural order.
order(List<Integer>) - Method in class com.google.common.collect.testing.TestIntegerSetGenerator
Returns the iteration ordering of elements, given the order in which they were added to the container.
order(List<Integer>) - Method in class com.google.common.collect.testing.TestIntegerSortedSetGenerator
Sorts the elements by their natural ordering.
order(List<Object>) - Method in class com.google.common.collect.testing.TestCollidingSetGenerator
Returns the original element list, unchanged.
order(List<String>) - Method in class com.google.common.collect.testing.google.SetGenerators.ImmutableSortedSetExplicitComparator
 
order(List<String>) - Method in class com.google.common.collect.testing.google.SetGenerators.ImmutableSortedSetExplicitSuperclassComparatorGenerator
 
order(List<String>) - Method in class com.google.common.collect.testing.google.SetGenerators.ImmutableSortedSetReversedOrderGenerator
 
order(List<String>) - Method in class com.google.common.collect.testing.google.SortedMapGenerators.ImmutableSortedMapKeyListGenerator
 
order(List<String>) - Method in class com.google.common.collect.testing.google.TestStringMultisetGenerator
Returns the original element list, unchanged.
order(List<String>) - Method in class com.google.common.collect.testing.TestStringCollectionGenerator
Returns the original element list, unchanged.
order(List<String>) - Method in class com.google.common.collect.testing.TestStringListGenerator
Returns the original element list, unchanged.
order(List<String>) - Method in class com.google.common.collect.testing.TestStringQueueGenerator
Returns the original element list, unchanged.
order(List<String>) - Method in class com.google.common.collect.testing.TestStringSetGenerator
Returns the iteration ordering of elements, given the order in which they were added to the container.
order(List<String>) - Method in class com.google.common.collect.testing.TestStringSortedSetGenerator
Sorts the elements by their natural ordering.
order(List<Map.Entry<AnEnum, String>>) - Method in class com.google.common.collect.testing.google.MapGenerators.ImmutableMapCopyOfEnumMapGenerator
 
order(List<Map.Entry<AnEnum, String>>) - Method in class com.google.common.collect.testing.TestEnumMapGenerator
Returns the elements sorted in natural order.
order(List<Map.Entry<String, Integer>>) - Method in class com.google.common.collect.testing.google.MapGenerators.ImmutableMapEntryListGenerator
 
order(List<Map.Entry<String, Integer>>) - Method in class com.google.common.collect.testing.google.SortedMapGenerators.ImmutableSortedMapEntryListGenerator
 
order(List<Map.Entry<String, String>>) - Method in class com.google.common.collect.testing.google.TestStringBiMapGenerator
Returns the original element list, unchanged.
order(List<Map.Entry<String, String>>) - Method in class com.google.common.collect.testing.google.TestStringListMultimapGenerator
Returns the original element list, unchanged.
order(List<Map.Entry<String, String>>) - Method in class com.google.common.collect.testing.google.TestStringSetMultimapGenerator
Returns the original element list, unchanged.
order(List<Map.Entry<String, String>>) - Method in class com.google.common.collect.testing.TestStringMapGenerator
Returns the original element list, unchanged.
order(List<Map.Entry<String, String>>) - Method in class com.google.common.collect.testing.TestStringSortedMapGenerator
 
order(List<Map.Entry<String, Collection<Integer>>>) - Method in class com.google.common.collect.testing.google.MapGenerators.ImmutableMapValuesAsSingletonSetGenerator
 
order(List<Map.Entry<K, Collection<V>>>) - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.AsMapGenerator
 
order(List<Map.Entry<K, V>>) - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.ForwardingTestMapGenerator
 
order(List<Map.Entry<K, V>>) - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.MapEntrySetGenerator
 
order(List<Map.Entry<K, V>>) - Method in class com.google.common.collect.testing.google.DerivedGoogleCollectionGenerators.MapGenerator
 
order(List<Map.Entry<K, V>>) - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.EntriesGenerator
 
order(List<Map.Entry<K, V>>) - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.ReserializedMultimapGenerator
 
order(List<Map.Entry<K, V>>) - Method in class com.google.common.collect.testing.MapTestSuiteBuilder.ReserializedMapGenerator
 
order(List<Map.Entry<K, V>>) - Method in class com.google.common.collect.testing.NavigableMapTestSuiteBuilder.DescendingTestMapGenerator
 
order(List<Map.Entry<K, V>>) - Method in class com.google.common.collect.testing.TestMapEntrySetGenerator
Returns the original element list, unchanged.
order(List<Map.Entry<V, K>>) - Method in class com.google.common.collect.testing.google.DerivedGoogleCollectionGenerators.InverseBiMapGenerator
 
order(List<K>) - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.MapKeySetGenerator
 
order(List<K>) - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.KeysGenerator
 
order(List<V>) - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.MapValueCollectionGenerator
 
order(List<V>) - Method in class com.google.common.collect.testing.google.DerivedGoogleCollectionGenerators.BiMapValueSetGenerator
 
order(List<V>) - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.MultimapGetGenerator
 
order(List<V>) - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.ValuesGenerator
 
orderColumnsBy(Comparator<? super C>) - Method in class com.google.common.collect.ImmutableTable.Builder
Specifies the ordering of the generated table's columns.
ordered(N, N) - Static method in class com.google.common.graph.EndpointPair
Returns an EndpointPair representing the endpoints of a directed edge.
Ordered(N, N) - Constructor for class com.google.common.graph.EndpointPair.Ordered
 
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.
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<K>) - Static method in class com.google.common.collect.ImmutableSortedMap
Returns a builder that creates immutable sorted maps with an explicit comparator.
orderedNodeConnections - Variable in class com.google.common.graph.DirectedGraphConnections
All node connections in this graph, in edge insertion order.
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.
orderEntriesByKey(List<Map.Entry<K, V>>) - Static method in class com.google.common.collect.testing.Helpers
 
orderEntriesByValue(Comparator<? super V>) - Method in class com.google.common.collect.ImmutableBiMap.Builder
Configures this Builder to order entries by value according to the specified comparator.
orderEntriesByValue(Comparator<? super V>) - Method in class com.google.common.collect.ImmutableMap.Builder
Configures this Builder to order entries by value according to the specified comparator.
orderEntriesByValue(Comparator<? super V>) - Method in class com.google.common.collect.ImmutableSortedMap.Builder
Deprecated.
Unsupported by ImmutableSortedMap.Builder.
ordering - Variable in class com.google.common.collect.ByFunctionOrdering
 
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() - Method in class com.google.common.collect.MinMaxPriorityQueue.Builder
 
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_BY_CONSTRUCTOR_PARAMETER_LIST - Static variable in class com.google.common.util.concurrent.FuturesGetChecked
 
Ordering.ArbitraryOrdering - Class in com.google.common.collect
 
Ordering.ArbitraryOrderingHolder - Class in com.google.common.collect
 
Ordering.IncomparableValueException - Exception Class 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.
ORIGIN - Static variable in class com.google.common.net.HttpHeaders.ReferrerPolicyValues
 
ORIGIN_ISOLATION - Static variable in class com.google.common.net.HttpHeaders
The HTTP Origin-Isolation header field name.
ORIGIN_TRIAL - Static variable in class com.google.common.net.HttpHeaders
The HTTP Origin-Trial header field name.
ORIGIN_WHEN_CROSS_ORIGIN - Static variable in class com.google.common.net.HttpHeaders.ReferrerPolicyValues
 
original - Variable in class com.google.common.base.CharMatcher.Negated
 
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
 
OS_ARCH - Enum constant in enum class com.google.common.base.StandardSystemProperty
Operating system architecture.
OS_NAME - Enum constant in enum class com.google.common.base.StandardSystemProperty
Operating system name.
OS_VERSION - Enum constant in enum class com.google.common.base.StandardSystemProperty
Operating system version.
Other - Search tag in package com.google.common.base
Section
Other - Search tag in package com.google.common.collect
Section
otherHeap - Variable in class com.google.common.collect.MinMaxPriorityQueue.Heap
 
Other notes - Search tag in class com.google.common.collect.Range
Section
Other Notes - Search tag in interface com.google.common.collect.Multimap
Section
Other types of preconditions - Search tag in class com.google.common.base.Preconditions
Section
out - Variable in class com.google.common.io.FileBackedOutputStream
 
outDegree(N) - Method in class com.google.common.graph.AbstractBaseGraph
 
outDegree(N) - Method in class com.google.common.graph.AbstractNetwork
 
outDegree(N) - Method in interface com.google.common.graph.BaseGraph
Returns the count of node's outgoing edges (equal to successors(node).size()) in a directed graph.
outDegree(N) - Method in class com.google.common.graph.ForwardingGraph
 
outDegree(N) - Method in class com.google.common.graph.ForwardingNetwork
 
outDegree(N) - Method in class com.google.common.graph.ForwardingValueGraph
 
outDegree(N) - Method in interface com.google.common.graph.Graph
Returns the count of node's outgoing edges (equal to successors(node).size()) in a directed graph.
outDegree(N) - Method in class com.google.common.graph.Graphs.TransposedGraph
 
outDegree(N) - Method in class com.google.common.graph.Graphs.TransposedNetwork
 
outDegree(N) - Method in class com.google.common.graph.Graphs.TransposedValueGraph
 
outDegree(N) - Method in interface com.google.common.graph.Network
Returns the count of node's outgoing edges in a directed network.
outDegree(N) - Method in interface com.google.common.graph.ValueGraph
Returns the count of node's outgoing edges (equal to successors(node).size()) in a directed graph.
outEdgeMap - Variable in class com.google.common.graph.AbstractDirectedNetworkConnections
Keys are edges outgoing from the origin node, values are the target node.
outEdges() - Method in class com.google.common.graph.AbstractDirectedNetworkConnections
 
outEdges() - Method in class com.google.common.graph.AbstractUndirectedNetworkConnections
 
outEdges() - Method in interface com.google.common.graph.NetworkConnections
 
outEdges(N) - Method in class com.google.common.graph.ForwardingNetwork
 
outEdges(N) - Method in class com.google.common.graph.Graphs.TransposedNetwork
 
outEdges(N) - Method in interface com.google.common.graph.Network
Returns a live view of all edges in this network which can be traversed in the direction (if any) of the edge starting from node.
outEdges(N) - Method in class com.google.common.graph.StandardNetwork
 
outEdgeToNode - Variable in class com.google.common.graph.MultiEdgesConnecting
 
outerSplitter - Variable in class com.google.common.base.Splitter.MapSplitter
 
output - Variable in class com.google.common.io.ByteStreams.ByteArrayDataOutputStream
 
output(int) - Method in class com.google.common.collect.EnumMultiset.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.AbstractMapBasedMultimap.Itr
 
OUTPUT_FUTURE_DONE - Enum constant in enum class com.google.common.util.concurrent.AggregateFuture.ReleaseResourcesReason
 
OverflowAvoidingLockSupport - Class in com.google.common.util.concurrent
Works around an android bug, where parking for more than INT_MAX seconds can produce an abort signal on 32 bit devices running Android Q.
OverflowAvoidingLockSupport() - Constructor for class com.google.common.util.concurrent.OverflowAvoidingLockSupport
 
overflowInParse(long, int, int) - Static method in class com.google.common.primitives.UnsignedLongs.ParseOverflowDetection
Returns true if (current * radix) + digit is a number too large to be represented by an unsigned long.
OWNED_BY_ENCLOSING_CLASS - Enum constant in enum class com.google.common.reflect.Types.ClassOwnership
 
owner - Variable in class com.google.common.util.concurrent.AbstractFuture.SetFuture
 
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
 
p0 - Variable in class com.google.common.hash.Striped64.Cell
 
p1 - Variable in class com.google.common.cache.Striped64.Cell
 
p1 - Variable in class com.google.common.hash.Striped64.Cell
 
p2 - Variable in class com.google.common.cache.Striped64.Cell
 
p2 - Variable in class com.google.common.hash.Striped64.Cell
 
p3 - Variable in class com.google.common.cache.Striped64.Cell
 
p3 - Variable in class com.google.common.hash.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
 
p4 - Variable in class com.google.common.hash.Striped64.Cell
 
p5 - Variable in class com.google.common.cache.Striped64.Cell
 
p5 - Variable in class com.google.common.hash.Striped64.Cell
 
p6 - Variable in class com.google.common.cache.Striped64.Cell
 
p6 - Variable in class com.google.common.hash.Striped64.Cell
 
PACKAGE - Enum constant in enum class com.google.common.testing.NullPointerTester.Visibility
 
packagesToTest - Variable in class com.google.common.testing.ClassSanityTester.FactoryMethodReturnValueTester
 
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
 
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.
PairedStats - Class in com.google.common.math
An immutable value object capturing some basic statistics about a collection of paired double values (e.g.
PairedStats(Stats, Stats, double) - Constructor for class com.google.common.math.PairedStats
Internal constructor.
PairedStatsAccumulator - Class in com.google.common.math
A mutable object which accumulates paired double values (e.g.
PairedStatsAccumulator() - Constructor for class com.google.common.math.PairedStatsAccumulator
 
pairwise() - Method in class com.google.common.base.Equivalence
Returns an equivalence over iterables based on the equivalence of their elements.
PairwiseEquivalence<E,T> - Class in com.google.common.base
 
PairwiseEquivalence(Equivalence<E>) - Constructor for class com.google.common.base.PairwiseEquivalence
 
PARALLEL_EDGES_NOT_ALLOWED - Static variable in class com.google.common.graph.GraphConstants
 
parallelStream() - Method in class com.google.common.collect.Sets.UnmodifiableNavigableSet
 
parallelStream() - Method in class com.google.common.collect.Synchronized.SynchronizedCollection
 
Parameter - Class in com.google.common.reflect
Represents a method or constructor parameter.
Parameter(Invokable<?, ?>, int, TypeToken<?>, Annotation[], Object) - Constructor for class com.google.common.reflect.Parameter
 
PARAMETER_JOINER - Static variable in class com.google.common.net.MediaType
 
ParameterHasNoDistinctValueException(Parameter) - Constructor for exception class com.google.common.testing.ClassSanityTester.ParameterHasNoDistinctValueException
 
ParameterizedTypeImpl(Type, Class<?>, Type[]) - Constructor for class com.google.common.reflect.Types.ParameterizedTypeImpl
 
ParameterNotInstantiableException(Parameter) - Constructor for exception class com.google.common.testing.ClassSanityTester.ParameterNotInstantiableException
 
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.SubscriberRegistry.MethodIdentifier
 
parameterTypes - Variable in class com.google.common.testing.NullPointerTester.Signature
 
ParametricNullness - Annotation Interface in com.google.common.base
Annotates a "top-level" type-variable usage that takes its nullness from the type argument supplied by the user of the class.
ParametricNullness - Annotation Interface in com.google.common.cache
Annotates a "top-level" type-variable usage that takes its nullness from the type argument supplied by the user of the class.
ParametricNullness - Annotation Interface in com.google.common.collect
Annotates a "top-level" type-variable usage that takes its nullness from the type argument supplied by the user of the class.
ParametricNullness - Annotation Interface in com.google.common.escape
Annotates a "top-level" type-variable usage that takes its nullness from the type argument supplied by the user of the class.
ParametricNullness - Annotation Interface in com.google.common.eventbus
Annotates a "top-level" type-variable usage that takes its nullness from the type argument supplied by the user of the class.
ParametricNullness - Annotation Interface in com.google.common.graph
Annotates a "top-level" type-variable usage that takes its nullness from the type argument supplied by the user of the class.
ParametricNullness - Annotation Interface in com.google.common.hash
Annotates a "top-level" type-variable usage that takes its nullness from the type argument supplied by the user of the class.
ParametricNullness - Annotation Interface in com.google.common.html
Annotates a "top-level" type-variable usage that takes its nullness from the type argument supplied by the user of the class.
ParametricNullness - Annotation Interface in com.google.common.io
Annotates a "top-level" type-variable usage that takes its nullness from the type argument supplied by the user of the class.
ParametricNullness - Annotation Interface in com.google.common.math
Annotates a "top-level" type-variable usage that takes its nullness from the type argument supplied by the user of the class.
ParametricNullness - Annotation Interface in com.google.common.net
Annotates a "top-level" type-variable usage that takes its nullness from the type argument supplied by the user of the class.
ParametricNullness - Annotation Interface in com.google.common.primitives
Annotates a "top-level" type-variable usage that takes its nullness from the type argument supplied by the user of the class.
ParametricNullness - Annotation Interface in com.google.common.reflect
Annotates a "top-level" type-variable usage that takes its nullness from the type argument supplied by the user of the class.
ParametricNullness - Annotation Interface in com.google.common.util.concurrent
Annotates a "top-level" type-variable usage that takes its nullness from the type argument supplied by the user of the class.
ParametricNullness - Annotation Interface in com.google.common.xml
Annotates a "top-level" type-variable usage that takes its nullness from the type argument supplied by the user of the class.
paramString(Class<?>, int) - Static method in class com.google.common.testing.FreshValueGenerator
 
parent - Variable in class com.google.common.primitives.ImmutableDoubleArray.AsList
 
parent - Variable in class com.google.common.primitives.ImmutableIntArray.AsList
 
parent - Variable in class com.google.common.primitives.ImmutableLongArray.AsList
 
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.
PARKED - Static variable in class com.google.common.util.concurrent.InterruptibleTask
 
parkNanos(Object, long) - Static method in class com.google.common.util.concurrent.OverflowAvoidingLockSupport
 
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(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.cache.CacheBuilderSpec
Creates a CacheBuilderSpec from a string.
parse(String) - Static method in class com.google.common.net.MediaType
Parses a media type from its string representation.
parsedCharset - Variable in class com.google.common.net.MediaType
 
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
 
parseFullString(String) - Static method in class com.google.thirdparty.publicsuffix.TrieParser
 
parseHextet(String, int, int) - 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
 
parseJavaClassPath() - Static method in class com.google.common.reflect.ClassPath
Returns the URLs in the class path specified by the java.class.path system property.
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, int, int) - Static method in class com.google.common.net.InetAddresses
 
ParseOverflowDetection() - Constructor for class com.google.common.primitives.UnsignedLongs.ParseOverflowDetection
 
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
 
Partially - Class in com.google.common.util.concurrent
Outer class that exists solely to let us write Partially.GwtIncompatible instead of plain GwtIncompatible.
Partially() - Constructor for class com.google.common.util.concurrent.Partially
 
Partially.GwtIncompatible - Annotation Interface in com.google.common.util.concurrent
The presence of this annotation on an API indicates that the method may be used with the Google Web Toolkit (GWT) but that it has some restrictions.
partialOverlap - Variable in class com.google.common.collect.testing.testers.CollectionRetainAllTester
 
partition(double[], int, int) - Static method in class com.google.common.math.Quantiles
Performs a partition operation on the slice of array with elements in the range [ from, to].
partition(int, int, int) - Method in class com.google.common.collect.TopKSelector
Partitions the contents of buffer in the range [left, right] around the pivot element previously stored in buffer[pivotValue].
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
 
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.
passedArgs - Variable in class com.google.common.testing.ForwardingWrapperTester.InteractionTester
 
path - Variable in class com.google.common.io.MoreFiles.PathByteSink
 
path - Variable in class com.google.common.io.MoreFiles.PathByteSource
 
PATH_SEPARATOR - Enum constant in enum class com.google.common.base.StandardSystemProperty
Path separator (":" on UNIX).
PathByteSink(Path, OpenOption...) - Constructor for class com.google.common.io.MoreFiles.PathByteSink
 
PathByteSource(Path, OpenOption...) - Constructor for class com.google.common.io.MoreFiles.PathByteSource
 
pathNotFound(Path, Collection<IOException>) - Static method in class com.google.common.io.MoreFiles
 
pattern - Variable in class com.google.common.base.JdkPattern
 
pattern - Variable in class com.google.common.base.Predicates.ContainsPatternPredicate
 
pattern - Variable in class com.google.common.io.PatternFilenameFilter
 
pattern() - Method in class com.google.common.base.CommonPattern
 
pattern() - Method in class com.google.common.base.JdkPattern
 
patternCompiler - Static variable in class com.google.common.base.Platform
 
PatternCompiler - Interface in com.google.common.base
Pluggable interface for compiling a regex pattern.
patternCompilerIsPcreLike() - Static method in class com.google.common.base.Platform
 
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
 
pearsonsCorrelationCoefficient() - Method in class com.google.common.math.PairedStats
pearsonsCorrelationCoefficient() - Method in class com.google.common.math.PairedStatsAccumulator
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.ForwardingQueue
 
peek() - Method in class com.google.common.collect.Iterators.PeekingImpl
 
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
Deprecated.
 
peekedElement - Variable in class com.google.common.collect.Iterators.PeekingImpl
 
Peeker(ImmutableList<ClosingFuture<?>>) - Constructor for class com.google.common.util.concurrent.ClosingFuture.Peeker
 
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(PeekingIterator<T>) - Static method in class com.google.common.collect.Iterators
Deprecated.
no need to use this
peekingIterator(Iterator<? extends T>) - Static method in class com.google.common.collect.Iterators
Returns a PeekingIterator backed by the given iterator.
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
 
PENDING - Enum constant in enum class com.google.common.graph.Graphs.NodeVisitState
 
pendingToString() - Method in class com.google.common.util.concurrent.AbstractCatchingFuture
 
pendingToString() - Method in class com.google.common.util.concurrent.AbstractFuture
Provide a human-readable explanation of why this future has not yet completed.
pendingToString() - Method in class com.google.common.util.concurrent.AbstractTransformFuture
 
pendingToString() - Method in class com.google.common.util.concurrent.AggregateFuture
 
pendingToString() - Method in class com.google.common.util.concurrent.Futures.InCompletionOrderFuture
 
pendingToString() - Method in class com.google.common.util.concurrent.Futures.NonCancellationPropagatingFuture
 
pendingToString() - Method in class com.google.common.util.concurrent.MoreExecutors.ScheduledListeningDecorator.NeverSuccessfulListenableFutureTask
 
pendingToString() - Method in class com.google.common.util.concurrent.TimeoutFuture
 
pendingToString() - Method in class com.google.common.util.concurrent.TrustedListenableFutureTask
 
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.
percentiles() - Static method in class com.google.common.math.Quantiles
Specifies the computation of percentiles (i.e.
PerCollectionSizeTestSuiteBuilder<B,G,T,E> - Class in com.google.common.collect.testing
This builder creates a composite test suite, containing a separate test suite for each CollectionSize present in the features specified by FeatureSpecificTestSuiteBuilder.withFeatures(Feature...).
PerCollectionSizeTestSuiteBuilder() - Constructor for class com.google.common.collect.testing.PerCollectionSizeTestSuiteBuilder
 
PerCollectionSizeTestSuiteBuilder.OneSizeTestSuiteBuilder<T,E> - Class in com.google.common.collect.testing
Builds a test suite for one particular CollectionSize.
Performance - Search tag in class com.google.common.base.Preconditions
Section
Performance - Search tag in class com.google.common.math.Quantiles
Section
Performance notes - Search tag in class com.google.common.collect.ImmutableCollection
Section
PerListenerQueue(L, Executor) - Constructor for class com.google.common.util.concurrent.ListenerCallQueue.PerListenerQueue
 
PERMISSIONS_POLICY - Static variable in class com.google.common.net.HttpHeaders
The HTTP Permissions-Policy header field name.
PERMISSIONS_POLICY_REPORT_ONLY - Static variable in class com.google.common.net.HttpHeaders
The HTTP Permissions-Policy-Report-Only header field name.
permitsToTime(double) - Method in class com.google.common.util.concurrent.SmoothRateLimiter.SmoothWarmingUp
 
PermittedMetaException(String) - Constructor for exception class com.google.common.collect.testing.AbstractIteratorTester.PermittedMetaException
 
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.
perThreadDispatchQueue() - Static method in class com.google.common.eventbus.Dispatcher
Returns a dispatcher that queues events that are posted reentrantly on a thread that is already dispatching an event, guaranteeing that all events posted on a single thread are dispatched to all subscribers in the order they are posted.
PerThreadQueuedDispatcher() - Constructor for class com.google.common.eventbus.Dispatcher.PerThreadQueuedDispatcher
 
Per-type static utilities - Search tag in package com.google.common.primitives
Section
pickFunction() - Static method in enum class com.google.common.hash.Hashing.Crc32CSupplier
 
pickInstance(Collection<T>, T) - Method in class com.google.common.testing.FreshValueGenerator
 
pickInstance(T[], T) - Method in class com.google.common.testing.FreshValueGenerator
 
pickSecureCreator() - Static method in class com.google.common.io.TempFileCreator
 
PING_FROM - Static variable in class com.google.common.net.HttpHeaders
The HTTP Ping-From header field name.
PING_TO - Static variable in class com.google.common.net.HttpHeaders
The HTTP Ping-To header field name.
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 - Class in com.google.common.collect
Methods factored out so that they can be emulated differently in GWT.
Platform - Class in com.google.common.collect.testing
Methods factored out so that they can be emulated differently in GWT.
Platform - Class in com.google.common.collect.testing.testers
This class is emulated in GWT.
Platform - Class in com.google.common.escape
Methods factored out so that they can be emulated differently in GWT.
Platform - Class in com.google.common.testing
Methods factored out so that they can be emulated differently in GWT.
Platform - Class in com.google.common.util.concurrent
Methods factored out so that they can be emulated differently in GWT.
Platform() - Constructor for class com.google.common.base.Platform
 
Platform() - Constructor for class com.google.common.collect.Platform
 
Platform() - Constructor for class com.google.common.collect.testing.Platform
 
Platform() - Constructor for class com.google.common.collect.testing.testers.Platform
 
Platform() - Constructor for class com.google.common.escape.Platform
 
Platform() - Constructor for class com.google.common.testing.Platform
 
Platform() - Constructor for class com.google.common.util.concurrent.Platform
 
Platform.JdkPatternCompiler - Class in com.google.common.base
 
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 class com.google.common.util.concurrent.CycleDetectingLockFactory.Policies
 
policy - Variable in class com.google.common.testing.NullPointerTester
 
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() - Method in class com.google.common.collect.ForwardingQueue
 
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.collect.ForwardingBlockingDeque
Deprecated.
 
poll(long, TimeUnit) - Method in class com.google.common.util.concurrent.ForwardingBlockingDeque
 
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() - 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
 
pollFirst() - Method in class com.google.common.collect.testing.SafeTreeSet
 
pollFirst(long, TimeUnit) - Method in class com.google.common.collect.ForwardingBlockingDeque
Deprecated.
 
pollFirst(long, TimeUnit) - Method in class com.google.common.util.concurrent.ForwardingBlockingDeque
 
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.testing.SafeTreeMap
 
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() - 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
 
pollLast() - Method in class com.google.common.collect.testing.SafeTreeSet
 
pollLast(long, TimeUnit) - Method in class com.google.common.collect.ForwardingBlockingDeque
Deprecated.
 
pollLast(long, TimeUnit) - Method in class com.google.common.util.concurrent.ForwardingBlockingDeque
 
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.testing.SafeTreeMap
 
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
 
populate(M, Map.Entry<T, String>[]) - Static method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
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
 
populationCovariance() - Method in class com.google.common.math.PairedStats
Returns the population covariance of the values.
populationCovariance() - Method in class com.google.common.math.PairedStatsAccumulator
Returns the population covariance of the values.
populationStandardDeviation() - Method in class com.google.common.math.Stats
Returns the population standard deviation of the values.
populationStandardDeviation() - Method in class com.google.common.math.StatsAccumulator
Returns the population standard deviation of the values.
populationVariance() - Method in class com.google.common.math.Stats
Returns the population variance of the values.
populationVariance() - Method in class com.google.common.math.StatsAccumulator
Returns the population variance of the values.
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
 
position(Buffer, int) - Static method in class com.google.common.base.Java8Compatibility
 
position(Buffer, int) - Static method in class com.google.common.hash.Java8Compatibility
 
position(Buffer, int) - Static method in class com.google.common.io.Java8Compatibility
 
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.
Posting Events - Search tag in class com.google.common.eventbus.EventBus
Section
postOrder(Iterator<? extends N>) - Method in class com.google.common.graph.Traverser.Traversal
 
postOrderIterator(T) - Method in class com.google.common.collect.TreeTraverser
Deprecated.
 
PostOrderIterator(T) - Constructor for class com.google.common.collect.TreeTraverser.PostOrderIterator
Deprecated.
 
PostOrderNode(T, Iterator<T>) - Constructor for class com.google.common.collect.TreeTraverser.PostOrderNode
Deprecated.
 
postOrderTraversal(T) - Method in class com.google.common.collect.TreeTraverser
Deprecated.
Use Traverser.depthFirstPostOrder(N) instead, which has the same behavior.
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.
PotentialDeadlockException(CycleDetectingLockFactory.LockGraphNode, CycleDetectingLockFactory.LockGraphNode, CycleDetectingLockFactory.ExampleStackTrace) - Constructor for exception class 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
 
powMod(long, long, long) - Method in enum class com.google.common.math.LongMath.MillerRabinTester
Returns a^p mod m.
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 (that is, whether its preconditions were met).
Preconditions() - Constructor for class com.google.common.base.Preconditions
 
pred - Variable in class com.google.common.collect.TreeMultiset.AvlNode
 
pred() - Method in class com.google.common.collect.TreeMultiset.AvlNode
 
Pred(N) - Constructor for class com.google.common.graph.DirectedGraphConnections.NodeConnection.Pred
 
PRED - Static variable in class com.google.common.graph.DirectedGraphConnections
 
PredAndSucc(Object) - Constructor for class com.google.common.graph.DirectedGraphConnections.PredAndSucc
 
predecessor - Variable in class com.google.common.collect.CompactLinkedHashSet
Pointer to the predecessor of an entry in insertion order.
predecessorCount - Variable in class com.google.common.graph.DirectedGraphConnections
 
predecessorInMultimap - Variable in class com.google.common.collect.LinkedHashMultimap.ValueEntry
 
predecessorInValueSet - Variable in class com.google.common.collect.LinkedHashMultimap.ValueEntry
 
predecessors() - Method in class com.google.common.graph.AbstractUndirectedNetworkConnections
 
predecessors() - Method in class com.google.common.graph.DirectedGraphConnections
 
predecessors() - Method in class com.google.common.graph.DirectedMultiNetworkConnections
 
predecessors() - Method in class com.google.common.graph.DirectedNetworkConnections
 
predecessors() - Method in interface com.google.common.graph.GraphConnections
 
predecessors() - Method in interface com.google.common.graph.NetworkConnections
 
predecessors() - Method in class com.google.common.graph.UndirectedGraphConnections
 
predecessors(N) - Method in interface com.google.common.graph.BaseGraph
Returns a live view of all nodes in this graph adjacent to node which can be reached by traversing node's incoming edges against the direction (if any) of the edge.
predecessors(N) - Method in class com.google.common.graph.ForwardingGraph
 
predecessors(N) - Method in class com.google.common.graph.ForwardingNetwork
 
predecessors(N) - Method in class com.google.common.graph.ForwardingValueGraph
 
predecessors(N) - Method in interface com.google.common.graph.Graph
Returns a live view of all nodes in this graph adjacent to node which can be reached by traversing node's incoming edges against the direction (if any) of the edge.
predecessors(N) - Method in class com.google.common.graph.Graphs.TransposedGraph
 
predecessors(N) - Method in class com.google.common.graph.Graphs.TransposedNetwork
 
predecessors(N) - Method in class com.google.common.graph.Graphs.TransposedValueGraph
 
predecessors(N) - Method in interface com.google.common.graph.Network
Returns a live view of all nodes in this network adjacent to node which can be reached by traversing node's incoming edges against the direction (if any) of the edge.
predecessors(N) - Method in interface com.google.common.graph.PredecessorsFunction
Returns all nodes in this graph adjacent to node which can be reached by traversing node's incoming edges against the direction (if any) of the edge.
predecessors(N) - Method in class com.google.common.graph.StandardNetwork
 
predecessors(N) - Method in class com.google.common.graph.StandardValueGraph
 
predecessors(N) - Method in interface com.google.common.graph.ValueGraph
Returns a live view of all nodes in this graph adjacent to node which can be reached by traversing node's incoming edges against the direction (if any) of the edge.
PredecessorsFunction<N> - Interface in com.google.common.graph
A functional interface for graph-structured data.
predecessorsMultiset() - Method in class com.google.common.graph.DirectedMultiNetworkConnections
 
predecessorsReference - Variable in class com.google.common.graph.DirectedMultiNetworkConnections
 
predicate - Variable in class com.google.common.base.CharMatcher.ForPredicate
 
predicate - Variable in class com.google.common.base.Functions.PredicateFunction
 
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
 
Predicate<T> - Interface in com.google.common.base
Legacy version of java.util.function.Predicate.
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.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<T> - Class in com.google.common.base
 
Predicates.IsEqualToPredicate - Class in com.google.common.base
 
Predicates.NotPredicate<T> - Class in com.google.common.base
 
Predicates.ObjectPredicate - Enum Class in com.google.common.base
 
Predicates.OrPredicate<T> - Class in com.google.common.base
 
Predicates.SubtypeOfPredicate - Class in com.google.common.base
 
Prefer Caffeine over Guava's caching API - Search tag in class com.google.common.cache.CacheBuilder
Section
Prefer ClassGraph over ClassPath - Search tag in class com.google.common.reflect.ClassPath
Section
preferringStringsThenThrowables(List<Constructor<X>>) - Static method in class com.google.common.util.concurrent.FuturesGetChecked
 
prefix - Variable in class com.google.common.collect.CollectSpliterators.FlatMapSpliterator
 
preOrder(Iterator<? extends N>) - Method in class com.google.common.graph.Traverser.Traversal
 
preOrderIterator(T) - Method in class com.google.common.collect.TreeTraverser
Deprecated.
 
PreOrderIterator(T) - Constructor for class com.google.common.collect.TreeTraverser.PreOrderIterator
Deprecated.
 
preOrderTraversal(T) - Method in class com.google.common.collect.TreeTraverser
Deprecated.
Use Traverser.depthFirstPreOrder(N) instead, which has the same behavior.
Presence() - Constructor for enum class com.google.common.graph.GraphConstants.Presence
 
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
 
Present(V) - Constructor for class com.google.common.util.concurrent.CollectionFuture.Present
 
presentFeatures - Variable in class com.google.common.collect.testing.features.TesterRequirements
 
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().
presentKeyNullValueEntry - Variable in class com.google.common.collect.testing.testers.MapPutTester
 
preservesInsertionOrderOnAddsSet() - Static method in class com.google.common.collect.Platform
Returns the platform preferred set implementation that preserves insertion order when used only for insertions.
preservesInsertionOrderOnPutsMap() - Static method in class com.google.common.collect.Platform
Returns the platform preferred map implementation that preserves insertion order when used only for insertions.
preservesInsertionOrderOnPutsMapWithExpectedSize(int) - Static method in class com.google.common.collect.Platform
Returns the platform preferred map implementation that preserves insertion order when used only for insertions, with a hint for how many entries to expect.
previewChar() - Method in class com.google.common.net.MediaType.Tokenizer
 
prevInKeyInsertionOrder - Variable in class com.google.common.collect.HashBiMap.BiEntry
 
previous - Variable in class com.google.common.collect.LinkedListMultimap.Node
 
previous - Variable in class com.google.common.collect.LinkedListMultimap.NodeIterator
 
previous - Variable in class com.google.common.collect.LinkedListMultimap.ValueForKeyIterator
 
previous - Variable in class com.google.common.collect.testing.AbstractIteratorTester
 
previous() - Method in class com.google.common.collect.AbstractIndexedListIterator
 
previous() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedList.WrappedListIterator
 
previous() - Method in class com.google.common.collect.ForwardingListIterator
 
previous() - Method in class com.google.common.collect.LinkedListMultimap.NodeIterator
 
previous() - Method in class com.google.common.collect.LinkedListMultimap.ValueForKeyIterator
 
previous() - Method in class com.google.common.collect.testing.AbstractIteratorTester.MultiExceptionListIterator
 
previous() - Method in class com.google.common.collect.TransformedListIterator
 
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(Integer) - Method in class com.google.common.collect.DiscreteDomain.IntegerDomain
 
previous(Long) - Method in class com.google.common.collect.DiscreteDomain.LongDomain
 
previous(BigInteger) - Method in class com.google.common.collect.DiscreteDomain.BigIntegerDomain
 
PREVIOUS_METHOD - Static variable in class com.google.common.collect.testing.AbstractIteratorTester
 
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
 
previousElements - Variable in class com.google.common.collect.testing.AbstractIteratorTester.MultiExceptionListIterator
The elements to be returned by future calls to previous(), with the first at the top of the stack.
previousIndex - Variable in class com.google.common.collect.testing.AbstractIteratorTester
 
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.testing.AbstractIteratorTester.MultiExceptionListIterator
 
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() - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Performs routine cleanup prior to executing a write.
preWriteCleanup(long) - Method in class com.google.common.cache.LocalCache.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
 
PRIVATE - Enum constant in enum class com.google.thirdparty.publicsuffix.PublicSuffixType
Public suffix that is provided by a private company, e.g.
process(ByteBuffer) - Method in class com.google.common.hash.AbstractStreamingHasher
Processes the available bytes of the buffer (at most chunk bytes).
process(ByteBuffer) - Method in class com.google.common.hash.Crc32cHashFunction.Crc32cHasher
 
process(ByteBuffer) - Method in class com.google.common.hash.Murmur3_128HashFunction.Murmur3_128Hasher
 
process(ByteBuffer) - Method in class com.google.common.hash.SipHashFunction.SipHasher
 
processAllMustSucceedDoneFuture(int, ListenableFuture<? extends InputT>) - Method in class com.google.common.util.concurrent.AggregateFuture
 
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.
processCompleted(ImmutableCollection<? extends Future<? extends InputT>>) - Method in class com.google.common.util.concurrent.AggregateFuture
 
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.
processRemaining(ByteBuffer) - Method in class com.google.common.hash.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.Crc32cHashFunction.Crc32cHasher
 
processRemaining(ByteBuffer) - Method in class com.google.common.hash.Murmur3_128HashFunction.Murmur3_128Hasher
 
processRemaining(ByteBuffer) - Method in class com.google.common.hash.SipHashFunction.SipHasher
 
promoteToNext(E) - Method in class com.google.common.collect.testing.AbstractIteratorTester.MultiExceptionListIterator
Moves the given element from its current position in AbstractIteratorTester.MultiExceptionListIterator.nextElements to the top of the stack so that it is returned by the next call to Iterator.next().
propagate(Throwable) - Static method in class com.google.common.base.Throwables
Deprecated.
To preserve behavior, use throw e or throw new RuntimeException(e) directly, or use a combination of Throwables.throwIfUnchecked(java.lang.Throwable) and throw new RuntimeException(e). But consider whether users would be better off if your API threw a different type of exception. For background on the deprecation, read Why we deprecated Throwables.propagate.
propagateIfInstanceOf(Throwable, Class<X>) - Static method in class com.google.common.base.Throwables
Deprecated.
Use Throwables.throwIfInstanceOf(java.lang.Throwable, java.lang.Class<X>), which has the same behavior but rejects null.
propagateIfPossible(Throwable) - Static method in class com.google.common.base.Throwables
Deprecated.
Use Throwables.throwIfUnchecked(java.lang.Throwable), which has the same behavior but rejects null.
propagateIfPossible(Throwable, Class<X>) - Static method in class com.google.common.base.Throwables
Deprecated.
Use a combination of Throwables.throwIfInstanceOf(java.lang.Throwable, java.lang.Class<X>) and Throwables.throwIfUnchecked(java.lang.Throwable), which togther provide the same behavior except that they reject null.
propagateIfPossible(Throwable, Class<X1>, Class<X2>) - Static method in class com.google.common.base.Throwables
Deprecated.
Use a combination of two calls to Throwables.throwIfInstanceOf(java.lang.Throwable, java.lang.Class<X>) and one call to Throwables.throwIfUnchecked(java.lang.Throwable), which togther provide the same behavior except that they reject null.
PROTECTED - Enum constant in enum class com.google.common.testing.NullPointerTester.Visibility
 
PROTOBUF - Static variable in class com.google.common.net.MediaType
prototype - Variable in class com.google.common.hash.MacHashFunction
 
prototype - Variable in class com.google.common.hash.MessageDigestHashFunction
 
provideValueAndCloser(ClosingFuture.ValueAndCloserConsumer<C>, ClosingFuture<V>) - Static method in class com.google.common.util.concurrent.ClosingFuture
 
Providing input to a hash function - Search tag in interface com.google.common.hash.HashFunction
Section
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 Photoshop File Format (psd files) as defined by IANA, and found in /etc/mime.types, e.g.
PUBLIC - Enum constant in enum class com.google.common.testing.NullPointerTester.Visibility
 
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.
publicApiOnly() - Method in class com.google.common.testing.AbstractPackageSanityTests
Restricts the sanity tests for public API only.
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() - Method in class com.google.common.net.InternetDomainName
The index in the InternetDomainName.parts() list at which the public suffix begins.
publicSuffixIndexCache - Variable in class com.google.common.net.InternetDomainName
Cached value of #publicSuffixIndex().
PublicSuffixPatterns - Class in com.google.thirdparty.publicsuffix
Do not use this class directly.
PublicSuffixPatterns() - Constructor for class com.google.thirdparty.publicsuffix.PublicSuffixPatterns
 
PublicSuffixType - Enum Class in com.google.thirdparty.publicsuffix
Do not use this class directly.
PublicSuffixType(char, char) - Constructor for enum class com.google.thirdparty.publicsuffix.PublicSuffixType
 
publish(LogRecord) - Method in class com.google.common.testing.TestLogHandler
Adds the most recently logged record to our list.
PureJavaComparator() - Constructor for enum class com.google.common.primitives.UnsignedBytes.LexicographicalComparatorHolder.PureJavaComparator
 
PureJavaLongAddable() - Constructor for class com.google.common.cache.LongAddables.PureJavaLongAddable
 
PureJavaLongAddable() - Constructor for class com.google.common.hash.LongAddables.PureJavaLongAddable
 
Purpose - Search tag in interface com.google.common.util.concurrent.ListenableFuture
Section
PURPOSE - Static variable in class com.google.common.net.HttpHeaders
The HTTP Purpose header field name.
push(E) - Method in class com.google.common.collect.ForwardingDeque
 
push(E) - Method in class com.google.common.collect.Synchronized.SynchronizedDeque
 
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
Deprecated.
Unsupported operation.
put(Range<K>, V) - Method in interface com.google.common.collect.RangeMap
Maps a range to a specified value (optional operation).
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(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(TypeToken<? extends B>, B) - Method in class com.google.common.reflect.ImmutableTypeToInstanceMap
Deprecated.
unsupported operation
put(TypeToken<? extends B>, B) - Method in class com.google.common.reflect.MutableTypeToInstanceMap
Deprecated.
unsupported operation
put(TypeToken<T>, T) - Method in class com.google.common.reflect.ImmutableTypeToInstanceMap.Builder
Associates key with value in the built map.
put(C, Map<R, V>) - Method in class com.google.common.collect.ArrayTable.ColumnMap
 
put(C, R, V) - Method in class com.google.common.collect.Tables.TransposeTable
 
put(C, V) - Method in class com.google.common.collect.StandardTable.Row
 
put(C, V) - Method in class com.google.common.collect.TreeBasedTable.TreeRow
 
put(E) - Method in class com.google.common.collect.ForwardingBlockingDeque
Deprecated.
 
put(E) - Method in class com.google.common.util.concurrent.ForwardingBlockingDeque
 
put(E) - Method in class com.google.common.util.concurrent.ForwardingBlockingQueue
 
put(Class<? extends B>, B) - Method in class com.google.common.collect.MutableClassToInstanceMap
 
put(Class<T>, T) - Method in class com.google.common.collect.ImmutableClassToInstanceMap.Builder
Associates key with value in the built map.
put(Class<T>, T) - Method in class com.google.common.reflect.ImmutableTypeToInstanceMap.Builder
Associates key with value in the built map.
put(Map.Entry<? extends K, ? extends V>) - Method in class com.google.common.collect.ImmutableBiMap.Builder
Adds the given entry to the bimap.
put(Map.Entry<? extends K, ? extends V>) - Method in class com.google.common.collect.ImmutableListMultimap.Builder
Adds an entry to the built multimap.
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(Map.Entry<? extends K, ? extends V>) - Method in class com.google.common.collect.ImmutableMultimap.Builder
Adds an entry to the built multimap.
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(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(Map.Entry<K, V>) - Method in class com.google.common.collect.testing.testers.MapPutTester
 
put(K, int, V, boolean) - Method in class com.google.common.cache.LocalCache.Segment
 
put(K, int, V, boolean) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
 
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(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, 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(K, V) - Method in class com.google.common.collect.ArrayTable.ArrayMap
 
put(K, V) - Method in interface com.google.common.collect.BiMap
put(K, V) - Method in class com.google.common.collect.CollectCollectors.EnumMapAccumulator
 
put(K, V) - Method in class com.google.common.collect.CompactHashMap
 
put(K, V) - Method in class com.google.common.collect.EnumHashBiMap
 
put(K, V) - Method in class com.google.common.collect.ForwardingMap
 
put(K, V) - Method in class com.google.common.collect.ForwardingMultimap
 
put(K, V) - 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(K, V) - Method in class com.google.common.collect.ImmutableListMultimap.Builder
 
put(K, V) - Method in class com.google.common.collect.ImmutableMap.Builder
Associates key with value in the built map.
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(K, V) - Method in class com.google.common.collect.ImmutableMultimap
Deprecated.
Unsupported operation.
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(K, V) - Method in class com.google.common.collect.ImmutableSortedMap.Builder
Associates key with value in the built map.
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.MapMakerInternalMap
 
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, V) - Method in class com.google.common.collect.Multimaps.UnmodifiableMultimap
 
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(K, V) - Method in class com.google.common.collect.testing.SafeTreeMap
 
put(K, V) - Method in class com.google.common.graph.MapIteratorCache
 
put(K, V2) - Method in class com.google.common.collect.Multimaps.TransformedEntriesMultimap
 
put(K, V, boolean) - Method in class com.google.common.collect.HashBiMap
 
put(R, C, V) - Method in class com.google.common.collect.AbstractTable
 
put(R, C, V) - Method in class com.google.common.collect.ArrayTable
Associates the specified value with the specified keys.
put(R, C, V) - Method in class com.google.common.collect.ForwardingTable
 
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(R, C, V) - Method in class com.google.common.collect.ImmutableTable
Deprecated.
Unsupported operation.
put(R, C, V) - Method in class com.google.common.collect.StandardTable
 
put(R, C, V) - Method in class com.google.common.collect.Synchronized.SynchronizedTable
 
put(R, C, V) - Method in interface com.google.common.collect.Table
Associates the specified value with the specified keys.
put(R, C, V) - Method in class com.google.common.collect.Tables.UnmodifiableTable
 
put(R, C, V2) - Method in class com.google.common.collect.Tables.TransformedTable
 
put(R, C, V, BinaryOperator<V>) - Method in class com.google.common.collect.TableCollectors.ImmutableTableCollectorState
 
put(R, Map<C, V>) - Method in class com.google.common.collect.ArrayTable.RowMap
 
put(R, V) - Method in class com.google.common.collect.StandardTable.Column
 
put(T) - Method in class com.google.common.hash.BloomFilter
Puts an element into this BloomFilter.
put(T, Funnel<? super T>, int, BloomFilterStrategies.LockFreeBitArray) - Method in interface com.google.common.hash.BloomFilter.Strategy
Sets numHashFunctions bits of the given bit array, by hashing a user element.
put(V, K) - Method in class com.google.common.collect.HashBiMap.Inverse
 
putAll(Multimap<? extends K, ? extends V>) - Method in class com.google.common.collect.AbstractMultimap
 
putAll(Multimap<? extends K, ? extends V>) - Method in class com.google.common.collect.ForwardingMultimap
 
putAll(Multimap<? extends K, ? extends V>) - Method in class com.google.common.collect.ImmutableListMultimap.Builder
 
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(Multimap<? extends K, ? 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.ImmutableSetMultimap.Builder
 
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(Multimap<? extends K, ? 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.UnmodifiableMultimap
 
putAll(Multimap<? extends K, ? extends V>) - Method in class com.google.common.collect.Synchronized.SynchronizedMultimap
 
putAll(Multimap<? extends K, ? extends V2>) - Method in class com.google.common.collect.Multimaps.TransformedEntriesMultimap
 
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, ? extends V>) - Method in class com.google.common.collect.ImmutableRangeMap
Deprecated.
Unsupported operation.
putAll(RangeMap<K, ? extends V>) - Method in interface com.google.common.collect.RangeMap
Puts all the associations from rangeMap into this range map (optional operation).
putAll(RangeMap<K, ? extends V>) - Method in class com.google.common.collect.TreeRangeMap
 
putAll(RangeMap<K, ? extends V>) - Method in class com.google.common.collect.TreeRangeMap.SubRangeMap
 
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.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(Table<? extends R, ? extends C, ? extends V>) - Method in class com.google.common.collect.ForwardingTable
 
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(Table<? extends R, ? extends C, ? extends V>) - Method in class com.google.common.collect.Synchronized.SynchronizedTable
 
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 V>) - Method in class com.google.common.collect.Tables.UnmodifiableTable
 
putAll(Table<? extends R, ? extends C, ? extends V2>) - Method in class com.google.common.collect.Tables.TransformedTable
 
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.LockFreeBitArray) - Method in class com.google.common.hash.BloomFilterStrategies.LockFreeBitArray
Combines the two BitArrays using bitwise OR.
putAll(Iterable<? extends Map.Entry<? extends K, ? extends V>>) - Method in class com.google.common.collect.ImmutableBiMap.Builder
Adds all of the given entries to the built bimap.
putAll(Iterable<? extends Map.Entry<? extends K, ? extends V>>) - Method in class com.google.common.collect.ImmutableListMultimap.Builder
Adds entries to the built multimap.
putAll(Iterable<? extends Map.Entry<? extends K, ? extends V>>) - Method in class com.google.common.collect.ImmutableMap.Builder
Adds all of the given entries to the built map.
putAll(Iterable<? extends Map.Entry<? extends K, ? extends V>>) - Method in class com.google.common.collect.ImmutableMultimap.Builder
Adds entries to the built multimap.
putAll(Iterable<? extends Map.Entry<? extends K, ? extends V>>) - Method in class com.google.common.collect.ImmutableSetMultimap.Builder
Adds entries to the built multimap.
putAll(Iterable<? extends Map.Entry<? extends K, ? extends V>>) - Method in class com.google.common.collect.ImmutableSortedMap.Builder
Adds all the given entries to the built map.
putAll(Iterable<Map.Entry<K, V>>) - Method in class com.google.common.collect.testing.testers.MapPutAllTester
 
putAll(Map<? extends TypeToken<? extends B>, ? extends B>) - Method in class com.google.common.reflect.ImmutableTypeToInstanceMap
Deprecated.
unsupported operation
putAll(Map<? extends TypeToken<? extends B>, ? extends B>) - Method in class com.google.common.reflect.MutableTypeToInstanceMap
Deprecated.
unsupported operation
putAll(Map<? extends Class<? extends B>, ? extends B>) - Method in class com.google.common.collect.MutableClassToInstanceMap
 
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(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.
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(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(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 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(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(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(Map<? extends K, ? extends V>) - Method in class com.google.common.collect.Synchronized.SynchronizedMap
 
putAll(Map<? extends K, ? extends V>) - Method in class com.google.common.collect.testing.SafeTreeMap
 
putAll(K, Iterable<? extends V>) - Method in class com.google.common.collect.AbstractMultimap
 
putAll(K, Iterable<? extends V>) - Method in class com.google.common.collect.ForwardingMultimap
 
putAll(K, Iterable<? extends V>) - Method in class com.google.common.collect.ImmutableListMultimap.Builder
 
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, Iterable<? extends V>) - Method in class com.google.common.collect.ImmutableMultimap
Deprecated.
Unsupported operation.
putAll(K, Iterable<? extends V>) - Method in class com.google.common.collect.ImmutableSetMultimap.Builder
 
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(K, Iterable<? extends V>) - Method in class com.google.common.collect.Multimaps.MapMultimap
 
putAll(K, Iterable<? extends V>) - Method in class com.google.common.collect.Multimaps.UnmodifiableMultimap
 
putAll(K, Iterable<? extends V>) - Method in class com.google.common.collect.Synchronized.SynchronizedMultimap
 
putAll(K, Iterable<? extends V2>) - Method in class com.google.common.collect.Multimaps.TransformedEntriesMultimap
 
putAll(K, V...) - Method in class com.google.common.collect.ImmutableListMultimap.Builder
 
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(K, V...) - Method in class com.google.common.collect.ImmutableSetMultimap.Builder
 
putAllImpl(Map<K, V>, Map<? extends K, ? extends V>) - Static method in class com.google.common.collect.Maps
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.AbstractStreamingHasher
 
putByte(byte) - Method in interface com.google.common.hash.Hasher
 
putByte(byte) - Method in class com.google.common.hash.Murmur3_32HashFunction.Murmur3_32Hasher
 
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[]) - Method in class com.google.common.hash.AbstractHasher
 
putBytes(byte[]) - 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 class com.google.common.hash.AbstractByteHasher
 
putBytes(byte[], int, int) - Method in class com.google.common.hash.AbstractHasher
 
putBytes(byte[], int, int) - Method in class com.google.common.hash.AbstractNonStreamingHashFunction.BufferingHasher
 
putBytes(byte[], int, int) - Method in class com.google.common.hash.AbstractStreamingHasher
 
putBytes(byte[], int, int) - Method in interface com.google.common.hash.Hasher
 
putBytes(byte[], int, int) - Method in class com.google.common.hash.Murmur3_32HashFunction.Murmur3_32Hasher
 
putBytes(byte[], int, int) - Method in interface com.google.common.hash.PrimitiveSink
Puts a chunk of an array of bytes into this sink.
putBytes(ByteBuffer) - Method in class com.google.common.hash.AbstractByteHasher
 
putBytes(ByteBuffer) - Method in class com.google.common.hash.AbstractHasher
 
putBytes(ByteBuffer) - Method in class com.google.common.hash.AbstractNonStreamingHashFunction.BufferingHasher
 
putBytes(ByteBuffer) - Method in class com.google.common.hash.AbstractStreamingHasher
 
putBytes(ByteBuffer) - Method in interface com.google.common.hash.Hasher
 
putBytes(ByteBuffer) - Method in class com.google.common.hash.Murmur3_32HashFunction.Murmur3_32Hasher
 
putBytes(ByteBuffer) - Method in interface com.google.common.hash.PrimitiveSink
Puts the remaining bytes of a byte buffer into this sink.
putBytesInternal(ByteBuffer) - Method in class com.google.common.hash.AbstractStreamingHasher
 
putChar(char) - Method in class com.google.common.hash.AbstractByteHasher
 
putChar(char) - Method in class com.google.common.hash.AbstractHasher
 
putChar(char) - Method in class com.google.common.hash.AbstractStreamingHasher
 
putChar(char) - Method in interface com.google.common.hash.Hasher
 
putChar(char) - Method in class com.google.common.hash.Murmur3_32HashFunction.Murmur3_32Hasher
 
putChar(char) - Method in interface com.google.common.hash.PrimitiveSink
Puts a character into this sink.
putCoalescing(Range<K>, V) - Method in class com.google.common.collect.ImmutableRangeMap
Deprecated.
Unsupported operation.
putCoalescing(Range<K>, V) - Method in interface com.google.common.collect.RangeMap
Maps a range to a specified value, coalescing this range with any existing ranges with the same value that are connected to this range.
putCoalescing(Range<K>, V) - Method in class com.google.common.collect.TreeRangeMap
 
putCoalescing(Range<K>, V) - Method in class com.google.common.collect.TreeRangeMap.SubRangeMap
 
putData(int, long) - Method in class com.google.common.hash.BloomFilterStrategies.LockFreeBitArray
ORs the bits encoded in the ith long in the underlying AtomicLongArray with the given value.
putDistinctKeysDistinctValues() - Method in class com.google.common.collect.testing.google.BiMapPutTester
 
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.
putEdge(EndpointPair<N>) - Method in class com.google.common.graph.ImmutableGraph.Builder
Adds an edge connecting endpoints (in the order, if any, specified by endpoints) if one is not already present.
putEdge(EndpointPair<N>) - Method in interface com.google.common.graph.MutableGraph
Adds an edge connecting endpoints (in the order, if any, specified by endpoints) if one is not already present.
putEdge(EndpointPair<N>) - Method in class com.google.common.graph.StandardMutableGraph
 
putEdge(N, N) - Method in class com.google.common.graph.ImmutableGraph.Builder
Adds an edge connecting nodeU to nodeV if one is not already present.
putEdge(N, N) - Method in interface com.google.common.graph.MutableGraph
Adds an edge connecting nodeU to nodeV if one is not already present.
putEdge(N, N) - Method in class com.google.common.graph.StandardMutableGraph
 
putEdgeValue(EndpointPair<N>, V) - Method in class com.google.common.graph.ImmutableValueGraph.Builder
Adds an edge connecting endpoints if one is not already present, and sets a value for that edge to value (overwriting the existing value, if any).
putEdgeValue(EndpointPair<N>, V) - Method in interface com.google.common.graph.MutableValueGraph
Adds an edge connecting endpoints if one is not already present, and sets a value for that edge to value (overwriting the existing value, if any).
putEdgeValue(EndpointPair<N>, V) - Method in class com.google.common.graph.StandardMutableValueGraph
 
putEdgeValue(N, N, V) - Method in class com.google.common.graph.ImmutableValueGraph.Builder
Adds an edge connecting nodeU to nodeV if one is not already present, and sets a value for that edge to value (overwriting the existing value, if any).
putEdgeValue(N, N, V) - Method in interface com.google.common.graph.MutableValueGraph
Adds an edge connecting nodeU to nodeV if one is not already present, and sets a value for that edge to value (overwriting the existing value, if any).
putEdgeValue(N, N, V) - Method in class com.google.common.graph.StandardMutableValueGraph
 
putFirst(E) - Method in class com.google.common.collect.ForwardingBlockingDeque
Deprecated.
 
putFirst(E) - Method in class com.google.common.util.concurrent.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(Map.Entry<K, V>) - Method in class com.google.common.collect.testing.testers.ConcurrentMapPutIfAbsentTester
 
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.
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.ImmutableMap
Deprecated.
Unsupported operation.
putIfAbsent(K, V) - Method in class com.google.common.collect.MapMakerInternalMap
 
putIfAbsent(K, V) - Method in class com.google.common.collect.Maps.UnmodifiableBiMap
 
putIfAbsent(K, V) - Method in class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
putIfAbsent(K, V) - Method in class com.google.common.collect.Synchronized.SynchronizedMap
 
putInBothMaps(K, V, boolean) - Method in class com.google.common.collect.AbstractBiMap
 
putInstance(TypeToken<T>, T) - Method in class com.google.common.reflect.ImmutableTypeToInstanceMap
Deprecated.
unsupported operation
putInstance(TypeToken<T>, T) - Method in class com.google.common.reflect.MutableTypeToInstanceMap
 
putInstance(TypeToken<T>, T) - Method in interface com.google.common.reflect.TypeToInstanceMap
Maps the specified type to the specified value.
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(Class<T>, T) - Method in class com.google.common.reflect.ImmutableTypeToInstanceMap
Deprecated.
unsupported operation
putInstance(Class<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.
putInt(int) - Method in class com.google.common.hash.AbstractByteHasher
 
putInt(int) - Method in class com.google.common.hash.AbstractHasher
 
putInt(int) - Method in class com.google.common.hash.AbstractStreamingHasher
 
putInt(int) - Method in interface com.google.common.hash.Hasher
 
putInt(int) - Method in class com.google.common.hash.Murmur3_32HashFunction.Murmur3_32Hasher
 
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
Deprecated.
 
putLast(E) - Method in class com.google.common.util.concurrent.ForwardingBlockingDeque
 
putLong(long) - Method in class com.google.common.hash.AbstractByteHasher
 
putLong(long) - Method in class com.google.common.hash.AbstractHasher
 
putLong(long) - Method in class com.google.common.hash.AbstractStreamingHasher
 
putLong(long) - Method in interface com.google.common.hash.Hasher
 
putLong(long) - Method in class com.google.common.hash.Murmur3_32HashFunction.Murmur3_32Hasher
 
putLong(long) - Method in interface com.google.common.hash.PrimitiveSink
Puts a long into this sink.
putLongLittleEndian(byte[], int, long) - Method in interface com.google.common.hash.LittleEndianByteArray.LittleEndianBytes
 
putNext(AbstractFuture.Waiter, AbstractFuture.Waiter) - Method in class com.google.common.util.concurrent.AbstractFuture.AtomicHelper
Non-volatile write of the waiter to the AbstractFuture.Waiter.next field.
putNext(AbstractFuture.Waiter, AbstractFuture.Waiter) - Method in class com.google.common.util.concurrent.AbstractFuture.SafeAtomicHelper
 
putNext(AbstractFuture.Waiter, AbstractFuture.Waiter) - Method in class com.google.common.util.concurrent.AbstractFuture.SynchronizedHelper
 
putNext(AbstractFuture.Waiter, AbstractFuture.Waiter) - Method in class com.google.common.util.concurrent.AbstractFuture.UnsafeAtomicHelper
 
putObject(T, Funnel<? super T>) - Method in class com.google.common.hash.AbstractHasher
 
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.AbstractHasher
 
putShort(short) - Method in class com.google.common.hash.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 class com.google.common.hash.Murmur3_32HashFunction.Murmur3_32Hasher
 
putString(CharSequence, Charset) - Method in interface com.google.common.hash.PrimitiveSink
Puts a string into this sink using the given charset.
putThread(AbstractFuture.Waiter, Thread) - Method in class com.google.common.util.concurrent.AbstractFuture.AtomicHelper
Non-volatile write of the thread to the AbstractFuture.Waiter.thread field.
putThread(AbstractFuture.Waiter, Thread) - Method in class com.google.common.util.concurrent.AbstractFuture.SafeAtomicHelper
 
putThread(AbstractFuture.Waiter, Thread) - Method in class com.google.common.util.concurrent.AbstractFuture.SynchronizedHelper
 
putThread(AbstractFuture.Waiter, Thread) - Method in class com.google.common.util.concurrent.AbstractFuture.UnsafeAtomicHelper
 
putUnencodedChars(CharSequence) - Method in class com.google.common.hash.AbstractHasher
 
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
 
q0 - Variable in class com.google.common.hash.Striped64.Cell
 
q1 - Variable in class com.google.common.cache.Striped64.Cell
 
q1 - Variable in class com.google.common.hash.Striped64.Cell
 
q2 - Variable in class com.google.common.cache.Striped64.Cell
 
q2 - Variable in class com.google.common.hash.Striped64.Cell
 
q3 - Variable in class com.google.common.cache.Striped64.Cell
 
q3 - Variable in class com.google.common.hash.Striped64.Cell
 
q4 - Variable in class com.google.common.cache.Striped64.Cell
 
q4 - Variable in class com.google.common.hash.Striped64.Cell
 
q5 - Variable in class com.google.common.cache.Striped64.Cell
 
q5 - Variable in class com.google.common.hash.Striped64.Cell
 
q6 - Variable in class com.google.common.cache.Striped64.Cell
 
q6 - Variable in class com.google.common.hash.Striped64.Cell
 
Quantiles - Class in com.google.common.math
Provides a fluent API for calculating quantiles.
Quantiles() - Constructor for class com.google.common.math.Quantiles
 
Quantiles.Scale - Class in com.google.common.math
Describes the point in a fluent API chain where only the scale (i.e.
Quantiles.ScaleAndIndex - Class in com.google.common.math
Describes the point in a fluent API chain where the scale and a single quantile index (i.e.
Quantiles.ScaleAndIndexes - Class in com.google.common.math
Describes the point in a fluent API chain where the scale and a multiple quantile indexes (i.e.
quartiles() - Static method in class com.google.common.math.Quantiles
Specifies the computation of quartiles (i.e.
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.ConsumingQueueIterator
 
queue - Variable in class com.google.common.collect.Iterators.MergingIterator
 
queue - Variable in class com.google.common.collect.MinMaxPriorityQueue
 
queue - Variable in class com.google.common.collect.TreeTraverser.BreadthFirstIterator
Deprecated.
 
queue - Variable in class com.google.common.eventbus.Dispatcher.LegacyAsyncDispatcher
Global event queue.
queue - Variable in class com.google.common.eventbus.Dispatcher.PerThreadQueuedDispatcher
Per-thread queue of events to dispatch.
queue - Variable in class com.google.common.util.concurrent.SequentialExecutor
 
queue - Variable in class com.google.common.util.concurrent.Striped.SmallLazyStriped
 
queue(Queue<E>, Object) - Static method in class com.google.common.collect.Synchronized
 
QUEUED - Enum constant in enum class com.google.common.util.concurrent.SequentialExecutor.WorkerRunningState
runnable has been submitted but has not yet begun execution
QueueElementTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests element() operations on a queue.
QueueElementTester() - Constructor for class com.google.common.collect.testing.testers.QueueElementTester
 
queueForKeys - Variable in class com.google.common.collect.MapMakerInternalMap.WeakKeyDummyValueSegment
 
queueForKeys - Variable in class com.google.common.collect.MapMakerInternalMap.WeakKeyStrongValueSegment
 
queueForKeys - Variable in class com.google.common.collect.MapMakerInternalMap.WeakKeyWeakValueSegment
 
queueForValues - Variable in class com.google.common.collect.MapMakerInternalMap.StrongKeyWeakValueSegment
 
queueForValues - Variable in class com.google.common.collect.MapMakerInternalMap.WeakKeyWeakValueSegment
 
QueueIterator() - Constructor for class com.google.common.collect.MinMaxPriorityQueue.QueueIterator
 
QueueOfferTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests offer operations on a queue.
QueueOfferTester() - Constructor for class com.google.common.collect.testing.testers.QueueOfferTester
 
QueuePeekTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests peek() operations on a queue.
QueuePeekTester() - Constructor for class com.google.common.collect.testing.testers.QueuePeekTester
 
QueuePollTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests poll() operations on a queue.
QueuePollTester() - Constructor for class com.google.common.collect.testing.testers.QueuePollTester
 
QueueRemoveTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests remove() operations on a queue.
QueueRemoveTester() - Constructor for class com.google.common.collect.testing.testers.QueueRemoveTester
 
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
 
QueueTestSuiteBuilder<E> - Class in com.google.common.collect.testing
Creates, based on your criteria, a JUnit test suite that exhaustively tests a queue implementation.
QueueTestSuiteBuilder() - Constructor for class com.google.common.collect.testing.QueueTestSuiteBuilder
 
QueueWorker() - Constructor for class com.google.common.util.concurrent.SequentialExecutor.QueueWorker
 
QUEUING - Enum constant in enum class com.google.common.util.concurrent.SequentialExecutor.WorkerRunningState
Runnable is not running, but is being queued for execution
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.WrappedCollection) - Constructor for class com.google.common.collect.AbstractMapBasedMultimap.RandomAccessWrappedList
 
range - Variable 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() - 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() - Method in class com.google.common.collect.EmptyContiguousSet
 
range() - Method in class com.google.common.collect.RegularContiguousSet
 
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(BoundType, BoundType) - Method in class com.google.common.collect.EmptyContiguousSet
 
range(BoundType, BoundType) - Method in class com.google.common.collect.RegularContiguousSet
 
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(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> - 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 - Static variable in class com.google.common.net.HttpHeaders
The HTTP Range header field name.
RANGE_ENDS - Static variable in class com.google.common.base.CharMatcher.Invisible
 
RANGE_STARTS - Static variable in class com.google.common.base.CharMatcher.Invisible
 
Range.RangeLexOrdering - Class in com.google.common.collect
Needed to serialize sorted collections of Ranges.
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
 
RangeGwtSerializationDependencies<C> - Class in com.google.common.collect
A dummy superclass to support GWT serialization of the element type of a Range.
RangeGwtSerializationDependencies() - Constructor for class com.google.common.collect.RangeGwtSerializationDependencies
 
rangeLexOrdering() - Static method in class com.google.common.collect.Range
 
RangeLexOrdering() - Constructor for class com.google.common.collect.Range.RangeLexOrdering
 
RangeMap<K,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.Builder
 
ranges - Variable in class com.google.common.collect.ImmutableRangeSet
 
ranges - Variable in class com.google.common.collect.ImmutableRangeSet.SerializedForm
 
Ranges - Search tag in package com.google.common.collect
Section
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 - 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
 
RangeSet<C> - 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
RDF/XML documents, which are XML serializations of Resource Description Framework graphs.
reachableNodes(Graph<N>, N) - Static method in class com.google.common.graph.Graphs
Returns the set of nodes that are reachable from node.
reachableNodes(Graph<N>, N) - Static method in class com.google.common.graph.GraphsBridgeMethods
 
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() - Method in class com.google.common.io.ByteSource.AsCharSource
 
read() - 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() - Method in class com.google.common.io.ByteStreams.LimitedInputStream
 
read() - 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() - Method in class com.google.common.io.Files.FileByteSource
 
read() - Method in class com.google.common.io.MoreFiles.PathByteSource
 
read() - Method in class com.google.common.io.MultiInputStream
 
read() - Method in class com.google.common.io.ReaderInputStream
 
read() - Method in class com.google.common.testing.FakeTicker
 
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(byte[], int, int) - Method in class com.google.common.io.ByteStreams.LimitedInputStream
 
read(byte[], int, int) - Method in class com.google.common.io.CountingInputStream
 
read(byte[], int, int) - Method in class com.google.common.io.MultiInputStream
 
read(byte[], int, int) - Method in class com.google.common.io.ReaderInputStream
 
read(char[], int, int) - Method in class com.google.common.io.CharSequenceReader
 
read(char[], int, int) - Method in class com.google.common.io.MultiReader
 
read(ByteProcessor<T>) - Method in class com.google.common.io.ByteSource.ByteArrayByteSource
 
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(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
 
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.
readAttributes() - Method in class com.google.common.io.MoreFiles.PathByteSource
 
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(File, ByteProcessor<T>) - Static method in class com.google.common.io.Files
Deprecated.
Prefer asByteSource(file).read(processor).
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.
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
 
reader - Variable in class com.google.common.io.ReaderInputStream
 
ReaderInputStream - Class in com.google.common.io
An InputStream that converts characters from a Reader into bytes using an arbitrary Charset.
ReaderInputStream(Reader, CharsetEncoder, int) - Constructor for class com.google.common.io.ReaderInputStream
Creates a new input stream that will encode the characters from reader into bytes using the given character set encoder.
ReaderInputStream(Reader, Charset, int) - Constructor for class com.google.common.io.ReaderInputStream
Creates a new input stream that will encode the characters from reader into bytes using the given character set.
readFirstLine() - Method in class com.google.common.io.CharSource.CharSequenceCharSource
 
readFirstLine() - Method in class com.google.common.io.CharSource
Reads the first line of this source as a string.
readFirstLine(File, Charset) - Static method in class com.google.common.io.Files
Deprecated.
Prefer asCharSource(file, charset).readFirstLine().
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<? super T>) - Static method in class com.google.common.hash.BloomFilter
Reads a byte stream, which was written by BloomFilter.writeTo(OutputStream), into a BloomFilter.
readFrom(ByteBuffer) - Static method in class com.google.common.math.Stats
Creates a Stats instance from the byte representation read from the given ByteBuffer.
readFully(byte[]) - Method in interface com.google.common.io.ByteArrayDataInput
 
readFully(byte[]) - Method in class com.google.common.io.ByteStreams.ByteArrayDataInputStream
 
readFully(byte[]) - Method in class com.google.common.io.LittleEndianDataInputStream
 
readFully(byte[], int, int) - Method in interface com.google.common.io.ByteArrayDataInput
 
readFully(byte[], int, int) - Method in class com.google.common.io.ByteStreams.ByteArrayDataInputStream
 
readFully(byte[], int, int) - Method in class com.google.common.io.LittleEndianDataInputStream
 
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).
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() - 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.CharSequenceCharSource
 
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(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
Deprecated.
Prefer asCharSource(file, charset).readLines(callback).
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(URL, Charset) - Static method in class com.google.common.io.Resources
Reads all of the lines from a URL.
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.
readLock - Variable in class com.google.common.util.concurrent.CycleDetectingLockFactory.CycleDetectingReentrantReadWriteLock
 
readLock() - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory.CycleDetectingReentrantReadWriteLock
 
readLock() - Method in class com.google.common.util.concurrent.Striped.WeakSafeReadWriteLock
 
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
 
readMoreChars() - Method in class com.google.common.io.ReaderInputStream
Handle the case of underflow caused by needing more input characters.
readObject(ObjectInputStream) - Method in class com.google.common.base.Suppliers.ExpiringMemoizingSupplier
 
readObject(ObjectInputStream) - Method in class com.google.common.base.Suppliers.MemoizingSupplier
 
readObject(ObjectInputStream) - Method in class com.google.common.cache.LocalCache.LoadingSerializationProxy
 
readObject(ObjectInputStream) - Method in class com.google.common.cache.LocalCache.LocalLoadingCache
 
readObject(ObjectInputStream) - Method in class com.google.common.cache.LocalCache.LocalManualCache
 
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.CompactHashMap
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.CompactHashSet
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.ConcurrentHashMultiset
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.EmptyContiguousSet
 
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.Inverse
 
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.ImmutableBiMap
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.ImmutableCollection
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.ImmutableEnumMap
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.ImmutableEnumSet
 
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.ImmutableMap
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.ImmutableMapEntrySet
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.ImmutableMultimap.Keys
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.ImmutableMultiset.EntrySet
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.ImmutableMultiset
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.ImmutableRangeMap
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.ImmutableRangeSet.AsSet
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.ImmutableRangeSet
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.ImmutableSet
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.ImmutableSetMultimap
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.ImmutableSortedMap
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.ImmutableSortedMultiset
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.ImmutableSortedSet
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.ImmutableTable
 
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
 
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.MutableClassToInstanceMap
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.RegularContiguousSet
 
readObject(ObjectInputStream) - Method in class com.google.common.collect.RegularImmutableBiMap.Inverse
 
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.hash.BloomFilter
 
readObject(ObjectInputStream) - Method in class com.google.common.hash.Funnels.StringCharsetFunnel
 
readObject(ObjectInputStream) - Method in class com.google.common.hash.LongAdder
 
readObject(ObjectInputStream) - Method in class com.google.common.hash.MessageDigestHashFunction
 
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.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.EmptyImmutableListMultimap
 
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.ImmutableClassToInstanceMap
 
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.ImmutableMultimap.KeysSerializedForm
 
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.ImmutableRangeMap.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.ImmutableSortedMultiset.SerializedForm
 
readResolve() - Method in class com.google.common.collect.ImmutableSortedSet.SerializedForm
 
readResolve() - Method in class com.google.common.collect.ImmutableTable.SerializedForm
 
readResolve() - Method in class com.google.common.collect.MapMakerInternalMap.SerializationProxy
 
readResolve() - Method in class com.google.common.collect.MutableClassToInstanceMap.SerializedForm
 
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.RegularImmutableMap.KeySet.SerializedForm
 
readResolve() - Method in class com.google.common.collect.RegularImmutableMap.Values.SerializedForm
 
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.ImmutableDoubleArray
 
readResolve() - Method in class com.google.common.primitives.ImmutableIntArray
 
readResolve() - Method in class com.google.common.primitives.ImmutableLongArray
 
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
 
readResolve() - Method in class com.google.common.testing.ArbitraryInstances.AlwaysEqual
 
readResolve() - Method in class com.google.common.testing.ArbitraryInstances.ByToString
 
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 - Variable in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState
These two booleans are used to mark the state as ready to start.
ready() - Method in class com.google.common.io.CharSequenceReader
 
ready() - Method in class com.google.common.io.MultiReader
 
READY - Enum constant in enum class com.google.common.base.AbstractIterator.State
 
READY - Enum constant in enum class com.google.common.collect.AbstractIterator.State
We have computed the next element and haven't returned it yet.
rebalance() - Method in class com.google.common.collect.TreeMultiset.AvlNode
 
rebuildHashTable(int, Object[], int) - Static method in class com.google.common.collect.ImmutableSet.RegularSetBuilderImpl
Builds a new open-addressed hash table from the first n objects in elements.
Receiving Events - Search tag in class com.google.common.eventbus.EventBus
Section
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.
reclaimKey(ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache
 
reclaimKey(ReferenceEntry<K, V>, int) - Method in class com.google.common.cache.LocalCache.Segment
Removes an entry whose key has been garbage collected.
reclaimKey(E) - Method in class com.google.common.collect.MapMakerInternalMap
 
reclaimKey(E, 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(MapMakerInternalMap.WeakValueReference<K, V, E>) - Method in class com.google.common.collect.MapMakerInternalMap
 
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(K, int, MapMakerInternalMap.WeakValueReference<K, V, E>) - 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
 
recordCompletion() - Method in class com.google.common.util.concurrent.Futures.InCompletionOrderState
 
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.
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.
recordInputCompletion(ImmutableList<AbstractFuture<T>>, int) - Method in class com.google.common.util.concurrent.Futures.InCompletionOrderState
 
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(ReferenceEntry<K, V>, long) - Method in class com.google.common.cache.LocalCache.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.
recordOutputCancellation(boolean) - Method in class com.google.common.util.concurrent.Futures.InCompletionOrderState
 
recordRead(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.
recordsAccess() - Method in class com.google.common.cache.LocalCache
 
recordStats - Variable in class com.google.common.cache.CacheBuilderSpec
 
recordStats() - Method in class com.google.common.cache.CacheBuilder
Enable the accumulation of CacheStats during the operation of the cache.
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(ReferenceEntry<K, V>, int, long) - Method in class com.google.common.cache.LocalCache.Segment
Updates eviction metadata that entry was just written.
recreateCacheBuilder() - Method in class com.google.common.cache.LocalCache.ManualSerializationProxy
 
recurse(int) - Method in class com.google.common.collect.testing.AbstractIteratorTester
 
RecursiveDeleteOption - Enum Class in com.google.common.io
RecursiveDeleteOption() - Constructor for enum class com.google.common.io.RecursiveDeleteOption
 
reduceExponentIfGwt(int) - Static method in class com.google.common.collect.Platform
 
reduceIterationsIfGwt(int) - Static method in class com.google.common.collect.Platform
 
ReentrantLock - Search tag in class com.google.common.util.concurrent.Monitor
Section
ref - Variable in class com.google.common.util.concurrent.ExecutionSequencer
This reference acts as a pointer tracking the head of a linked list of ListenableFutures.
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
 
ReferenceEntry<K,V> - Interface in com.google.common.cache
An entry in a reference map.
referenceValue(LocalCache.Segment<K, V>, ReferenceEntry<K, V>, V, int) - Method in enum class com.google.common.cache.LocalCache.Strength
Creates a reference for the given value according to this value strength.
referent - Variable in class com.google.common.cache.LocalCache.StrongValueReference
 
REFERER - Static variable in class com.google.common.net.HttpHeaders
The HTTP Referer header field name.
REFERRER_POLICY - Static variable in class com.google.common.net.HttpHeaders
The HTTP Referrer-Policy header field name.
ReferrerPolicyValues() - Constructor for class com.google.common.net.HttpHeaders.ReferrerPolicyValues
 
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, 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.
refreshAfterWrite(Duration) - 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(C) - Method in class com.google.common.io.Closer
Registers the given closeable to be closed when this Closer is closed.
register(Object) - Method in class com.google.common.eventbus.EventBus
Registers all subscriber methods on object to receive events.
register(Object) - Method in class com.google.common.eventbus.SubscriberRegistry
Registers all subscriber methods on the given listener object.
REGISTRY - Enum constant in enum class com.google.thirdparty.publicsuffix.PublicSuffixType
Public suffix that is backed by an ICANN-style domain name registry
registrySuffix() - Method in class com.google.common.net.InternetDomainName
Returns the registry suffix portion of the domain name, or null if no registry suffix is present.
registrySuffixIndex() - Method in class com.google.common.net.InternetDomainName
The index in the InternetDomainName.parts() list at which the registry suffix begins.
registrySuffixIndexCache - Variable in class com.google.common.net.InternetDomainName
Cached value of #registrySuffixIndex().
RegularContiguousSet<C> - 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> - Class in com.google.common.collect
 
RegularEntrySet(ImmutableMap<K, V>, ImmutableList<Map.Entry<K, V>>) - Constructor for class com.google.common.collect.ImmutableMapEntrySet.RegularEntrySet
 
RegularEntrySet(ImmutableMap<K, V>, Map.Entry<K, V>[]) - Constructor for class com.google.common.collect.ImmutableMapEntrySet.RegularEntrySet
 
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 zero or more mappings.
RegularImmutableBiMap(ImmutableMapEntry<K, V>[], ImmutableMapEntry<K, V>[], Map.Entry<K, V>[], int, int) - Constructor for class com.google.common.collect.RegularImmutableBiMap
 
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
 
RegularImmutableList<E> - Class in com.google.common.collect
Implementation of ImmutableList backed by a simple array.
RegularImmutableList(Object[]) - Constructor for class com.google.common.collect.RegularImmutableList
 
RegularImmutableMap<K,V> - Class in com.google.common.collect
Implementation of ImmutableMap used for 0 entries and for 2+ entries.
RegularImmutableMap(Map.Entry<K, V>[], ImmutableMapEntry<K, V>[], int) - Constructor for class com.google.common.collect.RegularImmutableMap
 
RegularImmutableMap.BucketOverflowException - Exception Class in com.google.common.collect
 
RegularImmutableMap.KeySet<K> - Class in com.google.common.collect
 
RegularImmutableMap.KeySet.SerializedForm<K> - Class in com.google.common.collect
 
RegularImmutableMap.Values<K,V> - Class in com.google.common.collect
 
RegularImmutableMap.Values.SerializedForm<V> - Class in com.google.common.collect
 
RegularImmutableMultiset<E> - Class in com.google.common.collect
Implementation of ImmutableMultiset with zero or more elements.
RegularImmutableMultiset(Multisets.ImmutableEntry<E>[], Multisets.ImmutableEntry<?>[], int, int, ImmutableSet<E>) - Constructor for class com.google.common.collect.RegularImmutableMultiset
 
RegularImmutableMultiset.NonTerminalEntry<E> - Class in com.google.common.collect
 
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
 
RegularImmutableSortedMultiset<E> - Class in com.google.common.collect
An immutable sorted multiset with one or more distinct elements.
RegularImmutableSortedMultiset(RegularImmutableSortedSet<E>, long[], int, int) - Constructor for class com.google.common.collect.RegularImmutableSortedMultiset
 
RegularImmutableSortedMultiset(Comparator<? super E>) - 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
 
RegularLinearTransformation(double, double) - Constructor for class com.google.common.math.LinearTransformation.RegularLinearTransformation
 
RegularLinearTransformation(double, double, LinearTransformation) - Constructor for class com.google.common.math.LinearTransformation.RegularLinearTransformation
 
RegularSetBuilderImpl(int) - Constructor for class com.google.common.collect.ImmutableSet.RegularSetBuilderImpl
 
RegularSetBuilderImpl(ImmutableSet.RegularSetBuilderImpl<E>) - Constructor for class com.google.common.collect.ImmutableSet.RegularSetBuilderImpl
 
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
 
rejectionPropagatingExecutor(Executor, AbstractFuture<?>) - Static method in class com.google.common.util.concurrent.MoreExecutors
Returns an Executor that will propagate RejectedExecutionException from the delegate executor to the given future.
REJECTS_DUPLICATES_AT_CREATION - Enum constant in enum class com.google.common.collect.testing.features.CollectionFeature
Indicates that the constructor or factory method of a collection, usually an immutable set, throws an IllegalArgumentException when presented with duplicate elements instead of collapsing them to a single element or including duplicate instances in the collection.
REJECTS_DUPLICATES_AT_CREATION - Enum constant in enum class com.google.common.collect.testing.features.MapFeature
Indicates that the constructor or factory method of a map, usually an immutable map, throws an IllegalArgumentException when presented with duplicate keys instead of discarding all but one.
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.
relationshipName - Variable in class com.google.common.testing.RelationshipTester
 
RelationshipTester<T> - Class in com.google.common.testing
Implementation helper for EqualsTester and EquivalenceTester that tests for equivalence classes.
RelationshipTester(Equivalence<? super T>, String, String, RelationshipTester.ItemReporter) - Constructor for class com.google.common.testing.RelationshipTester
 
RelationshipTester.Item<T> - Class in com.google.common.testing
 
RelationshipTester.ItemReporter - Class in com.google.common.testing
 
Relationship to Object#hashCode - Search tag in interface com.google.common.hash.HashFunction
Section
Relationship to Ordering - Search tag in class com.google.common.collect.Comparators
Section
releaseResources(AggregateFuture.ReleaseResourcesReason) - Method in class com.google.common.util.concurrent.AggregateFuture
Clears fields that are no longer needed after this future has completed -- or at least all its inputs have completed (more precisely, after AggregateFuture.handleAllCompleted() has been called).
releaseResources(AggregateFuture.ReleaseResourcesReason) - Method in class com.google.common.util.concurrent.CollectionFuture
 
releaseResources(AggregateFuture.ReleaseResourcesReason) - Method in class com.google.common.util.concurrent.CombinedFuture
 
ReleaseResourcesReason() - Constructor for enum class com.google.common.util.concurrent.AggregateFuture.ReleaseResourcesReason
 
releaseWaiters() - Method in class com.google.common.util.concurrent.AbstractFuture
Releases all threads in the AbstractFuture.waiters list, and clears the list.
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 - Variable in class com.google.common.collect.HashBiMap.Itr
 
remaining - Variable in class com.google.common.util.concurrent.AggregateFutureState
 
remaining() - Method in class com.google.common.io.CharSequenceReader
 
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
Deprecated.
 
remainingCapacity() - Method in class com.google.common.util.concurrent.ForwardingBlockingDeque
 
remainingCapacity() - Method in class com.google.common.util.concurrent.ForwardingBlockingQueue
 
remainingCountUpdater - Variable in class com.google.common.util.concurrent.AggregateFutureState.SafeAtomicHelper
 
remainingNanos(long, long) - Static method in class com.google.common.util.concurrent.Monitor
Returns the remaining nanos until the given timeout, or 0L if the timeout has already elapsed.
remainingSuccessors - Variable in class com.google.common.graph.Graphs.NodeAndRemainingSuccessors
The successors left to be visited, or null if we just added this NodeAndRemainingSuccessors instance to the stack.
RemovalCause - Enum Class in com.google.common.cache
The reason why a cached entry was removed.
RemovalCause() - Constructor for enum class com.google.common.cache.RemovalCause
 
removalListener - Variable in class com.google.common.cache.CacheBuilder
 
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(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<K,V> - Interface in com.google.common.cache
An object that can receive a notification when an entry is removed from a cache.
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
 
removalNotificationQueue - Variable in class com.google.common.cache.LocalCache
Entries waiting to be consumed by the removal listener.
remove - Variable in class com.google.common.collect.testing.AbstractIteratorTester
 
remove() - Method in class com.google.common.base.AbstractIterator
 
remove() - Method in class com.google.common.cache.LocalCache.HashIterator
 
remove() - Method in class com.google.common.collect.AbstractMapBasedMultimap.AsMap.AsMapIterator
 
remove() - Method in class com.google.common.collect.AbstractMapBasedMultimap.Itr
 
remove() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection.WrappedIterator
 
remove() - Method in class com.google.common.collect.AbstractMapBasedMultiset.MapBasedMultisetIterator
 
remove() - Method in class com.google.common.collect.CompactHashMap.Itr
 
remove() - Method in class com.google.common.collect.EnumMultiset.Itr
 
remove() - Method in class com.google.common.collect.ForwardingIterator
 
remove() - Method in class com.google.common.collect.ForwardingQueue
 
remove() - Method in class com.google.common.collect.HashBiMap.Itr
 
remove() - Method in class com.google.common.collect.Iterators.ConcatenatedIterator
 
remove() - Method in enum class com.google.common.collect.Iterators.EmptyModifiableIterator
 
remove() - Method in class com.google.common.collect.Iterators.PeekingImpl
 
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() - Method in class com.google.common.collect.MapMakerInternalMap.HashIterator
 
remove() - Method in class com.google.common.collect.MinMaxPriorityQueue.QueueIterator
 
remove() - Method in class com.google.common.collect.Multisets.MultisetIteratorImpl
 
remove() - Method in interface com.google.common.collect.PeekingIterator
remove() - Method in class com.google.common.collect.StandardTable.CellIterator
 
remove() - Method in class com.google.common.collect.Synchronized.SynchronizedQueue
 
remove() - Method in class com.google.common.collect.testing.AbstractIteratorTester.MultiExceptionListIterator
 
remove() - Method in class com.google.common.collect.TransformedIterator
 
remove() - Method in class com.google.common.collect.UnmodifiableIterator
Deprecated.
Unsupported operation.
remove(int) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedList
 
remove(int) - Method in class com.google.common.collect.ForwardingList
 
remove(int) - Method in class com.google.common.collect.ImmutableList
Deprecated.
Unsupported operation.
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(int) - Method in class com.google.common.collect.Synchronized.SynchronizedList
 
remove(Range<C>) - Method in class com.google.common.collect.AbstractRangeSet
 
remove(Range<C>) - Method in class com.google.common.collect.ImmutableRangeSet
Deprecated.
Unsupported operation.
remove(Range<C>) - Method in interface com.google.common.collect.RangeSet
Removes the specified range from this RangeSet (optional operation).
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(Range<K>) - Method in class com.google.common.collect.ImmutableRangeMap
Deprecated.
Unsupported operation.
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<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.cache.LocalCache.AccessQueue
 
remove(Object) - Method in class com.google.common.cache.LocalCache.EntrySet
 
remove(Object) - Method in class com.google.common.cache.LocalCache.KeySet
 
remove(Object) - Method in class com.google.common.cache.LocalCache
 
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(Object) - Method in class com.google.common.collect.AbstractMapBasedMultimap.AsMap
 
remove(Object) - Method in class com.google.common.collect.AbstractMapBasedMultimap.KeySet
 
remove(Object) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection
 
remove(Object) - Method in class com.google.common.collect.AbstractMultiset
 
remove(Object) - Method in class com.google.common.collect.AbstractTable.CellSet
 
remove(Object) - Method in class com.google.common.collect.ArrayTable.ArrayMap
 
remove(Object) - Method in class com.google.common.collect.Collections2.FilteredCollection
 
remove(Object) - Method in class com.google.common.collect.CompactHashMap.EntrySetView
 
remove(Object) - Method in class com.google.common.collect.CompactHashMap.KeySetView
 
remove(Object) - Method in class com.google.common.collect.CompactHashMap
 
remove(Object) - Method in class com.google.common.collect.CompactHashSet
 
remove(Object) - Method in class com.google.common.collect.FilteredEntryMultimap.AsMap
 
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) - Method in class com.google.common.collect.ForwardingMap
 
remove(Object) - Method in class com.google.common.collect.HashBiMap.Inverse.InverseKeySet
 
remove(Object) - Method in class com.google.common.collect.HashBiMap.Inverse
 
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(Object) - Method in class com.google.common.collect.ImmutableMap
Deprecated.
Unsupported operation.
remove(Object) - Method in class com.google.common.collect.LinkedHashMultimap.ValueSet
 
remove(Object) - Method in class com.google.common.collect.MapMakerInternalMap.EntrySet
 
remove(Object) - Method in class com.google.common.collect.MapMakerInternalMap.KeySet
 
remove(Object) - Method in class com.google.common.collect.MapMakerInternalMap
 
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(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 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) - Method in class com.google.common.collect.Multisets.UnmodifiableMultiset
 
remove(Object) - Method in class com.google.common.collect.Sets.SetView
Deprecated.
Unsupported operation.
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) - 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(Object) - Method in class com.google.common.collect.Synchronized.SynchronizedMap
 
remove(Object) - Method in class com.google.common.collect.testing.SafeTreeMap
 
remove(Object) - Method in class com.google.common.collect.testing.SafeTreeSet
 
remove(Object) - Method in class com.google.common.collect.TreeRangeMap.SubRangeMap.SubRangeMapAsMap
 
remove(Object) - Method in class com.google.common.graph.IncidentEdgeSet
 
remove(Object) - Method in class com.google.common.graph.MapIteratorCache
 
remove(Object, int) - Method in class com.google.common.cache.LocalCache.Segment
 
remove(Object, int) - Method in class com.google.common.collect.AbstractMapBasedMultiset
 
remove(Object, int) - Method in class com.google.common.collect.AbstractMultiset
 
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, int) - Method in class com.google.common.collect.EnumMultiset
 
remove(Object, int) - Method in class com.google.common.collect.FilteredEntryMultimap.Keys
 
remove(Object, int) - Method in class com.google.common.collect.ForwardingMultiset
 
remove(Object, int) - Method in class com.google.common.collect.ImmutableMultiset
Deprecated.
Unsupported operation.
remove(Object, int) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
 
remove(Object, int) - Method in class com.google.common.collect.Multimaps.Keys
 
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, int) - Method in class com.google.common.collect.Multisets.FilteredMultiset
 
remove(Object, int) - Method in class com.google.common.collect.Multisets.UnmodifiableMultiset
 
remove(Object, int) - Method in class com.google.common.collect.Synchronized.SynchronizedMultiset
 
remove(Object, int) - Method in class com.google.common.collect.TreeMultiset
 
remove(Object, int, Object) - Method in class com.google.common.cache.LocalCache.Segment
 
remove(Object, int, Object) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
 
remove(Object, Object) - Method in class com.google.common.cache.LocalCache
 
remove(Object, Object) - Method in class com.google.common.collect.AbstractMultimap
 
remove(Object, Object) - Method in class com.google.common.collect.AbstractTable
 
remove(Object, Object) - Method in class com.google.common.collect.ArrayTable
remove(Object, Object) - Method in class com.google.common.collect.ForwardingConcurrentMap
 
remove(Object, Object) - Method in class com.google.common.collect.ForwardingMultimap
 
remove(Object, Object) - Method in class com.google.common.collect.ForwardingTable
 
remove(Object, 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, Object) - Method in class com.google.common.collect.ImmutableTable
Deprecated.
Unsupported operation.
remove(Object, Object) - Method in class com.google.common.collect.MapMakerInternalMap
 
remove(Object, Object) - Method in class com.google.common.collect.Maps.UnmodifiableBiMap
 
remove(Object, Object) - Method in class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
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, 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, Object) - Method in class com.google.common.collect.StandardTable
 
remove(Object, Object) - Method in class com.google.common.collect.Synchronized.SynchronizedMap
 
remove(Object, Object) - Method in class com.google.common.collect.Synchronized.SynchronizedMultimap
 
remove(Object, Object) - Method in class com.google.common.collect.Synchronized.SynchronizedTable
 
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(Object, Object, int, Object, int[], Object[], Object[]) - Static method in class com.google.common.collect.CompactHashing
 
remove(Comparator<? super E>, E, int, int[]) - Method in class com.google.common.collect.TreeMultiset.AvlNode
 
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.
REMOVE_METHOD - Static variable in class com.google.common.collect.testing.AbstractIteratorTester
 
REMOVE_OPERATIONS - Enum constant in enum class com.google.common.collect.testing.features.CollectionFeature
Features supported by collections where only removal is allowed.
REMOVE_OPERATIONS - Enum constant in enum class com.google.common.collect.testing.features.ListFeature
Features supported by lists where only removal is allowed.
removeAll(RangeSet<C>) - Method in class com.google.common.collect.AbstractRangeSet
 
removeAll(RangeSet<C>) - Method in class com.google.common.collect.ImmutableRangeSet
Deprecated.
Unsupported operation.
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(Iterable<?>, Collection<?>) - Static method in class com.google.common.collect.Iterables
Removes, from an iterable, every element that belongs to the provided collection.
removeAll(Iterable<Range<C>>) - Method in class com.google.common.collect.ImmutableRangeSet
Deprecated.
Unsupported operation.
removeAll(Iterable<Range<C>>) - Method in interface com.google.common.collect.RangeSet
Removes all of the specified ranges from this range set (optional operation).
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(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(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(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(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(Object) - Method in class com.google.common.collect.ImmutableSetMultimap
Deprecated.
Unsupported operation.
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(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(Object) - Method in interface com.google.common.collect.SetMultimap
Removes all values associated with the key key.
removeAll(Object) - Method in interface com.google.common.collect.SortedSetMultimap
Removes all values associated with a given key.
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
 
removeAll(Collection<?>) - Method in class com.google.common.collect.AbstractBiMap.EntrySet
 
removeAll(Collection<?>) - Method in class com.google.common.collect.AbstractBiMap.KeySet
 
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(Collection<?>) - Method in class com.google.common.collect.Collections2.FilteredCollection
 
removeAll(Collection<?>) - Method in class com.google.common.collect.FilteredMultimapValues
 
removeAll(Collection<?>) - Method in class com.google.common.collect.ForwardingCollection
 
removeAll(Collection<?>) - Method in class com.google.common.collect.ImmutableCollection
Deprecated.
Unsupported operation.
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(Collection<?>) - Method in interface com.google.common.collect.Multiset
removeAll(Collection<?>) - Method in class com.google.common.collect.Multisets.UnmodifiableMultiset
 
removeAll(Collection<?>) - Method in class com.google.common.collect.Sets.ImprovedAbstractSet
 
removeAll(Collection<?>) - Method in class com.google.common.collect.Sets.SetView
Deprecated.
Unsupported operation.
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(Collection<?>) - Method in class com.google.common.collect.testing.MinimalCollection
 
removeAll(Collection<?>) - Method in class com.google.common.collect.testing.SafeTreeSet
 
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.
removeAllImpl(Multiset<?>, Collection<?>) - Static method in class com.google.common.collect.Multisets
removeAllImpl(Set<?>, Collection<?>) - Static method in class com.google.common.collect.Sets
 
removeAllImpl(Set<?>, Iterator<?>) - Static method in class com.google.common.collect.Sets
Remove each element in an iterable from a set.
removeAllKeys(Map<K, V>, Predicate<? super Map.Entry<K, V>>, Collection<?>) - Static method in class com.google.common.collect.Maps.FilteredEntryMap
 
removeAllNodes(K) - 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(ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.Segment
 
removeColumn(Object) - Method in class com.google.common.collect.StandardTable
 
removeDuplicates(Map.Entry<K, V>[], int, int, IdentityHashMap<Map.Entry<K, V>, Boolean>) - Static method in class com.google.common.collect.RegularImmutableMap
Constructs a new entry array where each duplicated key from the original appears only once, at its first position but with its final value.
removeEdge(EndpointPair<N>) - Method in interface com.google.common.graph.MutableGraph
Removes the edge connecting endpoints, if it is present.
removeEdge(EndpointPair<N>) - Method in interface com.google.common.graph.MutableValueGraph
Removes the edge connecting endpoints, if it is present.
removeEdge(EndpointPair<N>) - Method in class com.google.common.graph.StandardMutableGraph
 
removeEdge(EndpointPair<N>) - Method in class com.google.common.graph.StandardMutableValueGraph
 
removeEdge(E) - Method in interface com.google.common.graph.MutableNetwork
Removes edge from this network, if it is present.
removeEdge(E) - Method in class com.google.common.graph.StandardMutableNetwork
 
removeEdge(N, N) - Method in interface com.google.common.graph.MutableGraph
Removes the edge connecting nodeU to nodeV, if it is present.
removeEdge(N, N) - Method in interface com.google.common.graph.MutableValueGraph
Removes the edge connecting nodeU to nodeV, if it is present.
removeEdge(N, N) - Method in class com.google.common.graph.StandardMutableGraph
 
removeEdge(N, N) - Method in class com.google.common.graph.StandardMutableValueGraph
 
removeEntriesIf(Predicate<? super Map.Entry<K, Collection<V>>>) - Method in class com.google.common.collect.FilteredEntryMultimap
 
removeEntry(ReferenceEntry<K, V>, int, RemovalCause) - Method in class com.google.common.cache.LocalCache.Segment
 
removeEntryForTesting(E) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
 
removeEntryFromChain(ReferenceEntry<K, V>, 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
Removes only this exact instance, not others that are equals()
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.Any
 
removeFrom(CharSequence) - Method in class com.google.common.base.CharMatcher.None
 
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(E, E) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Removes an entry from within a table.
removeFromChainForTesting(MapMakerInternalMap.InternalEntry<K, V, ?>, MapMakerInternalMap.InternalEntry<K, V, ?>) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Unsafely removes the given entry from the given chain in this segment's hash 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
 
removeHelper(Object) - Method in class com.google.common.collect.CompactHashMap
 
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(BiPredicate<? super K, ? super V>) - Method in class com.google.common.cache.LocalCache
 
removeIf(Predicate<? super E>) - Method in class com.google.common.collect.Collections2.FilteredCollection
 
removeIf(Predicate<? super E>) - Method in class com.google.common.collect.ImmutableCollection
Deprecated.
Unsupported operation.
removeIf(Predicate<? super E>) - Method in class com.google.common.collect.Multisets.UnmodifiableMultiset
 
removeIf(Predicate<? super E>) - Method in class com.google.common.collect.Sets.SetView
Deprecated.
Unsupported operation.
removeIf(Predicate<? super E>) - Method in class com.google.common.collect.Sets.UnmodifiableNavigableSet
 
removeIf(Predicate<? super E>) - Method in class com.google.common.collect.Synchronized.SynchronizedCollection
 
removeIf(Predicate<? super Map.Entry<K, V>>) - Method in class com.google.common.cache.LocalCache.EntrySet
 
removeIf(Predicate<? super T>) - Method in class com.google.common.collect.Collections2.TransformedCollection
 
removeIf(Predicate<? super T>) - Method in class com.google.common.collect.Lists.TransformingRandomAccessList
 
removeIf(Predicate<? super T>) - Method in class com.google.common.collect.Lists.TransformingSequentialList
 
removeIf(Predicate<? super V>) - Method in class com.google.common.cache.LocalCache.Values
 
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.
removeIfEmpty() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection
If collection is empty, remove it from AbstractMapBasedMultimap.this.map.
removeIfZero(K) - Method in class com.google.common.util.concurrent.AtomicLongMap
Atomically remove key from the map iff its associated value is 0.
removeInEdge(E, boolean) - Method in class com.google.common.graph.AbstractDirectedNetworkConnections
 
removeInEdge(E, boolean) - Method in class com.google.common.graph.AbstractUndirectedNetworkConnections
 
removeInEdge(E, boolean) - Method in class com.google.common.graph.DirectedMultiNetworkConnections
 
removeInEdge(E, boolean) - Method in interface com.google.common.graph.NetworkConnections
Remove edge from the set of incoming edges.
removeInEdge(E, boolean) - Method in class com.google.common.graph.UndirectedMultiNetworkConnections
 
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.
removeNode(N) - Method in interface com.google.common.graph.MutableGraph
Removes node if it is present; all edges incident to node will also be removed.
removeNode(N) - Method in interface com.google.common.graph.MutableNetwork
Removes node if it is present; all edges incident to node will also be removed.
removeNode(N) - Method in interface com.google.common.graph.MutableValueGraph
Removes node if it is present; all edges incident to node will also be removed.
removeNode(N) - Method in class com.google.common.graph.StandardMutableGraph
 
removeNode(N) - Method in class com.google.common.graph.StandardMutableNetwork
 
removeNode(N) - Method in class com.google.common.graph.StandardMutableValueGraph
 
removeOccurrences(Multiset<?>, Multiset<?>) - 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.
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.
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
 
removeOutEdge(E) - Method in class com.google.common.graph.AbstractDirectedNetworkConnections
 
removeOutEdge(E) - Method in class com.google.common.graph.AbstractUndirectedNetworkConnections
 
removeOutEdge(E) - Method in class com.google.common.graph.DirectedMultiNetworkConnections
 
removeOutEdge(E) - Method in interface com.google.common.graph.NetworkConnections
Remove edge from the set of outgoing edges.
removeOutEdge(E) - Method in class com.google.common.graph.UndirectedMultiNetworkConnections
 
removePredecessor(N) - Method in class com.google.common.graph.DirectedGraphConnections
 
removePredecessor(N) - Method in interface com.google.common.graph.GraphConnections
Remove node from the set of predecessors.
removePredecessor(N) - Method in class com.google.common.graph.UndirectedGraphConnections
 
removeRange(int, int) - Method in class com.google.common.collect.Lists.ReverseList
 
removeRange(int, int) - Method in class com.google.common.collect.Lists.TransformingRandomAccessList
The default implementation inherited is based on iteration and removal of each element which can be overkill.
removeRange(int, int) - 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.
removeSuccessor(Object) - Method in class com.google.common.graph.DirectedGraphConnections
 
removeSuccessor(N) - Method in interface com.google.common.graph.GraphConnections
Remove node from the set of successors.
removeSuccessor(N) - Method in class com.google.common.graph.UndirectedGraphConnections
 
removeTableEntryForTesting(MapMakerInternalMap.InternalEntry<K, V, ?>) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Unsafely removes the given entry from this segment's hash table.
removeValueFromChain(ReferenceEntry<K, V>, ReferenceEntry<K, V>, K, int, V, 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
 
removeWaiter(AbstractFuture.Waiter) - Method in class com.google.common.util.concurrent.AbstractFuture
Marks the given node as 'deleted' (null waiter) and then scans the list to unlink all deleted nodes.
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.
REPETITIONS - Static variable in class com.google.common.testing.EqualsTester
 
REPETITIONS - Static variable in class com.google.common.testing.EquivalenceTester
 
replace(K, int, V) - Method in class com.google.common.cache.LocalCache.Segment
 
replace(K, int, V) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
 
replace(K, int, V, V) - Method in class com.google.common.cache.LocalCache.Segment
 
replace(K, int, V, 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.
replace(K, V) - Method in class com.google.common.cache.LocalCache
 
replace(K, V) - Method in class com.google.common.collect.ForwardingConcurrentMap
 
replace(K, V) - Method in class com.google.common.collect.ImmutableMap
Deprecated.
Unsupported operation.
replace(K, V) - Method in class com.google.common.collect.MapMakerInternalMap
 
replace(K, V) - Method in class com.google.common.collect.Maps.UnmodifiableBiMap
 
replace(K, V) - Method in class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
replace(K, V) - Method in class com.google.common.collect.Synchronized.SynchronizedMap
 
replace(K, V, V) - Method in class com.google.common.cache.LocalCache
 
replace(K, V, V) - Method in class com.google.common.collect.ForwardingConcurrentMap
 
replace(K, V, V) - Method in class com.google.common.collect.ImmutableMap
Deprecated.
Unsupported operation.
replace(K, V, V) - Method in class com.google.common.collect.MapMakerInternalMap
 
replace(K, V, V) - Method in class com.google.common.collect.Maps.UnmodifiableBiMap
 
replace(K, V, V) - Method in class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
replace(K, V, V) - Method in class com.google.common.collect.Synchronized.SynchronizedMap
 
replaceAll(String) - Method in class com.google.common.base.CommonMatcher
 
replaceAll(String) - Method in class com.google.common.base.JdkPattern.JdkMatcher
 
replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in class com.google.common.collect.AbstractBiMap
 
replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in class com.google.common.collect.CompactHashMap
 
replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in class com.google.common.collect.ForwardingNavigableMap.StandardDescendingMap
 
replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in class com.google.common.collect.HashBiMap
 
replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in class com.google.common.collect.ImmutableMap
Deprecated.
Unsupported operation.
replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in class com.google.common.collect.Maps.FilteredEntryBiMap
 
replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in class com.google.common.collect.Maps.UnmodifiableBiMap
 
replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in class com.google.common.collect.Synchronized.SynchronizedMap
 
replaceAll(BiFunction<? super V, ? super K, ? extends K>) - Method in class com.google.common.collect.HashBiMap.Inverse
 
replaceAll(UnaryOperator<E>) - Method in class com.google.common.collect.ImmutableList
Deprecated.
Unsupported operation.
replaceAll(UnaryOperator<E>) - Method in class com.google.common.collect.Synchronized.SynchronizedList
 
replaced - Variable in class com.google.common.collect.MinMaxPriorityQueue.MoveDesc
 
REPLACED - Enum constant in enum class com.google.common.cache.RemovalCause
The entry itself was not actually removed, but its value was replaced by the user.
replaceFrom(CharSequence, char) - Method in class com.google.common.base.CharMatcher.Any
 
replaceFrom(CharSequence, char) - Method in class com.google.common.base.CharMatcher.Is
 
replaceFrom(CharSequence, char) - Method in class com.google.common.base.CharMatcher.None
 
replaceFrom(CharSequence, char) - Method in class com.google.common.base.CharMatcher
Returns a string copy of the input character sequence, with each matching BMP character replaced by a given replacement character.
replaceFrom(CharSequence, CharSequence) - Method in class com.google.common.base.CharMatcher.Any
 
replaceFrom(CharSequence, CharSequence) - Method in class com.google.common.base.CharMatcher.None
 
replaceFrom(CharSequence, CharSequence) - Method in class com.google.common.base.CharMatcher
Returns a string copy of the input character sequence, with each matching BMP character 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
 
replaceValue(List<Map.Entry<K, V>>, Map.Entry<K, V>) - Method in class com.google.common.collect.testing.AbstractMapTester
 
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 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 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
 
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
 
REPORT_TO - Static variable in class com.google.common.net.HttpHeaders
The HTTP Report-To header field name.
reportContext(List<E>) - Method in class com.google.common.collect.testing.testers.AbstractListTester
Used to delay string formatting until actually required, as it otherwise shows up in the test execution profile when running an extremely large numbers of tests.
reportItem(RelationshipTester.Item<?>) - Method in class com.google.common.testing.RelationshipTester.ItemReporter
 
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.
requireElements() - Method in class com.google.common.collect.CompactHashSet
 
requireEntries() - Method in class com.google.common.collect.CompactHashMap
 
requireEntries() - Method in class com.google.common.collect.CompactHashSet
 
requireKeys() - Method in class com.google.common.collect.CompactHashMap
 
requireLinks() - Method in class com.google.common.collect.CompactLinkedHashMap
 
requirePredecessors() - Method in class com.google.common.collect.CompactLinkedHashSet
 
requireSuccessors() - Method in class com.google.common.collect.CompactLinkedHashSet
 
requireTable() - Method in class com.google.common.collect.CompactHashMap
 
requireTable() - Method in class com.google.common.collect.CompactHashSet
 
requireValues() - Method in class com.google.common.collect.CompactHashMap
 
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.cancellationDelegate.
reserialize(T) - Static method in class com.google.common.collect.testing.ReserializingTestCollectionGenerator
 
reserialize(T) - Static method in class com.google.common.testing.Platform
Serializes and deserializes the specified object.
reserialize(T) - Static method in class com.google.common.testing.SerializableTester
Serializes and deserializes the specified object.
reserializeAndAssert(T) - Static method in class com.google.common.testing.SerializableTester
Serializes and deserializes the specified object and verifies that the re-serialized object is equal to the provided object, that the hashcodes are identical, and that the class of the re-serialized object is identical to that of the original.
ReserializedCollectionGenerator(OneSizeTestContainerGenerator<Collection<E>, E>) - Constructor for class com.google.common.collect.testing.CollectionTestSuiteBuilder.ReserializedCollectionGenerator
 
ReserializedListGenerator(OneSizeTestContainerGenerator<Collection<E>, E>) - Constructor for class com.google.common.collect.testing.ListTestSuiteBuilder.ReserializedListGenerator
 
ReserializedMapGenerator(OneSizeTestContainerGenerator<Map<K, V>, Map.Entry<K, V>>) - Constructor for class com.google.common.collect.testing.MapTestSuiteBuilder.ReserializedMapGenerator
 
ReserializedMultimapGenerator(OneSizeTestContainerGenerator<M, Map.Entry<K, V>>) - Constructor for class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.ReserializedMultimapGenerator
 
ReserializedMultisetGenerator(OneSizeTestContainerGenerator<Collection<E>, E>) - Constructor for class com.google.common.collect.testing.google.MultisetTestSuiteBuilder.ReserializedMultisetGenerator
 
ReserializedSetGenerator(OneSizeTestContainerGenerator<Collection<E>, E>) - Constructor for class com.google.common.collect.testing.SetTestSuiteBuilder.ReserializedSetGenerator
 
ReserializingTestCollectionGenerator<E> - Class in com.google.common.collect.testing
Reserializes the sets created by another test set generator.
ReserializingTestCollectionGenerator(TestCollectionGenerator<E>) - Constructor for class com.google.common.collect.testing.ReserializingTestCollectionGenerator
 
ReserializingTestSetGenerator<E> - Class in com.google.common.collect.testing
Reserializes the sets created by another test set generator.
ReserializingTestSetGenerator(TestSetGenerator<E>) - Constructor for class com.google.common.collect.testing.ReserializingTestSetGenerator
 
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.hash.LongAdder
Resets variables maintaining the sum to zero.
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.
reset(Buffer) - Static method in class com.google.common.io.Java8Compatibility
 
resetCollection() - Method in class com.google.common.collect.testing.AbstractCollectionTester
 
resetCollection() - Method in class com.google.common.collect.testing.google.AbstractMultimapTester
 
resetContainer() - Method in class com.google.common.collect.testing.AbstractContainerTester
Replaces the existing container under test with a new container created by the subject generator.
resetContainer(C) - Method in class com.google.common.collect.testing.AbstractContainerTester
Replaces the existing container under test with a new container.
resetContainer(Collection<E>) - Method in class com.google.common.collect.testing.AbstractCollectionTester
 
resetContainer(Map.Entry<K, V>...) - Method in class com.google.common.collect.testing.google.AbstractMultimapTester
 
resetContainer(M) - Method in class com.google.common.collect.testing.google.AbstractMultimapTester
 
resetMap() - Method in class com.google.common.collect.testing.AbstractMapTester
 
resetMap(Map.Entry<K, V>[]) - Method in class com.google.common.collect.testing.AbstractMapTester
 
resetOnFinalize - Variable in class com.google.common.io.FileBackedOutputStream
 
resetWithHole() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
Resets the contents of sortedMultiset to have entries a, c, for the navigation tests.
resetWithHole() - Method in class com.google.common.collect.testing.testers.NavigableMapNavigationTester
Resets the contents of navigableMap to have entries a, c, for the navigation tests.
resetWithHole() - Method in class com.google.common.collect.testing.testers.NavigableSetNavigationTester
Resets the contents of navigableSet to have elements a, c, for the navigation tests.
resizeEntries(int) - Method in class com.google.common.collect.CompactHashMap
Resizes the internal entries array to the specified capacity, which may be greater or less than the current capacity.
resizeEntries(int) - Method in class com.google.common.collect.CompactHashSet
Resizes the internal entries array to the specified capacity, which may be greater or less than the current capacity.
resizeEntries(int) - Method in class com.google.common.collect.CompactLinkedHashMap
 
resizeEntries(int) - Method in class com.google.common.collect.CompactLinkedHashSet
 
resizeMeMaybe(int) - Method in class com.google.common.collect.CompactHashMap
Resizes the entries storage if necessary.
resizeMeMaybe(int) - Method in class com.google.common.collect.CompactHashSet
Resizes the entries storage if necessary.
resizeTable(int, int, int, int) - Method in class com.google.common.collect.CompactHashMap
 
resizeTable(int, int, int, int) - Method in class com.google.common.collect.CompactHashSet
 
resolve(TypeVariable<?>) - Method in class com.google.common.reflect.TypeResolver.TypeTable
 
resolveGenericArrayType(GenericArrayType) - Method in class com.google.common.reflect.TypeResolver
 
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
 
resolveTypesInPlace(Type[]) - Method in class com.google.common.reflect.TypeResolver
 
resolveWildcardType(WildcardType) - Method in class com.google.common.reflect.TypeResolver
 
ResourceInfo(File, String, ClassLoader) - Constructor for class com.google.common.reflect.ClassPath.ResourceInfo
 
resourceName - Variable in class com.google.common.reflect.ClassPath.ResourceInfo
 
resources - Variable in class com.google.common.reflect.ClassPath
 
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.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
 
restoreInterruptIfIsInterruptedException(Throwable) - Static method in class com.google.common.util.concurrent.Platform
 
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.
RESTRICTS_ELEMENTS - Enum constant in enum class com.google.common.collect.testing.features.CollectionFeature
Indicates that a collection disallows certain elements (other than null, whose validity as an element is indicated by the presence or absence of CollectionFeature.ALLOWS_NULL_VALUES).
RESTRICTS_KEYS - Enum constant in enum class com.google.common.collect.testing.features.MapFeature
 
RESTRICTS_VALUES - Enum constant in enum class com.google.common.collect.testing.features.MapFeature
 
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.
result(Collector<T, A, R>, Iterable<T>) - Method in enum class com.google.common.testing.CollectorTester.CollectStrategy
 
resultEquivalence - Variable in class com.google.common.base.FunctionalEquivalence
 
resultIndex(int) - Method in enum class com.google.common.collect.SortedLists.KeyAbsentBehavior
 
resultIndex(Comparator<? super E>, E, List<? extends E>, int) - Method in enum class com.google.common.collect.SortedLists.KeyPresentBehavior
 
resync(long) - Method in class com.google.common.util.concurrent.SmoothRateLimiter
Updates storedPermits and nextFreeTicketMicros based on the current time.
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(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(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.Sets.SetView
Deprecated.
Unsupported operation.
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
 
retainAll(Collection<?>) - Method in class com.google.common.collect.testing.MinimalCollection
 
retainAll(Collection<?>) - Method in class com.google.common.collect.testing.SafeTreeSet
 
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.
retainAllImpl(Multiset<?>, Collection<?>) - Static method in class com.google.common.collect.Multisets
retainAllKeys(Map<K, V>, Predicate<? super Map.Entry<K, V>>, Collection<?>) - Static method in class com.google.common.collect.Maps.FilteredEntryMap
 
retainFrom(CharSequence) - Method in class com.google.common.base.CharMatcher
Returns a string containing all matching BMP 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.
retryUpdate(long, int[], boolean) - Method in class com.google.common.hash.Striped64
Handles cases of updates involving initialization, resizing, creating new Cells, and/or contention.
returning(TypeToken<R1>) - Method in class com.google.common.reflect.Invokable
Explicitly specifies the return type of this Invokable.
returning(Class<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.
returnTypeToTest - Variable in class com.google.common.testing.ClassSanityTester.FactoryMethodReturnValueTester
 
returnValue - Variable in class com.google.common.testing.ForwardingWrapperTester.InteractionTester
 
REUSING_EDGE - Static variable in class com.google.common.graph.GraphConstants
 
reverse - Variable in class com.google.common.base.Converter
 
reverse - Variable in class com.google.common.collect.GeneralRange
 
reverse() - Method in class com.google.common.base.Converter.IdentityConverter
 
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() - 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() - 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(boolean[]) - Static method in class com.google.common.primitives.Booleans
Reverses the elements of array.
reverse(boolean[], int, int) - Static method in class com.google.common.primitives.Booleans
Reverses the elements of array between fromIndex inclusive and toIndex exclusive.
reverse(byte[]) - Static method in class com.google.common.primitives.Bytes
Reverses the elements of array.
reverse(byte[], int, int) - Static method in class com.google.common.primitives.Bytes
Reverses the elements of array between fromIndex inclusive and toIndex exclusive.
reverse(char[]) - Static method in class com.google.common.primitives.Chars
Reverses the elements of array.
reverse(char[], int, int) - Static method in class com.google.common.primitives.Chars
Reverses the elements of array between fromIndex inclusive and toIndex exclusive.
reverse(double[]) - Static method in class com.google.common.primitives.Doubles
Reverses the elements of array.
reverse(double[], int, int) - Static method in class com.google.common.primitives.Doubles
Reverses the elements of array between fromIndex inclusive and toIndex exclusive.
reverse(float[]) - Static method in class com.google.common.primitives.Floats
Reverses the elements of array.
reverse(float[], int, int) - Static method in class com.google.common.primitives.Floats
Reverses the elements of array between fromIndex inclusive and toIndex exclusive.
reverse(int[]) - Static method in class com.google.common.primitives.Ints
Reverses the elements of array.
reverse(int[], int, int) - Static method in class com.google.common.primitives.Ints
Reverses the elements of array between fromIndex inclusive and toIndex exclusive.
reverse(long[]) - Static method in class com.google.common.primitives.Longs
Reverses the elements of array.
reverse(long[], int, int) - Static method in class com.google.common.primitives.Longs
Reverses the elements of array between fromIndex inclusive and toIndex exclusive.
reverse(short[]) - Static method in class com.google.common.primitives.Shorts
Reverses the elements of array.
reverse(short[], int, int) - Static method in class com.google.common.primitives.Shorts
Reverses the elements of array between fromIndex inclusive and toIndex exclusive.
reverse(CharSequence) - Static method in class com.google.thirdparty.publicsuffix.TrieParser
 
reverse(Comparator<T>) - Static method in class com.google.common.collect.Maps.DescendingMap
 
reverse(Comparator<T>) - Static method in class com.google.common.collect.Sets.DescendingSet
 
reverse(List<T>) - Static method in class com.google.common.collect.Lists
Returns a reversed view of the specified list.
reverse(List<T>) - Static method in class com.google.common.collect.testing.Helpers
 
reverse(Map.Entry<K, V>) - Method in class com.google.common.collect.testing.google.DerivedGoogleCollectionGenerators.InverseBiMapGenerator
 
ReverseConverter(Converter<A, B>) - Constructor for class com.google.common.base.Converter.ReverseConverter
 
reverseEntry(Map.Entry<K, V>) - Static method in class com.google.common.collect.testing.google.AbstractBiMapTester
 
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
 
review() - Method in class com.google.common.collect.ImmutableSet.RegularSetBuilderImpl
 
review() - Method in class com.google.common.collect.ImmutableSet.SetBuilderImpl
Call this before build().
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
 
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
rng - Static variable in class com.google.common.hash.Striped64
Generator of new random hash codes
root - Variable in class com.google.common.collect.TreeTraverser.PostOrderNode
Deprecated.
 
rootReference - Variable in class com.google.common.collect.TreeMultiset
 
rotate(boolean[], int) - Static method in class com.google.common.primitives.Booleans
Performs a right rotation of array of "distance" places, so that the first element is moved to index "distance", and the element at index i ends up at index (distance + i) mod array.length.
rotate(boolean[], int, int, int) - Static method in class com.google.common.primitives.Booleans
Performs a right rotation of array between fromIndex inclusive and toIndex exclusive.
rotate(byte[], int) - Static method in class com.google.common.primitives.Bytes
Performs a right rotation of array of "distance" places, so that the first element is moved to index "distance", and the element at index i ends up at index (distance + i) mod array.length.
rotate(byte[], int, int, int) - Static method in class com.google.common.primitives.Bytes
Performs a right rotation of array between fromIndex inclusive and toIndex exclusive.
rotate(char[], int) - Static method in class com.google.common.primitives.Chars
Performs a right rotation of array of "distance" places, so that the first element is moved to index "distance", and the element at index i ends up at index (distance + i) mod array.length.
rotate(char[], int, int, int) - Static method in class com.google.common.primitives.Chars
Performs a right rotation of array between fromIndex inclusive and toIndex exclusive.
rotate(double[], int) - Static method in class com.google.common.primitives.Doubles
Performs a right rotation of array of "distance" places, so that the first element is moved to index "distance", and the element at index i ends up at index (distance + i) mod array.length.
rotate(double[], int, int, int) - Static method in class com.google.common.primitives.Doubles
Performs a right rotation of array between fromIndex inclusive and toIndex exclusive.
rotate(float[], int) - Static method in class com.google.common.primitives.Floats
Performs a right rotation of array of "distance" places, so that the first element is moved to index "distance", and the element at index i ends up at index (distance + i) mod array.length.
rotate(float[], int, int, int) - Static method in class com.google.common.primitives.Floats
Performs a right rotation of array between fromIndex inclusive and toIndex exclusive.
rotate(int[], int) - Static method in class com.google.common.primitives.Ints
Performs a right rotation of array of "distance" places, so that the first element is moved to index "distance", and the element at index i ends up at index (distance + i) mod array.length.
rotate(int[], int, int, int) - Static method in class com.google.common.primitives.Ints
Performs a right rotation of array between fromIndex inclusive and toIndex exclusive.
rotate(long[], int) - Static method in class com.google.common.primitives.Longs
Performs a right rotation of array of "distance" places, so that the first element is moved to index "distance", and the element at index i ends up at index (distance + i) mod array.length.
rotate(long[], int, int, int) - Static method in class com.google.common.primitives.Longs
Performs a right rotation of array between fromIndex inclusive and toIndex exclusive.
rotate(short[], int) - Static method in class com.google.common.primitives.Shorts
Performs a right rotation of array of "distance" places, so that the first element is moved to index "distance", and the element at index i ends up at index (distance + i) mod array.length.
rotate(short[], int, int, int) - Static method in class com.google.common.primitives.Shorts
Performs a right rotation of array between fromIndex inclusive and toIndex exclusive.
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.
roundToDouble(long, RoundingMode) - Static method in class com.google.common.math.LongMath
Returns x, rounded to a double with the specified rounding mode.
roundToDouble(BigDecimal, RoundingMode) - Static method in class com.google.common.math.BigDecimalMath
Returns x, rounded to a double with the specified rounding mode.
roundToDouble(BigInteger, RoundingMode) - Static method in class com.google.common.math.BigIntegerMath
Returns x, rounded to a double with the specified rounding mode.
roundToDouble(X, RoundingMode) - Method in class com.google.common.math.ToDoubleRounder
Rounds x to a double.
roundToDoubleArbitrarily(BigDecimal) - Method in class com.google.common.math.BigDecimalMath.BigDecimalToDoubleRounder
 
roundToDoubleArbitrarily(BigInteger) - Method in class com.google.common.math.BigIntegerMath.BigIntegerToDoubleRounder
 
roundToDoubleArbitrarily(X) - Method in class com.google.common.math.ToDoubleRounder
Returns x rounded to either the greatest double less than or equal to the precise value of x, or the least double greater than or equal to the precise value of x.
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 - Variable in class com.google.common.collect.TableCollectors.MutableCell
 
row(C) - Method in class com.google.common.collect.Tables.TransposeTable
 
row(R) - Method in class com.google.common.collect.ArrayTable
Returns a view of all mappings that have the given row key.
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) - Method in class com.google.common.collect.Synchronized.SynchronizedTable
 
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(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.
Row(int) - Constructor for class com.google.common.collect.ArrayTable.Row
 
Row(int) - Constructor for class com.google.common.collect.DenseImmutableTable.Row
 
Row(R) - Constructor for class com.google.common.collect.StandardTable.Row
 
rowComparator - Variable in class com.google.common.collect.ImmutableTable.Builder
 
rowComparator() - Method in class com.google.common.collect.TreeBasedTable
Deprecated.
Use table.rowKeySet().comparator() instead.
rowCounts - Variable in class com.google.common.collect.DenseImmutableTable
 
rowEntry - Variable in class com.google.common.collect.StandardTable.CellIterator
 
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.
rowKeys - Variable in class com.google.common.collect.ImmutableTable.SerializedForm
 
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 class com.google.common.collect.Synchronized.SynchronizedTable
 
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 - Variable in class com.google.common.collect.DenseImmutableTable
 
rowMap - Variable in class com.google.common.collect.SparseImmutableTable
 
rowMap - Variable in class com.google.common.collect.StandardTable
 
rowMap() - Method in class com.google.common.collect.ArrayTable
 
rowMap() - Method in class com.google.common.collect.DenseImmutableTable
 
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() - 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() - Method in class com.google.common.collect.StandardTable
 
rowMap() - Method in class com.google.common.collect.Synchronized.SynchronizedTable
 
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
 
RowMap() - Constructor for class com.google.common.collect.ArrayTable.RowMap
 
RowMap() - Constructor for class com.google.common.collect.DenseImmutableTable.RowMap
 
RowMap() - Constructor for class com.google.common.collect.StandardTable.RowMap
 
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
 
RTT - Static variable in class com.google.common.net.HttpHeaders
The HTTP RTT header field name.
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.testing.ArbitraryInstances.Dummies.DummyRunnable
 
run() - Method in class com.google.common.util.concurrent.AbstractCatchingFuture
 
run() - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
Run the service.
run() - Method in class com.google.common.util.concurrent.AbstractFuture.SetFuture
 
run() - Method in class com.google.common.util.concurrent.AbstractScheduledService.ServiceDelegate.Task
 
run() - Method in class com.google.common.util.concurrent.AbstractTransformFuture
 
run() - Method in class com.google.common.util.concurrent.ExecutionSequencer.TaskNonReentrantExecutor
 
run() - Method in class com.google.common.util.concurrent.Futures.CallbackListener
 
run() - Method in class com.google.common.util.concurrent.Futures.NonCancellationPropagatingFuture
 
run() - Method in class com.google.common.util.concurrent.InterruptibleTask.Blocker
 
run() - Method in class com.google.common.util.concurrent.InterruptibleTask.DoNothingRunnable
 
run() - Method in class com.google.common.util.concurrent.InterruptibleTask
 
run() - Method in class com.google.common.util.concurrent.ListenerCallQueue.PerListenerQueue
 
run() - Method in class com.google.common.util.concurrent.MoreExecutors.ScheduledListeningDecorator.NeverSuccessfulListenableFutureTask
 
run() - Method in class com.google.common.util.concurrent.SequentialExecutor.QueueWorker
 
run() - Method in class com.google.common.util.concurrent.testing.MockFutureListener
 
run() - Method in class com.google.common.util.concurrent.TimeoutFuture.Fire
 
run() - Method in class com.google.common.util.concurrent.TrustedListenableFutureTask
 
run(Runnable, Executor) - Method in class com.google.common.util.concurrent.Futures.FutureCombiner
Creates the ListenableFuture which will return the result of running combiner when all Futures complete.
runCleanup() - Method in class com.google.common.collect.MapMakerInternalMap.Segment
 
runCollectionTests - Variable in class com.google.common.collect.testing.QueueTestSuiteBuilder
 
runEntryWithNullTest(Map.Entry<K, V>) - Method in class com.google.common.collect.testing.testers.MapHashCodeTester
 
runInterruptibly() - Method in class com.google.common.util.concurrent.CombinedFuture.AsyncCallableInterruptibleTask
 
runInterruptibly() - Method in class com.google.common.util.concurrent.CombinedFuture.CallableInterruptibleTask
 
runInterruptibly() - Method in class com.google.common.util.concurrent.InterruptibleTask
Do interruptible work here - do not complete Futures here, as their listeners could be interrupted.
runInterruptibly() - Method in class com.google.common.util.concurrent.TrustedListenableFutureTask.TrustedFutureInterruptibleAsyncTask
 
runInterruptibly() - Method in class com.google.common.util.concurrent.TrustedListenableFutureTask.TrustedFutureInterruptibleTask
 
runIteratorTest(Set<IteratorFeature>, AbstractIteratorTester.KnownOrder, Iterable<E>) - Method in class com.google.common.collect.testing.testers.CollectionIteratorTester
 
runListIteratorTest(Set<IteratorFeature>) - Method in class com.google.common.collect.testing.testers.ListListIteratorTester
 
runLockedCleanup() - Method in class com.google.common.collect.MapMakerInternalMap.Segment
 
runLockedCleanup(long) - Method in class com.google.common.cache.LocalCache.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() - 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 - Enum constant in enum class com.google.common.util.concurrent.SequentialExecutor.WorkerRunningState
 
RUNNING - Enum constant in enum class com.google.common.util.concurrent.Service.State
A service in this state is operational.
RUNNING_EVENT - Static variable in class com.google.common.util.concurrent.AbstractService
 
RunningState() - Constructor for enum class com.google.common.util.concurrent.ExecutionSequencer.RunningState
 
runningTask - Variable in class com.google.common.util.concurrent.AbstractScheduledService.ServiceDelegate
 
runningTasks - Variable in class com.google.common.util.concurrent.DirectExecutorService
 
runOneIteration() - Method in class com.google.common.util.concurrent.AbstractScheduledService
Run one iteration of the scheduled task.
runRemoveTest(int) - Method in class com.google.common.collect.testing.testers.ListRemoveAtIndexTester
 
runTearDown() - Method in class com.google.common.testing.TearDownStack
Causes teardown to execute.
runtime - Variable in class com.google.common.util.concurrent.UncaughtExceptionHandlers.Exiter
 
runtimeType - Variable in class com.google.common.reflect.TypeToken
 
runUninterruptiblyWithTimeout(Runnable, long, TimeUnit) - Method in class com.google.common.util.concurrent.FakeTimeLimiter
 
runUninterruptiblyWithTimeout(Runnable, long, TimeUnit) - Method in class com.google.common.util.concurrent.SimpleTimeLimiter
 
runUninterruptiblyWithTimeout(Runnable, long, TimeUnit) - Method in interface com.google.common.util.concurrent.TimeLimiter
Invokes a specified Runnable, timing out after the specified time limit.
runUninterruptiblyWithTimeout(Runnable, Duration) - Method in interface com.google.common.util.concurrent.TimeLimiter
Invokes a specified Runnable, timing out after the specified time limit.
runUnlockedCleanup() - Method in class com.google.common.cache.LocalCache.Segment
 
runWithTimeout(Runnable, long, TimeUnit) - Method in class com.google.common.util.concurrent.FakeTimeLimiter
 
runWithTimeout(Runnable, long, TimeUnit) - Method in class com.google.common.util.concurrent.SimpleTimeLimiter
 
runWithTimeout(Runnable, long, TimeUnit) - Method in interface com.google.common.util.concurrent.TimeLimiter
Invokes a specified Runnable, timing out after the specified time limit.
runWithTimeout(Runnable, Duration) - Method in interface com.google.common.util.concurrent.TimeLimiter
Invokes a specified Runnable, timing out after the specified time limit.

S

s - Variable in class com.google.common.collect.testing.BaseComparable
 
SafeAtomicHelper(AtomicReferenceFieldUpdater<? super AggregateFutureState<?>, ? super Set<Throwable>>, AtomicIntegerFieldUpdater<? super AggregateFutureState<?>>) - Constructor for class com.google.common.util.concurrent.AggregateFutureState.SafeAtomicHelper
 
SafeAtomicHelper(AtomicReferenceFieldUpdater<AbstractFuture.Waiter, Thread>, AtomicReferenceFieldUpdater<AbstractFuture.Waiter, AbstractFuture.Waiter>, AtomicReferenceFieldUpdater<? super AbstractFuture<?>, AbstractFuture.Waiter>, AtomicReferenceFieldUpdater<? super AbstractFuture<?>, AbstractFuture.Listener>, AtomicReferenceFieldUpdater<? super AbstractFuture<?>, Object>) - Constructor for class com.google.common.util.concurrent.AbstractFuture.SafeAtomicHelper
 
safeContains(Collection<?>, Object) - Static method in class com.google.common.collect.Collections2
safeContainsKey(Map<?, ?>, Object) - Static method in class com.google.common.collect.Maps
safeGet(Map<?, V>, Object) - Static method in class com.google.common.collect.Maps
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
safeRemove(Map<?, V>, Object) - Static method in class com.google.common.collect.Maps
SafeTreeMap<K,V> - Class in com.google.common.collect.testing
A wrapper around TreeMap that aggressively checks to see if keys are mutually comparable.
SafeTreeMap() - Constructor for class com.google.common.collect.testing.SafeTreeMap
 
SafeTreeMap(Comparator<? super K>) - Constructor for class com.google.common.collect.testing.SafeTreeMap
 
SafeTreeMap(Map<? extends K, ? extends V>) - Constructor for class com.google.common.collect.testing.SafeTreeMap
 
SafeTreeMap(NavigableMap<K, V>) - Constructor for class com.google.common.collect.testing.SafeTreeMap
 
SafeTreeMap(SortedMap<K, ? extends V>) - Constructor for class com.google.common.collect.testing.SafeTreeMap
 
SafeTreeSet<E> - Class in com.google.common.collect.testing
A wrapper around TreeSet that aggressively checks to see if elements are mutually comparable.
SafeTreeSet() - Constructor for class com.google.common.collect.testing.SafeTreeSet
 
SafeTreeSet(Collection<? extends E>) - Constructor for class com.google.common.collect.testing.SafeTreeSet
 
SafeTreeSet(Comparator<? super E>) - Constructor for class com.google.common.collect.testing.SafeTreeSet
 
SafeTreeSet(NavigableSet<E>) - Constructor for class com.google.common.collect.testing.SafeTreeSet
 
SafeTreeSet(SortedSet<E>) - Constructor for class com.google.common.collect.testing.SafeTreeSet
 
SAME_ORIGIN - Static variable in class com.google.common.net.HttpHeaders.ReferrerPolicyValues
 
sameElements - Variable in class com.google.common.collect.testing.testers.CollectionRetainAllTester
 
sameThreadScheduledExecutor() - Static method in class com.google.common.util.concurrent.testing.TestingExecutors
Creates a scheduled executor service that runs each task in the thread that invokes execute/submit/schedule, as in ThreadPoolExecutor.CallerRunsPolicy.
SameThreadScheduledExecutorService - Class in com.google.common.util.concurrent.testing
A ScheduledExecutorService that executes all scheduled actions immediately in the calling thread.
SameThreadScheduledExecutorService() - Constructor for class com.google.common.util.concurrent.testing.SameThreadScheduledExecutorService
 
SameThreadScheduledExecutorService.ImmediateScheduledFuture<V> - Class in com.google.common.util.concurrent.testing
 
sampleCovariance() - Method in class com.google.common.math.PairedStats
Returns the sample covariance of the values.
sampleCovariance() - Method in class com.google.common.math.PairedStatsAccumulator
Returns the sample covariance of the values.
SampleElements<E> - Class in com.google.common.collect.testing
A container class for the five sample elements we need for testing.
SampleElements(E, E, E, E, E) - Constructor for class com.google.common.collect.testing.SampleElements
 
SampleElements.Chars - Class in com.google.common.collect.testing
 
SampleElements.Collider - Class in com.google.common.collect.testing
 
SampleElements.Colliders - Class in com.google.common.collect.testing
 
SampleElements.Enums - Class in com.google.common.collect.testing
 
SampleElements.Ints - Class in com.google.common.collect.testing
 
SampleElements.Strings - Class in com.google.common.collect.testing
 
SampleElements.Unhashables - Class in com.google.common.collect.testing
 
sampleInstances - Variable in class com.google.common.testing.FreshValueGenerator
 
sampleKeys() - Method in class com.google.common.collect.testing.google.AbstractMultimapTester
 
sampleKeys() - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.ReserializedMultimapGenerator
 
sampleKeys() - Method in interface com.google.common.collect.testing.google.TestMultimapGenerator
 
sampleKeys() - Method in class com.google.common.collect.testing.google.TestStringListMultimapGenerator
 
sampleKeys() - Method in class com.google.common.collect.testing.google.TestStringSetMultimapGenerator
 
samples - Variable in class com.google.common.collect.testing.AbstractContainerTester
 
samples - Variable in class com.google.common.collect.testing.DerivedCollectionGenerators.MapKeySetGenerator
 
samples - Variable in class com.google.common.collect.testing.DerivedCollectionGenerators.MapValueCollectionGenerator
 
samples - Variable in class com.google.common.collect.testing.google.DerivedGoogleCollectionGenerators.BiMapValueSetGenerator
 
samples() - Method in class com.google.common.collect.testing.CollectionTestSuiteBuilder.ReserializedCollectionGenerator
 
samples() - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.ForwardingTestMapGenerator
 
samples() - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.MapEntrySetGenerator
 
samples() - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.MapKeySetGenerator
 
samples() - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.MapValueCollectionGenerator
 
samples() - Method in class com.google.common.collect.testing.DerivedCollectionGenerators.SortedSetSubsetTestSetGenerator
 
samples() - Method in class com.google.common.collect.testing.google.DerivedGoogleCollectionGenerators.BiMapValueSetGenerator
 
samples() - Method in class com.google.common.collect.testing.google.DerivedGoogleCollectionGenerators.InverseBiMapGenerator
 
samples() - Method in class com.google.common.collect.testing.google.DerivedGoogleCollectionGenerators.MapGenerator
 
samples() - Method in class com.google.common.collect.testing.google.MapGenerators.ImmutableMapEntryListGenerator
 
samples() - Method in class com.google.common.collect.testing.google.MapGenerators.ImmutableMapValuesAsSingletonSetGenerator
 
samples() - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.AsMapGenerator
 
samples() - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.EntriesGenerator
 
samples() - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.KeysGenerator
 
samples() - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.MultimapGetGenerator
 
samples() - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.ReserializedMultimapGenerator
 
samples() - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.ValuesGenerator
 
samples() - Method in class com.google.common.collect.testing.google.MultisetTestSuiteBuilder.ElementSetGenerator
 
samples() - Method in class com.google.common.collect.testing.google.MultisetTestSuiteBuilder.EntrySetGenerator
 
samples() - Method in class com.google.common.collect.testing.google.MultisetTestSuiteBuilder.ReserializedMultisetGenerator
 
samples() - Method in class com.google.common.collect.testing.google.SortedMapGenerators.ImmutableSortedMapEntryListGenerator
 
samples() - Method in class com.google.common.collect.testing.google.SortedMultisetTestSuiteBuilder.ForwardingTestMultisetGenerator
 
samples() - Method in class com.google.common.collect.testing.google.TestEnumMultisetGenerator
 
samples() - Method in class com.google.common.collect.testing.google.TestStringBiMapGenerator
 
samples() - Method in class com.google.common.collect.testing.google.TestStringListMultimapGenerator
 
samples() - Method in class com.google.common.collect.testing.google.TestStringMultisetGenerator
 
samples() - Method in class com.google.common.collect.testing.google.TestStringSetMultimapGenerator
 
samples() - Method in class com.google.common.collect.testing.ListTestSuiteBuilder.ReserializedListGenerator
 
samples() - Method in class com.google.common.collect.testing.MapTestSuiteBuilder.ReserializedMapGenerator
 
samples() - Method in class com.google.common.collect.testing.OneSizeGenerator
 
samples() - Method in class com.google.common.collect.testing.ReserializingTestCollectionGenerator
 
samples() - Method in class com.google.common.collect.testing.SetTestSuiteBuilder.ReserializedSetGenerator
 
samples() - Method in class com.google.common.collect.testing.TestCharacterListGenerator
 
samples() - Method in class com.google.common.collect.testing.TestCollidingSetGenerator
 
samples() - Method in interface com.google.common.collect.testing.TestContainerGenerator
Returns the sample elements that this generate populates its container with.
samples() - Method in class com.google.common.collect.testing.TestEnumMapGenerator
 
samples() - Method in class com.google.common.collect.testing.TestEnumSetGenerator
 
samples() - Method in class com.google.common.collect.testing.TestIntegerSetGenerator
 
samples() - Method in class com.google.common.collect.testing.TestMapEntrySetGenerator
 
samples() - Method in class com.google.common.collect.testing.TestStringCollectionGenerator
 
samples() - Method in class com.google.common.collect.testing.TestStringListGenerator
 
samples() - Method in class com.google.common.collect.testing.TestStringMapGenerator
 
samples() - Method in class com.google.common.collect.testing.TestStringQueueGenerator
 
samples() - Method in class com.google.common.collect.testing.TestStringSetGenerator
 
samples() - Method in class com.google.common.collect.testing.TestUnhashableCollectionGenerator
 
sampleStandardDeviation() - Method in class com.google.common.math.Stats
Returns the corrected sample standard deviation of the values.
sampleStandardDeviation() - Method in class com.google.common.math.StatsAccumulator
Returns the corrected sample standard deviation of the values.
sampleValues() - Method in class com.google.common.collect.testing.google.AbstractMultimapTester
 
sampleValues() - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.ReserializedMultimapGenerator
 
sampleValues() - Method in interface com.google.common.collect.testing.google.TestMultimapGenerator
 
sampleValues() - Method in class com.google.common.collect.testing.google.TestStringListMultimapGenerator
 
sampleValues() - Method in class com.google.common.collect.testing.google.TestStringSetMultimapGenerator
 
sampleValuesIterator() - Method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.KeysGenerator
 
sampleVariance() - Method in class com.google.common.math.Stats
Returns the unbiased sample variance of the values.
sampleVariance() - Method in class com.google.common.math.StatsAccumulator
Returns the unbiased sample variance of the values.
sanityError(Class<?>, List<String>, String, Throwable) - Static method in class com.google.common.testing.AbstractPackageSanityTests
 
satisfies(K, V) - Method in class com.google.common.collect.FilteredEntryMultimap
 
saturatedAdd(int, int) - Static method in class com.google.common.math.IntMath
Returns the sum of a and b unless it would overflow or underflow in which case Integer.MAX_VALUE or Integer.MIN_VALUE is returned, respectively.
saturatedAdd(long, long) - Static method in class com.google.common.math.LongMath
Returns the sum of a and b unless it would overflow or underflow in which case Long.MAX_VALUE or Long.MIN_VALUE is returned, respectively.
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.
saturatedCast(long) - Static method in class com.google.common.primitives.UnsignedInts
Returns the int value that, when treated as unsigned, is nearest in value to value.
saturatedMultiply(int, int) - Static method in class com.google.common.math.IntMath
Returns the product of a and b unless it would overflow or underflow in which case Integer.MAX_VALUE or Integer.MIN_VALUE is returned, respectively.
saturatedMultiply(long, long) - Static method in class com.google.common.math.LongMath
Returns the product of a and b unless it would overflow or underflow in which case Long.MAX_VALUE or Long.MIN_VALUE is returned, respectively.
saturatedPow(int, int) - Static method in class com.google.common.math.IntMath
Returns the b to the kth power, unless it would overflow or underflow in which case Integer.MAX_VALUE or Integer.MIN_VALUE is returned, respectively.
saturatedPow(long, int) - Static method in class com.google.common.math.LongMath
Returns the b to the kth power, unless it would overflow or underflow in which case Long.MAX_VALUE or Long.MIN_VALUE is returned, respectively.
saturatedSubtract(int, int) - Static method in class com.google.common.math.IntMath
Returns the difference of a and b unless it would overflow or underflow in which case Integer.MAX_VALUE or Integer.MIN_VALUE is returned, respectively.
saturatedSubtract(long, long) - Static method in class com.google.common.math.LongMath
Returns the difference of a and b unless it would overflow or underflow in which case Long.MAX_VALUE or Long.MIN_VALUE is returned, respectively.
SAVE_DATA - Static variable in class com.google.common.net.HttpHeaders
The HTTP Save-Data header field name.
sawReturn - Variable in class com.google.common.io.LineBuffer
Whether a line ending with a CR is pending processing.
scale - Variable in class com.google.common.math.Quantiles.Scale
 
scale - Variable in class com.google.common.math.Quantiles.ScaleAndIndex
 
scale - Variable in class com.google.common.math.Quantiles.ScaleAndIndexes
 
scale(int) - Static method in class com.google.common.math.Quantiles
Specifies the computation of q-quantiles.
Scale(int) - Constructor for class com.google.common.math.Quantiles.Scale
 
ScaleAndIndex(int, int) - Constructor for class com.google.common.math.Quantiles.ScaleAndIndex
 
ScaleAndIndexes(int, int[]) - Constructor for class com.google.common.math.Quantiles.ScaleAndIndexes
 
scaleNormalize(double) - Static method in class com.google.common.math.DoubleUtils
 
scan(File, Set<File>, ImmutableSet.Builder<ClassPath.ResourceInfo>) - Method in class com.google.common.reflect.ClassPath.LocationInfo
 
scanDirectory(File, ImmutableSet.Builder<ClassPath.ResourceInfo>) - Method in class com.google.common.reflect.ClassPath.LocationInfo
 
scanDirectory(File, String, Set<File>, ImmutableSet.Builder<ClassPath.ResourceInfo>) - Method in class com.google.common.reflect.ClassPath.LocationInfo
Recursively scan the given directory, adding resources for each file encountered.
scanJar(File, Set<File>, ImmutableSet.Builder<ClassPath.ResourceInfo>) - Method in class com.google.common.reflect.ClassPath.LocationInfo
 
scanJarFile(JarFile, ImmutableSet.Builder<ClassPath.ResourceInfo>) - Method in class com.google.common.reflect.ClassPath.LocationInfo
 
scanResources() - Method in class com.google.common.reflect.ClassPath.LocationInfo
Scans this location and returns all scanned resources.
scanResources(Set<File>) - Method in class com.google.common.reflect.ClassPath.LocationInfo
Scans this location and returns all scanned resources.
schedule(AbstractService, ScheduledExecutorService, Runnable) - Method in class com.google.common.util.concurrent.AbstractScheduledService.CustomScheduler
 
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(Runnable, long, TimeUnit) - Method in class com.google.common.util.concurrent.MoreExecutors.ScheduledListeningDecorator
 
schedule(Runnable, long, TimeUnit) - Method in class com.google.common.util.concurrent.testing.SameThreadScheduledExecutorService
 
schedule(Runnable, long, TimeUnit) - Method in class com.google.common.util.concurrent.testing.TestingExecutors.NoOpScheduledExecutorService
 
schedule(Runnable, long, TimeUnit) - Method in class com.google.common.util.concurrent.WrappingScheduledExecutorService
 
schedule(Runnable, Duration) - Method in interface com.google.common.util.concurrent.ListeningScheduledExecutorService
schedule(Callable<V>, long, TimeUnit) - Method in interface com.google.common.util.concurrent.ListeningScheduledExecutorService
 
schedule(Callable<V>, 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.testing.SameThreadScheduledExecutorService
 
schedule(Callable<V>, long, TimeUnit) - Method in class com.google.common.util.concurrent.testing.TestingExecutors.NoOpScheduledExecutorService
 
schedule(Callable<V>, long, TimeUnit) - Method in class com.google.common.util.concurrent.WrappingScheduledExecutorService
 
schedule(Callable<V>, Duration) - Method in interface com.google.common.util.concurrent.ListeningScheduledExecutorService
Schedule(long, TimeUnit) - Constructor for class com.google.common.util.concurrent.AbstractScheduledService.CustomScheduler.Schedule
 
Schedule(Duration) - Constructor for class com.google.common.util.concurrent.AbstractScheduledService.CustomScheduler.Schedule
 
scheduleAsync(AsyncCallable<O>, long, TimeUnit, ScheduledExecutorService) - Static method in class com.google.common.util.concurrent.Futures
Schedules callable on the specified executor, returning a Future.
scheduleAsync(AsyncCallable<O>, Duration, ScheduledExecutorService) - Static method in class com.google.common.util.concurrent.Futures
Schedules callable on the specified executor, returning a Future.
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.testing.SameThreadScheduledExecutorService
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class com.google.common.util.concurrent.testing.TestingExecutors.NoOpScheduledExecutorService
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class com.google.common.util.concurrent.WrappingScheduledExecutorService
 
scheduleAtFixedRate(Runnable, Duration, Duration) - Method in interface com.google.common.util.concurrent.ListeningScheduledExecutorService
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(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.testing.SameThreadScheduledExecutorService
 
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class com.google.common.util.concurrent.testing.TestingExecutors.NoOpScheduledExecutorService
 
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class com.google.common.util.concurrent.WrappingScheduledExecutorService
 
scheduleWithFixedDelay(Runnable, Duration, Duration) - Method in interface com.google.common.util.concurrent.ListeningScheduledExecutorService
scope - Variable in class com.google.common.net.InetAddresses.Scope
 
Scope() - Constructor for class com.google.common.net.InetAddresses.Scope
 
scopeWithDelimiter(Inet6Address) - Static method in class com.google.common.net.InetAddresses
 
scratch - Variable in class com.google.common.hash.AbstractByteHasher
 
SEC_AD_AUCTION_FETCH - Static variable in class com.google.common.net.HttpHeaders
The HTTP Sec-Ad-Auction-Fetch header field name.
SEC_BROWSING_TOPICS - Static variable in class com.google.common.net.HttpHeaders
The HTTP Sec-Browsing-Topics header field name.
SEC_CH_DPR - Static variable in class com.google.common.net.HttpHeaders
The HTTP Sec-CH-DPR header field name.
SEC_CH_PREFERS_COLOR_SCHEME - Static variable in class com.google.common.net.HttpHeaders
The HTTP Sec-CH-Prefers-Color-Scheme header field name.
SEC_CH_UA - Static variable in class com.google.common.net.HttpHeaders
The HTTP Sec-CH-UA header field name.
SEC_CH_UA_ARCH - Static variable in class com.google.common.net.HttpHeaders
The HTTP Sec-CH-UA-Arch header field name.
SEC_CH_UA_BITNESS - Static variable in class com.google.common.net.HttpHeaders
The HTTP Sec-CH-UA-Bitness header field name.
SEC_CH_UA_FORM_FACTOR - Static variable in class com.google.common.net.HttpHeaders
SEC_CH_UA_FORM_FACTORS - Static variable in class com.google.common.net.HttpHeaders
The HTTP Sec-CH-UA-Form-Factors header field name.
SEC_CH_UA_FULL_VERSION - Static variable in class com.google.common.net.HttpHeaders
SEC_CH_UA_FULL_VERSION_LIST - Static variable in class com.google.common.net.HttpHeaders
The HTTP Sec-CH-UA-Full-Version header field name.
SEC_CH_UA_MOBILE - Static variable in class com.google.common.net.HttpHeaders
The HTTP Sec-CH-UA-Mobile header field name.
SEC_CH_UA_MODEL - Static variable in class com.google.common.net.HttpHeaders
The HTTP Sec-CH-UA-Model header field name.
SEC_CH_UA_PLATFORM - Static variable in class com.google.common.net.HttpHeaders
The HTTP Sec-CH-UA-Platform header field name.
SEC_CH_UA_PLATFORM_VERSION - Static variable in class com.google.common.net.HttpHeaders
The HTTP Sec-CH-UA-Platform-Version header field name.
SEC_CH_UA_WOW64 - Static variable in class com.google.common.net.HttpHeaders
The HTTP Sec-CH-UA-WoW64 header field name.
SEC_CH_VIEWPORT_HEIGHT - Static variable in class com.google.common.net.HttpHeaders
The HTTP Sec-CH-Viewport-Height header field name.
SEC_CH_VIEWPORT_WIDTH - Static variable in class com.google.common.net.HttpHeaders
The HTTP Sec-CH-Viewport-Width header field name.
SEC_FETCH_DEST - Static variable in class com.google.common.net.HttpHeaders
The HTTP Sec-Fetch-Dest header field name.
SEC_FETCH_MODE - Static variable in class com.google.common.net.HttpHeaders
The HTTP Sec-Fetch-Mode header field name.
SEC_FETCH_SITE - Static variable in class com.google.common.net.HttpHeaders
The HTTP Sec-Fetch-Site header field name.
SEC_FETCH_USER - Static variable in class com.google.common.net.HttpHeaders
The HTTP Sec-Fetch-User header field name.
SEC_GPC - Static variable in class com.google.common.net.HttpHeaders
The HTTP Sec-GPC header field name.
SEC_METADATA - Static variable in class com.google.common.net.HttpHeaders
The HTTP Sec-Metadata header field name.
SEC_PROVIDED_TOKEN_BINDING_ID - Static variable in class com.google.common.net.HttpHeaders
The HTTP Sec-Provided-Token-Binding-ID header field name.
SEC_REFERRED_TOKEN_BINDING_ID - Static variable in class com.google.common.net.HttpHeaders
The HTTP Sec-Referred-Token-Binding-ID header field name.
SEC_TOKEN_BINDING - Static variable in class com.google.common.net.HttpHeaders
The HTTP Sec-Token-Binding header field name.
SEC_WEBSOCKET_ACCEPT - Static variable in class com.google.common.net.HttpHeaders
The HTTP Sec-WebSocket-Accept header field name.
SEC_WEBSOCKET_EXTENSIONS - Static variable in class com.google.common.net.HttpHeaders
The HTTP Sec-WebSocket-Extensions header field name.
SEC_WEBSOCKET_KEY - Static variable in class com.google.common.net.HttpHeaders
The HTTP Sec-WebSocket-Key header field name.
SEC_WEBSOCKET_PROTOCOL - Static variable in class com.google.common.net.HttpHeaders
The HTTP Sec-WebSocket-Protocol header field name.
SEC_WEBSOCKET_VERSION - Static variable in class com.google.common.net.HttpHeaders
The HTTP Sec-WebSocket-Version header field name.
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
 
See also - Search tag in class com.google.common.collect.ImmutableCollection
Section
See also - Search tag in class com.google.common.collect.Ordering
Section
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.AggregateFutureState
 
seenExceptionsUpdater - Variable in class com.google.common.util.concurrent.AggregateFutureState.SafeAtomicHelper
 
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, E, S>, 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.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.
selectAllInPlace(int[], int, int, double[], int, int) - Static method in class com.google.common.math.Quantiles
Performs an in-place selection, like Quantiles.selectInPlace(int, double[], int, int), to select all the indexes allRequired[i] for i in the range [requiredFrom, requiredTo].
selectInPlace(int, double[], int, int) - Static method in class com.google.common.math.Quantiles
Performs an in-place selection to find the element which would appear at a given index in a dataset if it were sorted.
self() - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Returns this up-casted to the specific MapMakerInternalMap.Segment implementation type S.
self() - Method in class com.google.common.collect.MapMakerInternalMap.StrongKeyDummyValueSegment
 
self() - Method in class com.google.common.collect.MapMakerInternalMap.StrongKeyStrongValueSegment
 
self() - Method in class com.google.common.collect.MapMakerInternalMap.StrongKeyWeakValueSegment
 
self() - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyDummyValueSegment
 
self() - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyStrongValueSegment
 
self() - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyWeakValueSegment
 
self() - Method in class com.google.common.collect.testing.FeatureSpecificTestSuiteBuilder
 
SELF_LOOPS_NOT_ALLOWED - Static variable in class com.google.common.graph.GraphConstants
 
selfLoopCount - Variable in class com.google.common.graph.AbstractDirectedNetworkConnections
 
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
 
separatingAppendable(Appendable, String, int) - Static method in class com.google.common.io.BaseEncoding
 
separatingWriter(Writer, 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
 
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
 
sequencer - Variable in class com.google.common.util.concurrent.ExecutionSequencer.TaskNonReentrantExecutor
Used to update and read the latestTaskQueue field.
SEQUENTIAL - Enum constant in enum class com.google.common.testing.CollectorTester.CollectStrategy
Get one accumulator and accumulate the elements into it sequentially.
SequentialExecutor - Class in com.google.common.util.concurrent
Executor ensuring that all Runnables submitted are executed in order, using the provided Executor, and sequentially such that no two will ever be running at the same time.
SequentialExecutor(Executor) - Constructor for class com.google.common.util.concurrent.SequentialExecutor
SequentialExecutor.QueueWorker - Class in com.google.common.util.concurrent
Worker that runs tasks from SequentialExecutor.queue until it is empty.
SequentialExecutor.WorkerRunningState - Enum Class in com.google.common.util.concurrent
 
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
 
serializable() - Element in annotation interface com.google.common.annotations.GwtCompatible
When true, the annotated type or the type of the method return value is GWT serializable.
SERIALIZABLE - Enum constant in enum class com.google.common.collect.testing.features.CollectionFeature
 
SERIALIZABLE_INCLUDING_VIEWS - Enum constant in enum class com.google.common.collect.testing.features.CollectionFeature
 
SERIALIZABLE_TEST_METHOD_NAMES - Static variable in class com.google.common.testing.AbstractPackageSanityTests
 
SerializableDummyProxy(ClassSanityTester) - Constructor for class com.google.common.testing.ClassSanityTester.SerializableDummyProxy
 
SerializableTester - Class in com.google.common.testing
Tests serialization and deserialization of an object, optionally asserting that the resulting object is equal to the original.
SerializableTester() - Constructor for class com.google.common.testing.SerializableTester
 
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>, int, 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(ImmutableBiMap<K, V>) - Constructor for class com.google.common.collect.ImmutableBiMap.SerializedForm
 
SerializedForm(ImmutableCollection<?>) - Constructor for class com.google.common.collect.ImmutableAsList.SerializedForm
 
SerializedForm(ImmutableList<Range<C>>) - Constructor for class com.google.common.collect.ImmutableRangeSet.SerializedForm
 
SerializedForm(ImmutableMap<?, V>) - Constructor for class com.google.common.collect.ImmutableMapValues.SerializedForm
 
SerializedForm(ImmutableMap<?, V>) - Constructor for class com.google.common.collect.RegularImmutableMap.Values.SerializedForm
 
SerializedForm(ImmutableMap<Range<K>, V>) - Constructor for class com.google.common.collect.ImmutableRangeMap.SerializedForm
 
SerializedForm(ImmutableMap<K, ?>) - Constructor for class com.google.common.collect.RegularImmutableMap.KeySet.SerializedForm
 
SerializedForm(ImmutableMap<K, V>) - Constructor for class com.google.common.collect.ImmutableMap.SerializedForm
 
SerializedForm(ImmutableSortedMap<K, V>) - Constructor for class com.google.common.collect.ImmutableSortedMap.SerializedForm
 
SerializedForm(Multiset<? extends Object>) - Constructor for class com.google.common.collect.ImmutableMultiset.SerializedForm
 
SerializedForm(Range<C>, DiscreteDomain<C>) - Constructor for class com.google.common.collect.RegularContiguousSet.SerializedForm
 
SerializedForm(SortedMultiset<E>) - Constructor for class com.google.common.collect.ImmutableSortedMultiset.SerializedForm
 
SerializedForm(Object[]) - Constructor for class com.google.common.collect.ImmutableList.SerializedForm
 
SerializedForm(Object[]) - Constructor for class com.google.common.collect.ImmutableSet.SerializedForm
 
SerializedForm(Object[], Object[], Object[], int[], int[]) - Constructor for class com.google.common.collect.ImmutableTable.SerializedForm
 
SerializedForm(String, int, String) - Constructor for class com.google.common.hash.MessageDigestHashFunction.SerializedForm
 
SerializedForm(Charset) - Constructor for class com.google.common.hash.Funnels.StringCharsetFunnel.SerializedForm
 
SerializedForm(Comparator<? super E>, Object[]) - Constructor for class com.google.common.collect.ImmutableSortedSet.SerializedForm
 
SerializedForm(Map<Class<? extends B>, B>) - Constructor for class com.google.common.collect.MutableClassToInstanceMap.SerializedForm
 
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.JdkPattern
 
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.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.Predicates.SubtypeOfPredicate
 
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 class com.google.common.collect.ComputationException
Deprecated.
 
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.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.ImmutableBiMap
 
serialVersionUID - Static variable in class com.google.common.collect.ImmutableCollection
 
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.ImmutableList
 
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.ImmutableMap
 
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.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.ImmutableMultiset
 
serialVersionUID - Static variable in class com.google.common.collect.ImmutableRangeMap.SerializedForm
 
serialVersionUID - Static variable in class com.google.common.collect.ImmutableRangeMap
 
serialVersionUID - Static variable in class com.google.common.collect.ImmutableSet.SerializedForm
 
serialVersionUID - Static variable in class com.google.common.collect.ImmutableSet
 
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.ImmutableSortedMultiset
 
serialVersionUID - Static variable in class com.google.common.collect.ImmutableSortedSet.SerializedForm
 
serialVersionUID - Static variable in class com.google.common.collect.ImmutableSortedSet
 
serialVersionUID - Static variable in class com.google.common.collect.ImmutableTable.SerializedForm
 
serialVersionUID - Static variable in class com.google.common.collect.ImmutableTable
 
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.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.SerializedForm
 
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 class com.google.common.collect.Ordering.IncomparableValueException
 
serialVersionUID - Static variable in class com.google.common.collect.Range.RangeLexOrdering
 
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.KeySet.SerializedForm
 
serialVersionUID - Static variable in class com.google.common.collect.RegularImmutableMap
 
serialVersionUID - Static variable in class com.google.common.collect.RegularImmutableMap.Values.SerializedForm
 
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 exception class com.google.common.collect.testing.AbstractIteratorTester.PermittedMetaException
 
serialVersionUID - Static variable in exception class com.google.common.collect.testing.AbstractIteratorTester.UnknownElementException
 
serialVersionUID - Static variable in class com.google.common.collect.testing.BaseComparable
 
serialVersionUID - Static variable in class com.google.common.collect.testing.DerivedComparable
 
serialVersionUID - Static variable in exception class com.google.common.collect.testing.features.ConflictingRequirementsException
 
serialVersionUID - Static variable in class com.google.common.collect.testing.features.TesterRequirements
 
serialVersionUID - Static variable in class com.google.common.collect.testing.google.BiMapInverseTester.BiMapPair
 
serialVersionUID - Static variable in class com.google.common.collect.testing.SafeTreeMap
 
serialVersionUID - Static variable in class com.google.common.collect.testing.SafeTreeSet
 
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.BloomFilter
 
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.LongAdder
 
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.math.PairedStats
 
serialVersionUID - Static variable in class com.google.common.math.Stats
 
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
 
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.AtomicDouble
 
serialVersionUID - Static variable in class com.google.common.util.concurrent.AtomicDoubleArray
 
serialVersionUID - Static variable in exception class com.google.common.util.concurrent.ExecutionError
 
serialVersionUID - Static variable in exception class com.google.common.util.concurrent.UncheckedExecutionException
 
serialVersionUID - Static variable in exception class com.google.common.util.concurrent.UncheckedTimeoutException
 
server - Variable in class com.google.common.net.InetAddresses.TeredoInfo
 
SERVER - Static variable in class com.google.common.net.HttpHeaders
The HTTP Server header field name.
SERVER_TIMING - Static variable in class com.google.common.net.HttpHeaders
The HTTP Server-Timing header field name.
service - Variable in class com.google.common.util.concurrent.AbstractScheduledService.CustomScheduler.ReschedulableCallable
The service that is managing this callable.
service - Variable in class com.google.common.util.concurrent.ServiceManager.ServiceListener
 
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_WORKER - Static variable in class com.google.common.net.HttpHeaders
The HTTP Service-Worker header field name.
SERVICE_WORKER_ALLOWED - Static variable in class com.google.common.net.HttpHeaders
The HTTP Service-Worker-Allowed header field name.
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 Class in com.google.common.util.concurrent
The lifecycle states of a service.
ServiceDelegate() - Constructor for class com.google.common.util.concurrent.AbstractScheduledService.ServiceDelegate
 
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 - Exception Class in com.google.common.util.concurrent
This is never thrown but only used for logging.
ServiceManager.FailedService - Exception Class in com.google.common.util.concurrent
 
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 ServiceManager.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.
ServiceManager.ServiceManagerState.AwaitHealthGuard - Class in com.google.common.util.concurrent
 
ServiceManager.ServiceManagerState.StoppedGuard - Class in com.google.common.util.concurrent
 
ServiceManagerBridge - Interface in com.google.common.util.concurrent
Superinterface of ServiceManager to introduce a bridge method for servicesByState(), to ensure binary compatibility with older Guava versions that specified servicesByState() to return ImmutableMultimap.
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.
servicesByState() - Method in interface com.google.common.util.concurrent.ServiceManagerBridge
 
set - Variable in class com.google.common.collect.CollectCollectors.EnumSetAccumulator
 
set - Variable in class com.google.common.collect.Maps.AsMapView
 
set - Variable in class com.google.common.collect.Maps.NavigableAsMapView
 
set - Variable in class com.google.common.collect.testing.AbstractIteratorTester
 
set(double) - Method in class com.google.common.util.concurrent.AtomicDouble
Sets to the given value.
set(int) - Method in class com.google.common.collect.Count
 
set(int, double) - Method in class com.google.common.util.concurrent.AtomicDoubleArray
Atomically sets the element at position i to the given value.
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.ForwardingList
 
set(int, E) - Method in class com.google.common.collect.ImmutableList
Deprecated.
Unsupported operation.
set(int, E) - Method in class com.google.common.collect.Lists.AbstractListWrapper
 
set(int, E) - Method in class com.google.common.collect.Synchronized.SynchronizedList
 
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(int, T) - Method in class com.google.common.collect.Lists.ReverseList
 
set(int, V) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedList
 
set(long) - Method in class com.google.common.hash.BloomFilterStrategies.LockFreeBitArray
Returns true if the bit changed value.
set(E) - Method in class com.google.common.collect.ForwardingListIterator
 
set(E) - Method in class com.google.common.collect.testing.AbstractIteratorTester.MultiExceptionListIterator
 
set(E) - Method in class com.google.common.collect.UnmodifiableListIterator
Deprecated.
Unsupported operation.
set(Map.Entry<K, V>) - Method in class com.google.common.collect.LinkedListMultimap.NodeIterator
 
set(Set<E>, Object) - Static method in class com.google.common.collect.Synchronized
 
set(T) - Method in class com.google.common.collect.TransformedListIterator
 
set(T, int) - Method in class com.google.common.collect.Serialization.FieldSetter
 
set(T, Object) - Method in class com.google.common.collect.Serialization.FieldSetter
 
set(V) - Method in class com.google.common.cache.LocalCache.LoadingValueReference
 
set(V) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedList.WrappedListIterator
 
set(V) - Method in class com.google.common.collect.LinkedListMultimap.ValueForKeyIterator
 
set(V) - Method in class com.google.common.util.concurrent.AbstractFuture
Sets the result of this Future unless this Future has already been cancelled or set (including set asynchronously).
set(V) - Method in class com.google.common.util.concurrent.SettableFuture
 
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.Invokable
setAccessTime(long) - Method in class com.google.common.cache.LocalCache.AbstractReferenceEntry
 
setAccessTime(long) - Method in enum class com.google.common.cache.LocalCache.NullEntry
 
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
 
setAccessTime(long) - Method in interface com.google.common.cache.ReferenceEntry
Sets the entry access time in ns.
SetAddAllTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests addAll operations on a set.
SetAddAllTester() - Constructor for class com.google.common.collect.testing.testers.SetAddAllTester
 
SetAddTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests add operations on a set.
SetAddTester() - Constructor for class com.google.common.collect.testing.testers.SetAddTester
 
setAutoIncrementStep(long, TimeUnit) - Method in class com.google.common.testing.FakeTicker
Sets the increment applied to the ticker whenever it is queried.
setAutoIncrementStep(Duration) - Method in class com.google.common.testing.FakeTicker
Sets the increment applied to the ticker whenever it is queried.
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.AnyOf
 
setBits(BitSet) - Method in class com.google.common.base.CharMatcher.BitSetMatcher
 
setBits(BitSet) - Method in class com.google.common.base.CharMatcher.InRange
 
setBits(BitSet) - Method in class com.google.common.base.CharMatcher.Is
 
setBits(BitSet) - Method in class com.google.common.base.CharMatcher.IsEither
 
setBits(BitSet) - Method in class com.google.common.base.CharMatcher.IsNot
 
setBits(BitSet) - Method in class com.google.common.base.CharMatcher.Negated
 
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.CharMatcher.Whitespace
 
setBits(BitSet) - Method in class com.google.common.base.SmallCharMatcher
 
SetBuilderImpl(int) - Constructor for class com.google.common.collect.ImmutableSet.SetBuilderImpl
 
SetBuilderImpl(ImmutableSet.SetBuilderImpl<E>) - Constructor for class com.google.common.collect.ImmutableSet.SetBuilderImpl
Initializes this SetBuilderImpl with a copy of the deduped elements array from toCopy.
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) - 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) - Method in class com.google.common.collect.EnumMultiset
 
setCount(E, 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) - 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) - Method in class com.google.common.collect.Multisets.UnmodifiableMultiset
 
setCount(E, int) - Method in class com.google.common.collect.Synchronized.SynchronizedMultiset
 
setCount(E, int) - Method in class com.google.common.collect.testing.google.MultisetSetCountConditionallyTester
 
setCount(E, int) - Method in class com.google.common.collect.testing.google.MultisetSetCountUnconditionallyTester
 
setCount(E, int) - Method in class com.google.common.collect.TreeMultiset
 
setCount(E, int, int) - Method in class com.google.common.collect.AbstractMultiset
 
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, int) - Method in class com.google.common.collect.ForwardingMultiset
 
setCount(E, int, int) - Method in class com.google.common.collect.ImmutableMultiset
Deprecated.
Unsupported operation.
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, int) - Method in class com.google.common.collect.Multisets.UnmodifiableMultiset
 
setCount(E, int, int) - Method in class com.google.common.collect.Synchronized.SynchronizedMultiset
 
setCount(E, int, int) - Method in class com.google.common.collect.TreeMultiset
 
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
 
setCountCheckReturnValue(E, int) - Method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
Call the setCount() method under test, and check its return value.
setCountCheckReturnValue(E, int) - Method in class com.google.common.collect.testing.google.MultisetSetCountConditionallyTester
 
setCountCheckReturnValue(E, int) - Method in class com.google.common.collect.testing.google.MultisetSetCountUnconditionallyTester
 
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
setCountNoCheckReturnValue(E, int) - Method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
Call the setCount() method under test, but do not check its return value.
setCountNoCheckReturnValue(E, int) - Method in class com.google.common.collect.testing.google.MultisetSetCountConditionallyTester
 
setCountNoCheckReturnValue(E, int) - Method in class com.google.common.collect.testing.google.MultisetSetCountUnconditionallyTester
 
SetCreationTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests creation (typically through a constructor or static factory method) of a set.
SetCreationTester() - Constructor for class com.google.common.collect.testing.testers.SetCreationTester
 
setDaemon(boolean) - Method in class com.google.common.util.concurrent.ThreadFactoryBuilder
Sets daemon or not for new threads created with this ThreadFactory.
setDefault(Class<T>, T) - Method in class com.google.common.testing.AbstractPackageSanityTests
Sets the default value for type, when dummy value for a parameter of the same type needs to be created in order to invoke a method or constructor.
setDefault(Class<T>, T) - Method in class com.google.common.testing.ClassSanityTester
Sets the default value for type.
setDefault(Class<T>, T) - Method in class com.google.common.testing.NullPointerTester
Sets a default value that can be used for any parameter of type type.
setDelegates(Map<K, V>, Map<V, K>) - Method in class com.google.common.collect.AbstractBiMap
Specifies the delegate maps going in each direction.
setDistinctValues(Class<T>, T, T) - Method in class com.google.common.testing.AbstractPackageSanityTests
Sets two distinct values for type.
setDistinctValues(Class<T>, T, T) - Method in class com.google.common.testing.ClassSanityTester
Sets distinct values for type, so that when a class Foo is tested for Object.equals(java.lang.Object) and Object.hashCode(), and its construction requires a parameter of type, the distinct values of type can be passed as parameters to create Foo instances that are unequal.
setElement(int, E) - Method in class com.google.common.collect.CompactHashSet
 
setEntry(int, int) - Method in class com.google.common.collect.CompactHashMap
 
setEntry(int, int) - Method in class com.google.common.collect.CompactHashSet
 
SetEqualsTester<E> - Class in com.google.common.collect.testing.testers
SetEqualsTester() - Constructor for class com.google.common.collect.testing.testers.SetEqualsTester
 
setException(Throwable) - Method in class com.google.common.cache.LocalCache.LoadingValueReference
 
setException(Throwable) - Method in class com.google.common.util.concurrent.AbstractFuture
Sets the failed result of this Future unless this Future has already been cancelled or set (including set asynchronously).
setException(Throwable) - Method in class com.google.common.util.concurrent.SettableFuture
 
SetFeature - Enum Class in com.google.common.collect.testing.features
Optional features of classes derived from Set.
SetFeature(Feature<? super Set>...) - Constructor for enum class com.google.common.collect.testing.features.SetFeature
 
SetFeature.Require - Annotation Interface in com.google.common.collect.testing.features
 
SetFieldSettersHolder() - Constructor for class com.google.common.collect.ImmutableSetMultimap.SetFieldSettersHolder
 
setFuture(ListenableFuture<? extends V>) - Method in class com.google.common.util.concurrent.AbstractFuture
Sets the result of this Future to match the supplied input Future once the supplied Future is done, unless this Future has already been cancelled or set (including "set asynchronously," defined below).
setFuture(ListenableFuture<? extends V>) - Method in class com.google.common.util.concurrent.SettableFuture
 
SetFuture(AbstractFuture<V>, ListenableFuture<? extends V>) - Constructor for class com.google.common.util.concurrent.AbstractFuture.SetFuture
 
SetGenerators - Class in com.google.common.collect.testing.google
Generators of different types of sets and derived collections from sets.
SetGenerators() - Constructor for class com.google.common.collect.testing.google.SetGenerators
 
SetGenerators.AbstractContiguousSetGenerator - Class in com.google.common.collect.testing.google
 
SetGenerators.ContiguousSetDescendingGenerator - Class in com.google.common.collect.testing.google
 
SetGenerators.ContiguousSetGenerator - Class in com.google.common.collect.testing.google
 
SetGenerators.ContiguousSetHeadsetGenerator - Class in com.google.common.collect.testing.google
 
SetGenerators.ContiguousSetSubsetGenerator - Class in com.google.common.collect.testing.google
 
SetGenerators.ContiguousSetTailsetGenerator - Class in com.google.common.collect.testing.google
 
SetGenerators.DegeneratedImmutableSetGenerator - Class in com.google.common.collect.testing.google
 
SetGenerators.ImmutableSetAsListGenerator - Class in com.google.common.collect.testing.google
 
SetGenerators.ImmutableSetCopyOfGenerator - Class in com.google.common.collect.testing.google
 
SetGenerators.ImmutableSetSizedBuilderGenerator - Class in com.google.common.collect.testing.google
 
SetGenerators.ImmutableSetTooBigBuilderGenerator - Class in com.google.common.collect.testing.google
 
SetGenerators.ImmutableSetTooSmallBuilderGenerator - Class in com.google.common.collect.testing.google
 
SetGenerators.ImmutableSetUnsizedBuilderGenerator - Class in com.google.common.collect.testing.google
 
SetGenerators.ImmutableSetWithBadHashesGenerator - Class in com.google.common.collect.testing.google
 
SetGenerators.ImmutableSortedSetAsListGenerator - Class in com.google.common.collect.testing.google
 
SetGenerators.ImmutableSortedSetAsListSubListGenerator - Class in com.google.common.collect.testing.google
 
SetGenerators.ImmutableSortedSetCopyOfGenerator - Class in com.google.common.collect.testing.google
 
SetGenerators.ImmutableSortedSetDescendingAsListGenerator - Class in com.google.common.collect.testing.google
 
SetGenerators.ImmutableSortedSetDescendingGenerator - Class in com.google.common.collect.testing.google
 
SetGenerators.ImmutableSortedSetExplicitComparator - Class in com.google.common.collect.testing.google
 
SetGenerators.ImmutableSortedSetExplicitSuperclassComparatorGenerator - Class in com.google.common.collect.testing.google
 
SetGenerators.ImmutableSortedSetHeadsetGenerator - Class in com.google.common.collect.testing.google
 
SetGenerators.ImmutableSortedSetReversedOrderGenerator - Class in com.google.common.collect.testing.google
 
SetGenerators.ImmutableSortedSetSubsetAsListGenerator - Class in com.google.common.collect.testing.google
 
SetGenerators.ImmutableSortedSetSubsetAsListSubListGenerator - Class in com.google.common.collect.testing.google
 
SetGenerators.ImmutableSortedSetSubsetGenerator - Class in com.google.common.collect.testing.google
 
SetGenerators.ImmutableSortedSetTailsetGenerator - Class in com.google.common.collect.testing.google
 
SetGenerators.ImmutableSortedSetUnhashableGenerator - Class in com.google.common.collect.testing.google
 
SetGenerators.TestUnhashableSetGenerator - Class in com.google.common.collect.testing.google
 
SetHashCodeTester<E> - Class in com.google.common.collect.testing.testers
SetHashCodeTester() - Constructor for class com.google.common.collect.testing.testers.SetHashCodeTester
 
setHashTableMask(int) - Method in class com.google.common.collect.CompactHashMap
Stores the hash table mask as the number of bits needed to represent an index.
setHashTableMask(int) - Method in class com.google.common.collect.CompactHashSet
Stores the hash table mask as the number of bits needed to represent an index.
setImplementation(Class<T>, Class<? extends T>) - Static method in class com.google.common.testing.ArbitraryInstances
 
setInverse(AbstractBiMap<V, K>) - Method in class com.google.common.collect.AbstractBiMap
 
setKey(int, K) - Method in class com.google.common.collect.CompactHashMap
 
setKeyStrength(LocalCache.Strength) - Method in class com.google.common.cache.CacheBuilder
 
setKeyStrength(MapMakerInternalMap.Strength) - Method in class com.google.common.collect.MapMaker
 
setLink(int, long) - Method in class com.google.common.collect.CompactLinkedHashMap
 
setMap(Map<K, Collection<V>>) - Method in class com.google.common.collect.AbstractMapBasedMultimap
Used during deserialization only.
setMultimap(SetMultimap<K, V>, Object) - Static method in class com.google.common.collect.Synchronized
 
SetMultimap<K,V> - Interface in com.google.common.collect
A Multimap that cannot hold duplicate key-value pairs.
SetMultimapAsMapTester<K,V> - Class in com.google.common.collect.testing.google
Testers for SetMultimap.asMap().
SetMultimapAsMapTester() - Constructor for class com.google.common.collect.testing.google.SetMultimapAsMapTester
 
SetMultimapBuilder() - Constructor for class com.google.common.collect.MultimapBuilder.SetMultimapBuilder
 
SetMultimapEqualsTester<K,V> - Class in com.google.common.collect.testing.google
SetMultimapEqualsTester() - Constructor for class com.google.common.collect.testing.google.SetMultimapEqualsTester
 
SetMultimapPutAllTester<K,V> - Class in com.google.common.collect.testing.google
SetMultimapPutAllTester() - Constructor for class com.google.common.collect.testing.google.SetMultimapPutAllTester
 
SetMultimapPutTester<K,V> - Class in com.google.common.collect.testing.google
SetMultimapPutTester() - Constructor for class com.google.common.collect.testing.google.SetMultimapPutTester
 
SetMultimapReplaceValuesTester<K,V> - Class in com.google.common.collect.testing.google
SetMultimapReplaceValuesTester() - Constructor for class com.google.common.collect.testing.google.SetMultimapReplaceValuesTester
 
SetMultimapTestSuiteBuilder<K,V> - Class in com.google.common.collect.testing.google
Creates, based on your criteria, a JUnit test suite that exhaustively tests a SetMultimap implementation.
SetMultimapTestSuiteBuilder() - Constructor for class com.google.common.collect.testing.google.SetMultimapTestSuiteBuilder
 
SetMultimapTestSuiteBuilder.EntriesGenerator<K,V> - Class in com.google.common.collect.testing.google
 
SetMultimapTestSuiteBuilder.MultimapAsMapGetGenerator<K,V> - Class in com.google.common.collect.testing.google
 
SetMultimapTestSuiteBuilder.MultimapGetGenerator<K,V> - Class in com.google.common.collect.testing.google
 
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.
setNext(AbstractFuture.Waiter) - Method in class com.google.common.util.concurrent.AbstractFuture.Waiter
 
setNextInAccessQueue(ReferenceEntry<Object, Object>) - Method in enum class com.google.common.cache.LocalCache.NullEntry
 
setNextInAccessQueue(ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.AbstractReferenceEntry
 
setNextInAccessQueue(ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.StrongAccessEntry
 
setNextInAccessQueue(ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.StrongAccessWriteEntry
 
setNextInAccessQueue(ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.WeakAccessEntry
 
setNextInAccessQueue(ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.WeakAccessWriteEntry
 
setNextInAccessQueue(ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.WeakEntry
 
setNextInAccessQueue(ReferenceEntry<K, V>) - Method in interface com.google.common.cache.ReferenceEntry
Sets the next entry in the access queue.
setNextInWriteQueue(ReferenceEntry<Object, Object>) - Method in enum class com.google.common.cache.LocalCache.NullEntry
 
setNextInWriteQueue(ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.AbstractReferenceEntry
 
setNextInWriteQueue(ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.StrongAccessWriteEntry
 
setNextInWriteQueue(ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.StrongWriteEntry
 
setNextInWriteQueue(ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.WeakAccessWriteEntry
 
setNextInWriteQueue(ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.WeakEntry
 
setNextInWriteQueue(ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.WeakWriteEntry
 
setNextInWriteQueue(ReferenceEntry<K, V>) - Method in interface com.google.common.cache.ReferenceEntry
Sets the next entry in the write queue.
setOwner(Thread) - Method in class com.google.common.util.concurrent.InterruptibleTask.Blocker
 
setPredecessor(int, int) - Method in class com.google.common.collect.CompactLinkedHashMap
 
setPredecessor(int, int) - Method in class com.google.common.collect.CompactLinkedHashSet
 
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
 
setPreviousInAccessQueue(ReferenceEntry<Object, Object>) - Method in enum class com.google.common.cache.LocalCache.NullEntry
 
setPreviousInAccessQueue(ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.AbstractReferenceEntry
 
setPreviousInAccessQueue(ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.StrongAccessEntry
 
setPreviousInAccessQueue(ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.StrongAccessWriteEntry
 
setPreviousInAccessQueue(ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.WeakAccessEntry
 
setPreviousInAccessQueue(ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.WeakAccessWriteEntry
 
setPreviousInAccessQueue(ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.WeakEntry
 
setPreviousInAccessQueue(ReferenceEntry<K, V>) - Method in interface com.google.common.cache.ReferenceEntry
Sets the previous entry in the access queue.
setPreviousInWriteQueue(ReferenceEntry<Object, Object>) - Method in enum class com.google.common.cache.LocalCache.NullEntry
 
setPreviousInWriteQueue(ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.AbstractReferenceEntry
 
setPreviousInWriteQueue(ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.StrongAccessWriteEntry
 
setPreviousInWriteQueue(ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.StrongWriteEntry
 
setPreviousInWriteQueue(ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.WeakAccessWriteEntry
 
setPreviousInWriteQueue(ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.WeakEntry
 
setPreviousInWriteQueue(ReferenceEntry<K, V>) - Method in class com.google.common.cache.LocalCache.WeakWriteEntry
 
setPreviousInWriteQueue(ReferenceEntry<K, V>) - Method in interface com.google.common.cache.ReferenceEntry
Sets the previous entry in the write queue.
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.
SetRemoveTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests remove operations on a set.
SetRemoveTester() - Constructor for class com.google.common.collect.testing.testers.SetRemoveTester
 
setResult(ListenableFuture<? extends O>) - Method in class com.google.common.util.concurrent.AbstractTransformFuture.AsyncTransformFuture
 
setResult(ListenableFuture<? extends V>) - Method in class com.google.common.util.concurrent.AbstractCatchingFuture.AsyncCatchingFuture
 
setResult(O) - Method in class com.google.common.util.concurrent.AbstractTransformFuture.TransformFuture
 
setResult(T) - Method in class com.google.common.util.concurrent.AbstractCatchingFuture
Template method for subtypes to actually set the result.
setResult(T) - Method in class com.google.common.util.concurrent.AbstractTransformFuture
Template method for subtypes to actually set the result.
setResult(V) - Method in class com.google.common.util.concurrent.AbstractCatchingFuture.CatchingFuture
 
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.
setSucceeds(int, int) - Method in class com.google.common.collect.CompactLinkedHashMap
 
setSucceeds(int, int) - Method in class com.google.common.collect.CompactLinkedHashSet
 
setSuccessor(int, int) - Method in class com.google.common.collect.CompactLinkedHashMap
 
setSuccessor(int, int) - Method in class com.google.common.collect.CompactLinkedHashSet
 
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
 
setTableEntryForTesting(int, MapMakerInternalMap.InternalEntry<K, V, ?>) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Unsafely sets the given index of this segment's internal hash table to be the given entry.
SettableFuture<V> - Class in com.google.common.util.concurrent
SettableFuture() - Constructor for class com.google.common.util.concurrent.SettableFuture
 
SetTestSuiteBuilder<E> - Class in com.google.common.collect.testing
Creates, based on your criteria, a JUnit test suite that exhaustively tests a Set implementation.
SetTestSuiteBuilder() - Constructor for class com.google.common.collect.testing.SetTestSuiteBuilder
 
SetTestSuiteBuilder.ReserializedSetGenerator<E> - Class in com.google.common.collect.testing
 
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.
setUp - Variable in class com.google.common.collect.testing.AbstractTester
 
setUp - Variable in class com.google.common.collect.testing.FeatureSpecificTestSuiteBuilder
 
setUp() - Method in class com.google.common.collect.testing.AbstractContainerTester
 
setUp() - Method in class com.google.common.collect.testing.AbstractTester
 
setUp() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
setUp() - Method in class com.google.common.collect.testing.testers.CollectionRetainAllTester
 
setUp() - Method in class com.google.common.collect.testing.testers.MapPutAllTester
 
setUp() - Method in class com.google.common.collect.testing.testers.MapPutTester
 
setUp() - Method in class com.google.common.collect.testing.testers.NavigableMapNavigationTester
 
setUp() - Method in class com.google.common.collect.testing.testers.NavigableSetNavigationTester
 
setUp() - Method in class com.google.common.collect.testing.testers.SortedMapNavigationTester
 
setUp() - Method in class com.google.common.collect.testing.testers.SortedSetNavigationTester
 
setUp() - Method in class com.google.common.util.concurrent.testing.AbstractListenableFutureTest
 
setValue(int, Map<C, V>) - Method in class com.google.common.collect.ArrayTable.RowMap
 
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.ArrayMap
 
setValue(int, V) - Method in class com.google.common.collect.ArrayTable.Column
 
setValue(int, V) - Method in class com.google.common.collect.ArrayTable.Row
 
setValue(int, V) - Method in class com.google.common.collect.CompactHashMap
 
setValue(ReferenceEntry<K, V>, K, V, long) - Method in class com.google.common.cache.LocalCache.Segment
Sets a new value of an entry.
setValue(MapMakerInternalMap.StrongKeyDummyValueSegment<K>, MapMakerInternalMap.StrongKeyDummyValueEntry<K>, MapMaker.Dummy) - Method in class com.google.common.collect.MapMakerInternalMap.StrongKeyDummyValueEntry.Helper
 
setValue(MapMakerInternalMap.StrongKeyStrongValueSegment<K, V>, MapMakerInternalMap.StrongKeyStrongValueEntry<K, V>, V) - Method in class com.google.common.collect.MapMakerInternalMap.StrongKeyStrongValueEntry.Helper
 
setValue(MapMakerInternalMap.StrongKeyWeakValueSegment<K, V>, MapMakerInternalMap.StrongKeyWeakValueEntry<K, V>, V) - Method in class com.google.common.collect.MapMakerInternalMap.StrongKeyWeakValueEntry.Helper
 
setValue(MapMakerInternalMap.WeakKeyDummyValueSegment<K>, MapMakerInternalMap.WeakKeyDummyValueEntry<K>, MapMaker.Dummy) - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyDummyValueEntry.Helper
 
setValue(MapMakerInternalMap.WeakKeyStrongValueSegment<K, V>, MapMakerInternalMap.WeakKeyStrongValueEntry<K, V>, V) - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyStrongValueEntry.Helper
 
setValue(MapMakerInternalMap.WeakKeyWeakValueSegment<K, V>, MapMakerInternalMap.WeakKeyWeakValueEntry<K, V>, V) - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyWeakValueEntry.Helper
 
setValue(ListenableFuture<V>) - Method in class com.google.common.util.concurrent.CombinedFuture.AsyncCallableInterruptibleTask
 
setValue(E, V) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Sets the value of the given entry.
setValue(S, E, V) - Method in interface com.google.common.collect.MapMakerInternalMap.InternalEntryHelper
Sets the value of the given entry in the given segment to be the given value
setValue(T) - Method in class com.google.common.util.concurrent.CombinedFuture.CombinedFutureInterruptibleTask
 
setValue(V) - Method in class com.google.common.cache.LocalCache.WriteThroughEntry
 
setValue(V) - Method in class com.google.common.collect.AbstractBiMap.BiMapEntry
 
setValue(V) - Method in class com.google.common.collect.AbstractMapEntry
 
setValue(V) - Method in class com.google.common.collect.CompactHashMap.MapEntry
 
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(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.CombinedFuture.CallableInterruptibleTask
 
setValueForTesting(MapMakerInternalMap.InternalEntry<K, V, ?>, V) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Unsafely sets the value of the given entry.
setValueReference(LocalCache.ValueReference<Object, Object>) - Method in enum class com.google.common.cache.LocalCache.NullEntry
 
setValueReference(LocalCache.ValueReference<K, V>) - Method in class com.google.common.cache.LocalCache.AbstractReferenceEntry
 
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(LocalCache.ValueReference<K, V>) - Method in interface com.google.common.cache.ReferenceEntry
Sets the value reference for this entry.
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
 
setWeakValueReferenceForTesting(MapMakerInternalMap.InternalEntry<K, V, ?>, MapMakerInternalMap.WeakValueReference<K, V, ? extends MapMakerInternalMap.InternalEntry<K, V, ?>>) - Method in class com.google.common.collect.MapMakerInternalMap.Segment
Unsafely sets the weak value reference inside the given entry to be the given valueReference
setWeakValueReferenceForTesting(MapMakerInternalMap.InternalEntry<K, V, ?>, MapMakerInternalMap.WeakValueReference<K, V, ? extends MapMakerInternalMap.InternalEntry<K, V, ?>>) - Method in class com.google.common.collect.MapMakerInternalMap.StrongKeyWeakValueSegment
 
setWeakValueReferenceForTesting(MapMakerInternalMap.InternalEntry<K, V, ?>, MapMakerInternalMap.WeakValueReference<K, V, ? extends MapMakerInternalMap.InternalEntry<K, V, ?>>) - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyWeakValueSegment
 
setWriteTime(long) - Method in class com.google.common.cache.LocalCache.AbstractReferenceEntry
 
setWriteTime(long) - Method in enum class com.google.common.cache.LocalCache.NullEntry
 
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
 
setWriteTime(long) - Method in interface com.google.common.cache.ReferenceEntry
Sets the entry write time in ns.
SEVERAL - Enum constant in enum class com.google.common.collect.testing.features.CollectionSize
Test a three-element collection.
SFNT - Static variable in class com.google.common.net.MediaType
RFC 8081 declares font/sfnt to be the correct media type for SFNT, but this may be necessary in certain situations for compatibility.
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_384 - Static variable in class com.google.common.hash.Hashing.Sha384Holder
 
SHA_512 - Static variable in class com.google.common.hash.Hashing.Sha512Holder
 
sha1() - Static method in class com.google.common.hash.Hashing
Deprecated.
If you must interoperate with a system that requires SHA-1, then use this method, despite its deprecation. But if you can choose your hash function, avoid SHA-1, which is neither fast nor secure. As of January 2017, we suggest:
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).
Sha256Holder() - Constructor for class com.google.common.hash.Hashing.Sha256Holder
 
sha384() - Static method in class com.google.common.hash.Hashing
Returns a hash function implementing the SHA-384 algorithm (384 hash bits).
Sha384Holder() - Constructor for class com.google.common.hash.Hashing.Sha384Holder
 
sha512() - Static method in class com.google.common.hash.Hashing
Returns a hash function implementing the SHA-512 algorithm (512 hash bits).
Sha512Holder() - Constructor for class com.google.common.hash.Hashing.Sha512Holder
 
SHARED_SECRETS_CLASSNAME - Static variable in class com.google.common.base.Throwables
SharedSecrets class name to load using reflection
shift - Variable in class com.google.common.hash.Murmur3_32HashFunction.Murmur3_32Hasher
 
SHIFT - Static variable in class com.google.common.base.CharMatcher.Whitespace
 
shiftMix(long) - Static method in class com.google.common.hash.FarmHashFingerprint64
 
shiftMix(long) - Static method in class com.google.common.hash.Fingerprint2011
 
SHOCKWAVE_FLASH - Static variable in class com.google.common.net.MediaType
 
SHORT_MASK - Static variable in class com.google.common.collect.CompactHashing
 
SHORT_MAX_SIZE - Static variable in class com.google.common.collect.CompactHashing
 
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 Class in com.google.common.primitives
 
Shorts.ShortArrayAsList - Class in com.google.common.primitives
 
Shorts.ShortConverter - Class in com.google.common.primitives
 
ShortsMethodsForWeb - Class in com.google.common.primitives
Holder for web specializations of methods of Shorts.
ShortsMethodsForWeb() - Constructor for class com.google.common.primitives.ShortsMethodsForWeb
 
shouldInterrupt - Variable in class com.google.common.util.concurrent.Futures.InCompletionOrderState
 
showCharacter(char) - Static method in class com.google.common.base.CharMatcher
Returns the Java Unicode escape sequence for the given char, in the form "ካ" where "12AB" is the four hexadecimal digits representing the 16-bit code unit.
shutdown - Variable in class com.google.common.util.concurrent.DirectExecutorService
 
shutdown - Variable in class com.google.common.util.concurrent.testing.TestingExecutors.NoOpScheduledExecutorService
 
shutdown() - Method in class com.google.common.util.concurrent.DirectExecutorService
 
shutdown() - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
shutdown() - Method in class com.google.common.util.concurrent.MoreExecutors.ListeningDecorator
 
shutdown() - Method in class com.google.common.util.concurrent.testing.SameThreadScheduledExecutorService
 
shutdown() - Method in class com.google.common.util.concurrent.testing.TestingExecutors.NoOpScheduledExecutorService
 
shutdown() - Method in class com.google.common.util.concurrent.WrappingExecutorService
 
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.
shutdownAndAwaitTermination(ExecutorService, long, TimeUnit) - Static method in class com.google.common.util.concurrent.MoreExecutors
Shuts down the given executor service gradually, first disabling new submissions and later, if necessary, cancelling remaining tasks.
shutdownAndAwaitTermination(ExecutorService, Duration) - Static method in class com.google.common.util.concurrent.MoreExecutors
Shuts down the given executor service gradually, first disabling new submissions and later, if necessary, cancelling remaining tasks.
shutdownNow() - Method in class com.google.common.util.concurrent.DirectExecutorService
 
shutdownNow() - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
shutdownNow() - Method in class com.google.common.util.concurrent.MoreExecutors.ListeningDecorator
 
shutdownNow() - Method in class com.google.common.util.concurrent.testing.SameThreadScheduledExecutorService
 
shutdownNow() - Method in class com.google.common.util.concurrent.testing.TestingExecutors.NoOpScheduledExecutorService
 
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.
SIEVE_30 - Static variable in class com.google.common.math.LongMath
 
sign(BigDecimal) - Method in class com.google.common.math.BigDecimalMath.BigDecimalToDoubleRounder
 
sign(BigInteger) - Method in class com.google.common.math.BigIntegerMath.BigIntegerToDoubleRounder
 
sign(X) - Method in class com.google.common.math.ToDoubleRounder
Returns the sign of x: either -1, 0, or 1.
SIGN_MASK - Static variable in class com.google.common.math.DoubleUtils
 
signal() - Method in class com.google.common.util.concurrent.ForwardingCondition
 
signalAll() - Method in class com.google.common.util.concurrent.ForwardingCondition
 
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.
Signature(Method) - Constructor for class com.google.common.testing.NullPointerTester.Signature
 
Signature(String, ImmutableList<Class<?>>) - Constructor for class com.google.common.testing.NullPointerTester.Signature
 
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 Class 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
 
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
 
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
 
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.
singleByte - Variable in class com.google.common.io.ReaderInputStream
 
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
 
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
 
SingletonImmutableTable<R,C,V> - Class in com.google.common.collect
An implementation of ImmutableTable that holds a single cell.
SingletonImmutableTable(Table.Cell<R, C, V>) - Constructor for class com.google.common.collect.SingletonImmutableTable
 
SingletonImmutableTable(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.
SingletonIterator(T) - Constructor for class com.google.common.collect.Iterators.SingletonIterator
 
singleValue - Variable in class com.google.common.collect.SingletonImmutableBiMap
 
singleValue - Variable in class com.google.common.collect.SingletonImmutableTable
 
singleWidth() - Static method in class com.google.common.base.CharMatcher
Deprecated.
Many such characters are supplementary characters; see the class documentation.
SingleWidth() - Constructor for class com.google.common.base.CharMatcher.SingleWidth
 
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.SipHashFunction
 
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.
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 - Variable in class com.google.common.collect.AbstractIndexedListIterator
 
size - Variable in class com.google.common.collect.AbstractMapBasedMultiset
 
size - Variable in class com.google.common.collect.Collections2.OrderedPermutationCollection
 
size - Variable in class com.google.common.collect.CompactHashMap
The number of elements contained in the set.
size - Variable in class com.google.common.collect.CompactHashSet
The number of elements contained in the set.
size - Variable in class com.google.common.collect.DenseImmutableTable.ImmutableArrayMap
 
size - Variable in class com.google.common.collect.EnumMultiset
 
size - Variable in class com.google.common.collect.HashBiMap
 
size - Variable in class com.google.common.collect.ImmutableList.Builder
 
size - Variable in class com.google.common.collect.ImmutableMap.Builder
 
size - Variable in class com.google.common.collect.ImmutableMultimap
 
size - Variable in class com.google.common.collect.ImmutableRangeSet.AsSet
 
size - Variable in class com.google.common.collect.ImmutableRangeSet.ComplementRanges
 
size - Variable in class com.google.common.collect.JdkBackedImmutableMultiset
 
size - Variable in class com.google.common.collect.LinkedHashMultimap.ValueSet
 
size - Variable in class com.google.common.collect.LinkedListMultimap
 
size - Variable in class com.google.common.collect.Lists.Partition
 
size - Variable in class com.google.common.collect.MinMaxPriorityQueue
 
size - Variable in class com.google.common.collect.RegularImmutableMultiset
 
size - Variable in class com.google.common.util.concurrent.Striped.LargeLazyStriped
 
size - Variable in class com.google.common.util.concurrent.Striped.SmallLazyStriped
 
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() - 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() - 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.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() - 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.CompactHashMap
 
size() - Method in class com.google.common.collect.CompactHashSet
 
size() - Method in class com.google.common.collect.ConcurrentHashMultiset
Returns the total number of all occurrences of all elements in this multiset.
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.EnumMultiset
 
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() - Method in class com.google.common.collect.HashBiMap
 
size() - Method in class com.google.common.collect.ImmutableAsList
 
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() - 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() - 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.ElementSet
 
size() - Method in class com.google.common.collect.ImmutableMultiset.EntrySet
 
size() - Method in class com.google.common.collect.ImmutableRangeSet.AsSet
 
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() - Method in class com.google.common.collect.JdkBackedImmutableBiMap.InverseEntries
 
size() - Method in class com.google.common.collect.JdkBackedImmutableBiMap
 
size() - Method in class com.google.common.collect.JdkBackedImmutableMap
 
size() - Method in class com.google.common.collect.JdkBackedImmutableMultiset
 
size() - Method in class com.google.common.collect.JdkBackedImmutableSet
 
size() - Method in class com.google.common.collect.LinkedHashMultimap.ValueSet
 
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() - 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.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.IteratorBasedAbstractMap
 
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() - 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
 
size() - Method in class com.google.common.collect.Multimaps.MapMultimap
 
size() - Method in class com.google.common.collect.Multimaps.TransformedEntriesMultimap
 
size() - Method in interface com.google.common.collect.Multiset
Returns the total number of all occurrences of all elements in this multiset.
size() - Method in class com.google.common.collect.Multisets.ElementSet
 
size() - Method in class com.google.common.collect.Multisets.ViewMultiset
 
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() - Method in class com.google.common.collect.RegularImmutableList
 
size() - Method in class com.google.common.collect.RegularImmutableMap.KeySet
 
size() - Method in class com.google.common.collect.RegularImmutableMap
 
size() - Method in class com.google.common.collect.RegularImmutableMap.Values
 
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
 
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 class com.google.common.collect.Synchronized.SynchronizedTable
 
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.testing.MinimalCollection
 
size() - Method in class com.google.common.collect.testing.SafeTreeMap
 
size() - Method in class com.google.common.collect.testing.SafeTreeSet
 
size() - Method in class com.google.common.collect.TreeMultiset
 
size() - Method in class com.google.common.collect.TreeRangeMap.AsMapOfRanges
 
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.graph.EdgesConnecting
 
size() - Method in class com.google.common.graph.IncidentEdgeSet
 
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, even if doing so requires opening and traversing an entire stream.
size() - Method in class com.google.common.io.Files.FileByteSource
 
size() - Method in class com.google.common.io.MoreFiles.PathByteSource
 
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.ImmutableDoubleArray.AsList
 
size() - Method in class com.google.common.primitives.ImmutableIntArray.AsList
 
size() - Method in class com.google.common.primitives.ImmutableLongArray.AsList
 
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() - 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() - Method in class com.google.common.util.concurrent.Striped.SmallLazyStriped
 
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 - Enum constant in enum class com.google.common.cache.RemovalCause
The entry was evicted due to size constraints.
SIZE - Enum constant in enum class com.google.common.collect.TreeMultiset.Aggregate
 
SIZE_FIELD_SETTER - Static variable in class com.google.common.collect.ImmutableMultimap.FieldSettersHolder
 
sizeIfKnown() - Method in class com.google.common.io.ByteSource.ByteArrayByteSource
 
sizeIfKnown() - Method in class com.google.common.io.ByteSource.ConcatenatedByteSource
 
sizeIfKnown() - Method in class com.google.common.io.ByteSource
Returns the size of this source in bytes, if the size can be easily determined without actually opening the data stream.
sizeIfKnown() - Method in class com.google.common.io.ByteSource.SlicedByteSource
 
sizeIfKnown() - Method in class com.google.common.io.Files.FileByteSource
 
sizeIfKnown() - Method in class com.google.common.io.MoreFiles.PathByteSource
 
SKETCHUP - Static variable in class com.google.common.net.MediaType
skp files produced by the 3D Modeling software SketchUp
skip(int) - Method in class com.google.common.collect.FluentIterable
Returns a view of this fluent 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
 
skip(Iterable<T>, int) - Static method in class com.google.common.collect.Iterables
Returns a view of iterable that skips its first numberToSkip elements.
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
 
skipCollectionTests() - Method in class com.google.common.collect.testing.QueueTestSuiteBuilder
Specify whether to skip the general collection tests.
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.
skipSafely(InputStream, long) - Static method in class com.google.common.io.ByteStreams
Attempts to skip up to n bytes from the given input stream, but not more than in.available() bytes.
skipUpTo(InputStream, long) - Static method in class com.google.common.io.ByteStreams
Discards up to n bytes of data from the input stream.
SleepingStopwatch() - Constructor for class com.google.common.util.concurrent.RateLimiter.SleepingStopwatch
Constructor for use by subclasses.
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.
sleepUninterruptibly(Duration) - 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.ByteArrayByteSource
 
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.math.LinearTransformation.RegularLinearTransformation
 
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)
slope() - Method in class com.google.common.math.LinearTransformation.NaNLinearTransformation
 
slope() - Method in class com.google.common.math.LinearTransformation.RegularLinearTransformation
 
slope() - Method in class com.google.common.math.LinearTransformation
Returns the slope of the transformation, i.e.
slope() - Method in class com.google.common.math.LinearTransformation.VerticalLinearTransformation
 
sloppyTearDown() - Method in class com.google.common.testing.SloppyTearDown
 
SloppyTearDown - Class in com.google.common.testing
Simple utility for when you want to create a TearDown that may throw an exception but should not fail a test when it does.
SloppyTearDown() - Constructor for class com.google.common.testing.SloppyTearDown
 
SMALL - Enum constant in enum class com.google.common.math.LongMath.MillerRabinTester
Works for inputs ≤ FLOOR_SQRT_MAX_LONG.
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 where coldInterval = coldFactor * stableInterval.
SmoothWarmingUp(RateLimiter.SleepingStopwatch, long, TimeUnit, double) - Constructor for class com.google.common.util.concurrent.SmoothRateLimiter.SmoothWarmingUp
 
snapshot - Variable in class com.google.common.util.concurrent.AbstractService
The current state of the service.
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() - Method in class com.google.common.math.PairedStatsAccumulator
Returns an immutable snapshot of the current statistics.
snapshot() - Method in class com.google.common.math.StatsAccumulator
Returns an immutable snapshot of the current statistics.
sneakyThrow(Throwable) - Static method in class com.google.common.collect.Streams
Throws an undeclared checked exception.
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.
SOAP_XML_UTF_8 - Static variable in class com.google.common.net.MediaType
As described in RFC 3902, this constant (application/soap+xml) is used to identify SOAP 1.2 message envelopes that have been serialized with XML 1.0.
SOFT - Enum constant in enum class com.google.common.cache.LocalCache.Strength
 
SoftValueReference(ReferenceQueue<V>, V, ReferenceEntry<K, V>) - Constructor for class com.google.common.cache.LocalCache.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).
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.
someRawTypeIsSubclassOf(Class<?>) - Method in class com.google.common.reflect.TypeToken
 
sort(byte[]) - Static method in class com.google.common.primitives.UnsignedBytes
Sorts the array, treating its elements as unsigned bytes.
sort(byte[], int, int) - Static method in class com.google.common.primitives.UnsignedBytes
Sorts the array between fromIndex inclusive and toIndex exclusive, treating its elements as unsigned bytes.
sort(int[]) - Static method in class com.google.common.primitives.UnsignedInts
Sorts the array, treating its elements as unsigned 32-bit integers.
sort(int[], int, int) - Static method in class com.google.common.primitives.UnsignedInts
Sorts the array between fromIndex inclusive and toIndex exclusive, treating its elements as unsigned 32-bit integers.
sort(long[]) - Static method in class com.google.common.primitives.UnsignedLongs
Sorts the array, treating its elements as unsigned 64-bit integers.
sort(long[], int, int) - Static method in class com.google.common.primitives.UnsignedLongs
Sorts the array between fromIndex inclusive and toIndex exclusive, treating its elements as unsigned 64-bit integers.
sort(Comparator<? super E>) - Method in class com.google.common.collect.ImmutableList
Deprecated.
Unsupported operation.
sort(Comparator<? super E>) - Method in class com.google.common.collect.Synchronized.SynchronizedList
 
sortAndDedup() - Method in class com.google.common.collect.ImmutableSortedSet.Builder
 
sortDescending(byte[]) - Static method in class com.google.common.primitives.SignedBytes
Sorts the elements of array in descending order.
sortDescending(byte[]) - Static method in class com.google.common.primitives.UnsignedBytes
Sorts the elements of array in descending order, interpreting them as unsigned 8-bit integers.
sortDescending(byte[], int, int) - Static method in class com.google.common.primitives.SignedBytes
Sorts the elements of array between fromIndex inclusive and toIndex exclusive in descending order.
sortDescending(byte[], int, int) - Static method in class com.google.common.primitives.UnsignedBytes
Sorts the elements of array between fromIndex inclusive and toIndex exclusive in descending order, interpreting them as unsigned 8-bit integers.
sortDescending(char[]) - Static method in class com.google.common.primitives.Chars
Sorts the elements of array in descending order.
sortDescending(char[], int, int) - Static method in class com.google.common.primitives.Chars
Sorts the elements of array between fromIndex inclusive and toIndex exclusive in descending order.
sortDescending(double[]) - Static method in class com.google.common.primitives.Doubles
Sorts the elements of array in descending order.
sortDescending(double[], int, int) - Static method in class com.google.common.primitives.Doubles
Sorts the elements of array between fromIndex inclusive and toIndex exclusive in descending order.
sortDescending(float[]) - Static method in class com.google.common.primitives.Floats
Sorts the elements of array in descending order.
sortDescending(float[], int, int) - Static method in class com.google.common.primitives.Floats
Sorts the elements of array between fromIndex inclusive and toIndex exclusive in descending order.
sortDescending(int[]) - Static method in class com.google.common.primitives.Ints
Sorts the elements of array in descending order.
sortDescending(int[]) - Static method in class com.google.common.primitives.UnsignedInts
Sorts the elements of array in descending order, interpreting them as unsigned 32-bit integers.
sortDescending(int[], int, int) - Static method in class com.google.common.primitives.Ints
Sorts the elements of array between fromIndex inclusive and toIndex exclusive in descending order.
sortDescending(int[], int, int) - Static method in class com.google.common.primitives.UnsignedInts
Sorts the elements of array between fromIndex inclusive and toIndex exclusive in descending order, interpreting them as unsigned 32-bit integers.
sortDescending(long[]) - Static method in class com.google.common.primitives.Longs
Sorts the elements of array in descending order.
sortDescending(long[]) - Static method in class com.google.common.primitives.UnsignedLongs
Sorts the elements of array in descending order, interpreting them as unsigned 64-bit integers.
sortDescending(long[], int, int) - Static method in class com.google.common.primitives.Longs
Sorts the elements of array between fromIndex inclusive and toIndex exclusive in descending order.
sortDescending(long[], int, int) - Static method in class com.google.common.primitives.UnsignedLongs
Sorts the elements of array between fromIndex inclusive and toIndex exclusive in descending order, interpreting them as unsigned 64-bit integers.
sortDescending(short[]) - Static method in class com.google.common.primitives.Shorts
Sorts the elements of array in descending order.
sortDescending(short[], int, int) - Static method in class com.google.common.primitives.Shorts
Sorts the elements of array between fromIndex inclusive and toIndex exclusive in descending order.
sorted(Comparator<S>) - Static method in class com.google.common.graph.ElementOrder
Returns an instance which specifies that the ordering of the elements is guaranteed to be determined by comparator.
SORTED - Enum constant in enum class com.google.common.graph.ElementOrder.Type
 
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.
sortedCopyOf(Iterable<? extends E>) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing the given elements, sorted according to their natural order.
sortedCopyOf(Comparator<? super E>, Iterable<? extends E>) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing the given elements, in sorted order relative to the specified comparator.
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() - Constructor for class com.google.common.collect.Maps.FilteredEntrySortedMap.SortedKeySet
 
SortedKeySet(SortedMap<K, Collection<V>>) - Constructor for class com.google.common.collect.AbstractMapBasedMultimap.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 Class 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 Class 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
 
SortedMapGenerators - Class in com.google.common.collect.testing.google
Generators of sorted maps and derived collections.
SortedMapGenerators() - Constructor for class com.google.common.collect.testing.google.SortedMapGenerators
 
SortedMapGenerators.ImmutableSortedMapCopyOfEntriesGenerator - Class in com.google.common.collect.testing.google
 
SortedMapGenerators.ImmutableSortedMapEntryListGenerator - Class in com.google.common.collect.testing.google
 
SortedMapGenerators.ImmutableSortedMapGenerator - Class in com.google.common.collect.testing.google
 
SortedMapGenerators.ImmutableSortedMapKeyListGenerator - Class in com.google.common.collect.testing.google
 
SortedMapGenerators.ImmutableSortedMapValueListGenerator - Class in com.google.common.collect.testing.google
 
SortedMapInterfaceTest<K,V> - Class in com.google.common.collect.testing
Tests representing the contract of SortedMap.
SortedMapInterfaceTest(boolean, boolean, boolean, boolean, boolean) - Constructor for class com.google.common.collect.testing.SortedMapInterfaceTest
 
SortedMapNavigationTester<K,V> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests operations on a SortedMap.
SortedMapNavigationTester() - Constructor for class com.google.common.collect.testing.testers.SortedMapNavigationTester
 
SortedMapSubmapTestMapGenerator(TestSortedMapGenerator<K, V>, DerivedCollectionGenerators.Bound, DerivedCollectionGenerators.Bound) - Constructor for class com.google.common.collect.testing.DerivedCollectionGenerators.SortedMapSubmapTestMapGenerator
 
SortedMapTestSuiteBuilder<K,V> - Class in com.google.common.collect.testing
Creates, based on your criteria, a JUnit test suite that exhaustively tests a SortedMap implementation.
SortedMapTestSuiteBuilder() - Constructor for class com.google.common.collect.testing.SortedMapTestSuiteBuilder
 
SortedMapTestSuiteBuilder.NoRecurse - Enum Class in com.google.common.collect.testing
To avoid infinite recursion, test suites with these marker features won't have derived suites created for them.
sortedMultiset - Variable in class com.google.common.collect.testing.google.MultisetNavigationTester
 
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().
SortedMultisetTestSuiteBuilder<E> - Class in com.google.common.collect.testing.google
Creates, based on your criteria, a JUnit test suite that exhaustively tests a SortedMultiset implementation.
SortedMultisetTestSuiteBuilder() - Constructor for class com.google.common.collect.testing.google.SortedMultisetTestSuiteBuilder
 
SortedMultisetTestSuiteBuilder.Bound - Enum Class in com.google.common.collect.testing.google
Two bounds (from and to) define how to build a subMultiset.
SortedMultisetTestSuiteBuilder.ForwardingTestMultisetGenerator<E> - Class in com.google.common.collect.testing.google
 
SortedMultisetTestSuiteBuilder.NoRecurse - Enum Class in com.google.common.collect.testing.google
To avoid infinite recursion, test suites with these marker features won't have derived suites created for them.
sortedSet - Variable in class com.google.common.collect.testing.testers.SortedSetNavigationTester
 
sortedSet(SortedSet<E>, Object) - Static method in class com.google.common.collect.Synchronized
 
sortedSetMultimap(SortedSetMultimap<K, V>, 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.
SortedSetMultimapAsMapTester<K,V> - Class in com.google.common.collect.testing.google
SortedSetMultimapAsMapTester() - Constructor for class com.google.common.collect.testing.google.SortedSetMultimapAsMapTester
 
SortedSetMultimapBuilder() - Constructor for class com.google.common.collect.MultimapBuilder.SortedSetMultimapBuilder
 
SortedSetMultimapGetTester<K,V> - Class in com.google.common.collect.testing.google
SortedSetMultimapGetTester() - Constructor for class com.google.common.collect.testing.google.SortedSetMultimapGetTester
 
SortedSetMultimapTestSuiteBuilder<K,V> - Class in com.google.common.collect.testing.google
Creates, based on your criteria, a JUnit test suite that exhaustively tests a SortedSetMultimap implementation.
SortedSetMultimapTestSuiteBuilder() - Constructor for class com.google.common.collect.testing.google.SortedSetMultimapTestSuiteBuilder
 
SortedSetNavigationTester<E> - Class in com.google.common.collect.testing.testers
A generic JUnit test which tests operations on a SortedSet.
SortedSetNavigationTester() - Constructor for class com.google.common.collect.testing.testers.SortedSetNavigationTester
 
SortedSetSubsetTestSetGenerator(TestSortedSetGenerator<E>, DerivedCollectionGenerators.Bound, DerivedCollectionGenerators.Bound) - Constructor for class com.google.common.collect.testing.DerivedCollectionGenerators.SortedSetSubsetTestSetGenerator
 
SortedSetTestSuiteBuilder<E> - Class in com.google.common.collect.testing
Creates, based on your criteria, a JUnit test suite that exhaustively tests a SortedSet implementation.
SortedSetTestSuiteBuilder() - Constructor for class com.google.common.collect.testing.SortedSetTestSuiteBuilder
 
sortKeysByValue(Map<K, V>, Comparator<? super V>) - Static method in class com.google.common.reflect.TypeToken.TypeCollector
 
source - Variable in exception class com.google.common.collect.testing.features.ConflictingRequirementsException
 
source - Variable in class com.google.common.eventbus.DeadEvent
 
source - Variable in class com.google.common.io.FileBackedOutputStream
 
source() - Method in class com.google.common.graph.EndpointPair.Ordered
 
source() - Method in class com.google.common.graph.EndpointPair
If this EndpointPair EndpointPair.isOrdered(), returns the node which is the source.
source() - Method in class com.google.common.graph.EndpointPair.Unordered
 
SOURCE_MAP - Static variable in class com.google.common.net.HttpHeaders
The HTTP SourceMap header field name.
sourceFormat - Variable in class com.google.common.base.CaseFormat.StringConverter
 
sourceNodeFn(Network<N, E>) - Static method in class com.google.common.graph.ImmutableNetwork
 
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() - 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
 
span(Range<C>) - Method in class com.google.common.collect.Range
Returns the minimal range that encloses both this range and other.
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().
SPIN_THRESHOLD_NANOS - Static variable in class com.google.common.util.concurrent.AbstractFuture
 
split(Cut<K>) - Method in class com.google.common.collect.TreeRangeMap
 
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.
spliterator - Variable in class com.google.common.collect.testing.SpliteratorTester.GeneralSpliterator
 
spliterator() - Method in class com.google.common.collect.AbstractMapBasedMultimap.AsMap.AsMapEntries
 
spliterator() - Method in class com.google.common.collect.AbstractMapBasedMultimap.KeySet
 
spliterator() - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection
 
spliterator() - Method in class com.google.common.collect.AbstractMultimap.Entries
 
spliterator() - Method in class com.google.common.collect.AbstractMultimap.Values
 
spliterator() - Method in class com.google.common.collect.AbstractTable.CellSet
 
spliterator() - Method in class com.google.common.collect.AbstractTable.Values
 
spliterator() - Method in class com.google.common.collect.Collections2.FilteredCollection
 
spliterator() - Method in class com.google.common.collect.Collections2.TransformedCollection
 
spliterator() - Method in class com.google.common.collect.CompactHashMap.EntrySetView
 
spliterator() - Method in class com.google.common.collect.CompactHashMap.KeySetView
 
spliterator() - Method in class com.google.common.collect.CompactHashMap.ValuesView
 
spliterator() - Method in class com.google.common.collect.CompactHashSet
 
spliterator() - Method in class com.google.common.collect.CompactLinkedHashSet
 
spliterator() - Method in class com.google.common.collect.ImmutableCollection
 
spliterator() - Method in class com.google.common.collect.ImmutableEnumSet
 
spliterator() - Method in class com.google.common.collect.ImmutableList
 
spliterator() - Method in class com.google.common.collect.ImmutableMapEntrySet.RegularEntrySet
 
spliterator() - Method in class com.google.common.collect.ImmutableMapKeySet
 
spliterator() - Method in class com.google.common.collect.ImmutableMapValues
 
spliterator() - Method in class com.google.common.collect.ImmutableSet.Indexed
 
spliterator() - Method in class com.google.common.collect.ImmutableSortedAsList
 
spliterator() - Method in class com.google.common.collect.ImmutableSortedSet
 
spliterator() - Method in class com.google.common.collect.IndexedImmutableSet
 
spliterator() - Method in class com.google.common.collect.Iterables.UnmodifiableIterable
 
spliterator() - Method in class com.google.common.collect.Multimaps.Keys
 
spliterator() - Method in interface com.google.common.collect.Multiset
 
spliterator() - Method in class com.google.common.collect.RegularImmutableList
 
spliterator() - Method in class com.google.common.collect.RegularImmutableSet
 
spliterator() - Method in class com.google.common.collect.RegularImmutableSortedSet
 
spliterator() - Method in class com.google.common.collect.SingletonImmutableList
 
spliterator() - Method in class com.google.common.collect.Synchronized.SynchronizedCollection
 
spliterator() - Method in class com.google.common.primitives.Doubles.DoubleArrayAsList
 
spliterator() - Method in class com.google.common.primitives.ImmutableDoubleArray.AsList
 
spliterator() - Method in class com.google.common.primitives.ImmutableDoubleArray
 
spliterator() - Method in class com.google.common.primitives.ImmutableIntArray.AsList
 
spliterator() - Method in class com.google.common.primitives.ImmutableIntArray
 
spliterator() - Method in class com.google.common.primitives.ImmutableLongArray.AsList
 
spliterator() - Method in class com.google.common.primitives.ImmutableLongArray
 
spliterator() - Method in class com.google.common.primitives.Ints.IntArrayAsList
 
spliterator() - Method in class com.google.common.primitives.Longs.LongArrayAsList
 
SPLITERATOR_CHARACTERISTICS - Static variable in class com.google.common.collect.ImmutableCollection
 
SPLITERATOR_CHARACTERISTICS - Static variable in class com.google.common.collect.ImmutableSet
 
SPLITERATOR_CHARACTERISTICS - Static variable in class com.google.common.collect.ImmutableSortedSet
 
SpliteratorDecompositionStrategy() - Constructor for enum class com.google.common.collect.testing.SpliteratorTester.SpliteratorDecompositionStrategy
 
spliteratorImpl(Multiset<E>) - Static method in class com.google.common.collect.Multisets
 
spliteratorOfPrimitive - Variable in class com.google.common.collect.testing.SpliteratorTester.GeneralSpliteratorOfPrimitive
 
spliteratorSuppliers - Variable in class com.google.common.collect.testing.SpliteratorTester
 
SpliteratorTester<E> - Class in com.google.common.collect.testing
Tester for Spliterator implementations.
SpliteratorTester(ImmutableSet<Supplier<SpliteratorTester.GeneralSpliterator<E>>>) - Constructor for class com.google.common.collect.testing.SpliteratorTester
 
SpliteratorTester.GeneralSpliterator<E> - Class in com.google.common.collect.testing
 
SpliteratorTester.GeneralSpliteratorOfObject<E> - Class in com.google.common.collect.testing
 
SpliteratorTester.GeneralSpliteratorOfPrimitive<E,C,S> - Class in com.google.common.collect.testing
 
SpliteratorTester.Ordered - Interface in com.google.common.collect.testing
Return type from "contains the following elements" assertions.
SpliteratorTester.SpliteratorDecompositionStrategy - Enum Class in com.google.common.collect.testing
Different ways of decomposing a Spliterator, all of which must produce the same elements (up to ordering, if Spliterator.ORDERED is not present).
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.
splitToStream(CharSequence) - Method in class com.google.common.base.Splitter
Splits sequence into string components and makes them available through an Stream, which may be lazily evaluated.
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.
sqrt(BigInteger, RoundingMode) - Static method in class com.google.common.math.BigIntegerMath
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(int) - Static method in class com.google.common.math.IntMath
 
sqrtFloor(BigInteger) - Static method in class com.google.common.math.BigIntegerMath
 
squareMod(long, long) - Method in enum class com.google.common.math.LongMath.MillerRabinTester
Returns a^2 mod m.
stable() - Static method in class com.google.common.graph.ElementOrder
Returns an instance which specifies that ordering is guaranteed to be always be the same across iterations, and across releases.
STABLE - Enum constant in enum class com.google.common.graph.ElementOrder.Type
 
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.TreeTraverser.PostOrderIterator
Deprecated.
 
stack - Variable in class com.google.common.collect.TreeTraverser.PreOrderIterator
Deprecated.
 
stack - Variable in class com.google.common.io.Closer
 
stack - Variable in class com.google.common.testing.TearDownStack
 
stackWithLastReturnedElementAtTop - Variable in class com.google.common.collect.testing.AbstractIteratorTester.MultiExceptionListIterator
AbstractIteratorTester.MultiExceptionListIterator.nextElements if next() was called more recently then previous, AbstractIteratorTester.MultiExceptionListIterator.previousElements if the reverse is true, or -- overriding both of these -- null if remove() or add() has been called more recently than either.
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(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.ForwardingCollection
standardAddAll(Collection<? extends E>) - Method in class com.google.common.collect.ForwardingMultiset
StandardBaseEncoding(BaseEncoding.Alphabet, Character) - Constructor for class com.google.common.io.BaseEncoding.StandardBaseEncoding
 
StandardBaseEncoding(String, String, 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 ForwardingMultiset.equals(java.lang.Object) 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.
StandardMutableGraph<N> - Class in com.google.common.graph
Standard implementation of MutableGraph that supports both directed and undirected graphs.
StandardMutableGraph(AbstractGraphBuilder<? super N>) - Constructor for class com.google.common.graph.StandardMutableGraph
Constructs a MutableGraph with the properties specified in builder.
StandardMutableNetwork<N,E> - Class in com.google.common.graph
Standard implementation of MutableNetwork that supports both directed and undirected graphs.
StandardMutableNetwork(NetworkBuilder<? super N, ? super E>) - Constructor for class com.google.common.graph.StandardMutableNetwork
Constructs a mutable graph with the properties specified in builder.
StandardMutableValueGraph<N,V> - Class in com.google.common.graph
Standard implementation of MutableValueGraph that supports both directed and undirected graphs.
StandardMutableValueGraph(AbstractGraphBuilder<? super N>) - Constructor for class com.google.common.graph.StandardMutableValueGraph
Constructs a mutable graph with the properties specified in builder.
StandardNavigableKeySet() - Constructor for class com.google.common.collect.ForwardingNavigableMap.StandardNavigableKeySet
Constructor for use by subclasses.
StandardNetwork<N,E> - Class in com.google.common.graph
Standard implementation of Network that supports the options supplied by NetworkBuilder.
StandardNetwork(NetworkBuilder<? super N, ? super E>) - Constructor for class com.google.common.graph.StandardNetwork
Constructs a graph with the properties specified in builder.
StandardNetwork(NetworkBuilder<? super N, ? super E>, Map<N, NetworkConnections<N, E>>, Map<E, N>) - Constructor for class com.google.common.graph.StandardNetwork
Constructs a graph with the properties specified in builder, initialized with the given node and edge maps.
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 Class in com.google.common.base
StandardSystemProperty(String) - Constructor for enum class 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.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() .
StandardValueGraph<N,V> - Class in com.google.common.graph
Standard implementation of ValueGraph that supports the options supplied by AbstractGraphBuilder.
StandardValueGraph(AbstractGraphBuilder<? super N>) - Constructor for class com.google.common.graph.StandardValueGraph
Constructs a graph with the properties specified in builder.
StandardValueGraph(AbstractGraphBuilder<? super N>, Map<N, GraphConnections<N, V>>, long) - Constructor for class com.google.common.graph.StandardValueGraph
Constructs a graph with the properties specified in builder, initialized with the given node map.
StandardValues() - Constructor for class com.google.common.collect.ForwardingMap.StandardValues
Constructor for use by subclasses.
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.ImmutableDoubleArray
 
start - Variable in class com.google.common.primitives.ImmutableIntArray
 
start - Variable in class com.google.common.primitives.ImmutableLongArray
 
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
 
start() - Method in class com.google.common.base.CommonMatcher
 
start() - Method in class com.google.common.base.JdkPattern.JdkMatcher
 
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.
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.
startDraining(boolean) - Method in class com.google.common.io.ReaderInputStream
Flips the buffer output buffer so we can start reading bytes from it.
STARTED - Enum constant in enum class com.google.common.util.concurrent.ExecutionSequencer.RunningState
 
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.
startInclusive - Variable in class com.google.common.base.CharMatcher.InRange
 
startIndex - Variable in class com.google.common.collect.testing.AbstractIteratorTester
 
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 - Enum constant in enum class com.google.common.util.concurrent.Service.State
A service in this state is transitioning to Service.State.RUNNING.
STARTING_EVENT - Static variable in class com.google.common.util.concurrent.AbstractService
 
Starting a pipeline - Search tag in class com.google.common.util.concurrent.ClosingFuture
Section
startTask() - Method in class com.google.common.util.concurrent.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.
startupDurations() - Method in class com.google.common.util.concurrent.ServiceManager
Returns the service load times.
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 - Variable in class com.google.common.collect.AbstractIterator
 
state - Variable in class com.google.common.hash.Hashing.LinearCongruentialGenerator
 
state - Variable in class com.google.common.util.concurrent.AbstractService.StateSnapshot
The internal state, which equals external state unless shutdownWhenStartupFinishes is true.
state - Variable in class com.google.common.util.concurrent.ClosingFuture
 
state - Variable in class com.google.common.util.concurrent.Futures.InCompletionOrderFuture
 
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.
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() - Method in interface com.google.common.util.concurrent.Service
Returns the lifecycle state of the service.
State() - Constructor for enum class com.google.common.base.AbstractIterator.State
 
State() - Constructor for enum class com.google.common.collect.AbstractIterator.State
 
State() - Constructor for enum class com.google.common.util.concurrent.ClosingFuture.State
 
State() - Constructor for enum class com.google.common.util.concurrent.Service.State
 
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, or a set of default values if the cache is not recording statistics.
stats() - Method in class com.google.common.cache.ForwardingCache
 
stats() - Method in class com.google.common.cache.LocalCache.LocalManualCache
 
Stats - Class in com.google.common.math
A bundle of statistical summary values -- sum, count, mean/average, min and max, and several forms of variance -- that were computed from a single set of zero or more floating-point values.
Stats(long, double, double, double, double) - Constructor for class com.google.common.math.Stats
Internal constructor.
StatsAccumulator - Class in com.google.common.math
A mutable object which accumulates double values and tracks some basic statistics over all the values added so far.
StatsAccumulator() - Constructor for class com.google.common.math.StatsAccumulator
 
statsCounter - Variable in class com.google.common.cache.LocalCache.Segment
Accumulates cache statistics.
statsCounterSupplier - Variable in class com.google.common.cache.CacheBuilder
 
statusFuture() - Method in class com.google.common.util.concurrent.ClosingFuture
Returns a future that finishes when this step does.
stimuli - Variable in class com.google.common.collect.testing.AbstractIteratorTester
 
Stimulus(String) - Constructor for class com.google.common.collect.testing.AbstractIteratorTester.Stimulus
 
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_EVENT - 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.
StoppedGuard() - Constructor for class com.google.common.util.concurrent.ServiceManager.ServiceManagerState.StoppedGuard
 
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 - Enum constant in enum class com.google.common.util.concurrent.Service.State
A service in this state is transitioning to Service.State.TERMINATED.
STOPPING_FROM_RUNNING_EVENT - Static variable in class com.google.common.util.concurrent.AbstractService
 
STOPPING_FROM_STARTING_EVENT - Static variable in class com.google.common.util.concurrent.AbstractService
 
stoppingEvent(Service.State) - Static method in class com.google.common.util.concurrent.AbstractService
 
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.
Stopwatch - Class in com.google.common.base
An object that accurately measures elapsed time: the measured duration between two successive readings of "now" in the same process.
Stopwatch() - Constructor for class com.google.common.base.Stopwatch
 
Stopwatch(Ticker) - Constructor for class com.google.common.base.Stopwatch
 
store64(byte[], int, long) - Static method in class com.google.common.hash.LittleEndianByteArray
Store 8 bytes into the provided array at the indicated offset, using the value provided.
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
 
stream() - Method in class com.google.common.collect.FluentIterable
Returns a stream of this fluent iterable's contents (similar to calling Collection.stream() on a collection).
stream() - Method in class com.google.common.collect.Sets.UnmodifiableNavigableSet
 
stream() - Method in class com.google.common.collect.Synchronized.SynchronizedCollection
 
stream() - Method in class com.google.common.primitives.ImmutableDoubleArray
Returns a stream over the values in this array, in order.
stream() - Method in class com.google.common.primitives.ImmutableIntArray
Returns a stream over the values in this array, in order.
stream() - Method in class com.google.common.primitives.ImmutableLongArray
Returns a stream over the values in this array, in order.
stream(Optional<T>) - Static method in class com.google.common.collect.Streams
If a value is present in optional, returns a stream containing only that element, otherwise returns an empty stream.
stream(Iterable<T>) - Static method in class com.google.common.collect.Streams
Returns a sequential Stream of the contents of iterable, delegating to Collection.stream() if possible.
stream(Collection<T>) - Static method in class com.google.common.collect.Streams
Deprecated.
There is no reason to use this; just invoke collection.stream() directly.
stream(Iterator<T>) - Static method in class com.google.common.collect.Streams
Returns a sequential Stream of the remaining contents of iterator.
stream(Optional<T>) - Static method in class com.google.common.collect.Streams
If a value is present in optional, returns a stream containing only that element, otherwise returns an empty stream.
stream(OptionalDouble) - Static method in class com.google.common.collect.Streams
If a value is present in optional, returns a stream containing only that element, otherwise returns an empty stream.
stream(OptionalInt) - Static method in class com.google.common.collect.Streams
If a value is present in optional, returns a stream containing only that element, otherwise returns an empty stream.
stream(OptionalLong) - Static method in class com.google.common.collect.Streams
If a value is present in optional, returns a stream containing only that element, otherwise returns an empty stream.
Streams - Class in com.google.common.collect
Static utility methods related to Stream instances.
Streams() - Constructor for class com.google.common.collect.Streams
 
Streams.DoubleFunctionWithIndex<R> - Interface in com.google.common.collect
An analogue of DoubleFunction also accepting an index.
Streams.FunctionWithIndex<T,R> - Interface in com.google.common.collect
An analogue of Function also accepting an index.
Streams.IntFunctionWithIndex<R> - Interface in com.google.common.collect
An analogue of IntFunction also accepting an index.
Streams.LongFunctionWithIndex<R> - Interface in com.google.common.collect
An analogue of LongFunction also accepting an index.
Streams.MapWithIndexSpliterator<F,R,S> - Class in com.google.common.collect
 
Streams.TemporaryPair<A,B> - Class in com.google.common.collect
 
strength - Variable in class com.google.common.cache.CacheBuilderSpec.KeyStrengthParser
 
strength - Variable in class com.google.common.cache.CacheBuilderSpec.ValueStrengthParser
 
Strength() - Constructor for enum class com.google.common.cache.LocalCache.Strength
 
Strength() - Constructor for enum class com.google.common.collect.MapMakerInternalMap.Strength
 
STRICT_ORIGIN - Static variable in class com.google.common.net.HttpHeaders.ReferrerPolicyValues
 
STRICT_ORIGIN_WHEN_CROSS_ORIGIN - Static variable in class com.google.common.net.HttpHeaders.ReferrerPolicyValues
 
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
 
STRIDE_TABLE - Static variable in class com.google.common.hash.Crc32cHashFunction.Crc32cHasher
 
string - Variable in class com.google.common.collect.Lists.StringAsImmutableList
 
STRING_REVERSED - Static variable in class com.google.common.collect.testing.google.SetGenerators.ImmutableSortedSetExplicitComparator
 
StringAsImmutableList(String) - Constructor for class com.google.common.collect.Lists.StringAsImmutableList
 
StringCharsetFunnel(Charset) - Constructor for class com.google.common.hash.Funnels.StringCharsetFunnel
 
StringCharSource(String) - Constructor for class com.google.common.io.CharSource.StringCharSource
 
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().
stringConverter(Class<T>) - Static method in class com.google.common.base.Enums
Returns a serializable converter that converts between strings and enum values of type enumClass using Enum.valueOf(Class, String) and Enum.name().
StringConverter(CaseFormat, CaseFormat) - Constructor for class com.google.common.base.CaseFormat.StringConverter
 
StringConverter(Class<T>) - Constructor for class com.google.common.base.Enums.StringConverter
 
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.
stringIsNullOrEmpty(String) - Static method in class com.google.common.base.Platform
 
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
 
Strings() - Constructor for class com.google.common.collect.testing.SampleElements.Strings
 
String utilities - Search tag in package com.google.common.base
Section
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
 
Striped.WeakSafeCondition - Class in com.google.common.util.concurrent
Condition object that ensures a strong reference is retained to a specified object.
Striped.WeakSafeLock - Class in com.google.common.util.concurrent
Lock object that ensures a strong reference is retained to a specified object.
Striped.WeakSafeReadWriteLock - Class in com.google.common.util.concurrent
ReadWriteLock implementation whose read and write locks retain a reference back to this lock.
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 - Class in com.google.common.hash
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() - Constructor for class com.google.common.hash.Striped64
Package-private default constructor
Striped64.Cell - Class in com.google.common.cache
Padded variant of AtomicLong supporting only raw accesses plus CAS.
Striped64.Cell - Class in com.google.common.hash
Padded variant of AtomicLong supporting only raw accesses plus CAS.
strong - Variable in class com.google.common.collect.Interners.InternerBuilder
 
strong() - Method in class com.google.common.collect.Interners.InternerBuilder
Instructs the Interners.InternerBuilder to build a strong interner.
STRONG - Enum constant in enum class com.google.common.cache.LocalCache.EntryFactory
 
STRONG - Enum constant in enum class com.google.common.cache.LocalCache.Strength
 
STRONG - Enum constant in enum class com.google.common.collect.MapMakerInternalMap.Strength
 
STRONG_ACCESS - Enum constant in enum class com.google.common.cache.LocalCache.EntryFactory
 
STRONG_ACCESS_WRITE - Enum constant in enum class com.google.common.cache.LocalCache.EntryFactory
 
STRONG_WRITE - Enum constant in enum class com.google.common.cache.LocalCache.EntryFactory
 
StrongAccessEntry(K, int, ReferenceEntry<K, V>) - Constructor for class com.google.common.cache.LocalCache.StrongAccessEntry
 
StrongAccessWriteEntry(K, int, ReferenceEntry<K, V>) - Constructor for class com.google.common.cache.LocalCache.StrongAccessWriteEntry
 
StrongEntry(K, int, ReferenceEntry<K, V>) - Constructor for class com.google.common.cache.LocalCache.StrongEntry
 
StrongKeyDummyValueEntry(K, int) - Constructor for class com.google.common.collect.MapMakerInternalMap.StrongKeyDummyValueEntry
 
StrongKeyDummyValueSegment(MapMakerInternalMap<K, MapMaker.Dummy, MapMakerInternalMap.StrongKeyDummyValueEntry<K>, MapMakerInternalMap.StrongKeyDummyValueSegment<K>>, int) - Constructor for class com.google.common.collect.MapMakerInternalMap.StrongKeyDummyValueSegment
 
StrongKeyStrongValueEntry(K, int) - Constructor for class com.google.common.collect.MapMakerInternalMap.StrongKeyStrongValueEntry
 
StrongKeyStrongValueSegment(MapMakerInternalMap<K, V, MapMakerInternalMap.StrongKeyStrongValueEntry<K, V>, MapMakerInternalMap.StrongKeyStrongValueSegment<K, V>>, int) - Constructor for class com.google.common.collect.MapMakerInternalMap.StrongKeyStrongValueSegment
 
StrongKeyWeakValueEntry(K, int) - Constructor for class com.google.common.collect.MapMakerInternalMap.StrongKeyWeakValueEntry
 
StrongKeyWeakValueSegment(MapMakerInternalMap<K, V, MapMakerInternalMap.StrongKeyWeakValueEntry<K, V>, MapMakerInternalMap.StrongKeyWeakValueSegment<K, V>>, int) - Constructor for class com.google.common.collect.MapMakerInternalMap.StrongKeyWeakValueSegment
 
strongReference - Variable in class com.google.common.util.concurrent.Striped.WeakSafeCondition
 
strongReference - Variable in class com.google.common.util.concurrent.Striped.WeakSafeLock
 
StrongValueReference(V) - Constructor for class com.google.common.cache.LocalCache.StrongValueReference
 
StrongWriteEntry(K, int, 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.
subArray(int, int) - Method in class com.google.common.primitives.ImmutableDoubleArray
Returns a new immutable array containing the values in the specified range.
subArray(int, int) - Method in class com.google.common.primitives.ImmutableIntArray
Returns a new immutable array containing the values in the specified range.
subArray(int, int) - Method in class com.google.common.primitives.ImmutableLongArray
Returns a new immutable array containing the values in the specified range.
subgraphHasCycle(Graph<N>, Map<Object, Graphs.NodeVisitState>, N) - Static method in class com.google.common.graph.Graphs
Performs a traversal of the nodes reachable from startNode.
Subinterfaces - Search tag in interface com.google.common.collect.Multimap
Section
subjectGenerator - Variable in class com.google.common.collect.testing.AbstractTester
 
subjectGenerator - Variable in class com.google.common.collect.testing.FeatureSpecificTestSuiteBuilder
 
subList(int, int) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedList
 
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) - 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.ImmutableDoubleArray.AsList
 
subList(int, int) - Method in class com.google.common.primitives.ImmutableIntArray.AsList
 
subList(int, int) - Method in class com.google.common.primitives.ImmutableLongArray.AsList
 
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
 
SubList(int, int) - Constructor for class com.google.common.collect.ImmutableList.SubList
 
subListCopy(Object[], int) - Static method in class com.google.common.collect.testing.AbstractIteratorTester
 
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
 
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(Cut<C>, boolean, Cut<C>, boolean) - Method in class com.google.common.collect.TreeRangeSet.ComplementRangesByLowerBound
 
subMap(Cut<C>, boolean, Cut<C>, boolean) - Method in class com.google.common.collect.TreeRangeSet.RangesByUpperBound
 
subMap(Cut<C>, boolean, Cut<C>, boolean) - Method in class com.google.common.collect.TreeRangeSet.SubRangeSetRangesByLowerBound
 
subMap(Range<Cut<C>>) - Method in class com.google.common.collect.TreeRangeSet.ComplementRangesByLowerBound
 
subMap(Range<Cut<C>>) - Method in class com.google.common.collect.TreeRangeSet.RangesByUpperBound
 
subMap(Range<Cut<C>>) - Method in class com.google.common.collect.TreeRangeSet.SubRangeSetRangesByLowerBound
 
subMap(C, C) - Method in class com.google.common.collect.TreeBasedTable.TreeRow
 
subMap(NavigableMap<K, V>, Range<K>) - Static method in class com.google.common.collect.Maps
Returns a view of the portion of map whose keys are contained by range.
subMap(K, boolean, K, boolean) - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableAsMap
 
subMap(K, boolean, K, boolean) - Method in class com.google.common.collect.ForwardingNavigableMap
 
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, boolean, K, boolean) - Method in class com.google.common.collect.Maps.FilteredEntryNavigableMap
 
subMap(K, boolean, K, boolean) - Method in class com.google.common.collect.Maps.NavigableAsMapView
 
subMap(K, boolean, K, boolean) - Method in class com.google.common.collect.Maps.TransformedEntriesNavigableMap
 
subMap(K, boolean, K, boolean) - Method in class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
subMap(K, boolean, K, boolean) - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableMap
 
subMap(K, boolean, K, boolean) - Method in class com.google.common.collect.testing.SafeTreeMap
 
subMap(K, K) - 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, 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, K) - Method in class com.google.common.collect.Maps.DescendingMap
 
subMap(K, K) - Method in class com.google.common.collect.Maps.FilteredEntrySortedMap
 
subMap(K, K) - Method in class com.google.common.collect.Maps.SortedAsMapView
 
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, K) - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableMap
 
subMap(K, K) - Method in class com.google.common.collect.Synchronized.SynchronizedSortedMap
 
subMap(K, K) - Method in class com.google.common.collect.testing.SafeTreeMap
 
subMap(R, R) - Method in class com.google.common.collect.StandardRowSortedTable.RowSortedMap
 
SUBMAP - Enum constant in enum class com.google.common.collect.testing.SortedMapTestSuiteBuilder.NoRecurse
 
submit(ClosingFuture.ClosingCallable<V>, Executor) - Static method in class com.google.common.util.concurrent.ClosingFuture
Starts a ClosingFuture pipeline by submitting a callable block to an executor.
submit(Runnable) - Method in class com.google.common.util.concurrent.AbstractListeningExecutorService
 
submit(Runnable) - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
submit(Runnable) - Method in class com.google.common.util.concurrent.ForwardingListeningExecutorService
 
submit(Runnable) - Method in interface com.google.common.util.concurrent.ListeningExecutorService
 
submit(Runnable) - Method in class com.google.common.util.concurrent.testing.SameThreadScheduledExecutorService
 
submit(Runnable) - Method in class com.google.common.util.concurrent.WrappingExecutorService
 
submit(Runnable, Executor) - Static method in class com.google.common.util.concurrent.Futures
Executes runnable on the specified executor, returning a Future that will complete after execution.
submit(Runnable, T) - Method in class com.google.common.util.concurrent.AbstractListeningExecutorService
 
submit(Runnable, T) - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
submit(Runnable, T) - Method in class com.google.common.util.concurrent.ForwardingListeningExecutorService
 
submit(Runnable, T) - Method in interface com.google.common.util.concurrent.ListeningExecutorService
 
submit(Runnable, T) - Method in class com.google.common.util.concurrent.testing.SameThreadScheduledExecutorService
 
submit(Runnable, T) - Method in class com.google.common.util.concurrent.WrappingExecutorService
 
submit(Callable<O>, Executor) - Static method in class com.google.common.util.concurrent.Futures
Executes callable on the specified executor, returning a Future.
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(Callable<T>) - Method in class com.google.common.util.concurrent.ForwardingListeningExecutorService
 
submit(Callable<T>) - Method in interface com.google.common.util.concurrent.ListeningExecutorService
 
submit(Callable<T>) - Method in class com.google.common.util.concurrent.testing.SameThreadScheduledExecutorService
 
submit(Callable<T>) - Method in class com.google.common.util.concurrent.WrappingExecutorService
 
submit(Callable<T>, Executor) - Method in class com.google.common.util.concurrent.ExecutionSequencer
Enqueues a task to run when the previous task (if any) completes.
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.
submitAsync(AsyncCallable<O>, Executor) - Static method in class com.google.common.util.concurrent.Futures
Executes callable on the specified executor, returning a Future.
submitAsync(AsyncCallable<T>, Executor) - Method in class com.google.common.util.concurrent.ExecutionSequencer
Enqueues a task to run when the previous task (if any) completes.
submitAsync(ClosingFuture.AsyncClosingCallable<V>, Executor) - Static method in class com.google.common.util.concurrent.ClosingFuture
Starts a ClosingFuture pipeline by submitting a callable block to an executor.
submitting - Variable in class com.google.common.util.concurrent.ExecutionSequencer.TaskNonReentrantExecutor
Thread that called execute().
submitToExecutor(AbstractScheduledService.CustomScheduler.Schedule) - Method in class com.google.common.util.concurrent.AbstractScheduledService.CustomScheduler.ReschedulableCallable
 
subMultiset(SortedMultiset<E>, List<Multiset.Entry<E>>, int) - Method in enum class com.google.common.collect.testing.google.MultisetNavigationTester.SubMultisetSpec
 
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
 
SUBMULTISET - Enum constant in enum class com.google.common.collect.testing.google.SortedMultisetTestSuiteBuilder.NoRecurse
 
SubMultisetSpec() - Constructor for enum class com.google.common.collect.testing.google.MultisetNavigationTester.SubMultisetSpec
 
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>) - Method in class com.google.common.collect.TreeRangeMap.SubRangeMap
 
SubRangeMap(Range<K>) - Constructor for 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>) - Method in class com.google.common.collect.TreeRangeSet.SubRangeSet
 
SubRangeSet(Range<C>) - Constructor for 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 Interface in com.google.common.eventbus
Marks a method as an event subscriber.
subscriber - Variable in class com.google.common.eventbus.Dispatcher.LegacyAsyncDispatcher.EventWithSubscriber
 
subscriber - Variable in class com.google.common.eventbus.SubscriberExceptionContext
 
Subscriber - Class in com.google.common.eventbus
A subscriber method on a specific object, plus the executor that should be used for dispatching events to it.
Subscriber(EventBus, Object, Method) - Constructor for class com.google.common.eventbus.Subscriber
 
Subscriber.SynchronizedSubscriber - Class in com.google.common.eventbus
Subscriber that synchronizes invocations of a method to ensure that only one thread may enter the method at a time.
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 - Interface in com.google.common.eventbus
Handler for exceptions thrown by event subscribers.
subscriberMethod - Variable in class com.google.common.eventbus.SubscriberExceptionContext
 
Subscriber Methods - Search tag in class com.google.common.eventbus.EventBus
Section
subscriberMethodsCache - Static variable in class com.google.common.eventbus.SubscriberRegistry
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.
SubscriberRegistry - Class in com.google.common.eventbus
Registry of subscribers to a single event bus.
SubscriberRegistry(EventBus) - Constructor for class com.google.common.eventbus.SubscriberRegistry
 
SubscriberRegistry.MethodIdentifier - Class in com.google.common.eventbus
 
subscribers - Variable in class com.google.common.eventbus.Dispatcher.PerThreadQueuedDispatcher.Event
 
subscribers - Variable in class com.google.common.eventbus.EventBus
 
subscribers - Variable in class com.google.common.eventbus.SubscriberRegistry
All registered subscribers, indexed by event type.
subSet(Range<C>) - Method in class com.google.common.collect.ImmutableRangeSet.AsSet
 
subSet(C, boolean, C, boolean) - Method in class com.google.common.collect.ContiguousSet
 
subSet(C, C) - Method in class com.google.common.collect.ContiguousSet
 
subSet(E, boolean, E, boolean) - Method in class com.google.common.collect.ForwardingNavigableSet
 
subSet(E, boolean, E, boolean) - Method in class com.google.common.collect.ImmutableSortedSet
 
subSet(E, boolean, E, boolean) - 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, boolean, E, boolean) - Method in class com.google.common.collect.Sets.UnmodifiableNavigableSet
 
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, boolean, E, boolean) - Method in class com.google.common.collect.testing.SafeTreeSet
 
subSet(E, E) - Method in class com.google.common.collect.ForwardingSortedSet
 
subSet(E, E) - Method in class com.google.common.collect.ImmutableSortedSet
subSet(E, E) - Method in class com.google.common.collect.Sets.DescendingSet
 
subSet(E, E) - Method in class com.google.common.collect.Sets.FilteredSortedSet
 
subSet(E, E) - Method in class com.google.common.collect.SortedMultisets.ElementSet
 
subSet(E, E) - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableSet
 
subSet(E, E) - Method in class com.google.common.collect.Synchronized.SynchronizedSortedSet
 
subSet(E, E) - Method in class com.google.common.collect.testing.SafeTreeSet
 
subSet(NavigableSet<K>, Range<K>) - Static method in class com.google.common.collect.Sets
Returns a view of the portion of set whose elements are contained by range.
subSet(K, boolean, K, boolean) - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableKeySet
 
subSet(K, boolean, K, boolean) - Method in class com.google.common.collect.Maps.NavigableKeySet
 
subSet(K, K) - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableKeySet
 
subSet(K, K) - Method in class com.google.common.collect.AbstractMapBasedMultimap.SortedKeySet
 
subSet(K, K) - Method in class com.google.common.collect.Maps.FilteredEntrySortedMap.SortedKeySet
 
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(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(ImmutableMap<E, Integer>, int) - Constructor for class com.google.common.collect.Sets.SubSet
 
SUBSET_VIEW - Enum constant in enum class com.google.common.collect.testing.features.CollectionFeature
 
subSetImpl(C, boolean, C, boolean) - Method in class com.google.common.collect.ContiguousSet
 
subSetImpl(C, boolean, C, boolean) - Method in class com.google.common.collect.EmptyContiguousSet
 
subSetImpl(C, boolean, C, boolean) - Method in class com.google.common.collect.ImmutableRangeSet.AsSet
 
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.DescendingImmutableSortedSet
 
subSetImpl(E, boolean, E, boolean) - Method in class com.google.common.collect.ImmutableSortedSet
 
subSetImpl(E, boolean, E, boolean) - Method in class com.google.common.collect.RegularImmutableSortedSet
 
subSuiteUsing(TestSortedMapGenerator<K, V>) - Method in class com.google.common.collect.testing.ConcurrentNavigableMapTestSuiteBuilder
 
subSuiteUsing(TestSortedMapGenerator<K, V>) - Method in class com.google.common.collect.testing.NavigableMapTestSuiteBuilder
 
SUBSUMED - Enum constant in enum class com.google.common.util.concurrent.ClosingFuture.State
The ClosingFuture.CloseableList has been subsumed into another.
subtype - Variable in class com.google.common.net.MediaType
 
subtype() - Method in class com.google.common.net.MediaType
Returns the media subtype.
subtypeOf(Class<?>) - Static method in class com.google.common.base.Predicates
Returns a predicate that evaluates to true if the class being tested is assignable to (is a subtype of) clazz.
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.
SubtypeOfPredicate(Class<?>) - Constructor for class com.google.common.base.Predicates.SubtypeOfPredicate
 
succ - Variable in class com.google.common.collect.TreeMultiset.AvlNode
 
succ() - Method in class com.google.common.collect.TreeMultiset.AvlNode
 
Succ(N) - Constructor for class com.google.common.graph.DirectedGraphConnections.NodeConnection.Succ
 
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.
SUCCESSFULLY_COMPUTED - Static variable in class com.google.common.base.Suppliers.NonSerializableMemoizingSupplier
 
successor - Variable in class com.google.common.collect.CompactLinkedHashSet
Pointer to the successor of an entry in insertion order.
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
 
successorCount - Variable in class com.google.common.graph.DirectedGraphConnections
 
successorFunction - Variable in class com.google.common.graph.Traverser
 
successorFunction - Variable in class com.google.common.graph.Traverser.Traversal
 
successorInMultimap - Variable in class com.google.common.collect.LinkedHashMultimap.ValueEntry
 
successorInValueSet - Variable in class com.google.common.collect.LinkedHashMultimap.ValueEntry
 
successorIterator - Variable in class com.google.common.graph.EndpointPairIterator
 
successors() - Method in class com.google.common.graph.AbstractUndirectedNetworkConnections
 
successors() - Method in class com.google.common.graph.DirectedGraphConnections
 
successors() - Method in class com.google.common.graph.DirectedMultiNetworkConnections
 
successors() - Method in class com.google.common.graph.DirectedNetworkConnections
 
successors() - Method in interface com.google.common.graph.GraphConnections
 
successors() - Method in interface com.google.common.graph.NetworkConnections
 
successors() - Method in class com.google.common.graph.UndirectedGraphConnections
 
successors(N) - Method in interface com.google.common.graph.BaseGraph
Returns a live view of all nodes in this graph adjacent to node which can be reached by traversing node's outgoing edges in the direction (if any) of the edge.
successors(N) - Method in class com.google.common.graph.ForwardingGraph
 
successors(N) - Method in class com.google.common.graph.ForwardingNetwork
 
successors(N) - Method in class com.google.common.graph.ForwardingValueGraph
 
successors(N) - Method in interface com.google.common.graph.Graph
Returns a live view of all nodes in this graph adjacent to node which can be reached by traversing node's outgoing edges in the direction (if any) of the edge.
successors(N) - Method in class com.google.common.graph.Graphs.TransposedGraph
 
successors(N) - Method in class com.google.common.graph.Graphs.TransposedNetwork
 
successors(N) - Method in class com.google.common.graph.Graphs.TransposedValueGraph
 
successors(N) - Method in interface com.google.common.graph.Network
Returns a live view of all nodes in this network adjacent to node which can be reached by traversing node's outgoing edges in the direction (if any) of the edge.
successors(N) - Method in class com.google.common.graph.StandardNetwork
 
successors(N) - Method in class com.google.common.graph.StandardValueGraph
 
successors(N) - Method in interface com.google.common.graph.SuccessorsFunction
Returns all nodes in this graph adjacent to node which can be reached by traversing node's outgoing edges in the direction (if any) of the edge.
successors(N) - Method in interface com.google.common.graph.ValueGraph
Returns a live view of all nodes in this graph adjacent to node which can be reached by traversing node's outgoing edges in the direction (if any) of the edge.
SuccessorsFunction<N> - Interface in com.google.common.graph
A functional interface for graph-structured data.
successorsMultiset() - Method in class com.google.common.graph.DirectedMultiNetworkConnections
 
successorsReference - Variable in class com.google.common.graph.DirectedMultiNetworkConnections
 
successorValue - Variable in class com.google.common.graph.DirectedGraphConnections.PredAndSucc
 
suffix(String) - Static method in class com.google.common.testing.AbstractPackageSanityTests.Chopper
 
SUFFIX_NOT_INITIALIZED - Static variable in class com.google.common.net.InternetDomainName
Value of InternetDomainName.publicSuffixIndexCache or InternetDomainName.registrySuffixIndexCache which indicates that they were not initialized yet.
suite() - Static method in class com.google.common.collect.testing.TestsForListsInJavaUtil
 
suite() - Static method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
suite() - Static method in class com.google.common.collect.testing.TestsForQueuesInJavaUtil
 
suite() - Static method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
suiteName - Variable in class com.google.common.collect.testing.AbstractTester
 
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() - Method in interface com.google.common.hash.LongAddable
 
sum() - Method in class com.google.common.hash.LongAddables.PureJavaLongAddable
 
sum() - Method in class com.google.common.hash.LongAdder
Returns the current sum.
sum() - Method in class com.google.common.math.Stats
Returns the sum of the values.
sum() - Method in class com.google.common.math.StatsAccumulator
Returns the sum of the values.
sum() - Method in class com.google.common.util.concurrent.AtomicLongMap
Returns the sum of all values in this map.
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.
sumOfProductsOfDeltas - Variable in class com.google.common.math.PairedStats
 
sumOfProductsOfDeltas - Variable in class com.google.common.math.PairedStatsAccumulator
 
sumOfProductsOfDeltas() - Method in class com.google.common.math.PairedStats
 
sumOfSquaresOfDeltas - Variable in class com.google.common.math.Stats
 
sumOfSquaresOfDeltas - Variable in class com.google.common.math.StatsAccumulator
 
sumOfSquaresOfDeltas() - Method in class com.google.common.math.Stats
 
sumOfSquaresOfDeltas() - Method in class com.google.common.math.StatsAccumulator
 
sumThenReset() - Method in class com.google.common.cache.LongAdder
Equivalent in effect to LongAdder.sum() followed by LongAdder.reset().
sumThenReset() - Method in class com.google.common.hash.LongAdder
Equivalent in effect to LongAdder.sum() followed by LongAdder.reset().
superset - Variable in class com.google.common.collect.testing.testers.CollectionRetainAllTester
 
supertypeOf(Type) - Static method in class com.google.common.reflect.Types
Returns a new WildcardType with lowerBound.
SupplantableFuture(ReentrantLock, Future<Void>) - Constructor for class com.google.common.util.concurrent.AbstractScheduledService.CustomScheduler.SupplantableFuture
 
supplementaryPlaneFix - Variable in class com.google.common.hash.Murmur3_32HashFunction
 
supplier - Variable in class com.google.common.base.Functions.SupplierFunction
 
supplier - Variable in class com.google.common.base.Suppliers.SupplierComposition
 
supplier - Variable in class com.google.common.util.concurrent.Striped.LargeLazyStriped
 
supplier - Variable in class com.google.common.util.concurrent.Striped.SmallLazyStriped
 
Supplier<T> - Interface in com.google.common.base
Legacy version of java.util.function.Supplier.
SUPPLIER - Static variable in class com.google.common.cache.LongAddables
 
SUPPLIER - Static variable in class com.google.common.hash.LongAddables
 
SupplierComposition(Function<? super F, T>, Supplier<F>) - Constructor for class com.google.common.base.Suppliers.SupplierComposition
 
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.
SupplierFunction(Supplier<T>) - Constructor for class com.google.common.base.Functions.SupplierFunction
 
SupplierFunctionImpl() - Constructor for enum class 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.NonSerializableMemoizingSupplier<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 Class 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
 
SUPPORTS_ADD - Enum constant in enum class com.google.common.collect.testing.features.CollectionFeature
 
SUPPORTS_ADD - Enum constant in enum class com.google.common.collect.testing.IteratorFeature
Support for ListIterator.add(Object); ignored for plain Iterator implementations.
SUPPORTS_ADD_WITH_INDEX - Enum constant in enum class com.google.common.collect.testing.features.ListFeature
 
SUPPORTS_ITERATOR_REMOVE - Enum constant in enum class com.google.common.collect.testing.features.CollectionFeature
 
SUPPORTS_LOADING_MODE - Static variable in class com.google.common.net.HttpHeaders
The HTTP Supports-Loading-Mode header field name.
SUPPORTS_PUT - Enum constant in enum class com.google.common.collect.testing.features.MapFeature
 
SUPPORTS_REMOVE - Enum constant in enum class com.google.common.collect.testing.features.CollectionFeature
 
SUPPORTS_REMOVE - Enum constant in enum class com.google.common.collect.testing.features.MapFeature
 
SUPPORTS_REMOVE - Enum constant in enum class com.google.common.collect.testing.IteratorFeature
Support for Iterator.remove().
SUPPORTS_REMOVE_WITH_INDEX - Enum constant in enum class com.google.common.collect.testing.features.ListFeature
 
SUPPORTS_SET - Enum constant in enum class com.google.common.collect.testing.features.ListFeature
 
SUPPORTS_SET - Enum constant in enum class com.google.common.collect.testing.IteratorFeature
Support for ListIterator.set(Object); ignored for plain Iterator implementations.
supportsClear - Variable in class com.google.common.collect.testing.MapInterfaceTest
 
supportsClone - Variable in class com.google.common.hash.MacHashFunction
 
supportsClone - Variable in class com.google.common.hash.MessageDigestHashFunction
 
supportsClone(MessageDigest) - Static method in class com.google.common.hash.MessageDigestHashFunction
 
supportsClone(Mac) - Static method in class com.google.common.hash.MacHashFunction
 
supportsFastOffset - Variable in class com.google.common.collect.DiscreteDomain
 
supportsIteratorRemove - Variable in class com.google.common.collect.testing.MapInterfaceTest
 
supportsPut - Variable in class com.google.common.collect.testing.MapInterfaceTest
 
supportsRemove - Variable in class com.google.common.collect.testing.MapInterfaceTest
 
supportsValuesHashCode(Map<K, V>) - Method in class com.google.common.collect.testing.MapInterfaceTest
 
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.
suppressedTests - Variable in class com.google.common.collect.testing.FeatureSpecificTestSuiteBuilder
 
suppressForAbstractList() - Method in class com.google.common.collect.testing.TestsForListsInJavaUtil
 
suppressForAbstractSequentialList() - Method in class com.google.common.collect.testing.TestsForListsInJavaUtil
 
suppressForAbstractSet() - Method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
suppressForArrayBlockingQueue() - Method in class com.google.common.collect.testing.TestsForQueuesInJavaUtil
 
suppressForArrayDeque() - Method in class com.google.common.collect.testing.TestsForQueuesInJavaUtil
 
suppressForArrayList() - Method in class com.google.common.collect.testing.TestsForListsInJavaUtil
 
suppressForArraysAsList() - Method in class com.google.common.collect.testing.TestsForListsInJavaUtil
 
suppressForCheckedList() - Method in class com.google.common.collect.testing.TestsForListsInJavaUtil
 
suppressForCheckedMap() - Method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
suppressForCheckedNavigableMap() - Method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
suppressForCheckedNavigableSet() - Method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
suppressForCheckedQueue() - Method in class com.google.common.collect.testing.TestsForQueuesInJavaUtil
 
suppressForCheckedSet() - Method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
suppressForCheckedSortedMap() - Method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
suppressForCheckedSortedSet() - Method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
suppressForConcurrentHashMap() - Method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
suppressForConcurrentLinkedDeque() - Method in class com.google.common.collect.testing.TestsForQueuesInJavaUtil
 
suppressForConcurrentLinkedQueue() - Method in class com.google.common.collect.testing.TestsForQueuesInJavaUtil
 
suppressForConcurrentSkipListMap() - Method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
suppressForConcurrentSkipListSetNatural() - Method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
suppressForConcurrentSkipListSetWithComparator() - Method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
suppressForCopyOnWriteArrayList() - Method in class com.google.common.collect.testing.TestsForListsInJavaUtil
 
suppressForCopyOnWriteArraySet() - Method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
suppressForEmptyList() - Method in class com.google.common.collect.testing.TestsForListsInJavaUtil
 
suppressForEmptyMap() - Method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
suppressForEmptyNavigableMap() - Method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
suppressForEmptyNavigableSet() - Method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
suppressForEmptySet() - Method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
suppressForEmptySortedMap() - Method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
suppressForEmptySortedSet() - Method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
suppressForEnumMap() - Method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
suppressForEnumSet() - Method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
suppressForHashMap() - Method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
suppressForHashSet() - Method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
suppressForHashtable() - Method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
suppressForLinkedBlockingDeque() - Method in class com.google.common.collect.testing.TestsForQueuesInJavaUtil
 
suppressForLinkedBlockingQueue() - Method in class com.google.common.collect.testing.TestsForQueuesInJavaUtil
 
suppressForLinkedHashMap() - Method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
suppressForLinkedHashSet() - Method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
suppressForLinkedList() - Method in class com.google.common.collect.testing.TestsForListsInJavaUtil
 
suppressForLinkedList() - Method in class com.google.common.collect.testing.TestsForQueuesInJavaUtil
 
suppressForPriorityBlockingQueue() - Method in class com.google.common.collect.testing.TestsForQueuesInJavaUtil
 
suppressForPriorityQueue() - Method in class com.google.common.collect.testing.TestsForQueuesInJavaUtil
 
suppressForSingletonList() - Method in class com.google.common.collect.testing.TestsForListsInJavaUtil
 
suppressForSingletonMap() - Method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
suppressForSingletonSet() - Method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
suppressForSynchronizedNavigableMap() - Method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
suppressForSynchronizedNavigableSet() - Method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
suppressForTreeMapNatural() - Method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
suppressForTreeMapWithComparator() - Method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
suppressForTreeSetNatural() - Method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
suppressForTreeSetWithComparator() - Method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
suppressForUnmodifiableList() - Method in class com.google.common.collect.testing.TestsForListsInJavaUtil
 
suppressForUnmodifiableMap() - Method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
suppressForUnmodifiableNavigableMap() - Method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
suppressForUnmodifiableNavigableSet() - Method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
suppressForUnmodifiableSet() - Method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
suppressForUnmodifiableSortedMap() - Method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
suppressForVector() - Method in class com.google.common.collect.testing.TestsForListsInJavaUtil
 
suppressing(Method...) - Method in class com.google.common.collect.testing.FeatureSpecificTestSuiteBuilder
Prevents the given methods from being run as part of the test suite.
suppressing(Collection<Method>) - Method in class com.google.common.collect.testing.FeatureSpecificTestSuiteBuilder
 
SUPPRESSING_SUPPRESSOR - Static variable in class com.google.common.io.Closer
Suppresses exceptions by adding them to the exception that will be thrown using the addSuppressed(Throwable) mechanism.
suppressor - Variable in class com.google.common.io.Closer
 
suppressThrows - Variable in class com.google.common.testing.TearDownStack
 
SVG_UTF_8 - Static variable in class com.google.common.net.MediaType
 
swap(double[], int, int) - Static method in class com.google.common.math.Quantiles
Swaps the values at i and j in array.
swap(int, int) - Method in class com.google.common.collect.TopKSelector
 
swap(Object[], int, int) - Static method in class com.google.common.collect.ObjectArrays
Swaps array[i] with array[j].
swapWithConceptuallyLastElement(E) - Method in class com.google.common.collect.MinMaxPriorityQueue.Heap
Swap actualLastElement with the conceptually correct last element of the heap.
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.
synchronized - Search tag in class com.google.common.util.concurrent.Monitor
Section
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
 
Synchronized.SynchronizedTable<R,C,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
 
SynchronizedAtomicHelper() - Constructor for class com.google.common.util.concurrent.AggregateFutureState.SynchronizedAtomicHelper
 
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
 
SynchronizedHelper() - Constructor for class com.google.common.util.concurrent.AbstractFuture.SynchronizedHelper
 
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
 
SynchronizedSubscriber(EventBus, Object, Method) - Constructor for class com.google.common.eventbus.Subscriber.SynchronizedSubscriber
 
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.
synchronizedTable(Table<R, C, V>) - Static method in class com.google.common.collect.Tables
Returns a synchronized (thread-safe) table backed by the specified table.
SynchronizedTable(Table<R, C, V>, Object) - Constructor for class com.google.common.collect.Synchronized.SynchronizedTable
 
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
 
systemTicker() - Static method in class com.google.common.base.Ticker
A ticker that reads the current time using System.nanoTime().

T

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.CompactHashMap
The hashtable object.
table - Variable in class com.google.common.collect.CompactHashSet
The hashtable object.
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 - Variable in class com.google.common.collect.TableCollectors.ImmutableTableCollectorState
 
table(Table<R, C, V>, Object) - Static method in class com.google.common.collect.Synchronized
 
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 - Static variable in class com.google.common.base.CharMatcher.Whitespace
 
Table.Cell<R,C,V> - Interface in com.google.common.collect
Row key / column key / value triplet corresponding to a mapping in a table.
tableClear(Object) - Static method in class com.google.common.collect.CompactHashing
 
TableCollectors - Class in com.google.common.collect
Collectors utilities for common.collect.Table internals.
TableCollectors() - Constructor for class com.google.common.collect.TableCollectors
 
TableCollectors.ImmutableTableCollectorState<R,C,V> - Class in com.google.common.collect
 
TableCollectors.MutableCell<R,C,V> - Class in com.google.common.collect
 
tableGet(Object, int) - Static method in class com.google.common.collect.CompactHashing
Returns table[index], where table is actually a byte[], short[], or int[].
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(Object, int, int) - Static method in class com.google.common.collect.CompactHashing
Sets table[index] to entry, where table is actually a byte[], short[], or int[].
TableSet() - Constructor for class com.google.common.collect.StandardTable.TableSet
 
tableSize(int) - Static method in class com.google.common.collect.CompactHashing
Returns the power of 2 hashtable size required to hold the expected number of items or the minimum hashtable size, whichever is greater.
tail - Variable in class com.google.common.collect.LinkedListMultimap.KeyList
 
tail - Variable in class com.google.common.collect.LinkedListMultimap
 
TAIL_CLOSED - Enum constant in enum class com.google.common.collect.testing.google.MultisetNavigationTester.SubMultisetSpec
 
TAIL_OPEN - Enum constant in enum class com.google.common.collect.testing.google.MultisetNavigationTester.SubMultisetSpec
 
tailIndex(E, boolean) - Method in class com.google.common.collect.RegularImmutableSortedSet
 
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
 
tailMap(K) - 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) - 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) - Method in class com.google.common.collect.Maps.DescendingMap
 
tailMap(K) - Method in class com.google.common.collect.Maps.FilteredEntrySortedMap
 
tailMap(K) - Method in class com.google.common.collect.Maps.SortedAsMapView
 
tailMap(K) - 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) - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableMap
 
tailMap(K) - Method in class com.google.common.collect.Synchronized.SynchronizedSortedMap
 
tailMap(K) - Method in class com.google.common.collect.testing.SafeTreeMap
 
tailMap(K, boolean) - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableAsMap
 
tailMap(K, boolean) - Method in class com.google.common.collect.ForwardingNavigableMap
 
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, boolean) - Method in class com.google.common.collect.Maps.FilteredEntryNavigableMap
 
tailMap(K, boolean) - Method in class com.google.common.collect.Maps.NavigableAsMapView
 
tailMap(K, boolean) - Method in class com.google.common.collect.Maps.TransformedEntriesNavigableMap
 
tailMap(K, boolean) - Method in class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
tailMap(K, boolean) - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableMap
 
tailMap(K, boolean) - Method in class com.google.common.collect.testing.SafeTreeMap
 
tailMap(R) - Method in class com.google.common.collect.StandardRowSortedTable.RowSortedMap
 
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.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(C) - Method in class com.google.common.collect.ContiguousSet
 
tailSet(C, boolean) - Method in class com.google.common.collect.ContiguousSet
 
tailSet(E) - Method in class com.google.common.collect.ForwardingSortedSet
 
tailSet(E) - Method in class com.google.common.collect.ImmutableSortedSet
tailSet(E) - Method in class com.google.common.collect.Sets.DescendingSet
 
tailSet(E) - Method in class com.google.common.collect.Sets.FilteredSortedSet
 
tailSet(E) - Method in class com.google.common.collect.SortedMultisets.ElementSet
 
tailSet(E) - Method in class com.google.common.collect.Synchronized.SynchronizedNavigableSet
 
tailSet(E) - Method in class com.google.common.collect.Synchronized.SynchronizedSortedSet
 
tailSet(E) - Method in class com.google.common.collect.testing.SafeTreeSet
 
tailSet(E, boolean) - Method in class com.google.common.collect.ForwardingNavigableSet
 
tailSet(E, boolean) - Method in class com.google.common.collect.ImmutableSortedSet
 
tailSet(E, boolean) - Method in class com.google.common.collect.Sets.DescendingSet
 
tailSet(E, boolean) - Method in class com.google.common.collect.Sets.FilteredNavigableSet
 
tailSet(E, boolean) - Method in class com.google.common.collect.Sets.UnmodifiableNavigableSet
 
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, boolean) - Method in class com.google.common.collect.testing.SafeTreeSet
 
tailSet(K) - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableKeySet
 
tailSet(K) - Method in class com.google.common.collect.AbstractMapBasedMultimap.SortedKeySet
 
tailSet(K) - Method in class com.google.common.collect.Maps.FilteredEntrySortedMap.SortedKeySet
 
tailSet(K) - Method in class com.google.common.collect.Maps.NavigableKeySet
 
tailSet(K) - Method in class com.google.common.collect.Maps.SortedKeySet
 
tailSet(K, boolean) - Method in class com.google.common.collect.AbstractMapBasedMultimap.NavigableKeySet
 
tailSet(K, boolean) - Method in class com.google.common.collect.Maps.NavigableKeySet
 
tailSet(V) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedSortedSet
 
tailSet(V, boolean) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedNavigableSet
 
tailSetImpl(C, boolean) - Method in class com.google.common.collect.ContiguousSet
 
tailSetImpl(C, boolean) - Method in class com.google.common.collect.EmptyContiguousSet
 
tailSetImpl(C, boolean) - Method in class com.google.common.collect.ImmutableRangeSet.AsSet
 
tailSetImpl(C, boolean) - Method in class com.google.common.collect.RegularContiguousSet
 
tailSetImpl(E, boolean) - Method in class com.google.common.collect.DescendingImmutableSortedSet
 
tailSetImpl(E, boolean) - Method in class com.google.common.collect.ImmutableSortedSet
 
tailSetImpl(E, boolean) - Method in class com.google.common.collect.RegularImmutableSortedSet
 
take() - Method in class com.google.common.collect.ForwardingBlockingDeque
Deprecated.
 
take() - Method in class com.google.common.util.concurrent.ForwardingBlockingDeque
 
take() - Method in class com.google.common.util.concurrent.ForwardingBlockingQueue
 
takeFirst() - Method in class com.google.common.collect.ForwardingBlockingDeque
Deprecated.
 
takeFirst() - Method in class com.google.common.util.concurrent.ForwardingBlockingDeque
 
takeLast() - Method in class com.google.common.collect.ForwardingBlockingDeque
Deprecated.
 
takeLast() - Method in class com.google.common.util.concurrent.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.Subscriber
The object with the subscriber method.
target - Variable in class com.google.common.io.AppendableWriter
 
target - Variable in class com.google.common.reflect.TypeToken.Bounds
 
target() - Method in class com.google.common.graph.EndpointPair.Ordered
 
target() - Method in class com.google.common.graph.EndpointPair
If this EndpointPair EndpointPair.isOrdered(), returns the node which is the target.
target() - Method in class com.google.common.graph.EndpointPair.Unordered
 
Target(Collection<E>, String) - Constructor for class com.google.common.collect.testing.testers.CollectionRetainAllTester.Target
 
targetFormat - Variable in class com.google.common.base.CaseFormat.StringConverter
 
targetNode - Variable in class com.google.common.graph.EdgesConnecting
 
targetNode - Variable in class com.google.common.graph.MultiEdgesConnecting
 
targetNodeFn(Network<N, E>) - Static method in class com.google.common.graph.ImmutableNetwork
 
task - Variable in class com.google.common.util.concurrent.AbstractFuture.Listener
 
task - Variable in class com.google.common.util.concurrent.AbstractScheduledService.ServiceDelegate
 
task - Variable in class com.google.common.util.concurrent.CombinedFuture
 
task - Variable in class com.google.common.util.concurrent.ExecutionSequencer.TaskNonReentrantExecutor
Set before calling delegate.execute(); set to null once run, so that it can be GCed; this object may live on after, if submitAsync returns an incomplete future.
task - Variable in class com.google.common.util.concurrent.InterruptibleTask.Blocker
 
task - Variable in class com.google.common.util.concurrent.SequentialExecutor.QueueWorker
 
task - Variable in class com.google.common.util.concurrent.TrustedListenableFutureTask
 
Task() - Constructor for class com.google.common.util.concurrent.AbstractScheduledService.ServiceDelegate.Task
 
TaskNonReentrantExecutor(Executor, ExecutionSequencer) - Constructor for class com.google.common.util.concurrent.ExecutionSequencer.TaskNonReentrantExecutor
 
TE - Static variable in class com.google.common.net.HttpHeaders
The HTTP TE header field name.
tearDown - Variable in class com.google.common.collect.testing.AbstractTester
 
tearDown - Variable in class com.google.common.collect.testing.FeatureSpecificTestSuiteBuilder
 
tearDown() - Method in class com.google.common.collect.testing.AbstractTester
 
tearDown() - Method in class com.google.common.testing.SloppyTearDown
 
tearDown() - Method in interface com.google.common.testing.TearDown
Performs a single tear-down operation.
tearDown() - Method in class com.google.common.util.concurrent.testing.AbstractListenableFutureTest
 
TearDown - Interface in com.google.common.testing
An object that can perform a TearDown.tearDown() operation.
TearDownAccepter - Interface in com.google.common.testing
Any object which can accept registrations of TearDown instances.
TearDownStack - Class in com.google.common.testing
A TearDownStack contains a stack of TearDown instances.
TearDownStack() - Constructor for class com.google.common.testing.TearDownStack
 
TearDownStack(boolean) - Constructor for class com.google.common.testing.TearDownStack
 
TEMP_DIR_ATTEMPTS - Static variable in class com.google.common.io.TempFileCreator.JavaIoCreator
Maximum loop count when creating temp directories.
TempFileCreator - Class in com.google.common.io
Creates temporary files and directories whose permissions are restricted to the current user or, in the case of Android, the current app.
TempFileCreator() - Constructor for class com.google.common.io.TempFileCreator
 
TempFileCreator.JavaIoCreator - Class in com.google.common.io
 
TempFileCreator.JavaNioCreator - Class in com.google.common.io
 
TempFileCreator.JavaNioCreator.PermissionSupplier - Interface in com.google.common.io
 
TempFileCreator.ThrowingCreator - Class in com.google.common.io
 
TemporaryPair(A, B) - Constructor for class com.google.common.collect.Streams.TemporaryPair
 
TeredoInfo(Inet4Address, Inet4Address, int, int) - Constructor for class com.google.common.net.InetAddresses.TeredoInfo
Constructs a TeredoInfo instance.
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 - Enum constant in enum class com.google.common.util.concurrent.Service.State
A service in this state has completed execution normally.
TERMINATED_FROM_NEW_EVENT - Static variable in class com.google.common.util.concurrent.AbstractService
 
TERMINATED_FROM_RUNNING_EVENT - Static variable in class com.google.common.util.concurrent.AbstractService
 
TERMINATED_FROM_STARTING_EVENT - Static variable in class com.google.common.util.concurrent.AbstractService
 
TERMINATED_FROM_STOPPING_EVENT - Static variable in class com.google.common.util.concurrent.AbstractService
 
terminatedEvent(Service.State) - Static method in class com.google.common.util.concurrent.AbstractService
 
test() - Method in class com.google.common.collect.testing.AbstractIteratorTester
Executes the test.
test() - Method in class com.google.common.testing.EquivalenceTester
Run tests on equivalence methods, throwing a failure on an invalid test
test() - Method in class com.google.common.testing.RelationshipTester
 
test(long, long) - Static method in enum class com.google.common.math.LongMath.MillerRabinTester
 
test(T) - Method in interface com.google.common.base.Predicate
 
test(T, T) - Method in class com.google.common.base.Equivalence
Deprecated.
Provided only to satisfy the BiPredicate interface; use Equivalence.equivalent(T, T) instead.
TEST_SUFFIX - Static variable in class com.google.common.testing.AbstractPackageSanityTests
 
testAbsent() - Method in class com.google.common.collect.testing.testers.MapMergeTester
 
testAdd_nullSupported() - Method in class com.google.common.collect.testing.testers.CollectionAddTester
 
testAdd_nullUnsupported() - Method in class com.google.common.collect.testing.testers.CollectionAddTester
 
testAdd_supportedNotPresent() - Method in class com.google.common.collect.testing.testers.CollectionAddTester
 
testAdd_supportedNullPresent() - Method in class com.google.common.collect.testing.testers.ListAddTester
 
testAdd_supportedNullPresent() - Method in class com.google.common.collect.testing.testers.SetAddTester
 
testAdd_supportedPresent() - Method in class com.google.common.collect.testing.testers.ListAddTester
 
testAdd_supportedPresent() - Method in class com.google.common.collect.testing.testers.SetAddTester
 
testAdd_unsupportedNotPresent() - Method in class com.google.common.collect.testing.testers.CollectionAddTester
 
testAdd_unsupportedPresent() - Method in class com.google.common.collect.testing.testers.CollectionAddTester
 
testAdd_unsupportedPresent() - Method in class com.google.common.collect.testing.testers.ListAddTester
 
testAddAll_emptyMultiset() - Method in class com.google.common.collect.testing.google.MultisetAddTester
 
testAddAll_emptySet() - Method in class com.google.common.collect.testing.google.MultisetAddTester
 
testAddAll_nonEmptyList() - Method in class com.google.common.collect.testing.google.MultisetAddTester
 
testAddAll_nonEmptyMultiset() - Method in class com.google.common.collect.testing.google.MultisetAddTester
 
testAddAll_nullCollectionReference() - Method in class com.google.common.collect.testing.testers.CollectionAddAllTester
 
testAddAll_nullSupported() - Method in class com.google.common.collect.testing.testers.CollectionAddAllTester
 
testAddAll_nullUnsupported() - Method in class com.google.common.collect.testing.testers.CollectionAddAllTester
 
testAddAll_supportedAllPresent() - Method in class com.google.common.collect.testing.testers.ListAddAllTester
 
testAddAll_supportedAllPresent() - Method in class com.google.common.collect.testing.testers.SetAddAllTester
 
testAddAll_supportedNonePresent() - Method in class com.google.common.collect.testing.testers.CollectionAddAllTester
 
testAddAll_supportedNothing() - Method in class com.google.common.collect.testing.testers.CollectionAddAllTester
 
testAddAll_supportedSomePresent() - Method in class com.google.common.collect.testing.testers.CollectionAddAllTester
 
testAddAll_supportedSomePresent() - Method in class com.google.common.collect.testing.testers.SetAddAllTester
 
testAddAll_unsupportedAllPresent() - Method in class com.google.common.collect.testing.testers.CollectionAddAllTester
 
testAddAll_unsupportedAllPresent() - Method in class com.google.common.collect.testing.testers.ListAddAllTester
 
testAddAll_unsupportedNonePresent() - Method in class com.google.common.collect.testing.testers.CollectionAddAllTester
 
testAddAll_unsupportedNothing() - Method in class com.google.common.collect.testing.testers.CollectionAddAllTester
 
testAddAll_unsupportedSomePresent() - Method in class com.google.common.collect.testing.testers.CollectionAddAllTester
 
testAddAll_withDuplicates() - Method in class com.google.common.collect.testing.testers.ListAddAllTester
 
testAddAll_withDuplicates() - Method in class com.google.common.collect.testing.testers.SetAddAllTester
 
testAddAllAtIndex_end() - Method in class com.google.common.collect.testing.testers.ListAddAllAtIndexTester
 
testAddAllAtIndex_middle() - Method in class com.google.common.collect.testing.testers.ListAddAllAtIndexTester
 
testAddAllAtIndex_negative() - Method in class com.google.common.collect.testing.testers.ListAddAllAtIndexTester
 
testAddAllAtIndex_nullCollectionReference() - Method in class com.google.common.collect.testing.testers.ListAddAllAtIndexTester
 
testAddAllAtIndex_nullSupported() - Method in class com.google.common.collect.testing.testers.ListAddAllAtIndexTester
 
testAddAllAtIndex_nullUnsupported() - Method in class com.google.common.collect.testing.testers.ListAddAllAtIndexTester
 
testAddAllAtIndex_supportedAllPresent() - Method in class com.google.common.collect.testing.testers.ListAddAllAtIndexTester
 
testAddAllAtIndex_supportedNothing() - Method in class com.google.common.collect.testing.testers.ListAddAllAtIndexTester
 
testAddAllAtIndex_supportedSomePresent() - Method in class com.google.common.collect.testing.testers.ListAddAllAtIndexTester
 
testAddAllAtIndex_tooLarge() - Method in class com.google.common.collect.testing.testers.ListAddAllAtIndexTester
 
testAddAllAtIndex_unsupportedAllPresent() - Method in class com.google.common.collect.testing.testers.ListAddAllAtIndexTester
 
testAddAllAtIndex_unsupportedNothing() - Method in class com.google.common.collect.testing.testers.ListAddAllAtIndexTester
 
testAddAllAtIndex_unsupportedSomePresent() - Method in class com.google.common.collect.testing.testers.ListAddAllAtIndexTester
 
testAddAllAtIndex_withDuplicates() - Method in class com.google.common.collect.testing.testers.ListAddAllAtIndexTester
 
testAddAllConcurrentWithIteration() - Method in class com.google.common.collect.testing.testers.CollectionAddAllTester
 
testAddAtIndex_end() - Method in class com.google.common.collect.testing.testers.ListAddAtIndexTester
 
testAddAtIndex_middle() - Method in class com.google.common.collect.testing.testers.ListAddAtIndexTester
 
testAddAtIndex_negative() - Method in class com.google.common.collect.testing.testers.ListAddAtIndexTester
 
testAddAtIndex_nullSupported() - Method in class com.google.common.collect.testing.testers.ListAddAtIndexTester
 
testAddAtIndex_nullUnsupported() - Method in class com.google.common.collect.testing.testers.ListAddAtIndexTester
 
testAddAtIndex_supportedNotPresent() - Method in class com.google.common.collect.testing.testers.ListAddAtIndexTester
 
testAddAtIndex_supportedPresent() - Method in class com.google.common.collect.testing.testers.ListAddAtIndexTester
 
testAddAtIndex_tooLarge() - Method in class com.google.common.collect.testing.testers.ListAddAtIndexTester
 
testAddAtIndex_unsupportedNotPresent() - Method in class com.google.common.collect.testing.testers.ListAddAtIndexTester
 
testAddAtIndex_unsupportedPresent() - Method in class com.google.common.collect.testing.testers.ListAddAtIndexTester
 
testAddAtIndexConcurrentWithIteration() - Method in class com.google.common.collect.testing.testers.ListAddAtIndexTester
 
testAddConcurrentWithIteration() - Method in class com.google.common.collect.testing.testers.CollectionAddTester
 
testAddMeansAddOne() - Method in class com.google.common.collect.testing.google.MultisetAddTester
 
testAddNullValue() - Method in class com.google.common.collect.testing.google.MultimapAsMapGetTester
 
testAddNullValueUnsupported() - Method in class com.google.common.collect.testing.google.MultimapAsMapGetTester
 
testAddOccurrences() - Method in class com.google.common.collect.testing.google.MultisetAddTester
 
testAddOccurrences_unsupported() - Method in class com.google.common.collect.testing.google.MultisetAddTester
 
testAddOccurrencesNegative() - Method in class com.google.common.collect.testing.google.MultisetAddTester
 
testAddOccurrencesZero() - Method in class com.google.common.collect.testing.google.MultisetAddTester
 
testAddOutOfHeadBoundsOne() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testAddOutOfHeadBoundsSeveral() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testAddOutOfTailBoundsOne() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testAddOutOfTailBoundsSeveral() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testAddSeveralTimes() - Method in class com.google.common.collect.testing.google.MultisetAddTester
 
testAddTooMany() - Method in class com.google.common.collect.testing.google.MultisetAddTester
 
testAddUnsupported() - Method in class com.google.common.collect.testing.google.MultisetAddTester
 
testAddWithConflictingBounds() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testAllListenersCompleteSuccessfully() - Method in class com.google.common.util.concurrent.testing.AbstractListenableFutureTest
Tests that all listeners complete, even if they were added before or after the future was finishing.
testAllPublicConstructors(Class<?>) - Method in class com.google.common.testing.NullPointerTester
Runs NullPointerTester.testConstructor(java.lang.reflect.Constructor<?>) on every public constructor in class c.
testAllPublicInstanceMethods(Object) - Method in class com.google.common.testing.NullPointerTester
Runs NullPointerTester.testMethod(java.lang.Object, java.lang.reflect.Method) on every public instance method of the class of instance, including those inherited from superclasses of the same package.
testAllPublicStaticMethods(Class<?>) - Method in class com.google.common.testing.NullPointerTester
Runs NullPointerTester.testMethod(java.lang.Object, java.lang.reflect.Method) on every public static method of class c, including those "inherited" from superclasses of the same package.
testAsMapEntrySetIteratorRemovePropagatesToMultimap() - Method in class com.google.common.collect.testing.google.MultimapAsMapTester
 
testAsMapEntrySetReflectsPutDifferentKey() - Method in class com.google.common.collect.testing.google.MultimapAsMapTester
 
testAsMapEntrySetReflectsPutSameKey() - Method in class com.google.common.collect.testing.google.MultimapAsMapTester
 
testAsMapEntrySetRemovePropagatesToMultimap() - Method in class com.google.common.collect.testing.google.MultimapAsMapTester
 
testAsMapGet() - Method in class com.google.common.collect.testing.google.MultimapAsMapTester
 
testAsMapGetImplementsList() - Method in class com.google.common.collect.testing.google.ListMultimapAsMapTester
 
testAsMapGetImplementsSet() - Method in class com.google.common.collect.testing.google.SetMultimapAsMapTester
 
testAsMapGetImplementsSortedSet() - Method in class com.google.common.collect.testing.google.SortedSetMultimapAsMapTester
 
testAsMapGetNullKeyAbsent() - Method in class com.google.common.collect.testing.google.MultimapAsMapTester
 
testAsMapGetNullKeyPresent() - Method in class com.google.common.collect.testing.google.MultimapAsMapTester
 
testAsMapGetNullKeyUnsupported() - Method in class com.google.common.collect.testing.google.MultimapAsMapTester
 
testAsMapRemove() - Method in class com.google.common.collect.testing.google.MultimapAsMapTester
 
testAsMapRemoveImplementsList() - Method in class com.google.common.collect.testing.google.ListMultimapAsMapTester
 
testAsMapRemoveImplementsSet() - Method in class com.google.common.collect.testing.google.SetMultimapAsMapTester
 
testAsMapRemoveImplementsSortedSet() - Method in class com.google.common.collect.testing.google.SortedSetMultimapAsMapTester
 
testAsMapValuesImplementList() - Method in class com.google.common.collect.testing.google.ListMultimapAsMapTester
 
testAsMapValuesImplementSet() - Method in class com.google.common.collect.testing.google.SetMultimapAsMapTester
 
testAsMapValuesImplementSortedSet() - Method in class com.google.common.collect.testing.google.SortedSetMultimapAsMapTester
 
TestBiMapGenerator<K,V> - Interface in com.google.common.collect.testing.google
Creates bimaps, containing sample entries, to be tested.
testCanceledFutureThrowsCancellation() - Method in class com.google.common.util.concurrent.testing.AbstractListenableFutureTest
Tests that a canceled future throws a cancellation exception.
testCeiling() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testCeiling() - Method in class com.google.common.collect.testing.testers.NavigableMapNavigationTester
 
testCeiling() - Method in class com.google.common.collect.testing.testers.NavigableSetNavigationTester
 
testCeilingHole() - Method in class com.google.common.collect.testing.testers.NavigableSetNavigationTester
 
TestCharacterListGenerator - Class in com.google.common.collect.testing
Generates List<Character> instances for test suites.
TestCharacterListGenerator() - Constructor for class com.google.common.collect.testing.TestCharacterListGenerator
 
testClear() - Method in class com.google.common.collect.testing.google.MultimapClearTester
 
testClear() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testClear() - Method in class com.google.common.collect.testing.testers.CollectionClearTester
 
testClear() - Method in class com.google.common.collect.testing.testers.MapClearTester
 
testClear_unsupported() - Method in class com.google.common.collect.testing.testers.CollectionClearTester
 
testClear_unsupported() - Method in class com.google.common.collect.testing.testers.MapClearTester
 
testClear_unsupportedByEmptyCollection() - Method in class com.google.common.collect.testing.testers.CollectionClearTester
 
testClear_unsupportedByEmptyCollection() - Method in class com.google.common.collect.testing.testers.MapClearTester
 
testClearClearsInverse() - Method in class com.google.common.collect.testing.google.BiMapClearTester
 
testClearConcurrentWithEntrySetIteration() - Method in class com.google.common.collect.testing.testers.MapClearTester
 
testClearConcurrentWithIteration() - Method in class com.google.common.collect.testing.testers.CollectionClearTester
 
testClearConcurrentWithKeySetIteration() - Method in class com.google.common.collect.testing.testers.MapClearTester
 
testClearConcurrentWithValuesIteration() - Method in class com.google.common.collect.testing.testers.MapClearTester
 
testClearHeadClosed() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testClearHeadClosedEntrySet() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testClearHeadOpen() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testClearHeadOpenEntrySet() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testClearInverseClears() - Method in class com.google.common.collect.testing.google.BiMapClearTester
 
testClearInverseKeySetClears() - Method in class com.google.common.collect.testing.google.BiMapClearTester
 
testClearInverseValuesClears() - Method in class com.google.common.collect.testing.google.BiMapClearTester
 
testClearPropagatesToAsMap() - Method in class com.google.common.collect.testing.google.MultimapClearTester
 
testClearPropagatesToAsMapGet() - Method in class com.google.common.collect.testing.google.MultimapClearTester
 
testClearPropagatesToEntries() - Method in class com.google.common.collect.testing.google.MultimapClearTester
 
testClearPropagatesToGet() - Method in class com.google.common.collect.testing.google.MultimapClearTester
 
testClearTailClosed() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testClearTailClosedEntrySet() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testClearTailOpen() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testClearTailOpenEntrySet() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testClearThroughAsMap() - Method in class com.google.common.collect.testing.google.MultimapClearTester
 
testClearThroughEntries() - Method in class com.google.common.collect.testing.google.MultimapClearTester
 
testClearThroughKeys() - Method in class com.google.common.collect.testing.google.MultimapClearTester
 
testClearThroughKeySet() - Method in class com.google.common.collect.testing.google.MultimapClearTester
 
testClearThroughValues() - Method in class com.google.common.collect.testing.google.MultimapClearTester
 
testClearUnsupported() - Method in class com.google.common.collect.testing.google.MultimapClearTester
 
TestCollectionGenerator<E> - Interface in com.google.common.collect.testing
Creates collections, containing sample elements, to be tested.
TestCollidingSetGenerator - Class in com.google.common.collect.testing
A generator using sample elements whose hash codes all collide badly.
TestCollidingSetGenerator() - Constructor for class com.google.common.collect.testing.TestCollidingSetGenerator
 
testComparator(Comparator<? super T>, List<T>) - Static method in class com.google.common.collect.testing.Helpers
Asserts that all pairs of T values within valuesInExpectedOrder are ordered consistently between their order within valuesInExpectedOrder and the order implied by the given comparator.
testComparator(Comparator<? super T>, T...) - Static method in class com.google.common.collect.testing.Helpers
Asserts that all pairs of T values within valuesInExpectedOrder are ordered consistently between their order within valuesInExpectedOrder and the order implied by the given comparator.
testCompareToAndEquals(List<T>) - Static method in class com.google.common.collect.testing.Helpers
 
testCompute_absentFunctionThrows() - Method in class com.google.common.collect.testing.testers.MapComputeTester
 
testCompute_absentToAbsent() - Method in class com.google.common.collect.testing.testers.MapComputeTester
 
testCompute_absentToPresent() - Method in class com.google.common.collect.testing.testers.MapComputeTester
 
testCompute_nullKeyPresentToPresent() - Method in class com.google.common.collect.testing.testers.MapComputeTester
 
testCompute_presentFunctionThrows() - Method in class com.google.common.collect.testing.testers.MapComputeTester
 
testCompute_presentNullToNull() - Method in class com.google.common.collect.testing.testers.MapComputeTester
 
testCompute_presentNullToPresentNonnull() - Method in class com.google.common.collect.testing.testers.MapComputeTester
 
testCompute_presentToAbsent() - Method in class com.google.common.collect.testing.testers.MapComputeTester
 
testCompute_presentToPresent() - Method in class com.google.common.collect.testing.testers.MapComputeTester
 
testComputeIfAbsent_functionReturnsNullNotInserted() - Method in class com.google.common.collect.testing.testers.MapComputeIfAbsentTester
 
testComputeIfAbsent_functionThrows() - Method in class com.google.common.collect.testing.testers.MapComputeIfAbsentTester
 
testComputeIfAbsent_nullKeySupported() - Method in class com.google.common.collect.testing.testers.MapComputeIfAbsentTester
 
testComputeIfAbsent_nullKeyUnsupported() - Method in class com.google.common.collect.testing.testers.MapComputeIfAbsentTester
 
testComputeIfAbsent_nullTreatedAsAbsent() - Method in class com.google.common.collect.testing.testers.MapComputeIfAbsentTester
 
testComputeIfAbsent_supportedAbsent() - Method in class com.google.common.collect.testing.testers.MapComputeIfAbsentTester
 
testComputeIfAbsent_supportedPresent() - Method in class com.google.common.collect.testing.testers.MapComputeIfAbsentTester
 
testComputeIfAbsent_unsupportedAbsent() - Method in class com.google.common.collect.testing.testers.MapComputeIfAbsentTester
 
testComputeIfAbsent_unsupportedPresentDifferentValue() - Method in class com.google.common.collect.testing.testers.MapComputeIfAbsentTester
 
testComputeIfAbsent_unsupportedPresentExistingValue() - Method in class com.google.common.collect.testing.testers.MapComputeIfAbsentTester
 
testComputeIfPresent_functionReturnsNull() - Method in class com.google.common.collect.testing.testers.MapComputeIfPresentTester
 
testComputeIfPresent_functionThrows() - Method in class com.google.common.collect.testing.testers.MapComputeIfPresentTester
 
testComputeIfPresent_nullKeySupportedAbsent() - Method in class com.google.common.collect.testing.testers.MapComputeIfPresentTester
 
testComputeIfPresent_nullKeySupportedPresent() - Method in class com.google.common.collect.testing.testers.MapComputeIfPresentTester
 
testComputeIfPresent_nullTreatedAsAbsent() - Method in class com.google.common.collect.testing.testers.MapComputeIfPresentTester
 
testComputeIfPresent_supportedAbsent() - Method in class com.google.common.collect.testing.testers.MapComputeIfPresentTester
 
testComputeIfPresent_supportedPresent() - Method in class com.google.common.collect.testing.testers.MapComputeIfPresentTester
 
testComputeIfPresent_unsupportedAbsent() - Method in class com.google.common.collect.testing.testers.MapComputeIfPresentTester
 
testComputeIfPresent_unsupportedPresent() - Method in class com.google.common.collect.testing.testers.MapComputeIfPresentTester
 
testConflictingBounds() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testConstructor(Constructor<?>) - Method in class com.google.common.testing.NullPointerTester
Verifies that ctor produces a NullPointerException or UnsupportedOperationException whenever any of its non-nullable parameters are null.
testConstructorParameter(Constructor<?>, int) - Method in class com.google.common.testing.NullPointerTester
Verifies that ctor produces a NullPointerException or UnsupportedOperationException when the parameter in position paramIndex is null.
testConstructors(Class<?>, NullPointerTester.Visibility) - Method in class com.google.common.testing.NullPointerTester
Runs NullPointerTester.testConstructor(java.lang.reflect.Constructor<?>) on every constructor in class c that has at least minimalVisibility.
TestContainerGenerator<T,E> - Interface in com.google.common.collect.testing
To be implemented by test generators of things that can contain elements.
testContains_no() - Method in class com.google.common.collect.testing.testers.CollectionContainsTester
 
testContains_no() - Method in class com.google.common.collect.testing.testers.MapContainsKeyTester
 
testContains_no() - Method in class com.google.common.collect.testing.testers.MapContainsValueTester
 
testContains_nonNullWhenNullContained() - Method in class com.google.common.collect.testing.testers.CollectionContainsTester
 
testContains_nonNullWhenNullContained() - Method in class com.google.common.collect.testing.testers.MapContainsKeyTester
 
testContains_nonNullWhenNullContained() - Method in class com.google.common.collect.testing.testers.MapContainsValueTester
 
testContains_nullContained() - Method in class com.google.common.collect.testing.testers.CollectionContainsTester
 
testContains_nullContained() - Method in class com.google.common.collect.testing.testers.MapContainsKeyTester
 
testContains_nullContained() - Method in class com.google.common.collect.testing.testers.MapContainsValueTester
 
testContains_nullNotContainedAndUnsupported() - Method in class com.google.common.collect.testing.testers.CollectionContainsTester
 
testContains_nullNotContainedAndUnsupported() - Method in class com.google.common.collect.testing.testers.MapContainsKeyTester
 
testContains_nullNotContainedAndUnsupported() - Method in class com.google.common.collect.testing.testers.MapContainsValueTester
 
testContains_nullNotContainedButAllowed() - Method in class com.google.common.collect.testing.testers.MapContainsKeyTester
 
testContains_nullNotContainedButAllowed() - Method in class com.google.common.collect.testing.testers.MapContainsValueTester
 
testContains_nullNotContainedButQueriesSupported() - Method in class com.google.common.collect.testing.testers.CollectionContainsTester
 
testContains_wrongType() - Method in class com.google.common.collect.testing.testers.CollectionContainsTester
 
testContains_wrongType() - Method in class com.google.common.collect.testing.testers.MapContainsKeyTester
 
testContains_wrongType() - Method in class com.google.common.collect.testing.testers.MapContainsValueTester
 
testContains_yes() - Method in class com.google.common.collect.testing.testers.CollectionContainsTester
 
testContains_yes() - Method in class com.google.common.collect.testing.testers.MapContainsKeyTester
 
testContains_yes() - Method in class com.google.common.collect.testing.testers.MapContainsValueTester
 
testContainsAll_disjoint() - Method in class com.google.common.collect.testing.testers.CollectionContainsAllTester
 
testContainsAll_empty() - Method in class com.google.common.collect.testing.testers.CollectionContainsAllTester
 
testContainsAll_nullAllowed() - Method in class com.google.common.collect.testing.testers.CollectionContainsAllTester
 
testContainsAll_nullNotAllowed() - Method in class com.google.common.collect.testing.testers.CollectionContainsAllTester
 
testContainsAll_nullPresent() - Method in class com.google.common.collect.testing.testers.CollectionContainsAllTester
 
testContainsAll_partialOverlap() - Method in class com.google.common.collect.testing.testers.CollectionContainsAllTester
 
testContainsAll_sameElements() - Method in class com.google.common.collect.testing.testers.CollectionContainsAllTester
 
testContainsAll_self() - Method in class com.google.common.collect.testing.testers.CollectionContainsAllTester
 
testContainsAll_subset() - Method in class com.google.common.collect.testing.testers.CollectionContainsAllTester
 
testContainsAll_wrongType() - Method in class com.google.common.collect.testing.testers.CollectionContainsAllTester
 
testContainsAllListIgnoresFrequency() - Method in class com.google.common.collect.testing.google.MultisetContainsTester
 
testContainsAllMultisetIgnoresFrequency() - Method in class com.google.common.collect.testing.google.MultisetContainsTester
 
testContainsEntryAgreesWithGet() - Method in class com.google.common.collect.testing.google.MultimapContainsEntryTester
 
testContainsEntryNo() - Method in class com.google.common.collect.testing.google.MultimapContainsEntryTester
 
testContainsEntryNullDisallowedBecauseKeyQueriesDisallowed() - Method in class com.google.common.collect.testing.google.MultimapContainsEntryTester
 
testContainsEntryNullDisallowedBecauseValueQueriesDisallowed() - Method in class com.google.common.collect.testing.google.MultimapContainsEntryTester
 
testContainsEntryNullNo() - Method in class com.google.common.collect.testing.google.MultimapContainsEntryTester
 
testContainsEntryNullYes() - Method in class com.google.common.collect.testing.google.MultimapContainsEntryTester
 
testContainsEntryWithIncomparableKey() - Method in class com.google.common.collect.testing.testers.MapEntrySetTester
 
testContainsEntryWithIncomparableValue() - Method in class com.google.common.collect.testing.testers.MapEntrySetTester
 
testContainsEntryWithNullKeyAbsent() - Method in class com.google.common.collect.testing.google.MultimapEntriesTester
 
testContainsEntryWithNullKeyAbsent() - Method in class com.google.common.collect.testing.testers.MapEntrySetTester
 
testContainsEntryWithNullKeyPresent() - Method in class com.google.common.collect.testing.google.MultimapEntriesTester
 
testContainsEntryWithNullKeyPresent() - Method in class com.google.common.collect.testing.testers.MapEntrySetTester
 
testContainsEntryWithNullValueAbsent() - Method in class com.google.common.collect.testing.google.MultimapEntriesTester
 
testContainsEntryWithNullValueAbsent() - Method in class com.google.common.collect.testing.testers.MapEntrySetTester
 
testContainsEntryWithNullValuePresent() - Method in class com.google.common.collect.testing.google.MultimapEntriesTester
 
testContainsEntryWithNullValuePresent() - Method in class com.google.common.collect.testing.testers.MapEntrySetTester
 
testContainsEntryYes() - Method in class com.google.common.collect.testing.google.MultimapContainsEntryTester
 
testContainsKey() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testContainsKeyAgreesWithAsMap() - Method in class com.google.common.collect.testing.google.MultimapContainsKeyTester
 
testContainsKeyAgreesWithGet() - Method in class com.google.common.collect.testing.google.MultimapContainsKeyTester
 
testContainsKeyAgreesWithKeySet() - Method in class com.google.common.collect.testing.google.MultimapContainsKeyTester
 
testContainsKeyNo() - Method in class com.google.common.collect.testing.google.MultimapContainsKeyTester
 
testContainsKeyNullAbsent() - Method in class com.google.common.collect.testing.google.MultimapContainsKeyTester
 
testContainsKeyNullDisallowed() - Method in class com.google.common.collect.testing.google.MultimapContainsKeyTester
 
testContainsKeyNullPresent() - Method in class com.google.common.collect.testing.google.MultimapContainsKeyTester
 
testContainsKeysFromKeySet() - Method in class com.google.common.collect.testing.google.MultimapContainsKeyTester
 
testContainsKeyYes() - Method in class com.google.common.collect.testing.google.MultimapContainsKeyTester
 
testContainsNullValueFails() - Method in class com.google.common.collect.testing.google.MultimapContainsValueTester
 
testContainsNullValueNo() - Method in class com.google.common.collect.testing.google.MultimapContainsValueTester
 
testContainsNullValueYes() - Method in class com.google.common.collect.testing.google.MultimapContainsValueTester
 
testContainsValue() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testContainsValueNo() - Method in class com.google.common.collect.testing.google.MultimapContainsValueTester
 
testContainsValueYes() - Method in class com.google.common.collect.testing.google.MultimapContainsValueTester
 
testCount_0() - Method in class com.google.common.collect.testing.google.MultisetCountTester
 
testCount_1() - Method in class com.google.common.collect.testing.google.MultisetCountTester
 
testCount_3() - Method in class com.google.common.collect.testing.google.MultisetCountTester
 
testCount_null_forbidden() - Method in class com.google.common.collect.testing.google.MultisetCountTester
 
testCount_nullAbsent() - Method in class com.google.common.collect.testing.google.MultisetCountTester
 
testCount_nullPresent() - Method in class com.google.common.collect.testing.google.MultisetCountTester
 
testCount_wrongType() - Method in class com.google.common.collect.testing.google.MultisetCountTester
 
testCreateWithDuplicates() - Method in class com.google.common.collect.testing.testers.ListCreationTester
 
testCreateWithDuplicates_nonNullDuplicatesNotRejected() - Method in class com.google.common.collect.testing.testers.MapCreationTester
 
testCreateWithDuplicates_nonNullDuplicatesNotRejected() - Method in class com.google.common.collect.testing.testers.SetCreationTester
 
testCreateWithDuplicates_nonNullDuplicatesRejected() - Method in class com.google.common.collect.testing.testers.MapCreationTester
 
testCreateWithDuplicates_nonNullDuplicatesRejected() - Method in class com.google.common.collect.testing.testers.SetCreationTester
 
testCreateWithDuplicates_nullDuplicatesNotRejected() - Method in class com.google.common.collect.testing.testers.MapCreationTester
 
testCreateWithDuplicates_nullDuplicatesNotRejected() - Method in class com.google.common.collect.testing.testers.SetCreationTester
 
testCreateWithDuplicates_nullDuplicatesRejected() - Method in class com.google.common.collect.testing.testers.MapCreationTester
 
testCreateWithDuplicates_nullDuplicatesRejected() - Method in class com.google.common.collect.testing.testers.SetCreationTester
 
testCreateWithNull_supported() - Method in class com.google.common.collect.testing.testers.CollectionCreationTester
 
testCreateWithNull_unsupported() - Method in class com.google.common.collect.testing.testers.CollectionCreationTester
 
testCreateWithNullKeyAndValueSupported() - Method in class com.google.common.collect.testing.testers.MapCreationTester
 
testCreateWithNullKeySupported() - Method in class com.google.common.collect.testing.testers.MapCreationTester
 
testCreateWithNullKeyUnsupported() - Method in class com.google.common.collect.testing.testers.MapCreationTester
 
testCreateWithNullValueSupported() - Method in class com.google.common.collect.testing.testers.MapCreationTester
 
testCreateWithNullValueUnsupported() - Method in class com.google.common.collect.testing.testers.MapCreationTester
 
testDescendingNavigation() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testDescendingNavigation() - Method in class com.google.common.collect.testing.testers.NavigableMapNavigationTester
 
testDescendingNavigation() - Method in class com.google.common.collect.testing.testers.NavigableSetNavigationTester
 
testElement_empty() - Method in class com.google.common.collect.testing.testers.QueueElementTester
 
testElement_size1() - Method in class com.google.common.collect.testing.testers.QueueElementTester
 
testElement_sizeMany() - Method in class com.google.common.collect.testing.testers.QueueElementTester
 
testElementSet_contains() - Method in class com.google.common.collect.testing.google.MultisetReadsTester
 
testElementSetClear() - Method in class com.google.common.collect.testing.google.MultisetElementSetTester
 
testElementSetReflectsAddAbsent() - Method in class com.google.common.collect.testing.google.MultisetElementSetTester
 
testElementSetReflectsRemove() - Method in class com.google.common.collect.testing.google.MultisetElementSetTester
 
testElementSetRemoveAbsent() - Method in class com.google.common.collect.testing.google.MultisetElementSetTester
 
testElementSetRemoveDuplicatePropagatesToMultiset() - Method in class com.google.common.collect.testing.google.MultisetElementSetTester
 
testElementSetRemovePropagatesToMultiset() - Method in class com.google.common.collect.testing.google.MultisetElementSetTester
 
testElementSetSerialization() - Method in class com.google.common.collect.testing.google.MultisetSerializationTester
 
testEmptyMapFirst() - Method in class com.google.common.collect.testing.testers.NavigableMapNavigationTester
 
testEmptyMapFirst() - Method in class com.google.common.collect.testing.testers.SortedMapNavigationTester
 
testEmptyMapLast() - Method in class com.google.common.collect.testing.testers.NavigableMapNavigationTester
 
testEmptyMapLast() - Method in class com.google.common.collect.testing.testers.SortedMapNavigationTester
 
testEmptyMapNearby() - Method in class com.google.common.collect.testing.testers.NavigableMapNavigationTester
 
testEmptyMapPollFirst() - Method in class com.google.common.collect.testing.testers.NavigableMapNavigationTester
 
testEmptyMapPollLast() - Method in class com.google.common.collect.testing.testers.NavigableMapNavigationTester
 
testEmptyMultisetFirst() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testEmptyMultisetLast() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testEmptyMultisetNearby() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testEmptyMultisetPollFirst() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testEmptyMultisetPollLast() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testEmptyRangeSubMultiset(SortedMultiset<E>) - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testEmptyRangeSubMultisetSupportingAdd(SortedMultiset<E>) - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testEmptySetFirst() - Method in class com.google.common.collect.testing.testers.SortedSetNavigationTester
 
testEmptySetLast() - Method in class com.google.common.collect.testing.testers.SortedSetNavigationTester
 
testEmptySetNearby() - Method in class com.google.common.collect.testing.testers.NavigableSetNavigationTester
 
testEmptySetPollFirst() - Method in class com.google.common.collect.testing.testers.NavigableSetNavigationTester
 
testEmptySetPollLast() - Method in class com.google.common.collect.testing.testers.NavigableSetNavigationTester
 
testEmptySubSet() - Method in class com.google.common.collect.testing.testers.NavigableSetNavigationTester
 
testEntries() - Method in class com.google.common.collect.testing.google.MultimapEntriesTester
 
testEntriesRemainValidAfterRemove() - Method in class com.google.common.collect.testing.google.MultimapEntriesTester
 
testEntryReflectsClear() - Method in class com.google.common.collect.testing.google.MultisetEntrySetTester
 
testEntryReflectsElementSetClear() - Method in class com.google.common.collect.testing.google.MultisetEntrySetTester
 
testEntryReflectsElementSetIteratorRemove() - Method in class com.google.common.collect.testing.google.MultisetEntrySetTester
 
testEntryReflectsEntrySetClear() - Method in class com.google.common.collect.testing.google.MultisetEntrySetTester
 
testEntryReflectsEntrySetIteratorRemove() - Method in class com.google.common.collect.testing.google.MultisetEntrySetTester
 
testEntryReflectsIteratorRemove() - Method in class com.google.common.collect.testing.google.MultisetEntrySetTester
 
testEntryReflectsRemoveThenAdd() - Method in class com.google.common.collect.testing.google.MultisetEntrySetTester
 
testEntrySet() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testEntrySet_clear() - Method in class com.google.common.collect.testing.google.MultisetEntrySetTester
 
testEntrySet_contains() - Method in class com.google.common.collect.testing.google.MultisetReadsTester
 
testEntrySet_contains_count0() - Method in class com.google.common.collect.testing.google.MultisetReadsTester
 
testEntrySet_contains_nonentry() - Method in class com.google.common.collect.testing.google.MultisetReadsTester
 
testEntrySet_hashCode_size0() - Method in class com.google.common.collect.testing.google.MultisetReadsTester
 
testEntrySet_hashCode_size1() - Method in class com.google.common.collect.testing.google.MultisetReadsTester
 
testEntrySet_iteratorRemovePropagates() - Method in class com.google.common.collect.testing.google.MultisetEntrySetTester
 
testEntrySet_removeAbsent() - Method in class com.google.common.collect.testing.google.MultisetEntrySetTester
 
testEntrySet_removeAllAbsent() - Method in class com.google.common.collect.testing.google.MultisetEntrySetTester
 
testEntrySet_removeAllPresent() - Method in class com.google.common.collect.testing.google.MultisetEntrySetTester
 
testEntrySet_removePresent() - Method in class com.google.common.collect.testing.google.MultisetEntrySetTester
 
testEntrySet_retainAllAbsent() - Method in class com.google.common.collect.testing.google.MultisetEntrySetTester
 
testEntrySet_retainAllPresent() - Method in class com.google.common.collect.testing.google.MultisetEntrySetTester
 
testEntrySet_twice() - Method in class com.google.common.collect.testing.google.MultisetReadsTester
 
testEntrySetAddAndAddAll() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testEntrySetClear() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testEntrySetContainsEntryIncompatibleKey() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testEntrySetContainsEntryNullKeyMissing() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testEntrySetContainsEntryNullKeyPresent() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testEntrySetEquals() - Method in class com.google.common.collect.testing.google.ListMultimapAsMapTester
 
testEntrySetEquals() - Method in class com.google.common.collect.testing.google.SetMultimapAsMapTester
 
testEntrySetForEmptyMap() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testEntrySetIteratorRemove() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testEntrySetIteratorRemove() - Method in class com.google.common.collect.testing.testers.MapEntrySetTester
 
testEntrySetRemove() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testEntrySetRemoveAll() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testEntrySetRemoveAllNullFromEmpty() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testEntrySetRemoveDifferentValue() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testEntrySetRemoveMissingKey() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testEntrySetRemoveNullKeyMissing() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testEntrySetRemoveNullKeyPresent() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testEntrySetRetainAll() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testEntrySetRetainAllNullFromEmpty() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testEntrySetSerialization() - Method in class com.google.common.collect.testing.google.MultisetSerializationTester
 
testEntrySetSetValue() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testEntrySetSetValueSameValue() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testEntryViewReflectsRemove() - Method in class com.google.common.collect.testing.google.MultisetEntrySetTester
 
TestEnumMapGenerator - Class in com.google.common.collect.testing
Implementation helper for TestMapGenerator for use with enum maps.
TestEnumMapGenerator() - Constructor for class com.google.common.collect.testing.TestEnumMapGenerator
 
TestEnumMultisetGenerator - Class in com.google.common.collect.testing.google
An abstract TestMultisetGenerator for generating multisets containing enum values.
TestEnumMultisetGenerator() - Constructor for class com.google.common.collect.testing.google.TestEnumMultisetGenerator
 
TestEnumSetGenerator - Class in com.google.common.collect.testing
An abstract TestSetGenerator for generating sets containing enum values.
TestEnumSetGenerator() - Constructor for class com.google.common.collect.testing.TestEnumSetGenerator
 
testEquals() - Method in class com.google.common.collect.testing.google.ListMultimapAsMapTester
 
testEquals() - Method in class com.google.common.collect.testing.google.SetMultimapAsMapTester
 
testEquals() - Method in class com.google.common.testing.AbstractPackageSanityTests
Tests equals() and hashCode() implementations for every top-level class in the package, that explicitly implements Object.equals(java.lang.Object).
testEquals() - Method in class com.google.common.testing.ClassSanityTester.FactoryMethodReturnValueTester
Tests Object.equals(java.lang.Object) and Object.hashCode() against the return values of the static methods, by asserting that when equal parameters are passed to the same static method, the return value should also be equal; and vice versa.
testEquals() - Method in class com.google.common.testing.EqualsTester
Run tests on equals method, throwing a failure on an invalid test
testEquals(Class<?>) - Method in class com.google.common.testing.ClassSanityTester
testEquals(Class<T>, Function<? super T, ? extends T>) - Static method in class com.google.common.testing.ForwardingWrapperTester
 
testEquals_containingNull() - Method in class com.google.common.collect.testing.testers.ListEqualsTester
 
testEquals_containingNull() - Method in class com.google.common.collect.testing.testers.SetEqualsTester
 
testEquals_containingNullKey() - Method in class com.google.common.collect.testing.testers.MapEqualsTester
 
testEquals_containingNullValue() - Method in class com.google.common.collect.testing.testers.MapEqualsTester
 
testEquals_differentElements() - Method in class com.google.common.collect.testing.google.MultisetReadsTester
 
testEquals_differentSize() - Method in class com.google.common.collect.testing.google.MultisetReadsTester
 
testEquals_largerMap() - Method in class com.google.common.collect.testing.testers.MapEqualsTester
 
testEquals_largerSet() - Method in class com.google.common.collect.testing.testers.SetEqualsTester
 
testEquals_list() - Method in class com.google.common.collect.testing.testers.MapEqualsTester
 
testEquals_list() - Method in class com.google.common.collect.testing.testers.SetEqualsTester
 
testEquals_longerList() - Method in class com.google.common.collect.testing.testers.ListEqualsTester
 
testEquals_notACollection() - Method in class com.google.common.collect.testing.testers.CollectionEqualsTester
 
testEquals_null() - Method in class com.google.common.collect.testing.testers.CollectionEqualsTester
 
testEquals_otherContainsNull() - Method in class com.google.common.collect.testing.testers.SetEqualsTester
 
testEquals_otherContainsNullKey() - Method in class com.google.common.collect.testing.testers.MapEqualsTester
 
testEquals_otherContainsNullValue() - Method in class com.google.common.collect.testing.testers.MapEqualsTester
 
testEquals_otherListContainingNull() - Method in class com.google.common.collect.testing.testers.ListEqualsTester
 
testEquals_otherListWithDifferentElements() - Method in class com.google.common.collect.testing.testers.ListEqualsTester
 
testEquals_otherListWithSameElements() - Method in class com.google.common.collect.testing.testers.ListEqualsTester
 
testEquals_otherMapWithDifferentEntries() - Method in class com.google.common.collect.testing.testers.MapEqualsTester
 
testEquals_otherMapWithSameEntries() - Method in class com.google.common.collect.testing.testers.MapEqualsTester
 
testEquals_otherSetWithDifferentElements() - Method in class com.google.common.collect.testing.testers.SetEqualsTester
 
testEquals_otherSetWithSameElements() - Method in class com.google.common.collect.testing.testers.SetEqualsTester
 
testEquals_self() - Method in class com.google.common.collect.testing.testers.CollectionEqualsTester
 
testEquals_set() - Method in class com.google.common.collect.testing.testers.ListEqualsTester
 
testEquals_shorterList() - Method in class com.google.common.collect.testing.testers.ListEqualsTester
 
testEquals_smallerMap() - Method in class com.google.common.collect.testing.testers.MapEqualsTester
 
testEquals_smallerSet() - Method in class com.google.common.collect.testing.testers.SetEqualsTester
 
testEquals_yes() - Method in class com.google.common.collect.testing.google.MultisetReadsTester
 
testEqualsAndSerializable() - Method in class com.google.common.testing.ClassSanityTester.FactoryMethodReturnValueTester
Runs equals and serialization test on the return values.
testEqualsFalse() - Method in class com.google.common.collect.testing.google.MultimapEqualsTester
 
testEqualsForEmptyMap() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testEqualsForEqualMap() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testEqualsForLargerMap() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testEqualsForSmallerMap() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testEqualsMultimapWithNullKey() - Method in class com.google.common.collect.testing.google.MultimapEqualsTester
 
testEqualsMultimapWithNullValue() - Method in class com.google.common.collect.testing.google.MultimapEqualsTester
 
testEqualsMultisetWithNullValue() - Method in class com.google.common.collect.testing.google.MultisetEqualsTester
 
testEqualsSameContents() - Method in class com.google.common.collect.testing.google.MultisetEqualsTester
 
testEqualsTrue() - Method in class com.google.common.collect.testing.google.MultimapEqualsTester
 
testEqualsUsing(Invokable<?, ?>) - Method in class com.google.common.testing.ClassSanityTester
 
tester - Variable in class com.google.common.testing.AbstractPackageSanityTests
 
tester - Variable in class com.google.common.testing.ClassSanityTester.SerializableDummyProxy
 
TesterAnnotation - Annotation Interface in com.google.common.collect.testing.features
Use this to meta-annotate XxxFeature.Require annotations, so that those annotations can be used to decide whether to apply a test to a given class-under-test.
TesterRequirements - Class in com.google.common.collect.testing.features
Encapsulates the constraints that a class under test must satisfy in order for a tester method to be run against that class.
TesterRequirements() - Constructor for class com.google.common.collect.testing.features.TesterRequirements
 
TesterRequirements(TesterRequirements) - Constructor for class com.google.common.collect.testing.features.TesterRequirements
 
TesterRequirements(Set<Feature<?>>, Set<Feature<?>>) - Constructor for class com.google.common.collect.testing.features.TesterRequirements
 
testers - Variable in class com.google.common.collect.testing.PerCollectionSizeTestSuiteBuilder.OneSizeTestSuiteBuilder
 
TESTERS - Static variable in class com.google.common.collect.testing.ConcurrentMapTestSuiteBuilder
 
testExceptionPropagation(Class<T>, Method, Function<? super T, ? extends T>) - Static method in class com.google.common.testing.ForwardingWrapperTester
 
testFind_no() - Method in class com.google.common.collect.testing.testers.AbstractListIndexOfTester
 
testFind_nonNullWhenNullContained() - Method in class com.google.common.collect.testing.testers.AbstractListIndexOfTester
 
testFind_nullContained() - Method in class com.google.common.collect.testing.testers.AbstractListIndexOfTester
 
testFind_nullNotContainedAndUnsupported() - Method in class com.google.common.collect.testing.testers.AbstractListIndexOfTester
 
testFind_nullNotContainedButSupported() - Method in class com.google.common.collect.testing.testers.AbstractListIndexOfTester
 
testFind_wrongType() - Method in class com.google.common.collect.testing.testers.AbstractListIndexOfTester
 
testFind_yes() - Method in class com.google.common.collect.testing.testers.AbstractListIndexOfTester
 
testFirst() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testFirst() - Method in class com.google.common.collect.testing.testers.NavigableMapNavigationTester
 
testFirst() - Method in class com.google.common.collect.testing.testers.SortedMapNavigationTester
 
testFirst() - Method in class com.google.common.collect.testing.testers.SortedSetNavigationTester
 
testFloor() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testFloor() - Method in class com.google.common.collect.testing.testers.NavigableMapNavigationTester
 
testFloor() - Method in class com.google.common.collect.testing.testers.NavigableSetNavigationTester
 
testFloorHole() - Method in class com.google.common.collect.testing.testers.NavigableSetNavigationTester
 
testForcePutKeyAndValuePresent() - Method in class com.google.common.collect.testing.google.BiMapPutTester
 
testForcePutKeyPresent() - Method in class com.google.common.collect.testing.google.BiMapPutTester
 
testForcePutNullKeyPresent() - Method in class com.google.common.collect.testing.google.BiMapPutTester
 
testForcePutNullValuePresent() - Method in class com.google.common.collect.testing.google.BiMapPutTester
 
testForcePutValuePresent() - Method in class com.google.common.collect.testing.google.BiMapPutTester
 
testForEach() - Method in class com.google.common.collect.testing.google.MultimapForEachTester
 
testForEach_nullKeys() - Method in class com.google.common.collect.testing.testers.MapForEachTester
 
testForEach_nullValues() - Method in class com.google.common.collect.testing.testers.MapForEachTester
 
testForEachEntry() - Method in class com.google.common.collect.testing.google.MultisetForEachEntryTester
 
testForEachEntryDuplicates() - Method in class com.google.common.collect.testing.google.MultisetForEachEntryTester
 
testForEachEntryOrdered() - Method in class com.google.common.collect.testing.google.MultisetForEachEntryTester
 
testForEachKnownOrder() - Method in class com.google.common.collect.testing.testers.CollectionForEachTester
 
testForEachKnownOrder() - Method in class com.google.common.collect.testing.testers.MapForEachTester
 
testForEachOrder() - Method in class com.google.common.collect.testing.google.MultimapForEachTester
 
testForEachRemaining() - Method in class com.google.common.collect.testing.AbstractIteratorTester
 
testForEachUnknownOrder() - Method in class com.google.common.collect.testing.testers.CollectionForEachTester
 
testForEachUnknownOrder() - Method in class com.google.common.collect.testing.testers.MapForEachTester
 
testForwarding(Class<T>, Function<? super T, ? extends T>) - Method in class com.google.common.testing.ForwardingWrapperTester
Tests that the forwarding wrapper returned by wrapperFunction properly forwards method calls with parameters passed as is, return value returned as is, and exceptions propagated as is.
testGet() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testGet_negative() - Method in class com.google.common.collect.testing.testers.ListGetTester
 
testGet_no() - Method in class com.google.common.collect.testing.testers.MapGetTester
 
testGet_nonNullWhenNullContained() - Method in class com.google.common.collect.testing.testers.MapGetTester
 
testGet_nullContained() - Method in class com.google.common.collect.testing.testers.MapGetTester
 
testGet_nullNotContainedAndUnsupported() - Method in class com.google.common.collect.testing.testers.MapGetTester
 
testGet_nullNotContainedButAllowed() - Method in class com.google.common.collect.testing.testers.MapGetTester
 
testGet_tooLarge() - Method in class com.google.common.collect.testing.testers.ListGetTester
 
testGet_valid() - Method in class com.google.common.collect.testing.testers.ListGetTester
 
testGet_wrongType() - Method in class com.google.common.collect.testing.testers.MapGetOrDefaultTester
 
testGet_wrongType() - Method in class com.google.common.collect.testing.testers.MapGetTester
 
testGet_yes() - Method in class com.google.common.collect.testing.testers.MapGetTester
 
testGetAbsentKey() - Method in class com.google.common.collect.testing.google.MultimapGetTester
 
testGetBlocksUntilValueAvailable() - Method in class com.google.common.util.concurrent.testing.AbstractListenableFutureTest
Tests that the Future.get() method blocks until a value is available.
testGetEmpty() - Method in class com.google.common.collect.testing.google.MultimapGetTester
 
testGetForEmptyMap() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testGetMultiple() - Method in class com.google.common.collect.testing.google.MultimapGetTester
 
testGetNonEmpty() - Method in class com.google.common.collect.testing.google.MultimapGetTester
 
testGetNull() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testGetNullAbsent() - Method in class com.google.common.collect.testing.google.MultimapGetTester
 
testGetNullForbidden() - Method in class com.google.common.collect.testing.google.MultimapGetTester
 
testGetNullPresent() - Method in class com.google.common.collect.testing.google.MultimapGetTester
 
testGetOrDefault_absent() - Method in class com.google.common.collect.testing.testers.MapGetOrDefaultTester
 
testGetOrDefault_absentNull() - Method in class com.google.common.collect.testing.testers.MapGetOrDefaultTester
 
testGetOrDefault_absentNullDefault() - Method in class com.google.common.collect.testing.testers.MapGetOrDefaultTester
 
testGetOrDefault_nonNullWhenNullContained() - Method in class com.google.common.collect.testing.testers.MapGetOrDefaultTester
 
testGetOrDefault_nullAbsentAndUnsupported() - Method in class com.google.common.collect.testing.testers.MapGetOrDefaultTester
 
testGetOrDefault_present() - Method in class com.google.common.collect.testing.testers.MapGetOrDefaultTester
 
testGetOrDefault_presentMappedToNull() - Method in class com.google.common.collect.testing.testers.MapGetOrDefaultTester
 
testGetOrDefault_presentNull() - Method in class com.google.common.collect.testing.testers.MapGetOrDefaultTester
 
testGetOrDefault_presentNullDefault() - Method in class com.google.common.collect.testing.testers.MapGetOrDefaultTester
 
testGetWithNullValue() - Method in class com.google.common.collect.testing.google.MultimapGetTester
 
testHashCode() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testHashCode() - Method in class com.google.common.collect.testing.testers.ListHashCodeTester
 
testHashCode() - Method in class com.google.common.collect.testing.testers.MapHashCodeTester
 
testHashCode() - Method in class com.google.common.collect.testing.testers.SetHashCodeTester
 
testHashCode_containingNull() - Method in class com.google.common.collect.testing.testers.SetHashCodeTester
 
testHashCode_containingNullKey() - Method in class com.google.common.collect.testing.testers.MapHashCodeTester
 
testHashCode_containingNullValue() - Method in class com.google.common.collect.testing.testers.MapHashCodeTester
 
testHashCode_size0() - Method in class com.google.common.collect.testing.google.MultisetReadsTester
 
testHashCode_size1() - Method in class com.google.common.collect.testing.google.MultisetReadsTester
 
testHashCodeForEmptyMap() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testHashCodeMatchesAsMap() - Method in class com.google.common.collect.testing.google.MultimapEqualsTester
 
testHashCodeMatchesEntrySet() - Method in class com.google.common.collect.testing.google.MultisetEqualsTester
 
testHeadClosedDistinctElements() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testHeadClosedEntrySet() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testHeadClosedSize() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testHeadMap() - Method in class com.google.common.collect.testing.testers.SortedMapNavigationTester
 
testHeadMapExclusive() - Method in class com.google.common.collect.testing.testers.NavigableMapNavigationTester
 
testHeadMapExclusive() - Method in class com.google.common.collect.testing.testers.SortedMapNavigationTester
 
testHeadMapInclusive() - Method in class com.google.common.collect.testing.testers.NavigableMapNavigationTester
 
testHeadOpenDistinctElements() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testHeadOpenEntrySet() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testHeadOpenSize() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testHigher() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testHigher() - Method in class com.google.common.collect.testing.testers.NavigableMapNavigationTester
 
testHigher() - Method in class com.google.common.collect.testing.testers.NavigableSetNavigationTester
 
testHigherHole() - Method in class com.google.common.collect.testing.testers.NavigableSetNavigationTester
 
testIndexOf_duplicate() - Method in class com.google.common.collect.testing.testers.ListIndexOfTester
 
TestingExecutors - Class in com.google.common.util.concurrent.testing
Factory methods for ExecutorService for testing.
TestingExecutors() - Constructor for class com.google.common.util.concurrent.testing.TestingExecutors
 
TestingExecutors.NoOpScheduledExecutorService - Class in com.google.common.util.concurrent.testing
 
TestingExecutors.NoOpScheduledExecutorService.NeverScheduledFuture<V> - Class in com.google.common.util.concurrent.testing
 
testInstanceMethods(Object, NullPointerTester.Visibility) - Method in class com.google.common.testing.NullPointerTester
Runs NullPointerTester.testMethod(java.lang.Object, java.lang.reflect.Method) on every instance method of the class of instance with at least minimalVisibility, including those inherited from superclasses of the same package.
TestIntegerSetGenerator - Class in com.google.common.collect.testing
Create integer sets for collection tests.
TestIntegerSetGenerator() - Constructor for class com.google.common.collect.testing.TestIntegerSetGenerator
 
TestIntegerSortedSetGenerator - Class in com.google.common.collect.testing
Create integer sets for testing collections that are sorted by natural ordering.
TestIntegerSortedSetGenerator() - Constructor for class com.google.common.collect.testing.TestIntegerSortedSetGenerator
 
testInteraction(Function<? super T, ? extends T>) - Method in class com.google.common.testing.ForwardingWrapperTester.InteractionTester
 
testInversePut() - Method in class com.google.common.collect.testing.google.BiMapPutTester
 
testInverseSame() - Method in class com.google.common.collect.testing.google.BiMapInverseTester
 
testInverseSerialization() - Method in class com.google.common.collect.testing.google.BiMapInverseTester
 
testIsEmpty_no() - Method in class com.google.common.collect.testing.testers.CollectionIsEmptyTester
 
testIsEmpty_no() - Method in class com.google.common.collect.testing.testers.MapIsEmptyTester
 
testIsEmpty_yes() - Method in class com.google.common.collect.testing.testers.CollectionIsEmptyTester
 
testIsEmpty_yes() - Method in class com.google.common.collect.testing.testers.MapIsEmptyTester
 
testIsEmptyNo() - Method in class com.google.common.collect.testing.google.MultimapSizeTester
 
testIsEmptyYes() - Method in class com.google.common.collect.testing.google.MultimapSizeTester
 
testItems() - Method in class com.google.common.testing.EqualsTester
 
testItems() - Method in class com.google.common.testing.EquivalenceTester
 
testIterationOrdering() - Method in class com.google.common.collect.testing.testers.CollectionIteratorTester
 
testIterator() - Method in class com.google.common.collect.testing.testers.CollectionIteratorTester
 
testIterator_knownOrderRemoveSupported() - Method in class com.google.common.collect.testing.testers.CollectionIteratorTester
 
testIterator_knownOrderRemoveUnsupported() - Method in class com.google.common.collect.testing.testers.CollectionIteratorTester
 
testIterator_nullElement() - Method in class com.google.common.collect.testing.testers.CollectionIteratorTester
 
testIterator_removeAffectsBackingCollection() - Method in class com.google.common.collect.testing.testers.CollectionIteratorTester
 
testIterator_unknownOrderRemoveSupported() - Method in class com.google.common.collect.testing.testers.CollectionIteratorTester
 
testIterator_unknownOrderRemoveUnsupported() - Method in class com.google.common.collect.testing.testers.CollectionIteratorTester
 
TestIteratorGenerator<E> - Interface in com.google.common.collect.testing
Creates iterators to be tested.
testIteratorKnownOrder() - Method in class com.google.common.collect.testing.google.MultisetIteratorTester
 
testIteratorNoSuchElementException() - Method in class com.google.common.collect.testing.testers.CollectionIteratorTester
 
testIteratorRemove_unsupported() - Method in class com.google.common.collect.testing.testers.CollectionRemoveTester
 
testIteratorRemovePropagatesToMultimap() - Method in class com.google.common.collect.testing.google.MultimapEntriesTester
 
testIteratorUnknownOrder() - Method in class com.google.common.collect.testing.google.MultisetIteratorTester
 
testKeys() - Method in class com.google.common.collect.testing.google.MultimapKeysTester
 
testKeysCountAbsentNullKey() - Method in class com.google.common.collect.testing.google.MultimapKeysTester
 
testKeysElementSet() - Method in class com.google.common.collect.testing.google.MultimapKeysTester
 
testKeysEntrySetIteratorRemove() - Method in class com.google.common.collect.testing.google.MultimapKeysTester
 
testKeysEntrySetRemove() - Method in class com.google.common.collect.testing.google.MultimapKeysTester
 
testKeySet() - Method in class com.google.common.collect.testing.google.MultimapKeySetTester
 
testKeySetClear() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testKeySetClearClearsInverse() - Method in class com.google.common.collect.testing.google.BiMapClearTester
 
testKeySetContainsNullKeyAbsent() - Method in class com.google.common.collect.testing.google.MultimapKeySetTester
 
testKeySetContainsNullKeyPresent() - Method in class com.google.common.collect.testing.google.MultimapKeySetTester
 
testKeySetIteratorRemove() - Method in class com.google.common.collect.testing.google.BiMapRemoveTester
 
testKeySetIteratorRemove() - Method in class com.google.common.collect.testing.google.MultimapKeySetTester
 
testKeySetRemove() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testKeySetRemoveAll() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testKeySetRemoveAllNullFromEmpty() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testKeySetRemovePropagatesToMultimap() - Method in class com.google.common.collect.testing.google.MultimapKeySetTester
 
testKeySetRetainAll() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testKeySetRetainAllNullFromEmpty() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testKeysRemove() - Method in class com.google.common.collect.testing.google.MultimapKeysTester
 
testKeysWithNullKey() - Method in class com.google.common.collect.testing.google.MultimapKeysTester
 
testLast() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testLast() - Method in class com.google.common.collect.testing.testers.NavigableMapNavigationTester
 
testLast() - Method in class com.google.common.collect.testing.testers.SortedMapNavigationTester
 
testLast() - Method in class com.google.common.collect.testing.testers.SortedSetNavigationTester
 
testLastIndexOf_duplicate() - Method in class com.google.common.collect.testing.testers.ListLastIndexOfTester
 
testListenersNotifiedOnError() - Method in class com.google.common.util.concurrent.testing.AbstractListenableFutureTest
 
TestListGenerator<E> - Interface in com.google.common.collect.testing
Creates sets, containing sample elements, to be tested.
testListIterator_atSize() - Method in class com.google.common.collect.testing.testers.ListListIteratorTester
 
testListIterator_fullyModifiable() - Method in class com.google.common.collect.testing.testers.ListListIteratorTester
 
testListIterator_tooHigh() - Method in class com.google.common.collect.testing.testers.ListListIteratorTester
 
testListIterator_tooLow() - Method in class com.google.common.collect.testing.testers.ListListIteratorTester
 
testListIterator_unmodifiable() - Method in class com.google.common.collect.testing.testers.ListListIteratorTester
 
TestListMultimapGenerator<K,V> - Interface in com.google.common.collect.testing.google
A generator for ListMultimap implementations based on test data.
TestLogHandler - Class in com.google.common.testing
Tests may use this to intercept messages that are logged by the code under test.
TestLogHandler() - Constructor for class com.google.common.testing.TestLogHandler
 
testLower() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testLower() - Method in class com.google.common.collect.testing.testers.NavigableMapNavigationTester
 
testLower() - Method in class com.google.common.collect.testing.testers.NavigableSetNavigationTester
 
testLowerHole() - Method in class com.google.common.collect.testing.testers.NavigableSetNavigationTester
 
testMakingUserPermissionsFromScratch() - Static method in class com.google.common.io.TempFileCreator
Creates the permissions normally used for Windows filesystems, looking up the user afresh, even if previous calls have initialized the PermissionSupplier fields.
TestMapEntrySetGenerator<K,V> - Class in com.google.common.collect.testing
Creates map entries using sample keys and sample values.
TestMapEntrySetGenerator(SampleElements<K>, SampleElements<V>) - Constructor for class com.google.common.collect.testing.TestMapEntrySetGenerator
 
TestMapGenerator<K,V> - Interface in com.google.common.collect.testing
Creates maps, containing sample elements, to be tested.
testMappedToNull() - Method in class com.google.common.collect.testing.testers.MapMergeTester
 
testMergeAbsentNullKey() - Method in class com.google.common.collect.testing.testers.MapMergeTester
 
testMergeFunctionThrows() - Method in class com.google.common.collect.testing.testers.MapMergeTester
 
testMergeNullFunction() - Method in class com.google.common.collect.testing.testers.MapMergeTester
 
testMergeNullValue() - Method in class com.google.common.collect.testing.testers.MapMergeTester
 
testMergePresent() - Method in class com.google.common.collect.testing.testers.MapMergeTester
 
testMergePresentToNull() - Method in class com.google.common.collect.testing.testers.MapMergeTester
 
testMergeUnsupported() - Method in class com.google.common.collect.testing.testers.MapMergeTester
 
testMethod(Object, Method) - Method in class com.google.common.testing.NullPointerTester
Verifies that method produces a NullPointerException or UnsupportedOperationException whenever any of its non-nullable parameters are null.
testMethodParameter(Object, Method, int) - Method in class com.google.common.testing.NullPointerTester
Verifies that method produces a NullPointerException or UnsupportedOperationException when the parameter in position paramIndex is null.
TestMultimapGenerator<K,V,M> - Interface in com.google.common.collect.testing.google
Creates multimaps, containing sample elements, to be tested.
testMultimapRemoveDeletesFirstOccurrence() - Method in class com.google.common.collect.testing.google.ListMultimapRemoveTester
 
TestMultisetGenerator<E> - Interface in com.google.common.collect.testing.google
Creates multisets, containing sample elements, to be tested.
testNotEqualsEmpty() - Method in class com.google.common.collect.testing.google.MultimapEqualsTester
 
testNotEqualsEmpty() - Method in class com.google.common.collect.testing.google.MultisetEqualsTester
 
testNulls() - Method in class com.google.common.testing.AbstractPackageSanityTests
Performs NullPointerTester checks for all top-level classes in the package.
testNulls() - Method in class com.google.common.testing.ClassSanityTester.FactoryMethodReturnValueTester
Tests null checks against the instance methods of the return values, if any.
testNulls(Class<?>) - Method in class com.google.common.testing.ClassSanityTester
Tests that cls properly checks null on all constructor and method parameters that aren't annotated nullable (according to the rules of NullPointerTester).
testOffer_nullSupported() - Method in class com.google.common.collect.testing.testers.QueueOfferTester
 
testOffer_nullUnsupported() - Method in class com.google.common.collect.testing.testers.QueueOfferTester
 
testOffer_supportedNotPresent() - Method in class com.google.common.collect.testing.testers.QueueOfferTester
 
testOrderedByComparator() - Method in class com.google.common.collect.testing.testers.SortedMapNavigationTester
 
testOrderingAffectsEqualsComparisons() - Method in class com.google.common.collect.testing.google.ListMultimapEqualsTester
 
testOrderingDoesntAffectEqualsComparisons() - Method in class com.google.common.collect.testing.google.SetMultimapEqualsTester
 
testParameter(Object, Invokable<?, ?>, int, Class<?>) - Method in class com.google.common.testing.NullPointerTester
Verifies that invokable produces a NullPointerException or UnsupportedOperationException when the parameter in position paramIndex is null.
testPeek_empty() - Method in class com.google.common.collect.testing.testers.QueuePeekTester
 
testPeek_size1() - Method in class com.google.common.collect.testing.testers.QueuePeekTester
 
testPeek_sizeMany() - Method in class com.google.common.collect.testing.testers.QueuePeekTester
 
testPoll_empty() - Method in class com.google.common.collect.testing.testers.QueuePollTester
 
testPoll_size1() - Method in class com.google.common.collect.testing.testers.QueuePollTester
 
testPoll_sizeMany() - Method in class com.google.common.collect.testing.testers.QueuePollTester
 
testPollFirst() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testPollFirst() - Method in class com.google.common.collect.testing.testers.NavigableMapNavigationTester
 
testPollFirst() - Method in class com.google.common.collect.testing.testers.NavigableSetNavigationTester
 
testPollFirstUnsupported() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testPollFirstUnsupported() - Method in class com.google.common.collect.testing.testers.NavigableMapNavigationTester
 
testPollFirstUnsupported() - Method in class com.google.common.collect.testing.testers.NavigableSetNavigationTester
 
testPollLast() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testPollLast() - Method in class com.google.common.collect.testing.testers.NavigableMapNavigationTester
 
testPollLast() - Method in class com.google.common.collect.testing.testers.NavigableSetNavigationTester
 
testPollLastUnsupported() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testPollLastUnsupported() - Method in class com.google.common.collect.testing.testers.NavigableMapNavigationTester
 
testPollLastUnsupported() - Method in class com.google.common.collect.testing.testers.NavigableSetNavigationTester
 
testPropagatesAddAllToMultimap() - Method in class com.google.common.collect.testing.google.MultimapGetTester
 
testPropagatesAddToMultimap() - Method in class com.google.common.collect.testing.google.MultimapAsMapGetTester
 
testPropagatesAddToMultimap() - Method in class com.google.common.collect.testing.google.MultimapGetTester
 
testPropagatesClearToMultimap() - Method in class com.google.common.collect.testing.google.MultimapAsMapGetTester
 
testPropagatesRemoveLastElementToMultimap() - Method in class com.google.common.collect.testing.google.MultimapAsMapGetTester
 
testPropagatesRemoveLastElementToMultimap() - Method in class com.google.common.collect.testing.google.MultimapGetTester
 
testPropagatesRemoveLastThenAddToMultimap() - Method in class com.google.common.collect.testing.google.MultimapGetTester
 
testPropagatesRemoveThenAddToMultimap() - Method in class com.google.common.collect.testing.google.MultimapAsMapGetTester
 
testPropagatesRemoveToMultimap() - Method in class com.google.common.collect.testing.google.MultimapAsMapGetTester
 
testPropagatesRemoveToMultimap() - Method in class com.google.common.collect.testing.google.MultimapGetTester
 
testPut_nullKeyAndValueSupported() - Method in class com.google.common.collect.testing.testers.MapPutTester
 
testPut_nullKeySupportedNotPresent() - Method in class com.google.common.collect.testing.testers.MapPutTester
 
testPut_nullKeySupportedPresent() - Method in class com.google.common.collect.testing.testers.MapPutTester
 
testPut_nullKeyUnsupported() - Method in class com.google.common.collect.testing.testers.MapPutTester
 
testPut_nullValueSupported() - Method in class com.google.common.collect.testing.testers.MapPutIfAbsentTester
 
testPut_nullValueSupported() - Method in class com.google.common.collect.testing.testers.MapPutTester
 
testPut_nullValueUnsupported() - Method in class com.google.common.collect.testing.testers.MapPutTester
 
testPut_replaceNullValueWithNonNullSupported() - Method in class com.google.common.collect.testing.testers.MapPutTester
 
testPut_replaceNullValueWithNullSupported() - Method in class com.google.common.collect.testing.testers.MapPutTester
 
testPut_replaceWithNullValueSupported() - Method in class com.google.common.collect.testing.testers.MapPutTester
 
testPut_replaceWithNullValueUnsupported() - Method in class com.google.common.collect.testing.testers.MapPutTester
 
testPut_supportedNotPresent() - Method in class com.google.common.collect.testing.testers.MapPutTester
 
testPut_supportedPresent() - Method in class com.google.common.collect.testing.testers.MapPutTester
 
testPut_unsupportedNotPresent() - Method in class com.google.common.collect.testing.testers.MapPutTester
 
testPut_unsupportedPresentDifferentValue() - Method in class com.google.common.collect.testing.testers.MapPutTester
 
testPut_unsupportedPresentExistingValue() - Method in class com.google.common.collect.testing.testers.MapPutTester
 
testPutAbsentConcurrentWithEntrySetIteration() - Method in class com.google.common.collect.testing.testers.MapPutTester
 
testPutAbsentConcurrentWithKeySetIteration() - Method in class com.google.common.collect.testing.testers.MapPutTester
 
testPutAbsentConcurrentWithValueIteration() - Method in class com.google.common.collect.testing.testers.MapPutTester
 
testPutAddsValueAtEnd() - Method in class com.google.common.collect.testing.google.ListMultimapPutTester
 
testPutAll() - Method in class com.google.common.collect.testing.google.MultimapPutAllMultimapTester
 
testPutAll_nullCollectionReference() - Method in class com.google.common.collect.testing.testers.MapPutAllTester
 
testPutAll_nullKeySupported() - Method in class com.google.common.collect.testing.testers.MapPutAllTester
 
testPutAll_nullKeyUnsupported() - Method in class com.google.common.collect.testing.testers.MapPutAllTester
 
testPutAll_nullValueSupported() - Method in class com.google.common.collect.testing.testers.MapPutAllTester
 
testPutAll_nullValueUnsupported() - Method in class com.google.common.collect.testing.testers.MapPutAllTester
 
testPutAll_supportedNonePresent() - Method in class com.google.common.collect.testing.testers.MapPutAllTester
 
testPutAll_supportedNothing() - Method in class com.google.common.collect.testing.testers.MapPutAllTester
 
testPutAll_supportedSomePresent() - Method in class com.google.common.collect.testing.testers.MapPutAllTester
 
testPutAll_unsupportedAllPresent() - Method in class com.google.common.collect.testing.testers.MapPutAllTester
 
testPutAll_unsupportedNonePresent() - Method in class com.google.common.collect.testing.testers.MapPutAllTester
 
testPutAll_unsupportedNothing() - Method in class com.google.common.collect.testing.testers.MapPutAllTester
 
testPutAll_unsupportedSomePresent() - Method in class com.google.common.collect.testing.testers.MapPutAllTester
 
testPutAllAddsAtEndInOrder() - Method in class com.google.common.collect.testing.google.ListMultimapPutAllTester
 
testPutAllEmptyCollectionOnAbsentKey() - Method in class com.google.common.collect.testing.google.MultimapPutIterableTester
 
testPutAllEmptyIterableOnAbsentKey() - Method in class com.google.common.collect.testing.google.MultimapPutIterableTester
 
testPutAllEmptyIterableOnPresentKey() - Method in class com.google.common.collect.testing.google.MultimapPutIterableTester
 
testPutAllExistingKey() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testPutAllHandlesDuplicates() - Method in class com.google.common.collect.testing.google.SetMultimapPutAllTester
 
testPutAllIntoEmpty() - Method in class com.google.common.collect.testing.google.MultimapPutAllMultimapTester
 
testPutAllNewKey() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testPutAllNonEmptyCollectionOnAbsentKey() - Method in class com.google.common.collect.testing.google.MultimapPutIterableTester
 
testPutAllNonEmptyCollectionOnPresentKey() - Method in class com.google.common.collect.testing.google.MultimapPutIterableTester
 
testPutAllNonEmptyIterableOnAbsentKey() - Method in class com.google.common.collect.testing.google.MultimapPutIterableTester
 
testPutAllNonEmptyIterableOnPresentKey() - Method in class com.google.common.collect.testing.google.MultimapPutIterableTester
 
testPutAllNullForbidden() - Method in class com.google.common.collect.testing.google.MultimapPutIterableTester
 
testPutAllNullValueNullFirst_unsupported() - Method in class com.google.common.collect.testing.google.MultimapPutIterableTester
 
testPutAllNullValueNullLast_unsupported() - Method in class com.google.common.collect.testing.google.MultimapPutIterableTester
 
testPutAllNullValueOnAbsentKey_supported() - Method in class com.google.common.collect.testing.google.MultimapPutIterableTester
 
testPutAllNullValueOnPresentKey_supported() - Method in class com.google.common.collect.testing.google.MultimapPutIterableTester
 
testPutAllNullValueSingle_unsupported() - Method in class com.google.common.collect.testing.google.MultimapPutIterableTester
 
testPutAllOnlyCallsIteratorOnce() - Method in class com.google.common.collect.testing.google.MultimapPutIterableTester
 
testPutAllOnPresentNullKey() - Method in class com.google.common.collect.testing.google.MultimapPutIterableTester
 
testPutAllPropagatesToGet() - Method in class com.google.common.collect.testing.google.MultimapPutAllMultimapTester
 
testPutAllPropagatesToGet() - Method in class com.google.common.collect.testing.google.MultimapPutIterableTester
 
testPutAllRejectsNullKey() - Method in class com.google.common.collect.testing.google.MultimapPutAllMultimapTester
 
testPutAllRejectsNullValue() - Method in class com.google.common.collect.testing.google.MultimapPutAllMultimapTester
 
testPutAllSomePresentConcurrentWithEntrySetIteration() - Method in class com.google.common.collect.testing.testers.MapPutAllTester
 
testPutAllWithNullKey() - Method in class com.google.common.collect.testing.google.MultimapPutAllMultimapTester
 
testPutAllWithNullValue() - Method in class com.google.common.collect.testing.google.MultimapPutAllMultimapTester
 
testPutDuplicateValue() - Method in class com.google.common.collect.testing.google.ListMultimapPutTester
 
testPutDuplicateValue() - Method in class com.google.common.collect.testing.google.SetMultimapPutTester
 
testPutDuplicateValue_null() - Method in class com.google.common.collect.testing.google.SetMultimapPutTester
 
testPutDuplicateValuePreservesSize() - Method in class com.google.common.collect.testing.google.SetMultimapPutTester
 
testPutEmpty() - Method in class com.google.common.collect.testing.google.MultimapPutTester
 
testPutExistingKey() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testPutIfAbsent_nullKeyUnsupported() - Method in class com.google.common.collect.testing.testers.ConcurrentMapPutIfAbsentTester
 
testPutIfAbsent_nullKeyUnsupported() - Method in class com.google.common.collect.testing.testers.MapPutIfAbsentTester
 
testPutIfAbsent_nullValueUnsupported() - Method in class com.google.common.collect.testing.testers.ConcurrentMapPutIfAbsentTester
 
testPutIfAbsent_nullValueUnsupportedAndKeyAbsent() - Method in class com.google.common.collect.testing.testers.MapPutIfAbsentTester
 
testPutIfAbsent_nullValueUnsupportedAndKeyPresent() - Method in class com.google.common.collect.testing.testers.MapPutIfAbsentTester
 
testPutIfAbsent_putWithNullValueUnsupported() - Method in class com.google.common.collect.testing.testers.ConcurrentMapPutIfAbsentTester
 
testPutIfAbsent_supportedAbsent() - Method in class com.google.common.collect.testing.testers.ConcurrentMapPutIfAbsentTester
 
testPutIfAbsent_supportedAbsent() - Method in class com.google.common.collect.testing.testers.MapPutIfAbsentTester
 
testPutIfAbsent_supportedPresent() - Method in class com.google.common.collect.testing.testers.ConcurrentMapPutIfAbsentTester
 
testPutIfAbsent_supportedPresent() - Method in class com.google.common.collect.testing.testers.MapPutIfAbsentTester
 
testPutIfAbsent_unsupportedAbsent() - Method in class com.google.common.collect.testing.testers.ConcurrentMapPutIfAbsentTester
 
testPutIfAbsent_unsupportedAbsent() - Method in class com.google.common.collect.testing.testers.MapPutIfAbsentTester
 
testPutIfAbsent_unsupportedPresentDifferentValue() - Method in class com.google.common.collect.testing.testers.ConcurrentMapPutIfAbsentTester
 
testPutIfAbsent_unsupportedPresentDifferentValue() - Method in class com.google.common.collect.testing.testers.MapPutIfAbsentTester
 
testPutIfAbsent_unsupportedPresentExistingValue() - Method in class com.google.common.collect.testing.testers.ConcurrentMapPutIfAbsentTester
 
testPutIfAbsent_unsupportedPresentExistingValue() - Method in class com.google.common.collect.testing.testers.MapPutIfAbsentTester
 
testPutNewKey() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testPutNotPresentKeyPropagatesToEntries() - Method in class com.google.common.collect.testing.google.MultimapPutTester
 
testPutNotPresentKeyPropagatesToGet() - Method in class com.google.common.collect.testing.google.MultimapPutTester
 
testPutNullKey() - Method in class com.google.common.collect.testing.google.MultimapPutTester
 
testPutNullKey() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testPutNullValue() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testPutNullValue_supported() - Method in class com.google.common.collect.testing.google.MultimapPutTester
 
testPutNullValue_unsupported() - Method in class com.google.common.collect.testing.google.MultimapPutTester
 
testPutNullValueForExistingKey() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testPutPresent() - Method in class com.google.common.collect.testing.google.MultimapPutTester
 
testPutPresentKeyDifferentValue() - Method in class com.google.common.collect.testing.google.BiMapPutTester
 
testPutPresentKeyPropagatesToAsMapEntrySet() - Method in class com.google.common.collect.testing.google.MultimapPutTester
 
testPutPresentKeyPropagatesToAsMapGet() - Method in class com.google.common.collect.testing.google.MultimapPutTester
 
testPutPresentKeyPropagatesToEntries() - Method in class com.google.common.collect.testing.google.MultimapPutTester
 
testPutPresentKeyPropagatesToGet() - Method in class com.google.common.collect.testing.google.MultimapPutTester
 
testPutTwoElements() - Method in class com.google.common.collect.testing.google.MultimapPutTester
 
testPutUnsupported() - Method in class com.google.common.collect.testing.google.MultimapPutAllMultimapTester
 
testPutUnsupported() - Method in class com.google.common.collect.testing.google.MultimapPutTester
 
testPutWithSameValueFails() - Method in class com.google.common.collect.testing.google.BiMapPutTester
 
TestQueueGenerator<E> - Interface in com.google.common.collect.testing
Creates queues, containing sample elements, to be tested.
testReflectsMultimapRemove() - Method in class com.google.common.collect.testing.google.MultimapAsMapGetTester
 
testRemove() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testRemove_duplicate() - Method in class com.google.common.collect.testing.testers.ListRemoveTester
 
testRemove_empty() - Method in class com.google.common.collect.testing.testers.QueueRemoveTester
 
testRemove_notPresent() - Method in class com.google.common.collect.testing.testers.CollectionRemoveTester
 
testRemove_notPresent() - Method in class com.google.common.collect.testing.testers.MapRemoveTester
 
testRemove_nullAbsent() - Method in class com.google.common.collect.testing.google.MultisetRemoveTester
 
testRemove_nullAllowed() - Method in class com.google.common.collect.testing.testers.CollectionRemoveTester
 
testRemove_nullForbidden() - Method in class com.google.common.collect.testing.google.MultisetRemoveTester
 
testRemove_nullKeyQueriesUnsupported() - Method in class com.google.common.collect.testing.testers.ConcurrentMapRemoveTester
 
testRemove_nullKeyQueriesUnsupported() - Method in class com.google.common.collect.testing.testers.MapRemoveEntryTester
 
testRemove_nullNotSupported() - Method in class com.google.common.collect.testing.testers.CollectionRemoveTester
 
testRemove_nullPresent() - Method in class com.google.common.collect.testing.google.MultisetRemoveTester
 
testRemove_nullPresent() - Method in class com.google.common.collect.testing.testers.CollectionRemoveTester
 
testRemove_nullPresent() - Method in class com.google.common.collect.testing.testers.MapRemoveTester
 
testRemove_nullQueriesNotSupported() - Method in class com.google.common.collect.testing.testers.MapRemoveTester
 
testRemove_nullSupportedMissing() - Method in class com.google.common.collect.testing.testers.MapRemoveTester
 
testRemove_nullValueQueriesUnsupported() - Method in class com.google.common.collect.testing.testers.ConcurrentMapRemoveTester
 
testRemove_nullValueQueriesUnsupported() - Method in class com.google.common.collect.testing.testers.MapRemoveEntryTester
 
testRemove_occurrences_0() - Method in class com.google.common.collect.testing.google.MultisetRemoveTester
 
testRemove_occurrences_absent() - Method in class com.google.common.collect.testing.google.MultisetRemoveTester
 
testRemove_occurrences_negative() - Method in class com.google.common.collect.testing.google.MultisetRemoveTester
 
testRemove_occurrences_present() - Method in class com.google.common.collect.testing.google.MultisetRemoveTester
 
testRemove_occurrences_unsupported_absent() - Method in class com.google.common.collect.testing.google.MultisetRemoveTester
 
testRemove_occurrences_wrongType() - Method in class com.google.common.collect.testing.google.MultisetRemoveTester
 
testRemove_present() - Method in class com.google.common.collect.testing.testers.CollectionRemoveTester
 
testRemove_present() - Method in class com.google.common.collect.testing.testers.MapRemoveTester
 
testRemove_present() - Method in class com.google.common.collect.testing.testers.SetRemoveTester
 
testRemove_size1() - Method in class com.google.common.collect.testing.testers.QueueRemoveTester
 
testRemove_sizeMany() - Method in class com.google.common.collect.testing.testers.QueueRemoveTester
 
testRemove_some_occurrences_present() - Method in class com.google.common.collect.testing.google.MultisetRemoveTester
 
testRemove_supportedAbsentKeyAbsentValue() - Method in class com.google.common.collect.testing.testers.ConcurrentMapRemoveTester
 
testRemove_supportedAbsentKeyAbsentValue() - Method in class com.google.common.collect.testing.testers.MapRemoveEntryTester
 
testRemove_supportedPresent() - Method in class com.google.common.collect.testing.testers.ConcurrentMapRemoveTester
 
testRemove_supportedPresent() - Method in class com.google.common.collect.testing.testers.MapRemoveEntryTester
 
testRemove_supportedPresentKeyWrongValue() - Method in class com.google.common.collect.testing.testers.ConcurrentMapRemoveTester
 
testRemove_supportedPresentKeyWrongValue() - Method in class com.google.common.collect.testing.testers.MapRemoveEntryTester
 
testRemove_supportedWrongKeyPresentValue() - Method in class com.google.common.collect.testing.testers.ConcurrentMapRemoveTester
 
testRemove_supportedWrongKeyPresentValue() - Method in class com.google.common.collect.testing.testers.MapRemoveEntryTester
 
testRemove_unsupported() - Method in class com.google.common.collect.testing.testers.CollectionRemoveTester
 
testRemove_unsupported() - Method in class com.google.common.collect.testing.testers.MapRemoveTester
 
testRemove_unsupportedAbsent() - Method in class com.google.common.collect.testing.testers.ConcurrentMapRemoveTester
 
testRemove_unsupportedAbsent() - Method in class com.google.common.collect.testing.testers.MapRemoveEntryTester
 
testRemove_unsupportedNotPresent() - Method in class com.google.common.collect.testing.testers.CollectionRemoveTester
 
testRemove_unsupportedNotPresent() - Method in class com.google.common.collect.testing.testers.MapRemoveTester
 
testRemove_unsupportedPresent() - Method in class com.google.common.collect.testing.testers.ConcurrentMapRemoveTester
 
testRemove_unsupportedPresent() - Method in class com.google.common.collect.testing.testers.MapRemoveEntryTester
 
testRemove_wrongType() - Method in class com.google.common.collect.testing.testers.CollectionRemoveTester
 
testRemove_wrongType() - Method in class com.google.common.collect.testing.testers.MapRemoveTester
 
testRemoveAbsent() - Method in class com.google.common.collect.testing.google.MultimapRemoveEntryTester
 
testRemoveAll_allPresent() - Method in class com.google.common.collect.testing.testers.CollectionRemoveAllTester
 
testRemoveAll_containsNullNo() - Method in class com.google.common.collect.testing.testers.CollectionRemoveAllTester
 
testRemoveAll_containsNullNoButAllowed() - Method in class com.google.common.collect.testing.testers.CollectionRemoveAllTester
 
testRemoveAll_containsNullYes() - Method in class com.google.common.collect.testing.testers.CollectionRemoveAllTester
 
testRemoveAll_containsWrongType() - Method in class com.google.common.collect.testing.testers.CollectionRemoveAllTester
 
testRemoveAll_duplicate() - Method in class com.google.common.collect.testing.testers.ListRemoveAllTester
 
testRemoveAll_emptyCollection() - Method in class com.google.common.collect.testing.testers.CollectionRemoveAllTester
 
testRemoveAll_nonePresent() - Method in class com.google.common.collect.testing.testers.CollectionRemoveAllTester
 
testRemoveAll_nullCollectionReferenceEmptySubject() - Method in class com.google.common.collect.testing.testers.CollectionRemoveAllTester
 
testRemoveAll_nullCollectionReferenceNonEmptySubject() - Method in class com.google.common.collect.testing.testers.CollectionRemoveAllTester
 
testRemoveAll_somePresent() - Method in class com.google.common.collect.testing.testers.CollectionRemoveAllTester
 
testRemoveAll_somePresentLargeCollectionToRemove() - Method in class com.google.common.collect.testing.testers.CollectionRemoveAllTester
Trigger the other.size() >= this.size() case in AbstractSet.removeAll(java.util.Collection<?>).
testRemoveAll_unsupportedEmptyCollection() - Method in class com.google.common.collect.testing.testers.CollectionRemoveAllTester
 
testRemoveAll_unsupportedNonePresent() - Method in class com.google.common.collect.testing.testers.CollectionRemoveAllTester
 
testRemoveAll_unsupportedPresent() - Method in class com.google.common.collect.testing.testers.CollectionRemoveAllTester
 
testRemoveAllAbsentKey() - Method in class com.google.common.collect.testing.google.MultimapRemoveAllTester
 
testRemoveAllIgnoresCount() - Method in class com.google.common.collect.testing.google.MultisetRemoveTester
 
testRemoveAllMultipleValues() - Method in class com.google.common.collect.testing.google.MultimapRemoveAllTester
 
testRemoveAllNullKeyAbsent() - Method in class com.google.common.collect.testing.google.MultimapRemoveAllTester
 
testRemoveAllNullKeyPresent() - Method in class com.google.common.collect.testing.google.MultimapRemoveAllTester
 
testRemoveAllPresentKey() - Method in class com.google.common.collect.testing.google.MultimapRemoveAllTester
 
testRemoveAllPropagatesToGet() - Method in class com.google.common.collect.testing.google.MultimapRemoveAllTester
 
testRemoveAllPropagatesToMultimap() - Method in class com.google.common.collect.testing.google.MultimapEntriesTester
 
testRemoveAllSomePresentConcurrentWithIteration() - Method in class com.google.common.collect.testing.testers.CollectionRemoveAllTester
 
testRemoveAtIndex_first() - Method in class com.google.common.collect.testing.testers.ListRemoveAtIndexTester
 
testRemoveAtIndex_last() - Method in class com.google.common.collect.testing.testers.ListRemoveAtIndexTester
 
testRemoveAtIndex_middle() - Method in class com.google.common.collect.testing.testers.ListRemoveAtIndexTester
 
testRemoveAtIndex_negative() - Method in class com.google.common.collect.testing.testers.ListRemoveAtIndexTester
 
testRemoveAtIndex_tooLarge() - Method in class com.google.common.collect.testing.testers.ListRemoveAtIndexTester
 
testRemoveAtIndex_unsupported() - Method in class com.google.common.collect.testing.testers.ListRemoveAtIndexTester
 
testRemoveAtIndexConcurrentWithIteration() - Method in class com.google.common.collect.testing.testers.ListRemoveAtIndexTester
 
testRemoveAtIndexFromAsMapEntrySetPropagates() - Method in class com.google.common.collect.testing.google.ListMultimapRemoveTester
 
testRemoveAtIndexFromAsMapPropagates() - Method in class com.google.common.collect.testing.google.ListMultimapRemoveTester
 
testRemoveAtIndexFromGetPropagates() - Method in class com.google.common.collect.testing.google.ListMultimapRemoveTester
 
testRemoveFromInverseKeySetRemovesFromForward() - Method in class com.google.common.collect.testing.google.BiMapRemoveTester
 
testRemoveFromInverseRemovesFromForward() - Method in class com.google.common.collect.testing.google.BiMapRemoveTester
 
testRemoveFromInverseValuesRemovesFromInverse() - Method in class com.google.common.collect.testing.google.BiMapRemoveTester
 
testRemoveFromValuesRemovesFromInverse() - Method in class com.google.common.collect.testing.google.BiMapRemoveTester
 
testRemoveIf_allPresent() - Method in class com.google.common.collect.testing.testers.CollectionRemoveIfTester
 
testRemoveIf_alwaysFalse() - Method in class com.google.common.collect.testing.testers.CollectionRemoveIfTester
 
testRemoveIf_alwaysTrueUnsupported() - Method in class com.google.common.collect.testing.testers.CollectionRemoveIfTester
 
testRemoveIf_sometimesTrue() - Method in class com.google.common.collect.testing.testers.CollectionRemoveIfTester
 
testRemoveIf_unsupportedEmptyCollection() - Method in class com.google.common.collect.testing.testers.CollectionRemoveIfTester
 
testRemoveIfSomeMatchesConcurrentWithIteration() - Method in class com.google.common.collect.testing.testers.CollectionRemoveIfTester
 
testRemoveKeyFromKeySetRemovesFromInverse() - Method in class com.google.common.collect.testing.google.BiMapRemoveTester
 
testRemoveKeyRemovesFromInverse() - Method in class com.google.common.collect.testing.google.BiMapRemoveTester
 
testRemoveMissingKey() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testRemoveNegative() - Method in class com.google.common.collect.testing.google.MultisetRemoveTester
 
testRemoveNullKeyAbsent() - Method in class com.google.common.collect.testing.google.MultimapRemoveEntryTester
 
testRemoveNullKeyForbidden() - Method in class com.google.common.collect.testing.google.MultimapRemoveEntryTester
 
testRemoveNullKeyPresent() - Method in class com.google.common.collect.testing.google.MultimapRemoveEntryTester
 
testRemoveNullValue() - Method in class com.google.common.collect.testing.google.MultimapAsMapGetTester
 
testRemoveNullValueAbsent() - Method in class com.google.common.collect.testing.google.MultimapRemoveEntryTester
 
testRemoveNullValueForbidden() - Method in class com.google.common.collect.testing.google.MultimapRemoveEntryTester
 
testRemoveNullValuePresent() - Method in class com.google.common.collect.testing.google.MultimapRemoveEntryTester
 
testRemoveOutOfHeadBoundsOne() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testRemoveOutOfHeadBoundsSeveral() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testRemoveOutOfTailBoundsOne() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testRemoveOutOfTailBoundsSeveral() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testRemovePresent() - Method in class com.google.common.collect.testing.google.MultimapRemoveEntryTester
 
testRemovePresentConcurrentWithEntrySetIteration() - Method in class com.google.common.collect.testing.testers.MapRemoveTester
 
testRemovePresentConcurrentWithIteration() - Method in class com.google.common.collect.testing.testers.CollectionRemoveTester
 
testRemovePresentConcurrentWithKeySetIteration() - Method in class com.google.common.collect.testing.testers.MapRemoveTester
 
testRemovePresentConcurrentWithValuesIteration() - Method in class com.google.common.collect.testing.testers.MapRemoveTester
 
testRemovePropagatesToAsMap() - Method in class com.google.common.collect.testing.google.MultimapRemoveEntryTester
 
testRemovePropagatesToAsMapEntrySet() - Method in class com.google.common.collect.testing.google.MultimapRemoveEntryTester
 
testRemovePropagatesToGet() - Method in class com.google.common.collect.testing.google.MultimapRemoveEntryTester
 
testRemovePropagatesToMultimap() - Method in class com.google.common.collect.testing.google.MultimapEntriesTester
 
testRemoveUnsupported() - Method in class com.google.common.collect.testing.google.MultisetRemoveTester
 
testRemoveZeroNoOp() - Method in class com.google.common.collect.testing.google.MultisetRemoveTester
 
testRemovingIteratorKnownOrder() - Method in class com.google.common.collect.testing.google.MultisetIteratorTester
 
testRemovingIteratorUnknownOrder() - Method in class com.google.common.collect.testing.google.MultisetIteratorTester
 
testReplace_absentNullKeyUnsupported() - Method in class com.google.common.collect.testing.testers.ConcurrentMapReplaceTester
 
testReplace_absentNullKeyUnsupported() - Method in class com.google.common.collect.testing.testers.MapReplaceTester
 
testReplace_absentNullValueUnsupported() - Method in class com.google.common.collect.testing.testers.ConcurrentMapReplaceTester
 
testReplace_absentNullValueUnsupported() - Method in class com.google.common.collect.testing.testers.MapReplaceTester
 
testReplace_presentNullValueUnsupported() - Method in class com.google.common.collect.testing.testers.ConcurrentMapReplaceTester
 
testReplace_presentNullValueUnsupported() - Method in class com.google.common.collect.testing.testers.MapReplaceTester
 
testReplace_supportedAbsent() - Method in class com.google.common.collect.testing.testers.ConcurrentMapReplaceTester
 
testReplace_supportedAbsent() - Method in class com.google.common.collect.testing.testers.MapReplaceTester
 
testReplace_supportedPresent() - Method in class com.google.common.collect.testing.testers.ConcurrentMapReplaceTester
 
testReplace_supportedPresent() - Method in class com.google.common.collect.testing.testers.MapReplaceTester
 
testReplace_supportedPresentNoChange() - Method in class com.google.common.collect.testing.testers.ConcurrentMapReplaceTester
 
testReplace_supportedPresentNoChange() - Method in class com.google.common.collect.testing.testers.MapReplaceTester
 
testReplace_unsupportedPresent() - Method in class com.google.common.collect.testing.testers.ConcurrentMapReplaceTester
 
testReplace_unsupportedPresent() - Method in class com.google.common.collect.testing.testers.MapReplaceTester
 
testReplaceAll() - Method in class com.google.common.collect.testing.testers.ListReplaceAllTester
 
testReplaceAll_changesSome() - Method in class com.google.common.collect.testing.testers.ListReplaceAllTester
 
testReplaceAll_unsupported() - Method in class com.google.common.collect.testing.testers.ListReplaceAllTester
 
testReplaceAll_unsupported() - Method in class com.google.common.collect.testing.testers.MapReplaceAllTester
 
testReplaceAll_unsupportedByEmptyCollection() - Method in class com.google.common.collect.testing.testers.MapReplaceAllTester
 
testReplaceAll_unsupportedNoOpFunction() - Method in class com.google.common.collect.testing.testers.MapReplaceAllTester
 
testReplaceAllPreservesOrder() - Method in class com.google.common.collect.testing.testers.MapReplaceAllTester
 
testReplaceAllRotate() - Method in class com.google.common.collect.testing.testers.MapReplaceAllTester
 
testReplaceEmptyValues() - Method in class com.google.common.collect.testing.google.MultimapReplaceValuesTester
 
testReplaceEntry_absentKeyNullValueUnsupported() - Method in class com.google.common.collect.testing.testers.ConcurrentMapReplaceEntryTester
 
testReplaceEntry_absentKeyNullValueUnsupported() - Method in class com.google.common.collect.testing.testers.MapReplaceEntryTester
 
testReplaceEntry_expectNullUnsupported() - Method in class com.google.common.collect.testing.testers.ConcurrentMapReplaceEntryTester
 
testReplaceEntry_expectNullUnsupported() - Method in class com.google.common.collect.testing.testers.MapReplaceEntryTester
 
testReplaceEntry_nullDifferentFromAbsent() - Method in class com.google.common.collect.testing.testers.ConcurrentMapReplaceEntryTester
 
testReplaceEntry_nullDifferentFromAbsent() - Method in class com.google.common.collect.testing.testers.MapReplaceEntryTester
 
testReplaceEntry_presentNullValueUnsupported() - Method in class com.google.common.collect.testing.testers.ConcurrentMapReplaceEntryTester
 
testReplaceEntry_presentNullValueUnsupported() - Method in class com.google.common.collect.testing.testers.MapReplaceEntryTester
 
testReplaceEntry_supportedAbsentKey() - Method in class com.google.common.collect.testing.testers.ConcurrentMapReplaceEntryTester
 
testReplaceEntry_supportedAbsentKey() - Method in class com.google.common.collect.testing.testers.MapReplaceEntryTester
 
testReplaceEntry_supportedPresent() - Method in class com.google.common.collect.testing.testers.ConcurrentMapReplaceEntryTester
 
testReplaceEntry_supportedPresent() - Method in class com.google.common.collect.testing.testers.MapReplaceEntryTester
 
testReplaceEntry_supportedPresentUnchanged() - Method in class com.google.common.collect.testing.testers.ConcurrentMapReplaceEntryTester
 
testReplaceEntry_supportedPresentUnchanged() - Method in class com.google.common.collect.testing.testers.MapReplaceEntryTester
 
testReplaceEntry_supportedWrongValue() - Method in class com.google.common.collect.testing.testers.ConcurrentMapReplaceEntryTester
 
testReplaceEntry_supportedWrongValue() - Method in class com.google.common.collect.testing.testers.MapReplaceEntryTester
 
testReplaceEntry_unsupportedAbsentKey() - Method in class com.google.common.collect.testing.testers.ConcurrentMapReplaceEntryTester
 
testReplaceEntry_unsupportedAbsentKey() - Method in class com.google.common.collect.testing.testers.MapReplaceEntryTester
 
testReplaceEntry_unsupportedPresent() - Method in class com.google.common.collect.testing.testers.ConcurrentMapReplaceEntryTester
 
testReplaceEntry_unsupportedPresent() - Method in class com.google.common.collect.testing.testers.MapReplaceEntryTester
 
testReplaceEntry_unsupportedWrongValue() - Method in class com.google.common.collect.testing.testers.ConcurrentMapReplaceEntryTester
 
testReplaceEntry_unsupportedWrongValue() - Method in class com.google.common.collect.testing.testers.MapReplaceEntryTester
 
testReplaceEntry_wrongValueNullValueUnsupported() - Method in class com.google.common.collect.testing.testers.ConcurrentMapReplaceEntryTester
 
testReplaceEntry_wrongValueNullValueUnsupported() - Method in class com.google.common.collect.testing.testers.MapReplaceEntryTester
 
testReplaceNonEmptyValues() - Method in class com.google.common.collect.testing.google.MultimapReplaceValuesTester
 
testReplaceValuesHandlesDuplicates() - Method in class com.google.common.collect.testing.google.SetMultimapReplaceValuesTester
 
testReplaceValuesPreservesOrder() - Method in class com.google.common.collect.testing.google.ListMultimapReplaceValuesTester
 
testReplaceValuesPropagatesToGet() - Method in class com.google.common.collect.testing.google.MultimapReplaceValuesTester
 
testReplaceValuesPutNotSupported() - Method in class com.google.common.collect.testing.google.MultimapReplaceValuesTester
 
testReplaceValuesRemoveNotSupported() - Method in class com.google.common.collect.testing.google.MultimapReplaceValuesTester
 
testReplaceValuesWithDuplicates() - Method in class com.google.common.collect.testing.google.MultimapReplaceValuesTester
 
testReplaceValuesWithEmpty() - Method in class com.google.common.collect.testing.google.MultimapReplaceValuesTester
 
testReplaceValuesWithNullKey() - Method in class com.google.common.collect.testing.google.MultimapReplaceValuesTester
 
testReplaceValuesWithNullValue() - Method in class com.google.common.collect.testing.google.MultimapReplaceValuesTester
 
testReserialize() - Method in class com.google.common.collect.testing.testers.CollectionSerializationEqualTester
 
testReserialize() - Method in class com.google.common.collect.testing.testers.CollectionSerializationTester
 
testReserializeEmptySubList() - Method in class com.google.common.collect.testing.testers.ListSubListTester
 
testReserializeMap() - Method in class com.google.common.collect.testing.testers.MapSerializationTester
 
testReserializeSubList() - Method in class com.google.common.collect.testing.testers.ListSubListTester
 
testReserializeWholeSubList() - Method in class com.google.common.collect.testing.testers.ListSubListTester
 
testRetainAll_containsDuplicatesSizeOne() - Method in class com.google.common.collect.testing.testers.CollectionRetainAllTester
 
testRetainAll_containsDuplicatesSizeSeveral() - Method in class com.google.common.collect.testing.testers.CollectionRetainAllTester
 
testRetainAll_containsNonNullWithNull() - Method in class com.google.common.collect.testing.testers.CollectionRetainAllTester
 
testRetainAll_countIgnored() - Method in class com.google.common.collect.testing.testers.ListRetainAllTester
 
testRetainAll_disjointPreviouslyEmpty() - Method in class com.google.common.collect.testing.testers.CollectionRetainAllTester
 
testRetainAll_disjointPreviouslyEmptyUnsupported() - Method in class com.google.common.collect.testing.testers.CollectionRetainAllTester
 
testRetainAll_disjointPreviouslyNonEmpty() - Method in class com.google.common.collect.testing.testers.CollectionRetainAllTester
 
testRetainAll_disjointPreviouslyNonEmptyUnsupported() - Method in class com.google.common.collect.testing.testers.CollectionRetainAllTester
 
testRetainAll_duplicatesKept() - Method in class com.google.common.collect.testing.testers.ListRetainAllTester
 
testRetainAll_duplicatesRemoved() - Method in class com.google.common.collect.testing.testers.ListRetainAllTester
 
testRetainAll_emptyPreviouslyEmpty() - Method in class com.google.common.collect.testing.testers.CollectionRetainAllTester
 
testRetainAll_emptyPreviouslyEmptyUnsupported() - Method in class com.google.common.collect.testing.testers.CollectionRetainAllTester
 
testRetainAll_emptyPreviouslyNonEmpty() - Method in class com.google.common.collect.testing.testers.CollectionRetainAllTester
 
testRetainAll_emptyPreviouslyNonEmptyUnsupported() - Method in class com.google.common.collect.testing.testers.CollectionRetainAllTester
 
testRetainAll_nullCollectionReferenceEmptySubject() - Method in class com.google.common.collect.testing.testers.CollectionRetainAllTester
 
testRetainAll_nullCollectionReferenceNonEmptySubject() - Method in class com.google.common.collect.testing.testers.CollectionRetainAllTester
 
testRetainAll_nullSingletonPreviouslyEmpty() - Method in class com.google.common.collect.testing.testers.CollectionRetainAllTester
 
testRetainAll_nullSingletonPreviouslyNonEmpty() - Method in class com.google.common.collect.testing.testers.CollectionRetainAllTester
 
testRetainAll_nullSingletonPreviouslySeveralWithNull() - Method in class com.google.common.collect.testing.testers.CollectionRetainAllTester
 
testRetainAll_nullSingletonPreviouslySingletonWithNull() - Method in class com.google.common.collect.testing.testers.CollectionRetainAllTester
 
testRetainAll_partialOverlap() - Method in class com.google.common.collect.testing.testers.CollectionRetainAllTester
 
testRetainAll_partialOverlapUnsupported() - Method in class com.google.common.collect.testing.testers.CollectionRetainAllTester
 
testRetainAll_sameElements() - Method in class com.google.common.collect.testing.testers.CollectionRetainAllTester
 
testRetainAll_sameElementsUnsupported() - Method in class com.google.common.collect.testing.testers.CollectionRetainAllTester
 
testRetainAll_subset() - Method in class com.google.common.collect.testing.testers.CollectionRetainAllTester
 
testRetainAll_subsetUnsupported() - Method in class com.google.common.collect.testing.testers.CollectionRetainAllTester
 
testRetainAll_superset() - Method in class com.google.common.collect.testing.testers.CollectionRetainAllTester
 
testRetainAll_supersetUnsupported() - Method in class com.google.common.collect.testing.testers.CollectionRetainAllTester
 
testRetainAllIgnoresCount() - Method in class com.google.common.collect.testing.google.MultisetRemoveTester
 
testRetainAllPropagatesToMultimap() - Method in class com.google.common.collect.testing.google.MultimapEntriesTester
 
testsEquals - Variable in class com.google.common.testing.ForwardingWrapperTester
 
testSerializable() - Method in class com.google.common.testing.AbstractPackageSanityTests
Tests all top-level Serializable classes in the package.
testSerializable() - Method in class com.google.common.testing.ClassSanityTester.FactoryMethodReturnValueTester
Runs serialization test on the return values of the static methods.
testSet() - Method in class com.google.common.collect.testing.testers.ListSetTester
 
testSet_indexTooHigh() - Method in class com.google.common.collect.testing.testers.ListSetTester
 
testSet_indexTooLow() - Method in class com.google.common.collect.testing.testers.ListSetTester
 
testSet_null() - Method in class com.google.common.collect.testing.testers.ListSetTester
 
testSet_nullUnsupported() - Method in class com.google.common.collect.testing.testers.ListSetTester
 
testSet_replacingNull() - Method in class com.google.common.collect.testing.testers.ListSetTester
 
testSet_unsupported() - Method in class com.google.common.collect.testing.testers.ListSetTester
 
testSet_unsupportedByEmptyList() - Method in class com.google.common.collect.testing.testers.ListSetTester
 
testSetCount_addNull_nullSupported() - Method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
 
testSetCount_addNull_nullUnsupported() - Method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
 
testSetCount_existingNoNopNull_nullSupported() - Method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
 
testSetCount_negative_removeSupported() - Method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
 
testSetCount_negative_removeUnsupported() - Method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
 
testSetCount_noOpNull_nullSupported() - Method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
 
testSetCount_noOpNull_nullUnsupported() - Method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
 
testSetCount_oneToOne_addSupported() - Method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
 
testSetCount_oneToOne_removeSupported() - Method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
 
testSetCount_oneToOne_unsupported() - Method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
 
testSetCount_oneToThree_supported() - Method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
 
testSetCount_oneToThree_unsupported() - Method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
 
testSetCount_oneToZero_supported() - Method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
 
testSetCount_oneToZero_unsupported() - Method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
 
testSetCount_removeNull_nullSupported() - Method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
 
testSetCount_threeToOne_supported() - Method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
 
testSetCount_threeToOne_unsupported() - Method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
 
testSetCount_threeToThree_addSupported() - Method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
 
testSetCount_threeToThree_removeSupported() - Method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
 
testSetCount_threeToThree_unsupported() - Method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
 
testSetCount_threeToZero_supported() - Method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
 
testSetCount_threeToZero_unsupported() - Method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
 
testSetCount_zeroToOne_supported() - Method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
 
testSetCount_zeroToOne_unsupported() - Method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
 
testSetCount_zeroToThree_supported() - Method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
 
testSetCount_zeroToThree_unsupported() - Method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
 
testSetCount_zeroToZero_addSupported() - Method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
 
testSetCount_zeroToZero_removeSupported() - Method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
 
testSetCount_zeroToZero_unsupported() - Method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
 
testSetCountConditional_negativeOldCount_addSupported() - Method in class com.google.common.collect.testing.google.MultisetSetCountConditionallyTester
 
testSetCountConditional_negativeOldCount_addUnsupported() - Method in class com.google.common.collect.testing.google.MultisetSetCountConditionallyTester
 
testSetCountConditional_oldCountTooLarge() - Method in class com.google.common.collect.testing.google.MultisetSetCountConditionallyTester
 
testSetCountConditional_oldCountTooSmallNonzero() - Method in class com.google.common.collect.testing.google.MultisetSetCountConditionallyTester
 
testSetCountConditional_oldCountTooSmallZero() - Method in class com.google.common.collect.testing.google.MultisetSetCountConditionallyTester
 
testSetCountOneToZeroConcurrentWithEntrySetIteration() - Method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
 
testSetCountOneToZeroConcurrentWithIteration() - Method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
 
testSetCountOutOfHeadBoundsOne() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testSetCountOutOfHeadBoundsSeveral() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testSetCountOutOfTailBoundsOne() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testSetCountOutOfTailBoundsSeveral() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testSetCountZeroToOneConcurrentWithEntrySetIteration() - Method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
 
testSetCountZeroToOneConcurrentWithIteration() - Method in class com.google.common.collect.testing.google.AbstractMultisetSetCountTester
 
TestSetGenerator<E> - Interface in com.google.common.collect.testing
Creates sets, containing sample elements, to be tested.
TestSetMultimapGenerator<K,V> - Interface in com.google.common.collect.testing.google
A generator for SetMultimap implementations based on test data.
testSetValue() - Method in class com.google.common.collect.testing.testers.MapEntrySetTester
 
testSetValue_valueAbsent() - Method in class com.google.common.collect.testing.google.BiMapEntrySetTester
 
testSetValue_valuePresent() - Method in class com.google.common.collect.testing.google.BiMapEntrySetTester
 
testSetValueNullSupported() - Method in class com.google.common.collect.testing.google.BiMapEntrySetTester
 
testSetValueNullUnsupported() - Method in class com.google.common.collect.testing.google.BiMapEntrySetTester
 
testSetValueWithNullValuesAbsent() - Method in class com.google.common.collect.testing.testers.MapEntrySetTester
 
testSetValueWithNullValuesPresent() - Method in class com.google.common.collect.testing.testers.MapEntrySetTester
 
testsForAbstractList() - Method in class com.google.common.collect.testing.TestsForListsInJavaUtil
 
testsForAbstractSequentialList() - Method in class com.google.common.collect.testing.TestsForListsInJavaUtil
 
testsForAbstractSet() - Method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
testsForArrayBlockingQueue() - Method in class com.google.common.collect.testing.TestsForQueuesInJavaUtil
 
testsForArrayDeque() - Method in class com.google.common.collect.testing.TestsForQueuesInJavaUtil
 
testsForArrayList() - Method in class com.google.common.collect.testing.TestsForListsInJavaUtil
 
testsForArraysAsList() - Method in class com.google.common.collect.testing.TestsForListsInJavaUtil
 
testsForBadlyCollidingHashSet() - Method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
testsForCheckedList() - Method in class com.google.common.collect.testing.TestsForListsInJavaUtil
 
testsForCheckedMap() - Method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
testsForCheckedNavigableMap() - Method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
testsForCheckedNavigableSet() - Method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
testsForCheckedQueue() - Method in class com.google.common.collect.testing.TestsForQueuesInJavaUtil
 
testsForCheckedSet() - Method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
testsForCheckedSortedMap() - Method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
testsForCheckedSortedSet() - Method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
testsForConcurrentHashMap() - Method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
testsForConcurrentLinkedDeque() - Method in class com.google.common.collect.testing.TestsForQueuesInJavaUtil
 
testsForConcurrentLinkedQueue() - Method in class com.google.common.collect.testing.TestsForQueuesInJavaUtil
 
testsForConcurrentSkipListMapNatural() - Method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
testsForConcurrentSkipListMapWithComparator() - Method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
testsForConcurrentSkipListSetNatural() - Method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
testsForConcurrentSkipListSetWithComparator() - Method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
testsForCopyOnWriteArrayList() - Method in class com.google.common.collect.testing.TestsForListsInJavaUtil
 
testsForCopyOnWriteArraySet() - Method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
testsForEmptyList() - Method in class com.google.common.collect.testing.TestsForListsInJavaUtil
 
testsForEmptyMap() - Method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
testsForEmptyNavigableMap() - Method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
testsForEmptyNavigableSet() - Method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
testsForEmptySet() - Method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
testsForEmptySortedMap() - Method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
testsForEmptySortedSet() - Method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
testsForEnumMap() - Method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
testsForEnumSet() - Method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
testsForHashMap() - Method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
testsForHashSet() - Method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
testsForHashtable() - Method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
testsForLinkedBlockingDeque() - Method in class com.google.common.collect.testing.TestsForQueuesInJavaUtil
 
testsForLinkedBlockingQueue() - Method in class com.google.common.collect.testing.TestsForQueuesInJavaUtil
 
testsForLinkedHashMap() - Method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
testsForLinkedHashSet() - Method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
testsForLinkedList() - Method in class com.google.common.collect.testing.TestsForListsInJavaUtil
 
testsForLinkedList() - Method in class com.google.common.collect.testing.TestsForQueuesInJavaUtil
 
TestsForListsInJavaUtil - Class in com.google.common.collect.testing
Generates a test suite covering the List implementations in the java.util package.
TestsForListsInJavaUtil() - Constructor for class com.google.common.collect.testing.TestsForListsInJavaUtil
 
TestsForMapsInJavaUtil - Class in com.google.common.collect.testing
Generates a test suite covering the Map implementations in the java.util package.
TestsForMapsInJavaUtil() - Constructor for class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
TestsForMapsInJavaUtil.NullFriendlyComparator<T> - Class in com.google.common.collect.testing
 
testsForPriorityBlockingQueue() - Method in class com.google.common.collect.testing.TestsForQueuesInJavaUtil
 
testsForPriorityQueue() - Method in class com.google.common.collect.testing.TestsForQueuesInJavaUtil
 
TestsForQueuesInJavaUtil - Class in com.google.common.collect.testing
Generates a test suite covering the Queue implementations in the java.util package.
TestsForQueuesInJavaUtil() - Constructor for class com.google.common.collect.testing.TestsForQueuesInJavaUtil
 
TestsForSetsInJavaUtil - Class in com.google.common.collect.testing
Generates a test suite covering the Set implementations in the java.util package.
TestsForSetsInJavaUtil() - Constructor for class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
TestsForSetsInJavaUtil.NullFriendlyComparator<T> - Class in com.google.common.collect.testing
 
testsForSingletonList() - Method in class com.google.common.collect.testing.TestsForListsInJavaUtil
 
testsForSingletonMap() - Method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
testsForSingletonSet() - Method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
testsForSynchronizedNavigableMap() - Method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
Tests regular NavigableMap behavior of synchronizedNavigableMap(treeMap); does not test the fact that it's synchronized.
testsForSynchronizedNavigableSet() - Method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
Tests regular NavigableSet behavior of synchronizedNavigableSet(treeSet); does not test the fact that it's synchronized.
testsForTreeMapNatural() - Method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
testsForTreeMapWithComparator() - Method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
testsForTreeSetNatural() - Method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
testsForTreeSetWithComparator() - Method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
testsForUnmodifiableList() - Method in class com.google.common.collect.testing.TestsForListsInJavaUtil
 
testsForUnmodifiableMap() - Method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
testsForUnmodifiableNavigableMap() - Method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
testsForUnmodifiableNavigableSet() - Method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
testsForUnmodifiableSet() - Method in class com.google.common.collect.testing.TestsForSetsInJavaUtil
 
testsForUnmodifiableSortedMap() - Method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
testsForVector() - Method in class com.google.common.collect.testing.TestsForListsInJavaUtil
 
testSingletonMapFirst() - Method in class com.google.common.collect.testing.testers.NavigableMapNavigationTester
 
testSingletonMapFirst() - Method in class com.google.common.collect.testing.testers.SortedMapNavigationTester
 
testSingletonMapLast() - Method in class com.google.common.collect.testing.testers.NavigableMapNavigationTester
 
testSingletonMapLast() - Method in class com.google.common.collect.testing.testers.SortedMapNavigationTester
 
testSingletonMapNearby() - Method in class com.google.common.collect.testing.testers.NavigableMapNavigationTester
 
testSingletonMapPollFirst() - Method in class com.google.common.collect.testing.testers.NavigableMapNavigationTester
 
testSingletonMapPollLast() - Method in class com.google.common.collect.testing.testers.NavigableMapNavigationTester
 
testSingletonMultisetFirst() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testSingletonMultisetLast() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testSingletonMultisetNearby() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testSingletonMultisetPollFirst() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testSingletonMultisetPollLast() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testSingletonSetFirst() - Method in class com.google.common.collect.testing.testers.SortedSetNavigationTester
 
testSingletonSetLast() - Method in class com.google.common.collect.testing.testers.SortedSetNavigationTester
 
testSingletonSetNearby() - Method in class com.google.common.collect.testing.testers.NavigableSetNavigationTester
 
testSingletonSetPollFirst() - Method in class com.google.common.collect.testing.testers.NavigableSetNavigationTester
 
testSingletonSetPollLast() - Method in class com.google.common.collect.testing.testers.NavigableSetNavigationTester
 
testSize() - Method in class com.google.common.collect.testing.google.MultimapSizeTester
 
testSize() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testSize() - Method in class com.google.common.collect.testing.testers.CollectionSizeTester
 
testSize() - Method in class com.google.common.collect.testing.testers.MapSizeTester
 
testSizeMultipleValues() - Method in class com.google.common.collect.testing.google.MultimapSizeTester
 
testSizeNullKey() - Method in class com.google.common.collect.testing.google.MultimapSizeTester
 
testSizeNullKeyAndValue() - Method in class com.google.common.collect.testing.google.MultimapSizeTester
 
testSizeNullValue() - Method in class com.google.common.collect.testing.google.MultimapSizeTester
 
TestSortedMapGenerator<K,V> - Interface in com.google.common.collect.testing
Creates sorted maps, containing sample elements, to be tested.
TestSortedSetGenerator<E> - Interface in com.google.common.collect.testing
Creates sorted sets, containing sample elements, to be tested.
testSpliteratorKnownOrder() - Method in class com.google.common.collect.testing.testers.CollectionSpliteratorTester
 
testSpliteratorNotImmutable_collectionAllowsAdd() - Method in class com.google.common.collect.testing.testers.CollectionSpliteratorTester
 
testSpliteratorNotImmutable_collectionAllowsRemove() - Method in class com.google.common.collect.testing.testers.CollectionSpliteratorTester
 
testSpliteratorNullable() - Method in class com.google.common.collect.testing.testers.CollectionSpliteratorTester
 
testSpliteratorUnknownOrder() - Method in class com.google.common.collect.testing.testers.CollectionSpliteratorTester
 
testStaticMethods(Class<?>, NullPointerTester.Visibility) - Method in class com.google.common.testing.NullPointerTester
Runs NullPointerTester.testMethod(java.lang.Object, java.lang.reflect.Method) on every static method of class c that has at least minimalVisibility, including those "inherited" from superclasses of the same package.
testStreamCount() - Method in class com.google.common.collect.testing.testers.CollectionStreamTester
 
testStreamToArrayKnownOrder() - Method in class com.google.common.collect.testing.testers.CollectionStreamTester
 
testStreamToArrayUnknownOrder() - Method in class com.google.common.collect.testing.testers.CollectionStreamTester
 
TestStringBiMapGenerator - Class in com.google.common.collect.testing.google
Implementation helper for TestBiMapGenerator for use with bimaps of strings.
TestStringBiMapGenerator() - Constructor for class com.google.common.collect.testing.google.TestStringBiMapGenerator
 
TestStringCollectionGenerator - Class in com.google.common.collect.testing
String creation for testing arbitrary collections.
TestStringCollectionGenerator() - Constructor for class com.google.common.collect.testing.TestStringCollectionGenerator
 
TestStringListGenerator - Class in com.google.common.collect.testing
TODO: javadoc.
TestStringListGenerator() - Constructor for class com.google.common.collect.testing.TestStringListGenerator
 
TestStringListMultimapGenerator - Class in com.google.common.collect.testing.google
A skeleton generator for a ListMultimap implementation.
TestStringListMultimapGenerator() - Constructor for class com.google.common.collect.testing.google.TestStringListMultimapGenerator
 
TestStringMapGenerator - Class in com.google.common.collect.testing
Implementation helper for TestMapGenerator for use with maps of strings.
TestStringMapGenerator() - Constructor for class com.google.common.collect.testing.TestStringMapGenerator
 
TestStringMultisetGenerator - Class in com.google.common.collect.testing.google
Create multisets of strings for tests.
TestStringMultisetGenerator() - Constructor for class com.google.common.collect.testing.google.TestStringMultisetGenerator
 
TestStringQueueGenerator - Class in com.google.common.collect.testing
Create queue of strings for tests.
TestStringQueueGenerator() - Constructor for class com.google.common.collect.testing.TestStringQueueGenerator
 
TestStringSetGenerator - Class in com.google.common.collect.testing
Create string sets for collection tests.
TestStringSetGenerator() - Constructor for class com.google.common.collect.testing.TestStringSetGenerator
 
TestStringSetMultimapGenerator - Class in com.google.common.collect.testing.google
A skeleton generator for a SetMultimap implementation.
TestStringSetMultimapGenerator() - Constructor for class com.google.common.collect.testing.google.TestStringSetMultimapGenerator
 
TestStringSortedMapGenerator - Class in com.google.common.collect.testing
Implementation helper for TestMapGenerator for use with sorted maps of strings.
TestStringSortedMapGenerator() - Constructor for class com.google.common.collect.testing.TestStringSortedMapGenerator
 
TestStringSortedSetGenerator - Class in com.google.common.collect.testing
Create string sets for testing collections that are sorted by natural ordering.
TestStringSortedSetGenerator() - Constructor for class com.google.common.collect.testing.TestStringSortedSetGenerator
 
TestSubjectGenerator<T> - Interface in com.google.common.collect.testing
To be implemented by test generators that can produce test subjects without requiring any parameters.
testSubList_contains() - Method in class com.google.common.collect.testing.testers.ListSubListTester
 
testSubList_empty() - Method in class com.google.common.collect.testing.testers.ListSubListTester
 
testSubList_endTooLarge() - Method in class com.google.common.collect.testing.testers.ListSubListTester
 
testSubList_entireList() - Method in class com.google.common.collect.testing.testers.ListSubListTester
 
testSubList_get() - Method in class com.google.common.collect.testing.testers.ListSubListTester
 
testSubList_indexOf() - Method in class com.google.common.collect.testing.testers.ListSubListTester
 
testSubList_isEmpty() - Method in class com.google.common.collect.testing.testers.ListSubListTester
 
testSubList_lastIndexOf() - Method in class com.google.common.collect.testing.testers.ListSubListTester
 
testSubList_ofSubListEmpty() - Method in class com.google.common.collect.testing.testers.ListSubListTester
 
testSubList_ofSubListNonEmpty() - Method in class com.google.common.collect.testing.testers.ListSubListTester
 
testSubList_originalListSetAffectsSubList() - Method in class com.google.common.collect.testing.testers.ListSubListTester
 
testSubList_originalListSetAffectsSubListLargeList() - Method in class com.google.common.collect.testing.testers.ListSubListTester
 
testSubList_size() - Method in class com.google.common.collect.testing.testers.ListSubListTester
 
testSubList_startGreaterThanEnd() - Method in class com.google.common.collect.testing.testers.ListSubListTester
 
testSubList_startNegative() - Method in class com.google.common.collect.testing.testers.ListSubListTester
 
testSubList_subListAddAffectsOriginal() - Method in class com.google.common.collect.testing.testers.ListSubListTester
 
testSubList_subListAddAtIndexAffectsOriginalLargeList() - Method in class com.google.common.collect.testing.testers.ListSubListTester
 
testSubList_subListClearAffectsOriginal() - Method in class com.google.common.collect.testing.testers.ListSubListTester
 
testSubList_subListRemoveAffectsOriginal() - Method in class com.google.common.collect.testing.testers.ListSubListTester
 
testSubList_subListRemoveAffectsOriginalLargeList() - Method in class com.google.common.collect.testing.testers.ListSubListTester
 
testSubList_subListSetAffectsOriginal() - Method in class com.google.common.collect.testing.testers.ListSubListTester
 
testSubList_subListSetAffectsOriginalLargeList() - Method in class com.google.common.collect.testing.testers.ListSubListTester
 
testSubMap() - Method in class com.google.common.collect.testing.testers.SortedMapNavigationTester
 
testSubMapIllegal() - Method in class com.google.common.collect.testing.testers.SortedMapNavigationTester
 
testSubMultisetDistinctElements(MultisetNavigationTester.SubMultisetSpec) - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testSubMultisetEntrySet(MultisetNavigationTester.SubMultisetSpec) - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testSubMultisetSize(MultisetNavigationTester.SubMultisetSpec) - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testSuccessfulForwarding(Class<T>, Method, Function<? super T, ? extends T>) - Static method in class com.google.common.testing.ForwardingWrapperTester
 
testTailClosedDistinctElements() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testTailClosedEntrySet() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testTailClosedSize() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testTailMap() - Method in class com.google.common.collect.testing.testers.SortedMapNavigationTester
 
testTailMapClearThrough() - Method in class com.google.common.collect.testing.SortedMapInterfaceTest
 
testTailMapExclusive() - Method in class com.google.common.collect.testing.testers.NavigableMapNavigationTester
 
testTailMapInclusive() - Method in class com.google.common.collect.testing.testers.NavigableMapNavigationTester
 
testTailMapInclusive() - Method in class com.google.common.collect.testing.testers.SortedMapNavigationTester
 
testTailMapRemoveThrough() - Method in class com.google.common.collect.testing.SortedMapInterfaceTest
 
testTailMapWriteThrough() - Method in class com.google.common.collect.testing.SortedMapInterfaceTest
 
testTailOpenDistinctElements() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testTailOpenEntrySet() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testTailOpenSize() - Method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
testTimeoutOnGetWorksCorrectly() - Method in class com.google.common.util.concurrent.testing.AbstractListenableFutureTest
Tests that the Future.get(long, TimeUnit) method times out correctly.
testToArray_emptyArray() - Method in class com.google.common.collect.testing.testers.CollectionToArrayTester
 
testToArray_emptyArray_ordered() - Method in class com.google.common.collect.testing.testers.CollectionToArrayTester
 
testToArray_emptyArrayOfObject() - Method in class com.google.common.collect.testing.testers.CollectionToArrayTester
 
testToArray_emptyArrayOfWrongTypeForEmptyCollection() - Method in class com.google.common.collect.testing.testers.CollectionToArrayTester
 
testToArray_emptyArrayOfWrongTypeForNonEmptyCollection() - Method in class com.google.common.collect.testing.testers.CollectionToArrayTester
 
testToArray_isPlainObjectArray() - Method in class com.google.common.collect.testing.testers.CollectionToArrayTester
Collection.toArray(Object[]) says: "Note that toArray(new Object[0]) is identical in function to toArray()."
testToArray_largeEnough() - Method in class com.google.common.collect.testing.testers.ListToArrayTester
 
testToArray_noArg() - Method in class com.google.common.collect.testing.testers.ListToArrayTester
 
testToArray_noArgs() - Method in class com.google.common.collect.testing.testers.CollectionToArrayTester
 
testToArray_oversizedArray() - Method in class com.google.common.collect.testing.testers.CollectionToArrayTester
 
testToArray_oversizedArray_ordered() - Method in class com.google.common.collect.testing.testers.CollectionToArrayTester
 
testToArray_rightSizedArray() - Method in class com.google.common.collect.testing.testers.CollectionToArrayTester
 
testToArray_rightSizedArray_ordered() - Method in class com.google.common.collect.testing.testers.CollectionToArrayTester
 
testToArray_rightSizedArrayOfObject() - Method in class com.google.common.collect.testing.testers.CollectionToArrayTester
 
testToArray_rightSizedArrayOfObject_ordered() - Method in class com.google.common.collect.testing.testers.CollectionToArrayTester
 
testToArray_tooSmall() - Method in class com.google.common.collect.testing.testers.ListToArrayTester
 
testToString() - Method in class com.google.common.collect.testing.google.MultisetEntrySetTester
 
testToString(Class<T>, Function<? super T, ? extends T>) - Static method in class com.google.common.testing.ForwardingWrapperTester
 
testToString_formatting() - Method in class com.google.common.collect.testing.testers.MapToStringTester
 
testToString_minimal() - Method in class com.google.common.collect.testing.testers.CollectionToStringTester
 
testToString_minimal() - Method in class com.google.common.collect.testing.testers.MapToStringTester
 
testToString_null() - Method in class com.google.common.collect.testing.testers.CollectionToStringTester
 
testToString_size0() - Method in class com.google.common.collect.testing.testers.CollectionToStringTester
 
testToString_size0() - Method in class com.google.common.collect.testing.testers.MapToStringTester
 
testToString_size1() - Method in class com.google.common.collect.testing.testers.CollectionToStringTester
 
testToString_size1() - Method in class com.google.common.collect.testing.testers.MapToStringTester
 
testToString_sizeSeveral() - Method in class com.google.common.collect.testing.testers.CollectionToStringTester
 
testToStringEmpty() - Method in class com.google.common.collect.testing.google.MultimapToStringTester
 
testToStringMatchesAsMap() - Method in class com.google.common.collect.testing.google.MultimapToStringTester
 
testToStringSingleton() - Method in class com.google.common.collect.testing.google.MultimapToStringTester
 
testToStringWithNullKey() - Method in class com.google.common.collect.testing.google.MultimapToStringTester
 
testToStringWithNullKey() - Method in class com.google.common.collect.testing.testers.MapToStringTester
 
testToStringWithNullValue() - Method in class com.google.common.collect.testing.google.MultimapToStringTester
 
testToStringWithNullValue() - Method in class com.google.common.collect.testing.testers.MapToStringTester
 
TestUnhashableCollectionGenerator<T> - Class in com.google.common.collect.testing
Creates collections containing unhashable sample elements, to be tested.
TestUnhashableCollectionGenerator() - Constructor for class com.google.common.collect.testing.TestUnhashableCollectionGenerator
 
TestUnhashableListGenerator() - Constructor for class com.google.common.collect.testing.google.ListGenerators.TestUnhashableListGenerator
 
TestUnhashableSetGenerator() - Constructor for class com.google.common.collect.testing.google.SetGenerators.TestUnhashableSetGenerator
 
testValueComparator() - Method in class com.google.common.collect.testing.google.SortedSetMultimapGetTester
 
testValues() - Method in class com.google.common.collect.testing.google.MultimapValuesTester
 
testValues() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testValuesClear() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testValuesClearClearsInverse() - Method in class com.google.common.collect.testing.google.BiMapClearTester
 
testValuesInOrder() - Method in class com.google.common.collect.testing.google.MultimapValuesTester
 
testValuesIteratorRemove() - Method in class com.google.common.collect.testing.google.MultimapValuesTester
 
testValuesIteratorRemove() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testValuesRemove() - Method in class com.google.common.collect.testing.google.ListMultimapAsMapTester
 
testValuesRemove() - Method in class com.google.common.collect.testing.google.SetMultimapAsMapTester
 
testValuesRemove() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testValuesRemoveAll() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testValuesRemoveAllNullFromEmpty() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testValuesRemoveMissing() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testValuesRetainAll() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testValuesRetainAllNullFromEmpty() - Method in class com.google.common.collect.testing.MapInterfaceTest
 
testWitness(long, long) - Method in enum class com.google.common.math.LongMath.MillerRabinTester
Returns true if n is a strong probable prime relative to the specified base.
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
 
thatReturn(Class<?>) - Method in class com.google.common.testing.ClassSanityTester.FactoryMethodReturnValueTester
Specifies that only the methods that are declared to return returnType or its subtype are tested.
The rest - Search tag in package com.google.common.base
Section
theUnsafe - Static variable in enum class com.google.common.hash.LittleEndianByteArray.UnsafeByteArray
 
theUnsafe - Static variable in enum class com.google.common.primitives.UnsignedBytes.LexicographicalComparatorHolder.UnsafeComparator
 
thread - Variable in class com.google.common.util.concurrent.AbstractFuture.Waiter
 
thread - Variable in class com.google.common.util.concurrent.ExecutionSequencer.ThreadConfinedTaskQueue
This field is only used for identity comparisons with the current thread.
ThreadConfinedTaskQueue() - Constructor for class com.google.common.util.concurrent.ExecutionSequencer.ThreadConfinedTaskQueue
 
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.
threadHashCode - Static variable in class com.google.common.hash.Striped64
ThreadLocal holding a single-slot int array holding hash code.
threadNameSupplier - Variable in class com.google.common.util.concurrent.AbstractIdleService
 
ThreadNameSupplier() - Constructor for class com.google.common.util.concurrent.AbstractIdleService.ThreadNameSupplier
 
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.
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.
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.
THREE_GPP_VIDEO - Static variable in class com.google.common.net.MediaType
The 3GP multimedia container format.
THREE_GPP2_VIDEO - Static variable in class com.google.common.net.MediaType
The 3G2 multimedia container format.
Three types of methods - Search tag in class com.google.common.collect.Ordering
Section
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.
threshold - Variable in class com.google.common.collect.TopKSelector
The largest of the lowest k elements we've seen so far relative to this comparator.
thresholdPermits - Variable in class com.google.common.util.concurrent.SmoothRateLimiter.SmoothWarmingUp
 
THROW - Enum constant in enum class com.google.common.util.concurrent.CycleDetectingLockFactory.Policies
When potential deadlock is detected, this policy results in the throwing of the PotentialDeadlockException indicating the potential deadlock, which includes stack traces illustrating the cycle in lock acquisition order.
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
 
throwDeleteFailed(Path, Collection<IOException>) - Static method in class com.google.common.io.MoreFiles
Throws an exception indicating that one or more files couldn't be deleted when deleting path or its contents.
throwFirst(List<X>) - Static method in class com.google.common.testing.ClassSanityTester
 
throwIfInstanceOf(Throwable, Class<X>) - Static method in class com.google.common.base.Throwables
Throws throwable if it is an instance of declaredType.
throwIfInvalid(IteratorFeature) - Method in class com.google.common.collect.testing.AbstractIteratorTester.MultiExceptionListIterator
 
throwIfUnchecked(Throwable) - Static method in class com.google.common.base.Throwables
Throws throwable if it is a RuntimeException or Error.
ThrowingCreator() - Constructor for class com.google.common.io.TempFileCreator.ThrowingCreator
 
thrown - Variable in class com.google.common.io.Closer
 
ticker - Variable in class com.google.common.base.Stopwatch
 
ticker - Variable in class com.google.common.cache.CacheBuilder
 
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(Ticker) - Method in class com.google.common.cache.CacheBuilder
Specifies a nanosecond-precision time source for this cache.
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.
TIFF - Static variable in class com.google.common.net.MediaType
 
TimeLimiter - Interface in com.google.common.util.concurrent
Imposes a time limit on method calls.
TimeoutFuture<V> - Class in com.google.common.util.concurrent
Implementation of Futures#withTimeout.
TimeoutFuture(ListenableFuture<V>) - Constructor for class com.google.common.util.concurrent.TimeoutFuture
 
TimeoutFuture.Fire<V> - Class in com.google.common.util.concurrent
A runnable that is called when the delegate or the timer completes.
TimeoutFuture.TimeoutFutureException - Exception Class in com.google.common.util.concurrent
 
TimeoutFutureException(String) - Constructor for exception class com.google.common.util.concurrent.TimeoutFuture.TimeoutFutureException
 
timeoutFutureRef - Variable in class com.google.common.util.concurrent.TimeoutFuture.Fire
 
timeoutSeconds() - Static method in class com.google.common.testing.GcFinalization
10 seconds ought to be long enough for any object to be GC'ed and finalized.
timer - Variable in class com.google.common.util.concurrent.TimeoutFuture
 
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 - Variable in class com.google.common.collect.testing.DerivedCollectionGenerators.SortedMapSubmapTestMapGenerator
 
to - Variable in class com.google.common.collect.testing.DerivedCollectionGenerators.SortedSetSubsetTestSetGenerator
 
to(CaseFormat, String) - Method in enum class com.google.common.base.CaseFormat
Converts the specified String str from this format to the specified format.
TO_BYTE_ARRAY_DEQUE_SIZE - Static variable in class com.google.common.io.ByteStreams
Large enough to never need to expand, given the geometric progression of buffer sizes.
TO_IMMUTABLE_ENUM_SET - Static variable in class com.google.common.collect.CollectCollectors.EnumSetAccumulator
 
TO_IMMUTABLE_LIST - Static variable in class com.google.common.collect.CollectCollectors
 
TO_IMMUTABLE_RANGE_SET - Static variable in class com.google.common.collect.CollectCollectors
 
TO_IMMUTABLE_SET - Static variable in class com.google.common.collect.CollectCollectors
 
TO_OPTIONAL - Static variable in class com.google.common.collect.MoreCollectors
 
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() - Method in class com.google.common.collect.AbstractBiMap.ValueSet
 
toArray() - Method in class com.google.common.collect.Collections2.FilteredCollection
 
toArray() - Method in class com.google.common.collect.CompactHashMap.KeySetView
 
toArray() - Method in class com.google.common.collect.CompactHashMap.ValuesView
 
toArray() - Method in class com.google.common.collect.CompactHashSet
 
toArray() - Method in class com.google.common.collect.CompactLinkedHashSet
 
toArray() - Method in class com.google.common.collect.ConcurrentHashMultiset.EntrySet
 
toArray() - Method in class com.google.common.collect.ConcurrentHashMultiset
 
toArray() - Method in class com.google.common.collect.DescendingMultiset
 
toArray() - Method in class com.google.common.collect.EvictingQueue
 
toArray() - Method in class com.google.common.collect.ForwardingCollection
 
toArray() - Method in class com.google.common.collect.ImmutableCollection
 
toArray() - Method in class com.google.common.collect.Maps.FilteredEntryMap.KeySet
 
toArray() - Method in class com.google.common.collect.Maps.FilteredMapValues
 
toArray() - 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() - Method in class com.google.common.collect.Synchronized.SynchronizedAsMapEntries
 
toArray() - Method in class com.google.common.collect.Synchronized.SynchronizedCollection
 
toArray() - Method in class com.google.common.collect.testing.MinimalCollection
 
toArray() - Method in class com.google.common.collect.testing.SafeTreeSet
 
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() - Method in class com.google.common.primitives.ImmutableDoubleArray
Returns a new, mutable copy of this array's values, as a primitive double[].
toArray() - Method in class com.google.common.primitives.ImmutableIntArray
Returns a new, mutable copy of this array's values, as a primitive int[].
toArray() - Method in class com.google.common.primitives.ImmutableLongArray
Returns a new, mutable copy of this array's values, as a primitive long[].
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(Class<V>) - Method in class com.google.common.collect.ArrayTable
Returns a two-dimensional array with the table contents.
toArray(Iterable<?>) - Static method in class com.google.common.collect.Iterables
Copies an iterable's elements into an array.
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<? extends T>, T[]) - Static method in class com.google.common.collect.Iterables
 
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<? 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<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<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<Type>) - Static method in class com.google.common.reflect.Types
 
toArray(Iterator<? extends T>, Class<T>) - Static method in class com.google.common.collect.Iterators
Copies an iterator's elements into an array.
toArray(T[]) - Method in class com.google.common.collect.AbstractBiMap.EntrySet
 
toArray(T[]) - Method in class com.google.common.collect.AbstractBiMap.ValueSet
 
toArray(T[]) - Method in class com.google.common.collect.Collections2.FilteredCollection
 
toArray(T[]) - Method in class com.google.common.collect.CompactHashMap.KeySetView
 
toArray(T[]) - Method in class com.google.common.collect.CompactHashMap.ValuesView
 
toArray(T[]) - Method in class com.google.common.collect.CompactHashSet
 
toArray(T[]) - Method in class com.google.common.collect.CompactLinkedHashSet
 
toArray(T[]) - Method in class com.google.common.collect.ConcurrentHashMultiset.EntrySet
 
toArray(T[]) - Method in class com.google.common.collect.ConcurrentHashMultiset
 
toArray(T[]) - Method in class com.google.common.collect.DescendingMultiset
 
toArray(T[]) - Method in class com.google.common.collect.ForwardingCollection
 
toArray(T[]) - Method in class com.google.common.collect.ImmutableCollection
 
toArray(T[]) - Method in class com.google.common.collect.Maps.FilteredEntryMap.KeySet
 
toArray(T[]) - Method in class com.google.common.collect.Maps.FilteredMapValues
 
toArray(T[]) - Method in class com.google.common.collect.Maps.UnmodifiableEntries
 
toArray(T[]) - Method in class com.google.common.collect.Sets.DescendingSet
 
toArray(T[]) - Method in class com.google.common.collect.Synchronized.SynchronizedAsMapEntries
 
toArray(T[]) - Method in class com.google.common.collect.Synchronized.SynchronizedCollection
 
toArray(T[]) - Method in class com.google.common.collect.testing.SafeTreeSet
 
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.
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.
toBigInteger(InetAddress) - Static method in class com.google.common.net.InetAddresses
Returns a BigInteger representing the address.
toBloomFilter(Funnel<? super T>, long) - Static method in class com.google.common.hash.BloomFilter
Returns a Collector expecting the specified number of insertions, and yielding a BloomFilter with false positive probability 3%.
toBloomFilter(Funnel<? super T>, long, double) - Static method in class com.google.common.hash.BloomFilter
Returns a Collector expecting the specified number of insertions, and yielding a BloomFilter with the specified expected false positive probability.
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() - Method in class com.google.common.math.PairedStats
Gets a byte array representation of this instance.
toByteArray() - Method in class com.google.common.math.Stats
Gets a byte array representation of this instance.
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().
toByteArray(File) - Static method in class com.google.common.io.Files
Reads all bytes from a file into a byte array.
toByteArray(InputStream) - Static method in class com.google.common.io.ByteStreams
Reads all bytes from an input stream into a byte array.
toByteArray(InputStream, long) - Static method in class com.google.common.io.ByteStreams
Reads all bytes from an input stream 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.
toByteArrayInternal(InputStream, Queue<byte[]>, int) - Static method in class com.google.common.io.ByteStreams
Returns a byte array containing the bytes from the buffers already in bufs (which have a total combined length of totalLen bytes) followed by all bytes remaining in the given input stream.
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
 
toDoubleArray() - Method in class com.google.common.primitives.Doubles.DoubleArrayAsList
 
ToDoubleRounder<X> - Class in com.google.common.math
Helper type to implement rounding X to a representable double value according to a RoundingMode.
ToDoubleRounder() - Constructor for class com.google.common.math.ToDoubleRounder
 
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.
toFile(URL) - Static method in class com.google.common.reflect.ClassPath
 
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.
toHashMap(Map.Entry<String, String>[]) - Static method in class com.google.common.collect.testing.TestsForMapsInJavaUtil
 
toImmutableBiMap(Function<? super T, ? extends K>, Function<? super T, ? extends V>) - Static method in class com.google.common.collect.CollectCollectors
 
toImmutableBiMap(Function<? super T, ? extends K>, Function<? super T, ? extends V>) - Static method in class com.google.common.collect.ImmutableBiMap
Returns a Collector that accumulates elements into an ImmutableBiMap whose keys and values are the result of applying the provided mapping functions to the input elements.
toImmutableEnumMap(Function<? super T, ? extends K>, Function<? super T, ? extends V>) - Static method in class com.google.common.collect.CollectCollectors
 
toImmutableEnumMap(Function<? super T, ? extends K>, Function<? super T, ? extends V>) - Static method in class com.google.common.collect.Maps
Returns a Collector that accumulates elements into an ImmutableMap whose keys and values are the result of applying the provided mapping functions to the input elements.
toImmutableEnumMap(Function<? super T, ? extends K>, Function<? super T, ? extends V>, BinaryOperator<V>) - Static method in class com.google.common.collect.CollectCollectors
 
toImmutableEnumMap(Function<? super T, ? extends K>, Function<? super T, ? extends V>, BinaryOperator<V>) - Static method in class com.google.common.collect.Maps
Returns a Collector that accumulates elements into an ImmutableMap whose keys and values are the result of applying the provided mapping functions to the input elements.
toImmutableEnumSet() - Static method in class com.google.common.collect.CollectCollectors
 
toImmutableEnumSet() - Static method in class com.google.common.collect.Sets
Returns a Collector that accumulates the input elements into a new ImmutableSet with an implementation specialized for enums.
toImmutableEnumSetGeneric() - Static method in class com.google.common.collect.CollectCollectors
 
toImmutableList() - Static method in class com.google.common.collect.CollectCollectors
 
toImmutableList() - Static method in class com.google.common.collect.ImmutableList
Returns a Collector that accumulates the input elements into a new ImmutableList, in encounter order.
toImmutableListMultimap(Function<? super T, ? extends K>, Function<? super T, ? extends V>) - Static method in class com.google.common.collect.CollectCollectors
 
toImmutableListMultimap(Function<? super T, ? extends K>, Function<? super T, ? extends V>) - Static method in class com.google.common.collect.ImmutableListMultimap
Returns a Collector that accumulates elements into an ImmutableListMultimap whose keys and values are the result of applying the provided mapping functions to the input elements.
toImmutableMap() - Method in class com.google.common.collect.CollectCollectors.EnumMapAccumulator
 
toImmutableMap(Function<? super T, ? extends K>, Function<? super T, ? extends V>) - Static method in class com.google.common.collect.CollectCollectors
 
toImmutableMap(Function<? super T, ? extends K>, Function<? super T, ? extends V>) - Static method in class com.google.common.collect.ImmutableBiMap
toImmutableMap(Function<? super T, ? extends K>, Function<? super T, ? extends V>) - Static method in class com.google.common.collect.ImmutableMap
Returns a Collector that accumulates elements into an ImmutableMap whose keys and values are the result of applying the provided mapping functions to the input elements.
toImmutableMap(Function<? super T, ? extends K>, Function<? super T, ? extends V>) - Static method in class com.google.common.collect.ImmutableSortedMap
toImmutableMap(Function<? super T, ? extends K>, Function<? super T, ? extends V>, BinaryOperator<V>) - Static method in class com.google.common.collect.CollectCollectors
 
toImmutableMap(Function<? super T, ? extends K>, Function<? super T, ? extends V>, BinaryOperator<V>) - Static method in class com.google.common.collect.ImmutableBiMap
Deprecated. 
toImmutableMap(Function<? super T, ? extends K>, Function<? super T, ? extends V>, BinaryOperator<V>) - Static method in class com.google.common.collect.ImmutableMap
Returns a Collector that accumulates elements into an ImmutableMap whose keys and values are the result of applying the provided mapping functions to the input elements.
toImmutableMap(Function<? super T, ? extends K>, Function<? super T, ? extends V>, BinaryOperator<V>) - Static method in class com.google.common.collect.ImmutableSortedMap
toImmutableMultiset() - Static method in class com.google.common.collect.ImmutableMultiset
Returns a Collector that accumulates the input elements into a new ImmutableMultiset.
toImmutableMultiset() - Static method in class com.google.common.collect.ImmutableSortedMultiset
toImmutableMultiset(Function<? super T, ? extends E>, ToIntFunction<? super T>) - Static method in class com.google.common.collect.CollectCollectors
 
toImmutableMultiset(Function<? super T, ? extends E>, ToIntFunction<? super T>) - Static method in class com.google.common.collect.ImmutableMultiset
Returns a Collector that accumulates elements into an ImmutableMultiset whose elements are the result of applying elementFunction to the inputs, with counts equal to the result of applying countFunction to the inputs.
toImmutableMultiset(Function<? super T, ? extends E>, ToIntFunction<? super T>) - Static method in class com.google.common.collect.ImmutableSortedMultiset
toImmutableRangeMap(Function<? super T, Range<K>>, Function<? super T, ? extends V>) - Static method in class com.google.common.collect.CollectCollectors
 
toImmutableRangeMap(Function<? super T, Range<K>>, Function<? super T, ? extends V>) - Static method in class com.google.common.collect.ImmutableRangeMap
Returns a Collector that accumulates the input elements into a new ImmutableRangeMap.
toImmutableRangeSet() - Static method in class com.google.common.collect.CollectCollectors
 
toImmutableRangeSet() - Static method in class com.google.common.collect.ImmutableRangeSet
Returns a Collector that accumulates the input elements into a new ImmutableRangeSet.
toImmutableSet() - Method in class com.google.common.collect.CollectCollectors.EnumSetAccumulator
 
toImmutableSet() - Static method in class com.google.common.collect.CollectCollectors
 
toImmutableSet() - Static method in class com.google.common.collect.ImmutableSet
Returns a Collector that accumulates the input elements into a new ImmutableSet.
toImmutableSet() - Static method in class com.google.common.collect.ImmutableSortedSet
toImmutableSetMultimap(Function<? super T, ? extends K>, Function<? super T, ? extends V>) - Static method in class com.google.common.collect.CollectCollectors
 
toImmutableSetMultimap(Function<? super T, ? extends K>, Function<? super T, ? extends V>) - Static method in class com.google.common.collect.ImmutableSetMultimap
Returns a Collector that accumulates elements into an ImmutableSetMultimap whose keys and values are the result of applying the provided mapping functions to the input elements.
toImmutableSortedMap(Comparator<? super K>, Function<? super T, ? extends K>, Function<? super T, ? extends V>) - Static method in class com.google.common.collect.CollectCollectors
 
toImmutableSortedMap(Comparator<? super K>, Function<? super T, ? extends K>, Function<? super T, ? extends V>) - Static method in class com.google.common.collect.ImmutableSortedMap
Returns a Collector that accumulates elements into an ImmutableSortedMap whose keys and values are the result of applying the provided mapping functions to the input elements.
toImmutableSortedMap(Comparator<? super K>, Function<? super T, ? extends K>, Function<? super T, ? extends V>, BinaryOperator<V>) - Static method in class com.google.common.collect.CollectCollectors
 
toImmutableSortedMap(Comparator<? super K>, Function<? super T, ? extends K>, Function<? super T, ? extends V>, BinaryOperator<V>) - Static method in class com.google.common.collect.ImmutableSortedMap
Returns a Collector that accumulates elements into an ImmutableSortedMap whose keys and values are the result of applying the provided mapping functions to the input elements.
toImmutableSortedMultiset(Comparator<? super E>) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns a Collector that accumulates the input elements into a new ImmutableMultiset.
toImmutableSortedMultiset(Comparator<? super E>, Function<? super T, ? extends E>, ToIntFunction<? super T>) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns a Collector that accumulates elements into an ImmutableSortedMultiset whose elements are the result of applying elementFunction to the inputs, with counts equal to the result of applying countFunction to the inputs.
toImmutableSortedSet(Comparator<? super E>) - Static method in class com.google.common.collect.CollectCollectors
 
toImmutableSortedSet(Comparator<? super E>) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns a Collector that accumulates the input elements into a new ImmutableSortedSet, ordered by the specified comparator.
toImmutableTable(Function<? super T, ? extends R>, Function<? super T, ? extends C>, Function<? super T, ? extends V>) - Static method in class com.google.common.collect.ImmutableTable
Returns a Collector that accumulates elements into an ImmutableTable.
toImmutableTable(Function<? super T, ? extends R>, Function<? super T, ? extends C>, Function<? super T, ? extends V>) - Static method in class com.google.common.collect.TableCollectors
 
toImmutableTable(Function<? super T, ? extends R>, Function<? super T, ? extends C>, Function<? super T, ? extends V>, BinaryOperator<V>) - Static method in class com.google.common.collect.ImmutableTable
Returns a Collector that accumulates elements into an ImmutableTable.
toImmutableTable(Function<? super T, ? extends R>, Function<? super T, ? extends C>, Function<? super T, ? extends V>, BinaryOperator<V>) - Static method in class com.google.common.collect.TableCollectors
 
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
 
toJavaUtil() - Method in class com.google.common.base.Optional
Returns the equivalent java.util.Optional value to this optional.
toJavaUtil(Optional<T>) - Static method in class com.google.common.base.Optional
Returns the equivalent java.util.Optional value to the given com.google.common.base.Optional, or null if the argument is null.
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(char) - Static method in class com.google.common.base.Ascii
If the argument is an uppercase ASCII character, returns the lowercase equivalent.
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(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.
toMap(Function<? super E, V>) - Method in class com.google.common.collect.FluentIterable
Returns an immutable map whose keys are the distinct elements of this FluentIterable and whose value for each key was computed by valueFunction.
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.
TOMBSTONE - Static variable in class com.google.common.util.concurrent.AbstractFuture.Listener
 
TOMBSTONE - Static variable in class com.google.common.util.concurrent.AbstractFuture.Waiter
 
toMultimap(Function<? super T, ? extends K>, Function<? super T, ? extends V>, Supplier<M>) - Static method in class com.google.common.collect.CollectCollectors
 
toMultimap(Function<? super T, ? extends K>, Function<? super T, ? extends V>, Supplier<M>) - Static method in class com.google.common.collect.Multimaps
Returns a Collector accumulating entries into a Multimap generated from the specified supplier.
toMultiset() - Method in class com.google.common.collect.FluentIterable
Returns an ImmutableMultiset containing all of the elements from this fluent iterable.
toMultiset(Function<? super T, E>, ToIntFunction<? super T>, Supplier<M>) - Static method in class com.google.common.collect.CollectCollectors
 
toMultiset(Function<? super T, E>, ToIntFunction<? super T>, Supplier<M>) - Static method in class com.google.common.collect.Multisets
Returns a Collector that accumulates elements into a multiset created via the specified Supplier, whose elements are the result of applying elementFunction to the inputs, with counts equal to the result of applying countFunction to the inputs.
toNanosSaturated(Duration) - Static method in class com.google.common.base.Internal
Returns the number of nanoseconds of the given duration without throwing or overflowing.
toNanosSaturated(Duration) - Static method in class com.google.common.cache.CacheBuilder
Returns the number of nanoseconds of the given duration without throwing or overflowing.
toNanosSaturated(Duration) - Static method in class com.google.common.util.concurrent.Internal
Returns the number of nanoseconds of the given duration without throwing or overflowing.
tooHigh(T) - Method in class com.google.common.collect.GeneralRange
 
tooLow(T) - Method in class com.google.common.collect.GeneralRange
 
toOptional() - Static method in class com.google.common.collect.MoreCollectors
A collector that converts a stream of zero or one elements to an Optional.
ToOptionalState() - Constructor for class com.google.common.collect.MoreCollectors.ToOptionalState
 
toParsableString() - Method in class com.google.common.cache.CacheBuilderSpec
Returns a string that can be used to parse an equivalent CacheBuilderSpec.
topDomainUnderRegistrySuffix() - Method in class com.google.common.net.InternetDomainName
Returns the portion of this domain name that is one level beneath the registry suffix.
topDown(Iterator<? extends N>, Traverser.InsertionOrder) - Method in class com.google.common.graph.Traverser.Traversal
In top-down traversal, an ancestor node is always traversed before any of its descendant nodes.
toPendingString() - Method in class com.google.common.util.concurrent.CombinedFuture.AsyncCallableInterruptibleTask
 
toPendingString() - Method in class com.google.common.util.concurrent.CombinedFuture.CallableInterruptibleTask
 
toPendingString() - Method in class com.google.common.util.concurrent.InterruptibleTask
 
toPendingString() - Method in class com.google.common.util.concurrent.TrustedListenableFutureTask.TrustedFutureInterruptibleAsyncTask
 
toPendingString() - Method in class com.google.common.util.concurrent.TrustedListenableFutureTask.TrustedFutureInterruptibleTask
 
topK() - Method in class com.google.common.collect.TopKSelector
Returns the top k elements offered to this TopKSelector, or all elements if fewer than k have been offered, in the order specified by the factory used to create this TopKSelector.
TopKSelector<T> - Class in com.google.common.collect
An accumulator that selects the "top" k elements added to it, relative to a provided comparator.
TopKSelector(Comparator<? super T>, int) - Constructor for class com.google.common.collect.TopKSelector
 
toPlainArray(AtomicLongArray) - Static method in class com.google.common.hash.BloomFilterStrategies.LockFreeBitArray
Careful here: if threads are mutating the atomicLongArray while this method is executing, the final long[] will be a "rolling snapshot" of the state of the bit array.
topMetaIterator - Variable in class com.google.common.collect.Iterators.ConcatenatedIterator
 
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.EnumMultiset.Itr
 
toRemove - Variable in class com.google.common.collect.HashBiMap.Itr
 
toRemove - Variable in class com.google.common.collect.Iterators.ConcatenatedIterator
 
toRetain - Variable in class com.google.common.collect.testing.testers.CollectionRetainAllTester.Target
 
toSafeNanos(long, TimeUnit) - Static method in class com.google.common.util.concurrent.Monitor
Returns unit.toNanos(time), additionally ensuring the returned value is not at risk of overflowing or underflowing, by bounding the value between 0 and (Long.MAX_VALUE / 4) * 3.
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
 
toStats() - Static method in class com.google.common.math.Stats
Returns a Collector which accumulates statistics from a Stream of any type of boxed Number into a Stats.
toString - Variable in class com.google.common.collect.testing.AbstractIteratorTester.Stimulus
 
toString - Variable in class com.google.common.hash.ChecksumHashFunction
 
toString - Variable in class com.google.common.hash.MacHashFunction
 
toString - Variable in class com.google.common.hash.MessageDigestHashFunction.SerializedForm
 
toString - Variable in class com.google.common.hash.MessageDigestHashFunction
 
toString - Variable in class com.google.common.net.MediaType
 
toString - Variable in enum class com.google.common.primitives.Booleans.BooleanComparator
 
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.And
 
toString() - Method in class com.google.common.base.CharMatcher.AnyOf
 
toString() - Method in class com.google.common.base.CharMatcher.BreakingWhitespace
 
toString() - Method in class com.google.common.base.CharMatcher.ForPredicate
 
toString() - Method in class com.google.common.base.CharMatcher.InRange
 
toString() - Method in class com.google.common.base.CharMatcher.Is
 
toString() - Method in class com.google.common.base.CharMatcher.IsEither
 
toString() - Method in class com.google.common.base.CharMatcher.IsNot
 
toString() - Method in class com.google.common.base.CharMatcher.JavaDigit
 
toString() - Method in class com.google.common.base.CharMatcher.JavaLetter
 
toString() - Method in class com.google.common.base.CharMatcher.JavaLetterOrDigit
 
toString() - Method in class com.google.common.base.CharMatcher.JavaLowerCase
 
toString() - Method in class com.google.common.base.CharMatcher.JavaUpperCase
 
toString() - Method in class com.google.common.base.CharMatcher.NamedFastMatcher
 
toString() - Method in class com.google.common.base.CharMatcher.Negated
 
toString() - Method in class com.google.common.base.CharMatcher.Or
 
toString() - Method in class com.google.common.base.CharMatcher.RangesMatcher
 
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.CommonPattern
 
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 class 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 class com.google.common.base.Functions.ToStringFunction
 
toString() - Method in class com.google.common.base.JdkPattern
 
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.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.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.Predicates.SubtypeOfPredicate
 
toString() - Method in class com.google.common.base.Present
 
toString() - Method in enum class 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.NonSerializableMemoizingSupplier
 
toString() - Method in class com.google.common.base.Suppliers.SupplierComposition
 
toString() - Method in enum class 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
 
toString() - Method in class com.google.common.cache.LongAdder
Returns the String representation of the LongAdder.sum().
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 class com.google.common.collect.ContiguousSet
Returns a shorthand 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.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() - Method in class com.google.common.collect.Iterables.UnmodifiableIterable
 
toString() - Method in class com.google.common.collect.LexicographicalOrdering
 
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() - 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.testing.AbstractIteratorTester.Stimulus
 
toString() - Method in class com.google.common.collect.testing.features.TesterRequirements
 
toString() - Method in class com.google.common.collect.testing.MapInterfaceTest.IncompatibleKeyType
 
toString() - Method in class com.google.common.collect.testing.SafeTreeMap
 
toString() - Method in class com.google.common.collect.testing.SafeTreeSet
 
toString() - Method in class com.google.common.collect.testing.testers.CollectionRetainAllTester.Target
 
toString() - Method in class com.google.common.collect.testing.UnhashableObject
 
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.DeadEvent
 
toString() - Method in class com.google.common.eventbus.EventBus
 
toString() - Method in class com.google.common.graph.AbstractGraph
Returns a string representation of this graph.
toString() - Method in class com.google.common.graph.AbstractNetwork
Returns a string representation of this network.
toString() - Method in class com.google.common.graph.AbstractValueGraph
Returns a string representation of this graph.
toString() - Method in class com.google.common.graph.ElementOrder
 
toString() - Method in class com.google.common.graph.EndpointPair.Ordered
 
toString() - Method in class com.google.common.graph.EndpointPair.Unordered
 
toString() - Method in class com.google.common.hash.ChecksumHashFunction
 
toString() - Method in class com.google.common.hash.Crc32cHashFunction
 
toString() - Method in class com.google.common.hash.FarmHashFingerprint64
 
toString() - Method in class com.google.common.hash.Fingerprint2011
 
toString() - Method in enum class com.google.common.hash.Funnels.ByteArrayFunnel
 
toString() - Method in enum class com.google.common.hash.Funnels.IntegerFunnel
 
toString() - Method in enum class 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 class 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() - Method in class com.google.common.hash.LongAdder
Returns the String representation of the LongAdder.sum().
toString() - Method in class com.google.common.hash.MacHashFunction
 
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.AsByteSource
 
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() - Method in class com.google.common.io.Files.FileByteSink
 
toString() - Method in class com.google.common.io.Files.FileByteSource
 
toString() - Method in class com.google.common.io.MoreFiles.PathByteSink
 
toString() - Method in class com.google.common.io.MoreFiles.PathByteSource
 
toString() - Method in class com.google.common.io.Resources.UrlByteSource
 
toString() - Method in class com.google.common.math.LinearTransformation.NaNLinearTransformation
 
toString() - Method in class com.google.common.math.LinearTransformation.RegularLinearTransformation
 
toString() - Method in class com.google.common.math.LinearTransformation.VerticalLinearTransformation
 
toString() - Method in class com.google.common.math.PairedStats
 
toString() - Method in class com.google.common.math.Stats
 
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 enum class com.google.common.primitives.Booleans.BooleanComparator
 
toString() - Method in enum class com.google.common.primitives.Booleans.LexicographicalComparator
 
toString() - Method in class com.google.common.primitives.Bytes.ByteArrayAsList
 
toString() - Method in class com.google.common.primitives.Chars.CharArrayAsList
 
toString() - Method in enum class com.google.common.primitives.Chars.LexicographicalComparator
 
toString() - Method in class com.google.common.primitives.Doubles.DoubleArrayAsList
 
toString() - Method in class com.google.common.primitives.Doubles.DoubleConverter
 
toString() - Method in enum class com.google.common.primitives.Doubles.LexicographicalComparator
 
toString() - Method in class com.google.common.primitives.Floats.FloatArrayAsList
 
toString() - Method in class com.google.common.primitives.Floats.FloatConverter
 
toString() - Method in enum class com.google.common.primitives.Floats.LexicographicalComparator
 
toString() - Method in class com.google.common.primitives.ImmutableDoubleArray.AsList
 
toString() - Method in class com.google.common.primitives.ImmutableDoubleArray
Returns a string representation of this array in the same form as Arrays.toString(double[]), for example "[1, 2, 3]".
toString() - Method in class com.google.common.primitives.ImmutableIntArray.AsList
 
toString() - Method in class com.google.common.primitives.ImmutableIntArray
Returns a string representation of this array in the same form as Arrays.toString(int[]), for example "[1, 2, 3]".
toString() - Method in class com.google.common.primitives.ImmutableLongArray.AsList
 
toString() - Method in class com.google.common.primitives.ImmutableLongArray
Returns a string representation of this array in the same form as Arrays.toString(long[]), for example "[1, 2, 3]".
toString() - Method in class com.google.common.primitives.Ints.IntArrayAsList
 
toString() - Method in class com.google.common.primitives.Ints.IntConverter
 
toString() - Method in enum class com.google.common.primitives.Ints.LexicographicalComparator
 
toString() - Method in enum class com.google.common.primitives.Longs.LexicographicalComparator
 
toString() - Method in class com.google.common.primitives.Longs.LongArrayAsList
 
toString() - Method in class com.google.common.primitives.Longs.LongConverter
 
toString() - Method in enum class com.google.common.primitives.Shorts.LexicographicalComparator
 
toString() - Method in class com.google.common.primitives.Shorts.ShortArrayAsList
 
toString() - Method in class com.google.common.primitives.Shorts.ShortConverter
 
toString() - Method in enum class com.google.common.primitives.SignedBytes.LexicographicalComparator
 
toString() - Method in enum class com.google.common.primitives.UnsignedBytes.LexicographicalComparatorHolder.PureJavaComparator
 
toString() - Method in enum class com.google.common.primitives.UnsignedBytes.LexicographicalComparatorHolder.UnsafeComparator
 
toString() - Method in class com.google.common.primitives.UnsignedInteger
Returns a string representation of the UnsignedInteger value, in base 10.
toString() - Method in enum class com.google.common.primitives.UnsignedInts.LexicographicalComparator
 
toString() - Method in class com.google.common.primitives.UnsignedLong
Returns a string representation of the UnsignedLong value, in base 10.
toString() - Method in enum class com.google.common.primitives.UnsignedLongs.LexicographicalComparator
 
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.LocationInfo
 
toString() - Method in class com.google.common.reflect.ClassPath.ResourceInfo
 
toString() - Method in class com.google.common.reflect.Invokable
 
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() - 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.testing.ArbitraryInstances.AlwaysEqual
 
toString() - Method in class com.google.common.testing.ArbitraryInstances.ByToString
 
toString() - Method in class com.google.common.testing.DummyProxy.DummyHandler
 
toString() - Method in class com.google.common.testing.ForwardingWrapperTester.InteractionTester
 
toString() - Method in class com.google.common.testing.FreshValueGenerator.FreshInvocationHandler
 
toString() - Method in class com.google.common.testing.RelationshipTester.Item
 
toString() - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
 
toString() - Method in class com.google.common.util.concurrent.AbstractFuture
 
toString() - Method in class com.google.common.util.concurrent.AbstractIdleService.DelegateService
 
toString() - Method in class com.google.common.util.concurrent.AbstractIdleService
 
toString() - Method in class com.google.common.util.concurrent.AbstractScheduledService.ServiceDelegate
 
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.ClosingFuture
 
toString() - Method in enum class com.google.common.util.concurrent.DirectExecutor
 
toString() - Method in class com.google.common.util.concurrent.ForwardingFluentFuture
 
toString() - Method in class com.google.common.util.concurrent.Futures.CallbackListener
 
toString() - Method in class com.google.common.util.concurrent.ImmediateFuture
 
toString() - Method in class com.google.common.util.concurrent.InterruptibleTask.Blocker
 
toString() - Method in class com.google.common.util.concurrent.InterruptibleTask
 
toString() - Method in class com.google.common.util.concurrent.MoreExecutors.ListeningDecorator
 
toString() - Method in class com.google.common.util.concurrent.RateLimiter
 
toString() - Method in class com.google.common.util.concurrent.SequentialExecutor.QueueWorker
 
toString() - Method in class com.google.common.util.concurrent.SequentialExecutor
 
toString() - Method in class com.google.common.util.concurrent.ServiceManager
 
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(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) - Method in class com.google.common.primitives.UnsignedLong
Returns a string representation of the UnsignedLong value, in base radix.
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(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(Cut<?>, Cut<?>) - Static method in class com.google.common.collect.Range
 
toString(File, Charset) - Static method in class com.google.common.io.Files
Deprecated.
Prefer asCharSource(file, charset).read().
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(Object) - Method in class com.google.common.base.Joiner
 
toString(Readable) - Static method in class com.google.common.io.CharStreams
Reads all characters from a Readable object into a String.
toString(Type) - Static method in class com.google.common.reflect.Types
Returns a human-readable string representation of type.
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(Iterator<?>) - Static method in class com.google.common.collect.Iterators
Returns a string representation of iterator, with the format [e1, e2, ..., en].
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
A function equivalent to the method reference Object::toString, for users not yet using Java 8.
ToStringFunction() - Constructor for enum class com.google.common.base.Functions.ToStringFunction
 
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(Object) - Static method in class com.google.common.base.MoreObjects
Creates an instance of MoreObjects.ToStringHelper.
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, Iterable<?>) - Static method in class com.google.common.base.Predicates
 
ToStringHelper(String) - Constructor for class com.google.common.base.MoreObjects.ToStringHelper
Use MoreObjects.toStringHelper(Object) to create an instance.
toStringImpl(Collection<?>) - Static method in class com.google.common.collect.Collections2
An implementation of
invalid reference
Collection#toString()
.
toStringImpl(Map<?, ?>) - Static method in class com.google.common.collect.Maps
An implementation of
invalid reference
Map#toString
.
toTable() - Method in class com.google.common.collect.TableCollectors.ImmutableTableCollectorState
 
toTable(Function<? super T, ? extends R>, Function<? super T, ? extends C>, Function<? super T, ? extends V>, BinaryOperator<V>, Supplier<I>) - Static method in class com.google.common.collect.TableCollectors
 
toTable(Function<? super T, ? extends R>, Function<? super T, ? extends C>, Function<? super T, ? extends V>, BinaryOperator<V>, Supplier<I>) - Static method in class com.google.common.collect.Tables
Returns a Collector that accumulates elements into a Table created using the specified supplier, whose cells are generated by applying the provided mapping functions to the input elements.
toTable(Function<? super T, ? extends R>, Function<? super T, ? extends C>, Function<? super T, ? extends V>, Supplier<I>) - Static method in class com.google.common.collect.TableCollectors
 
toTable(Function<? super T, ? extends R>, Function<? super T, ? extends C>, Function<? super T, ? extends V>, Supplier<I>) - Static method in class com.google.common.collect.Tables
Returns a Collector that accumulates elements into a Table created using the specified supplier, whose cells are generated by applying the provided mapping functions to the input elements.
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
 
totalSize(Iterable<? extends Multiset.Entry<?>>) - Static method in class com.google.common.collect.testing.google.MultisetNavigationTester
 
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.
touch(Path) - Static method in class com.google.common.io.MoreFiles
Like the unix command of the same name, creates an empty file or updates the last modified timestamp of the existing file at the given path to the current system time.
toUpperCase(char) - Static method in class com.google.common.base.Ascii
If the argument is a lowercase ASCII character, returns the uppercase equivalent.
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(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.
toUriString(InetAddress) - Static method in class com.google.common.net.InetAddresses
Returns the string representation of an InetAddress suitable for inclusion in a URI.
toX(double, RoundingMode) - Method in class com.google.common.math.BigDecimalMath.BigDecimalToDoubleRounder
 
toX(double, RoundingMode) - Method in class com.google.common.math.BigIntegerMath.BigIntegerToDoubleRounder
 
toX(double, RoundingMode) - Method in class com.google.common.math.ToDoubleRounder
Returns d's value as an X, rounded with the specified mode.
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.
transferElement(Stack<E>, Stack<E>) - Method in class com.google.common.collect.testing.AbstractIteratorTester.MultiExceptionListIterator
 
transform(double) - Method in class com.google.common.math.LinearTransformation.NaNLinearTransformation
 
transform(double) - Method in class com.google.common.math.LinearTransformation.RegularLinearTransformation
 
transform(double) - Method in class com.google.common.math.LinearTransformation
Returns the y corresponding to the given x.
transform(double) - Method in class com.google.common.math.LinearTransformation.VerticalLinearTransformation
 
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(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(Function<? super V, T>, Executor) - Method in class com.google.common.util.concurrent.FluentFuture
Returns a new Future whose result is derived from the result of this Future.
transform(ClosingFuture.ClosingFunction<? super V, U>, Executor) - Method in class com.google.common.util.concurrent.ClosingFuture
Returns a new ClosingFuture pipeline step derived from this one by applying a function to its value.
transform(ListenableFuture<I>, Function<? super I, ? extends O>, Executor) - Static method in class com.google.common.util.concurrent.Futures
Returns a new Future whose result is derived from the result of the given Future.
transform(F) - Method in class com.google.common.collect.TransformedIterator
 
transform(Iterable<F>, Function<? super F, ? extends T>) - Static method in class com.google.common.collect.Iterables
Returns a view containing the result of applying function to each element of fromIterable.
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(Iterator<F>, Function<? super F, ? extends T>) - Static method in class com.google.common.collect.Iterators
Returns a view containing the result of applying 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
 
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.
transformAsync(AsyncFunction<? super V, T>, Executor) - Method in class com.google.common.util.concurrent.FluentFuture
Returns a new Future whose result is asynchronously derived from the result of this Future.
transformAsync(ClosingFuture.AsyncClosingFunction<? super V, U>, Executor) - Method in class com.google.common.util.concurrent.ClosingFuture
Returns a new ClosingFuture pipeline step derived from this one by applying a function that returns a ClosingFuture to its value.
transformAsync(ListenableFuture<I>, AsyncFunction<? super I, ? extends O>, Executor) - Static method in class com.google.common.util.concurrent.Futures
Returns a new Future whose result is asynchronously derived from the result of the given Future.
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(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(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(Iterator<Map.Entry<K, V>>) - Static method in class com.google.common.reflect.MutableTypeToInstanceMap.UnmodifiableEntry
 
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(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(Set<Map.Entry<K, V>>) - Static method in class com.google.common.reflect.MutableTypeToInstanceMap.UnmodifiableEntry
 
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.
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.
transformEntry(Map.Entry<K, V1>) - Method in class com.google.common.collect.Maps.TransformedEntriesNavigableMap
 
transformEntry(K, V1) - Method in interface com.google.common.collect.Maps.EntryTransformer
Determines an output value based on a key-value pair.
transformer - Variable in class com.google.common.collect.Maps.TransformedEntriesMap
 
transformer - Variable in class com.google.common.collect.Multimaps.TransformedEntriesMultimap
 
TransformFuture(ListenableFuture<? extends I>, Function<? super I, ? extends O>) - Constructor for class com.google.common.util.concurrent.AbstractTransformFuture.TransformFuture
 
Transforming - Search tag in class com.google.common.util.concurrent.ClosingFuture
Section
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(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(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(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.
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(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(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.
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.
transitiveClosure(Graph<N>) - Static method in class com.google.common.graph.Graphs
Returns the transitive closure of graph.
transitiveClosure(Graph<N>) - Static method in class com.google.common.graph.GraphsBridgeMethods
 
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(EndpointPair<N>) - Static method in class com.google.common.graph.Graphs
 
transpose(Graph<N>) - Static method in class com.google.common.graph.Graphs
Returns a view of graph with the direction (if any) of every edge reversed.
transpose(Network<N, E>) - Static method in class com.google.common.graph.Graphs
Returns a view of network with the direction (if any) of every edge reversed.
transpose(ValueGraph<N, V>) - Static method in class com.google.common.graph.Graphs
Returns a view of graph with the direction (if any) of every edge reversed.
transposeCell(Table.Cell<R, C, V>) - Static method in class com.google.common.collect.Tables
 
TransposedGraph(Graph<N>) - Constructor for class com.google.common.graph.Graphs.TransposedGraph
 
TransposedNetwork(Network<N, E>) - Constructor for class com.google.common.graph.Graphs.TransposedNetwork
 
TransposedValueGraph(ValueGraph<N, V>) - Constructor for class com.google.common.graph.Graphs.TransposedValueGraph
 
TransposeTable(Table<R, C, V>) - Constructor for class com.google.common.collect.Tables.TransposeTable
 
Traversal(SuccessorsFunction<N>) - Constructor for class com.google.common.graph.Traverser.Traversal
 
Traverser<N> - Class in com.google.common.graph
An object that can traverse the nodes that are reachable from a specified (set of) start node(s) using a specified SuccessorsFunction.
Traverser(SuccessorsFunction<N>) - Constructor for class com.google.common.graph.Traverser
 
Traverser.InsertionOrder - Enum Class in com.google.common.graph
Poor man's method reference for Deque::addFirst and Deque::addLast.
Traverser.Traversal<N> - Class in com.google.common.graph
Abstracts away the difference between traversing a graph vs.
treeAggregate(TreeMultiset.AvlNode<?>) - Method in enum class 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 Class 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,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,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> - 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> - Class in com.google.common.collect
 
TreeRangeSet.RangesByUpperBound<C> - Class in com.google.common.collect
 
TreeRangeSet.SubRangeSet - Class in com.google.common.collect
 
TreeRangeSet.SubRangeSetRangesByLowerBound<C> - 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
Deprecated.
Use Traverser instead. All instance methods have their equivalent on the result of Traverser.forTree(tree) where tree implements SuccessorsFunction, which has a similar API as TreeTraverser.children(T) or can be the same lambda function as passed into TreeTraverser.using(Function).

This class is scheduled to be removed in October 2019.

TreeTraverser() - Constructor for class com.google.common.collect.TreeTraverser
Deprecated.
 
TreeTraverser.BreadthFirstIterator - Class in com.google.common.collect
Deprecated.
 
TreeTraverser.PostOrderIterator - Class in com.google.common.collect
Deprecated.
 
TreeTraverser.PostOrderNode<T> - Class in com.google.common.collect
Deprecated.
 
TreeTraverser.PreOrderIterator - Class in com.google.common.collect
Deprecated.
 
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.
trim() - Method in class com.google.common.collect.TopKSelector
Quickselects the top k elements from the 2k elements in the buffer.
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 BMP characters at the start or end of the sequence are removed without replacement.
trimFrom(CharSequence) - Method in class com.google.common.base.CharMatcher.Any
 
trimFrom(CharSequence) - Method in class com.google.common.base.CharMatcher.None
 
trimFrom(CharSequence) - Method in class com.google.common.base.CharMatcher
Returns a substring of the input character sequence that omits all matching BMP characters from the beginning and from the end of the string.
trimLeadingFrom(CharSequence) - Method in class com.google.common.base.CharMatcher.None
 
trimLeadingFrom(CharSequence) - Method in class com.google.common.base.CharMatcher
Returns a substring of the input character sequence that omits all matching BMP characters from the beginning of the string.
trimmed() - Method in class com.google.common.primitives.ImmutableDoubleArray
Returns an immutable array containing the same values as this array.
trimmed() - Method in class com.google.common.primitives.ImmutableIntArray
Returns an immutable array containing the same values as this array.
trimmed() - Method in class com.google.common.primitives.ImmutableLongArray
Returns an immutable array containing the same values as this array.
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
Deprecated.
For a ListMultimap that automatically trims to size, use ImmutableListMultimap. If you need a mutable collection, remove the trimToSize call, or switch to a HashMap<K, ArrayList<V>>.
trimToSize() - Method in class com.google.common.collect.CompactHashMap
Ensures that this CompactHashMap has the smallest representation in memory, given its current size.
trimToSize() - Method in class com.google.common.collect.CompactHashSet
Ensures that this CompactHashSet has the smallest representation in memory, given its current size.
trimTrailingFrom(CharSequence) - Method in class com.google.common.base.CharMatcher.None
 
trimTrailingFrom(CharSequence) - Method in class com.google.common.base.CharMatcher
Returns a substring of the input character sequence that omits all matching BMP characters from the end of the string.
trimTrailingPadding(CharSequence) - Method in class com.google.common.io.BaseEncoding.SeparatedBaseEncoding
 
trimTrailingPadding(CharSequence) - Method in class com.google.common.io.BaseEncoding.StandardBaseEncoding
 
trimTrailingPadding(CharSequence) - Method in class com.google.common.io.BaseEncoding
 
TRUE_FIRST - Enum constant in enum class com.google.common.primitives.Booleans.BooleanComparator
 
trueFirst() - Static method in class com.google.common.primitives.Booleans
Returns a Comparator<Boolean> that sorts true before false.
trueValue - Variable in enum class com.google.common.primitives.Booleans.BooleanComparator
 
truncate(CharSequence, int, String) - Static method in class com.google.common.base.Ascii
Truncates the given character sequence to the given maximum length.
TrustedFuture() - Constructor for class com.google.common.util.concurrent.AbstractFuture.TrustedFuture
 
TrustedFuture() - Constructor for class com.google.common.util.concurrent.FluentFuture.TrustedFuture
 
TrustedFutureInterruptibleAsyncTask(AsyncCallable<V>) - Constructor for class com.google.common.util.concurrent.TrustedListenableFutureTask.TrustedFutureInterruptibleAsyncTask
 
TrustedFutureInterruptibleTask(Callable<V>) - Constructor for class com.google.common.util.concurrent.TrustedListenableFutureTask.TrustedFutureInterruptibleTask
 
trustedGet(TypeToken<T>) - Method in class com.google.common.reflect.ImmutableTypeToInstanceMap
 
trustedGet(TypeToken<T>) - Method in class com.google.common.reflect.MutableTypeToInstanceMap
 
TrustedListenableFutureTask<V> - Class in com.google.common.util.concurrent
A RunnableFuture that also implements the ListenableFuture interface.
TrustedListenableFutureTask(AsyncCallable<V>) - Constructor for class com.google.common.util.concurrent.TrustedListenableFutureTask
 
TrustedListenableFutureTask(Callable<V>) - Constructor for class com.google.common.util.concurrent.TrustedListenableFutureTask
 
TrustedListenableFutureTask.TrustedFutureInterruptibleAsyncTask - Class in com.google.common.util.concurrent
 
TrustedListenableFutureTask.TrustedFutureInterruptibleTask - Class in com.google.common.util.concurrent
 
trustedPut(TypeToken<T>, T) - Method in class com.google.common.reflect.MutableTypeToInstanceMap
 
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) - Method in class com.google.common.util.concurrent.RateLimiter
Acquires permits 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.
tryAcquire(int, Duration) - 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.
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(Duration) - 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.
tryAcquireUninterruptibly(Semaphore, int, long, TimeUnit) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes semaphore.tryAcquire(permits, timeout, unit) uninterruptibly.
tryAcquireUninterruptibly(Semaphore, int, Duration) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes semaphore.tryAcquire(permits, timeout, unit) uninterruptibly.
tryAcquireUninterruptibly(Semaphore, long, TimeUnit) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes semaphore.tryAcquire(1, timeout, unit) uninterruptibly.
tryAcquireUninterruptibly(Semaphore, Duration) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes semaphore.tryAcquire(1, timeout, unit) uninterruptibly.
tryAdvance(Consumer<? super E>) - Method in class com.google.common.collect.testing.SpliteratorTester.GeneralSpliterator
 
tryAdvance(Consumer<? super E>) - Method in class com.google.common.collect.testing.SpliteratorTester.GeneralSpliteratorOfObject
 
tryAdvance(Consumer<? super E>) - Method in class com.google.common.collect.testing.SpliteratorTester.GeneralSpliteratorOfPrimitive
 
tryAdvance(Consumer<? super OutElementT>) - Method in class com.google.common.collect.CollectSpliterators.FlatMapSpliterator
 
tryAdvance(OutConsumerT) - Method in class com.google.common.collect.CollectSpliterators.FlatMapSpliteratorOfPrimitive
 
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.
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.
tryInternalFastPathGetFailure() - Method in class com.google.common.util.concurrent.AbstractFuture
Usually returns null but, if this Future has failed, may optionally return the cause of the failure.
tryInternalFastPathGetFailure() - Method in class com.google.common.util.concurrent.internal.InternalFutureFailureAccess
Usually returns null but, if this Future has failed, may optionally return the cause of the failure.
tryInternalFastPathGetFailure(InternalFutureFailureAccess) - Static method in class com.google.common.util.concurrent.internal.InternalFutures
Usually returns null but, if the given Future has failed, may optionally return the cause of the failure.
tryLock() - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory.CycleDetectingReentrantLock
 
tryLock() - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory.CycleDetectingReentrantReadLock
 
tryLock() - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory.CycleDetectingReentrantWriteLock
 
tryLock() - Method in class com.google.common.util.concurrent.ForwardingLock
 
tryLock(long, TimeUnit) - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory.CycleDetectingReentrantLock
 
tryLock(long, TimeUnit) - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory.CycleDetectingReentrantReadLock
 
tryLock(long, TimeUnit) - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory.CycleDetectingReentrantWriteLock
 
tryLock(long, TimeUnit) - Method in class com.google.common.util.concurrent.ForwardingLock
 
tryLockUninterruptibly(Lock, long, TimeUnit) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes lock.tryLock(timeout, unit) uninterruptibly.
tryLockUninterruptibly(Lock, Duration) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes lock.tryLock(timeout, unit) uninterruptibly.
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) - Static method in class com.google.common.primitives.Longs
Parses the specified string as a signed decimal long 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, int) - Static method in class com.google.common.primitives.Longs
Parses the specified string as a signed long value using the specified radix.
tryParseDecimal(String, int, int) - Static method in class com.google.common.net.InetAddresses
Returns a -1 if unable to parse
trySetAccessible() - Method in class com.google.common.reflect.Invokable
trySetCancelled() - Method in class com.google.common.util.concurrent.ExecutionSequencer.TaskNonReentrantExecutor
 
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.
trySetStarted() - Method in class com.google.common.util.concurrent.ExecutionSequencer.TaskNonReentrantExecutor
 
trySplit() - Method in class com.google.common.collect.CollectSpliterators.FlatMapSpliterator
 
trySplit() - Method in class com.google.common.collect.Streams.MapWithIndexSpliterator
 
trySplit() - Method in class com.google.common.collect.testing.SpliteratorTester.GeneralSpliterator
 
trySplit() - Method in class com.google.common.collect.testing.SpliteratorTester.GeneralSpliteratorOfObject
 
trySplit() - Method in class com.google.common.collect.testing.SpliteratorTester.GeneralSpliteratorOfPrimitive
 
trySplitTestingSize(SpliteratorTester.GeneralSpliterator<E>) - Static method in class com.google.common.collect.testing.SpliteratorTester
 
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.collect.testing.MinimalCollection
 
type - Variable in class com.google.common.graph.ElementOrder
 
type - Variable in class com.google.common.net.MediaType
 
type - Variable in class com.google.common.reflect.Parameter
 
type() - Method in class com.google.common.graph.ElementOrder
Returns the type of ordering used.
type() - Method in class com.google.common.net.MediaType
Returns the top-level media type.
Type() - Constructor for enum class com.google.common.graph.ElementOrder.Type
 
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 class com.google.common.reflect.TypeToken.TypeFilter
 
TypeMappingIntrospector() - Constructor for class com.google.common.reflect.TypeResolver.TypeMappingIntrospector
 
typeName(Type) - Method in enum class 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.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 - Variable in class com.google.common.reflect.TypeToken.TypeSet
 
Types - Class in com.google.common.reflect
Utilities for working with Type.
Types() - Constructor for class com.google.common.reflect.Types
 
Types.ClassOwnership - Enum Class 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 Class in com.google.common.reflect
 
Types.NativeTypeVariableEquals<X> - Class in com.google.common.reflect
Per issue 1635, In JDK 1.7.0_51-b13, Types.TypeVariableImpl.equals(Object) is changed to no longer be equal to custom TypeVariable implementations.
Types.ParameterizedTypeImpl - Class in com.google.common.reflect
 
Types.TypeVariableImpl<D> - Class in com.google.common.reflect
 
Types.TypeVariableInvocationHandler - Class in com.google.common.reflect
Invocation handler to work around a compatibility problem between Java 7 and Java 8.
Types.WildcardTypeImpl - Class in com.google.common.reflect
 
TypeSet() - Constructor for class com.google.common.reflect.TypeToken.TypeSet
 
Types of ranges - Search tag in class com.google.common.collect.Range
Section
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.Bounds - Class in com.google.common.reflect
 
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 subtype.
TypeToken.TypeCollector.ForwardingTypeCollector<K> - Class in com.google.common.reflect
 
TypeToken.TypeFilter - Enum Class 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 - Variable in class com.google.common.reflect.Types.TypeVariableInvocationHandler
 
TypeVariableImpl(D, String, Type[]) - Constructor for class com.google.common.reflect.Types.TypeVariableImpl
 
TypeVariableInvocationHandler(Types.TypeVariableImpl<?>) - Constructor for class com.google.common.reflect.Types.TypeVariableInvocationHandler
 
TypeVariableKey(TypeVariable<?>) - Constructor for class com.google.common.reflect.TypeResolver.TypeVariableKey
 
typeVariableMethods - Static variable in class com.google.common.reflect.Types.TypeVariableInvocationHandler
 
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
 
uncheckedCastNullableTToT(T) - Static method in class com.google.common.base.NullnessCasts
Accepts a @Nullable T and returns a plain T, without performing any check that that conversion is safe.
uncheckedCastNullableTToT(T) - Static method in class com.google.common.collect.NullnessCasts
Accepts a @Nullable T and returns a plain T, without performing any check that that conversion is safe.
uncheckedCastNullableTToT(T) - Static method in class com.google.common.util.concurrent.NullnessCasts
Accepts a @Nullable T and returns a plain T, without performing any check that that conversion is safe.
UncheckedExecutionException - Exception Class in com.google.common.util.concurrent
Unchecked variant of ExecutionException.
UncheckedExecutionException() - Constructor for exception class com.google.common.util.concurrent.UncheckedExecutionException
Deprecated.
Prefer UncheckedExecutionException(java.lang.Throwable) a constructor that accepts a cause: Users of this class typically expect for instances to have a non-null cause. At the moment, you can usually still preserve behavior by passing an explicit null cause. Note, however, that passing an explicit null cause prevents anyone from calling Throwable.initCause(java.lang.Throwable) later, so it is not quite equivalent to using a constructor that omits the cause.
UncheckedExecutionException(String) - Constructor for exception class com.google.common.util.concurrent.UncheckedExecutionException
Deprecated.
Prefer UncheckedExecutionException(java.lang.String,java.lang.Throwable) a constructor that accepts a cause: Users of this class typically expect for instances to have a non-null cause. At the moment, you can usually still preserve behavior by passing an explicit null cause. Note, however, that passing an explicit null cause prevents anyone from calling Throwable.initCause(java.lang.Throwable) later, so it is not quite equivalent to using a constructor that omits the cause.
UncheckedExecutionException(String, Throwable) - Constructor for exception class com.google.common.util.concurrent.UncheckedExecutionException
Creates a new instance with the given detail message and cause.
UncheckedExecutionException(Throwable) - Constructor for exception class com.google.common.util.concurrent.UncheckedExecutionException
Creates a new instance with null as its detail message and the given cause.
uncheckedNull() - Static method in class com.google.common.util.concurrent.NullnessCasts
Returns null cast to any type.
UncheckedTimeoutException - Exception Class in com.google.common.util.concurrent
Unchecked version of TimeoutException.
UncheckedTimeoutException() - Constructor for exception class com.google.common.util.concurrent.UncheckedTimeoutException
 
UncheckedTimeoutException(String) - Constructor for exception class com.google.common.util.concurrent.UncheckedTimeoutException
 
UncheckedTimeoutException(String, Throwable) - Constructor for exception class com.google.common.util.concurrent.UncheckedTimeoutException
 
UncheckedTimeoutException(Throwable) - Constructor for exception class com.google.common.util.concurrent.UncheckedTimeoutException
 
UnconditionalValueHolder() - Constructor for class com.google.common.base.MoreObjects.ToStringHelper.UnconditionalValueHolder
 
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.
UNDERSCORE_IN_NAME - Static variable in class com.google.common.testing.AbstractPackageSanityTests
A predicate that matches classes with an underscore in the class name.
Understanding complex orderings - Search tag in class com.google.common.collect.Ordering
Section
undirected() - Static method in class com.google.common.graph.GraphBuilder
Returns a GraphBuilder for building undirected graphs.
undirected() - Static method in class com.google.common.graph.NetworkBuilder
Returns a NetworkBuilder for building undirected networks.
undirected() - Static method in class com.google.common.graph.ValueGraphBuilder
Returns a ValueGraphBuilder for building undirected graphs.
Undirected(BaseGraph<N>) - Constructor for class com.google.common.graph.EndpointPairIterator.Undirected
 
UndirectedGraphConnections<N,V> - Class in com.google.common.graph
An implementation of GraphConnections for undirected graphs.
UndirectedGraphConnections(Map<N, V>) - Constructor for class com.google.common.graph.UndirectedGraphConnections
 
UndirectedMultiNetworkConnections<N,E> - Class in com.google.common.graph
An implementation of NetworkConnections for undirected networks with parallel edges.
UndirectedMultiNetworkConnections(Map<E, N>) - Constructor for class com.google.common.graph.UndirectedMultiNetworkConnections
 
UndirectedNetworkConnections<N,E> - Class in com.google.common.graph
An implementation of NetworkConnections for undirected networks.
UndirectedNetworkConnections(Map<E, N>) - Constructor for class com.google.common.graph.UndirectedNetworkConnections
 
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 class 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 - Variable in class com.google.common.collect.FilteredKeyMultimap
 
unfiltered - Variable in class com.google.common.collect.Maps.AbstractFilteredMap
 
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.FilteredEntryMultimap
 
unfiltered() - Method in class com.google.common.collect.FilteredEntrySetMultimap
 
unfiltered() - Method in class com.google.common.collect.FilteredKeyListMultimap
 
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() - Method in class com.google.common.collect.Maps.FilteredEntryBiMap
 
unfiltered() - Method in class com.google.common.collect.Sets.FilteredNavigableSet
 
UnhashableElementsImmutableListGenerator() - Constructor for class com.google.common.collect.testing.google.ListGenerators.UnhashableElementsImmutableListGenerator
 
UnhashableObject - Class in com.google.common.collect.testing
An unhashable object to be used in testing as values in our collections.
UnhashableObject(int) - Constructor for class com.google.common.collect.testing.UnhashableObject
 
Unhashables() - Constructor for class com.google.common.collect.testing.SampleElements.Unhashables
 
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(RangeSet<C>) - Method in class com.google.common.collect.ImmutableRangeSet
Returns a new range set consisting of the union of this range set and other.
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.
unionOf(Iterable<Range<C>>) - Static method in class com.google.common.collect.ImmutableRangeSet
Returns an ImmutableRangeSet representing the union of the specified ranges.
uniqueIndex(Function<? super E, K>) - Method in class com.google.common.collect.FluentIterable
Returns a map with the contents of this FluentIterable as its values, indexed by keys derived from those values.
uniqueIndex(Iterable<V>, Function<? super V, K>) - Static method in class com.google.common.collect.Maps
Returns a map with the given values, indexed by keys derived from those values.
uniqueIndex(Iterator<V>, Function<? super V, K>) - Static method in class com.google.common.collect.Maps
Returns a map with the given values, indexed by keys derived from those values.
uniqueIndex(Iterator<V>, Function<? super V, K>, ImmutableMap.Builder<K, V>) - Static method in class com.google.common.collect.Maps
 
unit - Variable in class com.google.common.util.concurrent.AbstractScheduledService.CustomScheduler.Schedule
 
UNKNOWN_ORDER - Enum constant in enum class com.google.common.collect.testing.AbstractIteratorTester.KnownOrder
 
UnknownElementException(Collection<?>, Object) - Constructor for exception class com.google.common.collect.testing.AbstractIteratorTester.UnknownElementException
 
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
 
unlock() - Method in class com.google.common.util.concurrent.ForwardingLock
 
UNMODIFIABLE - Static variable in enum class com.google.common.collect.testing.IteratorFeature
A set containing none of the optional features of the Iterator or ListIterator interfaces.
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<E>) - Method in class com.google.common.collect.AbstractListMultimap
 
unmodifiableCollectionSubclass(Collection<E>) - Method in class com.google.common.collect.AbstractMapBasedMultimap
 
unmodifiableCollectionSubclass(Collection<E>) - Method in class com.google.common.collect.AbstractSetMultimap
 
unmodifiableCollectionSubclass(Collection<E>) - Method in class com.google.common.collect.AbstractSortedSetMultimap
 
unmodifiableCollectionSubclass(Collection<E>) - Method in class com.google.common.collect.Multimaps.CustomMultimap
 
unmodifiableCollectionSubclass(Collection<E>) - Method in class com.google.common.collect.Multimaps.CustomSetMultimap
 
UnmodifiableCollectionTests - Class in com.google.common.collect.testing.google
A series of tests that support asserting that collections cannot be modified, either through direct or indirect means.
UnmodifiableCollectionTests() - Constructor for class com.google.common.collect.testing.google.UnmodifiableCollectionTests
 
unmodifiableDelegate - Variable in class com.google.common.collect.Sets.UnmodifiableNavigableSet
 
unmodifiableEmptyCollection() - Method in class com.google.common.collect.FilteredEntryMultimap
 
unmodifiableEmptyCollection() - Method in class com.google.common.collect.FilteredKeyMultimap
 
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.
UnmodifiableEntries(Collection<Map.Entry<K, V>>) - Constructor for class com.google.common.collect.Maps.UnmodifiableEntries
 
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
 
unmodifiableEntryIterator(Iterator<Map.Entry<K, V>>) - Static method in class com.google.common.collect.Maps
 
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(ImmutableCollection<E>) - Static method in class com.google.common.collect.Iterables
Deprecated.
no need to use this
unmodifiableIterable(Iterable<? extends T>) - Static method in class com.google.common.collect.Iterables
Returns an unmodifiable view of iterable.
UnmodifiableIterable(Iterable<? extends T>) - Constructor for class com.google.common.collect.Iterables.UnmodifiableIterable
 
unmodifiableIterator(UnmodifiableIterator<T>) - Static method in class com.google.common.collect.Iterators
Deprecated.
no need to use this
unmodifiableIterator(Iterator<? extends T>) - Static method in class com.google.common.collect.Iterators
Returns an unmodifiable view of iterator.
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.
unmodifiableKeySet() - Method in class com.google.common.graph.MapIteratorCache
 
UnmodifiableListIterator<E> - Class in com.google.common.collect
UnmodifiableListIterator() - Constructor for class com.google.common.collect.UnmodifiableListIterator
Constructor for use by subclasses.
unmodifiableListMultimap(ImmutableListMultimap<K, V>) - Static method in class com.google.common.collect.Multimaps
Deprecated.
no need to use this
unmodifiableListMultimap(ListMultimap<K, V>) - Static method in class com.google.common.collect.Multimaps
Returns an unmodifiable view of the specified ListMultimap.
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, ? extends V>) - Static method in class com.google.common.collect.Maps
 
unmodifiableMultimap(ImmutableMultimap<K, V>) - Static method in class com.google.common.collect.Multimaps
Deprecated.
no need to use this
unmodifiableMultimap(Multimap<K, V>) - Static method in class com.google.common.collect.Multimaps
Returns an unmodifiable view of the specified multimap.
UnmodifiableMultimap(Multimap<K, V>) - Constructor for class com.google.common.collect.Multimaps.UnmodifiableMultimap
 
unmodifiableMultiset(ImmutableMultiset<E>) - Static method in class com.google.common.collect.Multisets
Deprecated.
no need to use this
unmodifiableMultiset(Multiset<? extends E>) - Static method in class com.google.common.collect.Multisets
Returns an unmodifiable view of the specified multiset.
UnmodifiableMultiset(Multiset<? extends E>) - Constructor for class com.google.common.collect.Multisets.UnmodifiableMultiset
 
unmodifiableNavigableMap(NavigableMap<K, ? extends V>) - Static method in class com.google.common.collect.Maps
Returns an unmodifiable view of the specified navigable map.
UnmodifiableNavigableMap(NavigableMap<K, ? extends V>) - Constructor for class com.google.common.collect.Maps.UnmodifiableNavigableMap
 
UnmodifiableNavigableMap(NavigableMap<K, ? extends 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, ? extends 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(ImmutableSetMultimap<K, V>) - Static method in class com.google.common.collect.Multimaps
Deprecated.
no need to use this
unmodifiableSetMultimap(SetMultimap<K, V>) - Static method in class com.google.common.collect.Multimaps
Returns an unmodifiable view of the specified SetMultimap.
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
 
unordered() - Static method in class com.google.common.graph.ElementOrder
Returns an instance which specifies that no ordering is guaranteed.
unordered(N, N) - Static method in class com.google.common.graph.EndpointPair
Returns an EndpointPair representing the endpoints of an undirected edge.
Unordered(N, N) - Constructor for class com.google.common.graph.EndpointPair.Unordered
 
UNORDERED - Enum constant in enum class com.google.common.graph.ElementOrder.Type
 
unpairedSurrogateMsg(int) - Static method in class com.google.common.base.Utf8
 
unpark() - Method in class com.google.common.util.concurrent.AbstractFuture.Waiter
 
unregister(Object) - Method in class com.google.common.eventbus.EventBus
Unregisters all subscriber methods on a registered object.
unregister(Object) - Method in class com.google.common.eventbus.SubscriberRegistry
Unregisters all subscribers on the given listener object.
UNSAFE - Static variable in class com.google.common.cache.Striped64.Cell
 
UNSAFE - Static variable in class com.google.common.cache.Striped64
 
UNSAFE - Static variable in class com.google.common.hash.Striped64.Cell
 
UNSAFE - Static variable in class com.google.common.hash.Striped64
 
UNSAFE - Static variable in class com.google.common.util.concurrent.AbstractFuture.UnsafeAtomicHelper
 
UNSAFE_BIG_ENDIAN - Enum constant in enum class com.google.common.hash.LittleEndianByteArray.UnsafeByteArray
 
UNSAFE_COMPARATOR_NAME - Static variable in class com.google.common.primitives.UnsignedBytes.LexicographicalComparatorHolder
 
UNSAFE_LITTLE_ENDIAN - Enum constant in enum class com.google.common.hash.LittleEndianByteArray.UnsafeByteArray
 
UNSAFE_URL - Static variable in class com.google.common.net.HttpHeaders.ReferrerPolicyValues
 
UnsafeAtomicHelper() - Constructor for class com.google.common.util.concurrent.AbstractFuture.UnsafeAtomicHelper
 
unsafeBinarySearch(Object) - Method in class com.google.common.collect.RegularImmutableSortedSet
 
UnsafeByteArray() - Constructor for enum class com.google.common.hash.LittleEndianByteArray.UnsafeByteArray
 
unsafeComparator() - Method in class com.google.common.collect.RegularImmutableSortedSet
 
UnsafeComparator() - Constructor for enum class com.google.common.primitives.UnsignedBytes.LexicographicalComparatorHolder.UnsafeComparator
 
unsafeCompare(Object, Object) - Method in class com.google.common.collect.ImmutableSortedSet
 
unsafeCompare(Comparator<?>, Object, Object) - Static method in class com.google.common.collect.ForwardingSortedMap
 
unsafeCompare(Comparator<?>, Object, Object) - Static method in class com.google.common.collect.ImmutableSortedSet
 
unsafeDoBackward(B) - Method in class com.google.common.base.Converter
 
unsafeDoForward(A) - Method in class com.google.common.base.Converter
 
unsafeNull() - Static method in class com.google.common.collect.NullnessCasts
Returns null as any type, even one that does not include null.
unsafeReplacement - Variable in class com.google.common.escape.Escapers.Builder
 
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.cache.LocalCache
Placeholder.
UNSET - Static variable in class com.google.common.collect.CompactHashing
Indicates blank table entries.
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
 
UNSET_WEAK_VALUE_REFERENCE - Static variable in class com.google.common.collect.MapMakerInternalMap
A singleton MapMakerInternalMap.WeakValueReference used to denote an unset value in an entry with weak values.
unsetWeakValueReference() - Static method in class com.google.common.collect.MapMakerInternalMap
 
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 Class in com.google.common.primitives
 
UnsignedBytes.LexicographicalComparatorHolder.UnsafeComparator - Enum Class 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 Class 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 Class in com.google.common.primitives
 
UnsignedLongs.ParseOverflowDetection - Class in com.google.common.primitives
 
UnsupportedLoadingOperationException() - Constructor for exception class com.google.common.cache.CacheLoader.UnsupportedLoadingOperationException
 
unused1 - Variable in class com.google.common.util.concurrent.Striped.PaddedLock
 
unused1 - Variable in class com.google.common.util.concurrent.Striped.PaddedSemaphore
 
unused2 - Variable in class com.google.common.util.concurrent.Striped.PaddedLock
 
unused2 - Variable in class com.google.common.util.concurrent.Striped.PaddedSemaphore
 
unused3 - Variable in class com.google.common.util.concurrent.Striped.PaddedLock
 
unused3 - Variable in class com.google.common.util.concurrent.Striped.PaddedSemaphore
 
unwrap() - Method in class com.google.common.reflect.TypeToken
Returns the corresponding primitive type if this is a wrapper type; otherwise returns this itself.
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.
UOE - Static variable in exception class com.google.common.collect.testing.AbstractIteratorTester.PermittedMetaException
 
UOE_OR_ISE - Static variable in exception class com.google.common.collect.testing.AbstractIteratorTester.PermittedMetaException
 
up() - Static method in class com.google.common.collect.testing.MinimalCollection
 
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.ChecksumHashFunction.ChecksumHasher
 
update(byte) - Method in class com.google.common.hash.MacHashFunction.MacHasher
 
update(byte) - Method in class com.google.common.hash.MessageDigestHashFunction.MessageDigestHasher
 
update(byte[]) - Method in class com.google.common.hash.AbstractByteHasher
Updates this hasher with the given bytes.
update(byte[]) - Method in class com.google.common.hash.MacHashFunction.MacHasher
 
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(byte[], int, int) - Method in class com.google.common.hash.ChecksumHashFunction.ChecksumHasher
 
update(byte[], int, int) - Method in class com.google.common.hash.MacHashFunction.MacHasher
 
update(byte[], int, int) - Method in class com.google.common.hash.MessageDigestHashFunction.MessageDigestHasher
 
update(int) - Method in class com.google.common.hash.AbstractByteHasher
Updates the sink with the given number of bytes from the buffer.
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.
update(int, long) - Method in class com.google.common.hash.Murmur3_32HashFunction.Murmur3_32Hasher
 
update(ByteBuffer) - Method in class com.google.common.hash.AbstractByteHasher
Updates this hasher with bytes from the given buffer.
update(ByteBuffer) - Method in class com.google.common.hash.ChecksumHashFunction.ChecksumHasher
 
update(ByteBuffer) - Method in class com.google.common.hash.MacHashFunction.MacHasher
 
update(ByteBuffer) - Method in class com.google.common.hash.MessageDigestHashFunction.MessageDigestHasher
 
UPDATE_BB - Static variable in class com.google.common.hash.ChecksumHashFunction.ChecksumMethodHandles
 
updateAndGet(int, DoubleUnaryOperator) - Method in class com.google.common.util.concurrent.AtomicDoubleArray
Atomically updates the element at index i with the results of applying the given function to the current value.
updateAndGet(DoubleUnaryOperator) - Method in class com.google.common.util.concurrent.AtomicDouble
Atomically updates the current value with the results of applying the given function.
updateAndGet(K, LongUnaryOperator) - Method in class com.google.common.util.concurrent.AtomicLongMap
Updates the value currently associated with key with the specified function, and returns the new value.
updateBackingRowMapField() - Method in class com.google.common.collect.StandardTable.Row
 
updateByteBuffer() - Static method in class com.google.common.hash.ChecksumHashFunction.ChecksumMethodHandles
 
updateByteBuffer(Checksum, ByteBuffer) - Static method in class com.google.common.hash.ChecksumHashFunction.ChecksumMethodHandles
 
updateInverseMap(K, boolean, V, V) - Method in class com.google.common.collect.AbstractBiMap
 
updateLastKnownIndex() - Method in class com.google.common.collect.CompactHashMap.MapEntry
 
updater - Static variable in class com.google.common.util.concurrent.AtomicDouble
 
updateWholeRowField() - Method in class com.google.common.collect.TreeBasedTable.TreeRow
 
UPGRADE - Static variable in class com.google.common.net.HttpHeaders
The HTTP Upgrade header field name.
UPGRADE_INSECURE_REQUESTS - Static variable in class com.google.common.net.HttpHeaders
The HTTP Upgrade-Insecure-Requests header field name.
UPPER_CAMEL - Enum constant in enum class com.google.common.base.CaseFormat
Java and C++ class naming convention, e.g., "UpperCamel".
UPPER_HEX_DIGITS - Static variable in class com.google.common.net.PercentEscaper
 
UPPER_UNDERSCORE - Enum constant in enum class com.google.common.base.CaseFormat
Java and C++ constant naming convention, e.g., "UPPER_UNDERSCORE".
upperBound - Variable in class com.google.common.collect.Range
 
upperBound - Variable in class com.google.common.collect.TreeBasedTable.TreeRow
 
upperBound() - 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 - Variable in class com.google.common.io.BaseEncoding.StandardBaseEncoding
 
upperCase() - Method in class com.google.common.io.BaseEncoding.Alphabet
 
upperCase() - Method in class com.google.common.io.BaseEncoding.SeparatedBaseEncoding
 
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(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).
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.
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).
Usage - Search tag in interface com.google.common.graph.PredecessorsFunction
Section
Usage - Search tag in interface com.google.common.graph.SuccessorsFunction
Section
Usage Example - Search tag in class com.google.common.util.concurrent.AbstractScheduledService
Section
USE_LEGACY_SERIALIZATION - Static variable in class com.google.common.collect.ImmutableMap.SerializedForm
 
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 class com.google.common.reflect.Types.JavaVersion
 
usedInGenericType(Type[]) - Method in enum class 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.
USER_DIR - Enum constant in enum class com.google.common.base.StandardSystemProperty
User's current working directory.
USER_HOME - Enum constant in enum class com.google.common.base.StandardSystemProperty
User's home directory.
USER_NAME - Enum constant in enum class com.google.common.base.StandardSystemProperty
User's account name.
userPermissions() - Static method in class com.google.common.io.TempFileCreator.JavaNioCreator
 
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
 
usesValueReferences() - Method in class com.google.common.cache.LocalCache
 
usesWriteEntries() - Method in class com.google.common.cache.LocalCache
 
usesWriteQueue() - Method in class com.google.common.cache.LocalCache
 
using(Function<T, ? extends Iterable<T>>) - Static method in class com.google.common.collect.TreeTraverser
Deprecated.
Use Traverser.forTree(com.google.common.graph.SuccessorsFunction<N>) instead. If you are using a lambda, these methods have exactly the same signature.
using(TestBiMapGenerator<K, V>) - Static method in class com.google.common.collect.testing.google.BiMapTestSuiteBuilder
 
using(TestListMultimapGenerator<K, V>) - Static method in class com.google.common.collect.testing.google.ListMultimapTestSuiteBuilder
 
using(TestMultimapGenerator<K, V, M>) - Static method in class com.google.common.collect.testing.google.MultimapTestSuiteBuilder
 
using(TestMultisetGenerator<E>) - Static method in class com.google.common.collect.testing.google.MultisetTestSuiteBuilder
 
using(TestMultisetGenerator<E>) - Static method in class com.google.common.collect.testing.google.SortedMultisetTestSuiteBuilder
 
using(TestSetMultimapGenerator<K, V>) - Static method in class com.google.common.collect.testing.google.SetMultimapTestSuiteBuilder
 
using(TestSetMultimapGenerator<K, V>) - Static method in class com.google.common.collect.testing.google.SortedSetMultimapTestSuiteBuilder
 
using(TestCollectionGenerator<E>) - Static method in class com.google.common.collect.testing.CollectionTestSuiteBuilder
 
using(TestListGenerator<E>) - Static method in class com.google.common.collect.testing.ListTestSuiteBuilder
 
using(TestMapGenerator<K, V>) - Static method in class com.google.common.collect.testing.ConcurrentMapTestSuiteBuilder
 
using(TestMapGenerator<K, V>) - Static method in class com.google.common.collect.testing.MapTestSuiteBuilder
 
using(TestQueueGenerator<E>) - Static method in class com.google.common.collect.testing.QueueTestSuiteBuilder
 
using(TestSetGenerator<E>) - Static method in class com.google.common.collect.testing.SetTestSuiteBuilder
 
using(TestSortedMapGenerator<K, V>) - Static method in class com.google.common.collect.testing.ConcurrentNavigableMapTestSuiteBuilder
 
using(TestSortedMapGenerator<K, V>) - Static method in class com.google.common.collect.testing.NavigableMapTestSuiteBuilder
 
using(TestSortedMapGenerator<K, V>) - Static method in class com.google.common.collect.testing.SortedMapTestSuiteBuilder
 
using(TestSortedSetGenerator<E>) - Static method in class com.google.common.collect.testing.NavigableSetTestSuiteBuilder
 
using(TestSortedSetGenerator<E>) - Static method in class com.google.common.collect.testing.SortedSetTestSuiteBuilder
 
Using - Search tag in class com.google.common.collect.Ordering
Section
usingGenerator(G) - Method in class com.google.common.collect.testing.FeatureSpecificTestSuiteBuilder
 
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
 
usingUnsafe() - Static method in class com.google.common.hash.LittleEndianByteArray
Indicates that the loading of Unsafe was successful and the load and store operations will be very efficient.
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
 
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
 

V

v0 - Variable in class com.google.common.hash.SipHashFunction.SipHasher
 
v0() - Method in class com.google.common.collect.testing.AbstractMapTester
 
v0() - Method in class com.google.common.collect.testing.google.AbstractMultimapTester
 
v1 - Variable in class com.google.common.hash.SipHashFunction.SipHasher
 
v1() - Method in class com.google.common.collect.testing.AbstractMapTester
 
v1() - Method in class com.google.common.collect.testing.google.AbstractMultimapTester
 
v2 - Variable in class com.google.common.hash.SipHashFunction.SipHasher
 
v2() - Method in class com.google.common.collect.testing.AbstractMapTester
 
v2() - Method in class com.google.common.collect.testing.google.AbstractMultimapTester
 
v3 - Variable in class com.google.common.hash.SipHashFunction.SipHasher
 
v3() - Method in class com.google.common.collect.testing.AbstractMapTester
 
v3() - Method in class com.google.common.collect.testing.google.AbstractMultimapTester
 
v4() - Method in class com.google.common.collect.testing.AbstractMapTester
 
v4() - Method in class com.google.common.collect.testing.google.AbstractMultimapTester
 
validate() - Method in class com.google.common.graph.InvalidatableSet
 
validate(Iterable<? extends N>) - Method in class com.google.common.graph.Traverser
 
validateClass(Class<? extends Exception>) - Method in interface com.google.common.util.concurrent.FuturesGetChecked.GetCheckedTypeValidator
 
validateClass(Class<? extends Exception>) - Method in enum class com.google.common.util.concurrent.FuturesGetChecked.GetCheckedTypeValidatorHolder.ClassValueValidator
 
validateClass(Class<? extends Exception>) - Method in enum class com.google.common.util.concurrent.FuturesGetChecked.GetCheckedTypeValidatorHolder.WeakSetValidator
 
validateEndpoints(EndpointPair<?>) - Method in class com.google.common.graph.AbstractBaseGraph
Throws IllegalArgumentException if the ordering of endpoints is not compatible with the directionality of this graph.
validateEndpoints(EndpointPair<?>) - Method in class com.google.common.graph.AbstractNetwork
Throws an IllegalArgumentException if the ordering of endpoints is not compatible with the directionality of this graph.
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 from to ensure that the domain name is syntactically valid according to RFC 1035.
validator - Variable in class com.google.common.graph.InvalidatableSet
 
validClasses - Static variable in enum class com.google.common.util.concurrent.FuturesGetChecked.GetCheckedTypeValidatorHolder.WeakSetValidator
 
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.Suppliers.ExpiringMemoizingSupplier
 
value - Variable in class com.google.common.base.Suppliers.MemoizingSupplier
 
value - Variable in class com.google.common.base.Suppliers.NonSerializableMemoizingSupplier
 
value - Variable in class com.google.common.cache.LocalCache.WriteThroughEntry
 
value - Variable in class com.google.common.cache.Striped64.Cell
 
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.Iterators.SingletonIterator
 
value - Variable in class com.google.common.collect.LinkedListMultimap.Node
 
value - Variable in class com.google.common.collect.MapMakerInternalMap.StrongKeyStrongValueEntry
 
value - Variable in class com.google.common.collect.MapMakerInternalMap.WeakKeyStrongValueEntry
 
value - Variable in class com.google.common.collect.MapMakerInternalMap.WriteThroughEntry
 
value - Variable in exception class com.google.common.collect.Ordering.IncomparableValueException
 
value - Variable in class com.google.common.collect.TableCollectors.MutableCell
 
value - Variable in class com.google.common.collect.Tables.ImmutableCell
 
value - Variable in class com.google.common.collect.testing.SampleElements.Collider
 
value - Variable in class com.google.common.collect.testing.UnhashableObject
 
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.graph.MapRetrievalCache.CacheEntry
 
value - Variable in class com.google.common.hash.Striped64.Cell
 
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.testing.RelationshipTester.Item
 
value - Variable in class com.google.common.util.concurrent.AbstractFuture
This field encodes the current state of the future.
value - Variable in class com.google.common.util.concurrent.AtomicDouble
 
value - Variable in class com.google.common.util.concurrent.CollectionFuture.Present
 
value - Variable in class com.google.common.util.concurrent.ImmediateFuture
 
value() - Element in annotation interface com.google.common.annotations.GwtIncompatible
Describes why the annotated element is incompatible with GWT.
value() - Method in enum class com.google.common.base.StandardSystemProperty
Returns the current value for this system property by delegating to System.getProperty(String).
value() - Element in annotation interface com.google.common.collect.testing.features.CollectionFeature.Require
 
value() - Element in annotation interface com.google.common.collect.testing.features.CollectionSize.Require
 
value() - Element in annotation interface com.google.common.collect.testing.features.ListFeature.Require
 
value() - Element in annotation interface com.google.common.collect.testing.features.MapFeature.Require
 
value() - Element in annotation interface com.google.common.collect.testing.features.SetFeature.Require
 
value() - Element in annotation interface com.google.common.collect.testing.google.MultimapFeature.Require
 
value() - Element in annotation interface com.google.common.collect.testing.google.MultisetFeature.Require
 
value() - Element in annotation interface com.google.common.util.concurrent.Partially.GwtIncompatible
 
value(int) - Method in class com.google.common.collect.CompactHashMap
 
value(N) - Method in class com.google.common.graph.DirectedGraphConnections
 
value(N) - Method in interface com.google.common.graph.GraphConnections
Returns the value associated with the edge connecting the origin node to node, or null if there is no such edge.
value(N) - Method in class com.google.common.graph.UndirectedGraphConnections
 
VALUE - Enum constant in enum class com.google.common.collect.MapMaker.Dummy
 
VALUE - Enum constant in enum class com.google.common.collect.Maps.EntryFunction
 
VALUE - Enum constant in enum class com.google.common.collect.testing.WrongType
 
VALUE_COLLECTIONS_SUPPORT_ITERATOR_REMOVE - Enum constant in enum class com.google.common.collect.testing.google.MultimapFeature
 
VALUE_OFFSET - Static variable in class com.google.common.util.concurrent.AbstractFuture.UnsafeAtomicHelper
 
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
 
ValueAndCloser(ClosingFuture<? extends V>) - Constructor for class com.google.common.util.concurrent.ClosingFuture.ValueAndCloser
 
valueComparator - Variable in class com.google.common.collect.ImmutableMap.Builder
 
valueComparator - Variable in class com.google.common.collect.ImmutableMultimap.Builder
 
valueComparator - Variable in class com.google.common.collect.Multimaps.CustomSortedSetMultimap
 
valueComparator - Variable in class com.google.common.collect.TreeMultimap
 
valueComparator() - Method in class com.google.common.collect.ForwardingSortedSetMultimap
 
valueComparator() - Method in class com.google.common.collect.ImmutableSetMultimap
 
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() - 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 - 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() - Method in class com.google.common.collect.MapMakerInternalMap
 
valueEquivalence(Equivalence<Object>) - Method in class com.google.common.cache.CacheBuilder
Sets a custom Equivalence strategy for comparing values.
ValueForKeyIterator(K) - Constructor for class com.google.common.collect.LinkedListMultimap.ValueForKeyIterator
Constructs a new iterator over all values for the specified key.
ValueForKeyIterator(K, 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
 
ValueGraph<N,V> - Interface in com.google.common.graph
An interface for graph-structured data, whose edges have associated non-unique values.
ValueGraphBuilder<N,V> - Class in com.google.common.graph
A builder for constructing instances of MutableValueGraph or ImmutableValueGraph with user-defined properties.
ValueGraphBuilder(boolean) - Constructor for class com.google.common.graph.ValueGraphBuilder
Creates a new instance with the specified edge directionality.
valueHash - Variable in class com.google.common.collect.HashBiMap.BiEntry
 
ValueHolder() - Constructor for class com.google.common.base.MoreObjects.ToStringHelper.ValueHolder
 
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() - Method in class com.google.common.collect.ImmutableMultimap
 
valueIterator() - Method in class com.google.common.collect.LinkedHashMultimap
 
valueIterator(Iterator<Map.Entry<K, V>>) - Static method in class com.google.common.collect.Maps
 
ValueIterator() - Constructor for class com.google.common.cache.LocalCache.ValueIterator
 
ValueIterator() - Constructor for class com.google.common.collect.MapMakerInternalMap.ValueIterator
 
valueList - Variable in class com.google.common.collect.ImmutableSortedMap
 
valueOf(long) - Static method in class com.google.common.primitives.UnsignedInteger
Returns an UnsignedInteger that is equal to value, if possible.
valueOf(long) - Static method in class com.google.common.primitives.UnsignedLong
Returns an UnsignedLong representing the same value as the specified long.
valueOf(String) - Static method in enum class com.google.common.base.AbstractIterator.State
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.base.CaseFormat
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.base.Functions.IdentityFunction
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.base.Functions.ToStringFunction
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.base.Predicates.ObjectPredicate
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.base.StandardSystemProperty
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.base.Suppliers.SupplierFunctionImpl
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.cache.CacheBuilder.NullListener
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.cache.CacheBuilder.OneWeigher
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.cache.LocalCache.EntryFactory
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.cache.LocalCache.NullEntry
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.cache.LocalCache.Strength
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.cache.RemovalCause
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.collect.AbstractIterator.State
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.collect.BoundType
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.collect.Iterators.EmptyModifiableIterator
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.collect.MapMaker.Dummy
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.collect.MapMakerInternalMap.Strength
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.collect.Maps.EntryFunction
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.collect.MultimapBuilder.LinkedListSupplier
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.collect.SortedLists.KeyAbsentBehavior
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.collect.SortedLists.KeyPresentBehavior
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.collect.testing.AbstractIteratorTester.KnownOrder
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.collect.testing.AnEnum
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.collect.testing.DerivedCollectionGenerators.Bound
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.collect.testing.features.CollectionFeature
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.collect.testing.features.CollectionSize
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.collect.testing.features.ListFeature
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.collect.testing.features.MapFeature
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.collect.testing.features.SetFeature
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.collect.testing.google.BiMapTestSuiteBuilder.NoRecurse
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.collect.testing.google.MultimapFeature
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.collect.testing.google.MultisetFeature
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.collect.testing.google.MultisetNavigationTester.SubMultisetSpec
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.collect.testing.google.MultisetTestSuiteBuilder.NoRecurse
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.collect.testing.google.SortedMultisetTestSuiteBuilder.Bound
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.collect.testing.google.SortedMultisetTestSuiteBuilder.NoRecurse
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.collect.testing.IteratorFeature
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.collect.testing.SortedMapTestSuiteBuilder.NoRecurse
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.collect.testing.SpliteratorTester.SpliteratorDecompositionStrategy
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.collect.testing.testers.MapEntrySetTester.IncomparableType
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.collect.testing.WrongType
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.collect.TreeMultiset.Aggregate
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.graph.ElementOrder.Type
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.graph.GraphConstants.Presence
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.graph.Graphs.NodeVisitState
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.graph.Traverser.InsertionOrder
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.hash.BloomFilterStrategies
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.hash.Funnels.ByteArrayFunnel
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.hash.Funnels.IntegerFunnel
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.hash.Funnels.LongFunnel
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.hash.Funnels.UnencodedCharsFunnel
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.hash.Hashing.ChecksumType
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.hash.Hashing.Crc32CSupplier
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.hash.LittleEndianByteArray.JavaLittleEndianBytes
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.hash.LittleEndianByteArray.UnsafeByteArray
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.io.Files.FilePredicate
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.io.FileWriteMode
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.io.RecursiveDeleteOption
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.math.LongMath.MillerRabinTester
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.primitives.Booleans.BooleanComparator
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.primitives.Booleans.LexicographicalComparator
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.primitives.Chars.LexicographicalComparator
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.primitives.Doubles.LexicographicalComparator
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.primitives.Floats.LexicographicalComparator
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.primitives.Ints.LexicographicalComparator
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.primitives.Longs.LexicographicalComparator
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.primitives.Shorts.LexicographicalComparator
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.primitives.SignedBytes.LexicographicalComparator
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.primitives.UnsignedBytes.LexicographicalComparatorHolder.PureJavaComparator
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.primitives.UnsignedBytes.LexicographicalComparatorHolder.UnsafeComparator
Returns the enum constant of this class with the specified name.
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) - Static method in enum class com.google.common.primitives.UnsignedInts.LexicographicalComparator
Returns the enum constant of this class with the specified name.
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) - Static method in enum class com.google.common.primitives.UnsignedLongs.LexicographicalComparator
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.reflect.Types.ClassOwnership
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.reflect.Types.JavaVersion
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.reflect.TypeToken.TypeFilter
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.testing.CollectorTester.CollectStrategy
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.testing.EqualsTester.NotAnInstance
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.testing.NullPointerTester.ExceptionTypePolicy
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.testing.NullPointerTester.NullnessAnnotationReader
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.testing.NullPointerTester.Visibility
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.util.concurrent.AggregateFuture.ReleaseResourcesReason
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.util.concurrent.ClosingFuture.State
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.util.concurrent.CycleDetectingLockFactory.Policies
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.util.concurrent.DirectExecutor
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.util.concurrent.ExecutionSequencer.RunningState
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.util.concurrent.FuturesGetChecked.GetCheckedTypeValidatorHolder.ClassValueValidator
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.util.concurrent.FuturesGetChecked.GetCheckedTypeValidatorHolder.WeakSetValidator
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.util.concurrent.SequentialExecutor.WorkerRunningState
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.common.util.concurrent.Service.State
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.google.thirdparty.publicsuffix.PublicSuffixType
Returns the enum constant of this class with the specified name.
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, 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(BigInteger) - Static method in class com.google.common.primitives.UnsignedInteger
Returns a UnsignedInteger representing the same value as the specified BigInteger.
valueOf(BigInteger) - Static method in class com.google.common.primitives.UnsignedLong
Returns a UnsignedLong representing the same value as the specified BigInteger.
valueOffset - Static variable in class com.google.common.cache.Striped64.Cell
 
valueOffset - Static variable in class com.google.common.hash.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.StrongKeyWeakValueEntry
 
valueReference - Variable in class com.google.common.collect.MapMakerInternalMap.WeakKeyWeakValueEntry
 
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.
values - Variable in class com.google.common.cache.LocalCache
 
values - Variable in class com.google.common.collect.AbstractMultimap
 
values - Variable in class com.google.common.collect.AbstractTable
 
values - Variable in class com.google.common.collect.CompactHashMap
The values of the entries in the map, in the range of [0, size()).
values - Variable in class com.google.common.collect.DenseImmutableTable
 
values - Variable in class com.google.common.collect.ImmutableMap.SerializedForm
 
values - Variable in class com.google.common.collect.ImmutableMap
 
values - Variable in class com.google.common.collect.ImmutableRangeMap
 
values - Variable in class com.google.common.collect.MapMakerInternalMap
 
values - Variable in class com.google.common.collect.Maps.UnmodifiableBiMap
 
values - Variable in class com.google.common.collect.Maps.ViewCachingAbstractMap
 
values - Variable in class com.google.common.collect.Multimaps.UnmodifiableMultimap
 
values - Variable in class com.google.common.collect.Synchronized.SynchronizedMap
 
values - Variable in class com.google.common.collect.testing.testers.NavigableSetNavigationTester
 
values - Variable in class com.google.common.collect.testing.testers.SortedSetNavigationTester
 
values - Variable in class com.google.common.collect.testing.TestMapEntrySetGenerator
 
values - Variable in class com.google.common.util.concurrent.CollectionFuture
 
values() - Static method in enum class com.google.common.base.AbstractIterator.State
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.base.CaseFormat
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.base.Functions.IdentityFunction
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.base.Functions.ToStringFunction
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.base.Predicates.ObjectPredicate
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.base.StandardSystemProperty
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.base.Suppliers.SupplierFunctionImpl
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.cache.CacheBuilder.NullListener
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.cache.CacheBuilder.OneWeigher
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.cache.LocalCache.EntryFactory
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.cache.LocalCache.NullEntry
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.cache.LocalCache.Strength
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Method in class com.google.common.cache.LocalCache
 
values() - Static method in enum class com.google.common.cache.RemovalCause
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Method in class com.google.common.collect.AbstractBiMap
 
values() - Static method in enum class com.google.common.collect.AbstractIterator.State
Returns an array containing the constants of this enum class, 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() - Method in class com.google.common.collect.AbstractMultimap
 
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() - Method in class com.google.common.collect.AbstractTable
 
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 class com.google.common.collect.BoundType
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Method in class com.google.common.collect.CompactHashMap
 
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() - 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, in the same order they appear in ImmutableMap.entrySet.
values() - Method in class com.google.common.collect.ImmutableMap
Returns an immutable collection of the values in this map, in the same order that they appear in ImmutableMap.entrySet.
values() - Method in class com.google.common.collect.ImmutableMultimap
Returns an immutable collection of the values in this multimap.
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 class com.google.common.collect.Iterators.EmptyModifiableIterator
Returns an array containing the constants of this enum class, 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() - Static method in enum class com.google.common.collect.MapMaker.Dummy
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.collect.MapMakerInternalMap.Strength
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Method in class com.google.common.collect.MapMakerInternalMap
 
values() - Method in class com.google.common.collect.Maps.DescendingMap
 
values() - Static method in enum class com.google.common.collect.Maps.EntryFunction
Returns an array containing the constants of this enum class, 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() - Method in class com.google.common.collect.Maps.TransformedEntriesMap
 
values() - Method in class com.google.common.collect.Maps.UnmodifiableBiMap
 
values() - Method in class com.google.common.collect.Maps.ViewCachingAbstractMap
 
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 class com.google.common.collect.MultimapBuilder.LinkedListSupplier
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Method in class com.google.common.collect.Multimaps.UnmodifiableMultimap
 
values() - Static method in enum class com.google.common.collect.SortedLists.KeyAbsentBehavior
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.collect.SortedLists.KeyPresentBehavior
Returns an array containing the constants of this enum class, in the order they are declared.
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() - Method in class com.google.common.collect.Synchronized.SynchronizedMap
 
values() - Method in class com.google.common.collect.Synchronized.SynchronizedMultimap
 
values() - Method in class com.google.common.collect.Synchronized.SynchronizedTable
 
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 class com.google.common.collect.testing.AbstractIteratorTester.KnownOrder
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.collect.testing.AnEnum
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.collect.testing.DerivedCollectionGenerators.Bound
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.collect.testing.features.CollectionFeature
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.collect.testing.features.CollectionSize
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.collect.testing.features.ListFeature
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.collect.testing.features.MapFeature
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.collect.testing.features.SetFeature
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.collect.testing.google.BiMapTestSuiteBuilder.NoRecurse
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.collect.testing.google.MultimapFeature
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.collect.testing.google.MultisetFeature
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.collect.testing.google.MultisetNavigationTester.SubMultisetSpec
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.collect.testing.google.MultisetTestSuiteBuilder.NoRecurse
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.collect.testing.google.SortedMultisetTestSuiteBuilder.Bound
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.collect.testing.google.SortedMultisetTestSuiteBuilder.NoRecurse
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.collect.testing.IteratorFeature
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Method in class com.google.common.collect.testing.SafeTreeMap
 
values() - Static method in enum class com.google.common.collect.testing.SortedMapTestSuiteBuilder.NoRecurse
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.collect.testing.SpliteratorTester.SpliteratorDecompositionStrategy
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.collect.testing.testers.MapEntrySetTester.IncomparableType
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Method in class com.google.common.collect.testing.testers.MapReplaceAllTester
 
values() - Static method in enum class com.google.common.collect.testing.WrongType
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.collect.TreeMultiset.Aggregate
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Method in class com.google.common.collect.TreeRangeMap.SubRangeMap.SubRangeMapAsMap
 
values() - Static method in enum class com.google.common.graph.ElementOrder.Type
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.graph.GraphConstants.Presence
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.graph.Graphs.NodeVisitState
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.graph.Traverser.InsertionOrder
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.hash.BloomFilterStrategies
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.hash.Funnels.ByteArrayFunnel
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.hash.Funnels.IntegerFunnel
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.hash.Funnels.LongFunnel
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.hash.Funnels.UnencodedCharsFunnel
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.hash.Hashing.ChecksumType
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.hash.Hashing.Crc32CSupplier
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.hash.LittleEndianByteArray.JavaLittleEndianBytes
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.hash.LittleEndianByteArray.UnsafeByteArray
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.io.Files.FilePredicate
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.io.FileWriteMode
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.io.RecursiveDeleteOption
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.math.LongMath.MillerRabinTester
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.primitives.Booleans.BooleanComparator
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.primitives.Booleans.LexicographicalComparator
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.primitives.Chars.LexicographicalComparator
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.primitives.Doubles.LexicographicalComparator
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.primitives.Floats.LexicographicalComparator
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.primitives.Ints.LexicographicalComparator
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.primitives.Longs.LexicographicalComparator
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.primitives.Shorts.LexicographicalComparator
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.primitives.SignedBytes.LexicographicalComparator
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.primitives.UnsignedBytes.LexicographicalComparatorHolder.PureJavaComparator
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.primitives.UnsignedBytes.LexicographicalComparatorHolder.UnsafeComparator
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.primitives.UnsignedInts.LexicographicalComparator
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.primitives.UnsignedLongs.LexicographicalComparator
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.reflect.Types.ClassOwnership
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.reflect.Types.JavaVersion
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.reflect.TypeToken.TypeFilter
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.testing.CollectorTester.CollectStrategy
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.testing.EqualsTester.NotAnInstance
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.testing.NullPointerTester.ExceptionTypePolicy
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.testing.NullPointerTester.NullnessAnnotationReader
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.testing.NullPointerTester.Visibility
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.util.concurrent.AggregateFuture.ReleaseResourcesReason
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.util.concurrent.ClosingFuture.State
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.util.concurrent.CycleDetectingLockFactory.Policies
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.util.concurrent.DirectExecutor
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.util.concurrent.ExecutionSequencer.RunningState
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.util.concurrent.FuturesGetChecked.GetCheckedTypeValidatorHolder.ClassValueValidator
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.util.concurrent.FuturesGetChecked.GetCheckedTypeValidatorHolder.WeakSetValidator
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.util.concurrent.SequentialExecutor.WorkerRunningState
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.common.util.concurrent.Service.State
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.google.thirdparty.publicsuffix.PublicSuffixType
Returns an array containing the constants of this enum class, in the order they are declared.
Values() - Constructor for class com.google.common.cache.LocalCache.Values
 
Values() - Constructor for class com.google.common.collect.AbstractMultimap.Values
 
Values() - Constructor for class com.google.common.collect.AbstractTable.Values
 
Values() - Constructor for class com.google.common.collect.MapMakerInternalMap.Values
 
Values() - Constructor for class com.google.common.collect.RegularImmutableTable.Values
 
Values() - Constructor for class com.google.common.collect.StandardTable.Column.Values
 
Values(ImmutableMultimap<K, V>) - Constructor for class com.google.common.collect.ImmutableMultimap.Values
 
Values(RegularImmutableMap<K, V>) - Constructor for class com.google.common.collect.RegularImmutableMap.Values
 
Values(Map<K, V>) - Constructor for class com.google.common.collect.Maps.Values
 
valuesBuilder(Comparator<? super V>) - Static method in class com.google.common.collect.ImmutableSetMultimap
 
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 - Variable in class com.google.common.collect.Synchronized.SynchronizedBiMap
 
valueSet(Comparator<? super V>, Collection<? extends V>) - Static method in class com.google.common.collect.ImmutableSetMultimap
 
ValueSet() - Constructor for class com.google.common.collect.AbstractBiMap.ValueSet
 
ValueSet(K, int) - Constructor for class com.google.common.collect.LinkedHashMultimap.ValueSet
 
valueSetCapacity - Variable in class com.google.common.collect.LinkedHashMultimap
 
ValuesGenerator(OneSizeTestContainerGenerator<M, Map.Entry<K, V>>) - Constructor for class com.google.common.collect.testing.google.MultimapTestSuiteBuilder.ValuesGenerator
 
valuesIterator() - Method in class com.google.common.collect.AbstractTable
 
valuesIterator() - Method in class com.google.common.collect.ArrayTable
 
valuesIterator() - Method in class com.google.common.collect.CompactHashMap
 
valuesIterator() - Method in class com.google.common.collect.ImmutableTable
 
valueSpliterator() - Method in class com.google.common.collect.AbstractMapBasedMultimap
 
valueSpliterator() - Method in class com.google.common.collect.AbstractMultimap
 
valueSpliterator() - Method in class com.google.common.collect.LinkedHashMultimap
 
valuesSpliterator() - Method in class com.google.common.collect.AbstractTable
 
valuesSpliterator() - Method in class com.google.common.collect.ArrayTable
 
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() - Method in interface com.google.common.collect.MapMakerInternalMap.InternalEntryHelper
The strength of the value type in each entry.
valueStrength() - Method in class com.google.common.collect.MapMakerInternalMap.StrongKeyDummyValueEntry.Helper
 
valueStrength() - Method in class com.google.common.collect.MapMakerInternalMap.StrongKeyStrongValueEntry.Helper
 
valueStrength() - Method in class com.google.common.collect.MapMakerInternalMap.StrongKeyWeakValueEntry.Helper
 
valueStrength() - Method in class com.google.common.collect.MapMakerInternalMap
 
valueStrength() - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyDummyValueEntry.Helper
 
valueStrength() - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyStrongValueEntry.Helper
 
valueStrength() - Method in class com.google.common.collect.MapMakerInternalMap.WeakKeyWeakValueEntry.Helper
 
ValueStrengthParser(LocalCache.Strength) - Constructor for class com.google.common.cache.CacheBuilderSpec.ValueStrengthParser
 
valuesView - Variable in class com.google.common.collect.CompactHashMap
 
ValuesView() - Constructor for class com.google.common.collect.CompactHashMap.ValuesView
 
valueTable - Variable in class com.google.common.collect.RegularImmutableBiMap
 
valueType() - Method in class com.google.common.collect.EnumBiMap
Returns the associated value type.
valueTypeOrObjectUnderJ2cl - Variable in class com.google.common.collect.EnumBiMap
 
Value types - Search tag in package com.google.common.primitives
Section
valueUpdater - Variable in class com.google.common.util.concurrent.AbstractFuture.SafeAtomicHelper
 
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(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, char) - Static method in class com.google.common.base.Verify
Ensures that expression is true, throwing a VerifyException with a custom message otherwise.
verify(boolean, String, char, char) - Static method in class com.google.common.base.Verify
Ensures that expression is true, throwing a VerifyException with a custom message otherwise.
verify(boolean, String, char, int) - Static method in class com.google.common.base.Verify
Ensures that expression is true, throwing a VerifyException with a custom message otherwise.
verify(boolean, String, char, long) - Static method in class com.google.common.base.Verify
Ensures that expression is true, throwing a VerifyException with a custom message otherwise.
verify(boolean, String, char, Object) - Static method in class com.google.common.base.Verify
Ensures that expression is true, throwing a VerifyException with a custom message otherwise.
verify(boolean, String, int) - Static method in class com.google.common.base.Verify
Ensures that expression is true, throwing a VerifyException with a custom message otherwise.
verify(boolean, String, int, char) - Static method in class com.google.common.base.Verify
Ensures that expression is true, throwing a VerifyException with a custom message otherwise.
verify(boolean, String, int, int) - Static method in class com.google.common.base.Verify
Ensures that expression is true, throwing a VerifyException with a custom message otherwise.
verify(boolean, String, int, long) - Static method in class com.google.common.base.Verify
Ensures that expression is true, throwing a VerifyException with a custom message otherwise.
verify(boolean, String, int, Object) - Static method in class com.google.common.base.Verify
Ensures that expression is true, throwing a VerifyException with a custom message otherwise.
verify(boolean, String, long) - Static method in class com.google.common.base.Verify
Ensures that expression is true, throwing a VerifyException with a custom message otherwise.
verify(boolean, String, long, char) - Static method in class com.google.common.base.Verify
Ensures that expression is true, throwing a VerifyException with a custom message otherwise.
verify(boolean, String, long, int) - Static method in class com.google.common.base.Verify
Ensures that expression is true, throwing a VerifyException with a custom message otherwise.
verify(boolean, String, long, long) - Static method in class com.google.common.base.Verify
Ensures that expression is true, throwing a VerifyException with a custom message otherwise.
verify(boolean, String, long, Object) - Static method in class com.google.common.base.Verify
Ensures that expression is true, throwing a VerifyException with a custom 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.
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.
verify(boolean, String, Object, char) - Static method in class com.google.common.base.Verify
Ensures that expression is true, throwing a VerifyException with a custom message otherwise.
verify(boolean, String, Object, int) - Static method in class com.google.common.base.Verify
Ensures that expression is true, throwing a VerifyException with a custom message otherwise.
verify(boolean, String, Object, long) - Static method in class com.google.common.base.Verify
Ensures that expression is true, throwing a VerifyException with a custom message otherwise.
verify(boolean, String, Object, Object) - Static method in class com.google.common.base.Verify
Ensures that expression is true, throwing a VerifyException with a custom message otherwise.
verify(boolean, String, Object, Object, Object) - Static method in class com.google.common.base.Verify
Ensures that expression is true, throwing a VerifyException with a custom message otherwise.
verify(boolean, String, Object, Object, Object, Object) - Static method in class com.google.common.base.Verify
Ensures that expression is true, throwing a VerifyException with a custom message otherwise.
verify(List<E>) - Method in class com.google.common.collect.testing.AbstractIteratorTester
Override this to verify anything after running a list of Stimuli.
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
 
VerifyException - Exception Class 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 class com.google.common.base.VerifyException
Constructs a VerifyException with no message.
VerifyException(String) - Constructor for exception class com.google.common.base.VerifyException
Constructs a VerifyException with the message message.
VerifyException(String, Throwable) - Constructor for exception class com.google.common.base.VerifyException
Constructs a VerifyException with the message message and the cause cause.
VerifyException(Throwable) - Constructor for exception class com.google.common.base.VerifyException
Constructs a VerifyException with the cause cause and a message that is null if cause is null, and cause.toString() otherwise.
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.
vertical(double) - Static method in class com.google.common.math.LinearTransformation
Builds an instance representing a vertical transformation with a constant value of x.
VerticalLinearTransformation(double) - Constructor for class com.google.common.math.LinearTransformation.VerticalLinearTransformation
 
VerticalLinearTransformation(double, LinearTransformation) - Constructor for class com.google.common.math.LinearTransformation.VerticalLinearTransformation
 
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
 
ViewCachingAbstractMap() - Constructor for class com.google.common.collect.Maps.ViewCachingAbstractMap
 
ViewMultiset() - Constructor for class com.google.common.collect.Multisets.ViewMultiset
 
VIEWPORT_WIDTH - Static variable in class com.google.common.net.HttpHeaders
The HTTP Viewport-Width header field name.
Views - Search tag in interface com.google.common.collect.Multimap
Section
visibility - Variable in class com.google.common.testing.AbstractPackageSanityTests
 
Visibility() - Constructor for enum class com.google.common.testing.NullPointerTester.Visibility
 
VisibleForTesting - Annotation Interface 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
 
visitedNodes - Variable in class com.google.common.graph.EndpointPairIterator.Undirected
 
visitGenericArrayType(GenericArrayType) - Method in class com.google.common.reflect.TypeVisitor
 
visitNext(Deque<Iterator<? extends N>>) - Method in class com.google.common.graph.Traverser.Traversal
Visits the next node from the top iterator of horizon and returns the visited node.
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
 
VND_REAL_AUDIO - Static variable in class com.google.common.net.MediaType
Real Audio.
VND_WAVE_AUDIO - Static variable in class com.google.common.net.MediaType
WAVE format, as defined by RFC 2361.
VORBIS_AUDIO - Static variable in class com.google.common.net.MediaType
Vorbis Audio, as defined by RFC 5215.
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.
VTT_UTF_8 - Static variable in class com.google.common.net.MediaType
As described in the VTT spec, this is used for Web Video Text Tracks (WebVTT) files, used with the HTML5 track element.

W

Waiter() - Constructor for class com.google.common.util.concurrent.AbstractFuture.Waiter
 
Waiter(boolean) - Constructor for class com.google.common.util.concurrent.AbstractFuture.Waiter
Constructor for the TOMBSTONE, avoids use of ATOMIC_HELPER in case this class is loaded before the ATOMIC_HELPER.
WAITER_NEXT_OFFSET - Static variable in class com.google.common.util.concurrent.AbstractFuture.UnsafeAtomicHelper
 
WAITER_THREAD_OFFSET - Static variable in class com.google.common.util.concurrent.AbstractFuture.UnsafeAtomicHelper
 
waiterCount - Variable in class com.google.common.util.concurrent.Monitor.Guard
 
waiterNextUpdater - Variable in class com.google.common.util.concurrent.AbstractFuture.SafeAtomicHelper
 
waiters - Variable in class com.google.common.util.concurrent.AbstractFuture
All waiting threads.
WAITERS_OFFSET - Static variable in class com.google.common.util.concurrent.AbstractFuture.UnsafeAtomicHelper
 
waitersUpdater - Variable in class com.google.common.util.concurrent.AbstractFuture.SafeAtomicHelper
 
waiterThreadUpdater - Variable in class com.google.common.util.concurrent.AbstractFuture.SafeAtomicHelper
 
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.
waitFor(Monitor.Guard, Duration) - Method in class com.google.common.util.concurrent.Monitor
Waits for the guard to be satisfied.
waitForInterrupt(Thread) - Method in class com.google.common.util.concurrent.InterruptibleTask
 
waitForLoadingValue(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.
waitForUninterruptibly(Monitor.Guard, Duration) - 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
 
waitQueue - Variable in class com.google.common.util.concurrent.ListenerCallQueue.PerListenerQueue
 
warmupPeriodMicros - Variable in class com.google.common.util.concurrent.SmoothRateLimiter.SmoothWarmingUp
 
WARN - Enum constant in enum class com.google.common.util.concurrent.CycleDetectingLockFactory.Policies
When potential deadlock is detected, this policy results in the logging of a Level.SEVERE message indicating the potential deadlock, which includes stack traces illustrating the cycle in lock acquisition order.
WARNING - Static variable in class com.google.common.net.HttpHeaders
The HTTP Warning header field name.
Warning: Security of recursive deletes - Search tag in com.google.common.io.MoreFiles.deleteDirectoryContents(Path, RecursiveDeleteOption...)
Section
Warning: Security of recursive deletes - Search tag in com.google.common.io.MoreFiles.deleteRecursively(Path, RecursiveDeleteOption...)
Section
Warning about performance - Search tag in class com.google.common.base.Verify
Section
Warnings - Search tag in class com.google.common.collect.ImmutableCollection
Section
Warnings - Search tag in class com.google.common.collect.Range
Section
wasCancelled - Variable in class com.google.common.util.concurrent.Futures.InCompletionOrderState
 
wasEvicted() - Method in enum class 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).
wasInterrupted - Variable in class com.google.common.util.concurrent.AbstractFuture.Cancellation
 
wasInterrupted() - Method in class com.google.common.util.concurrent.AbstractFuture
Returns true if this future was cancelled with mayInterruptIfRunning set to true.
WASM_APPLICATION - Static variable in class com.google.common.net.MediaType
WASM applications.
WAX_AUDIO - Static variable in class com.google.common.net.MediaType
Windows Media metafiles.
weak() - Method in class com.google.common.collect.Interners.InternerBuilder
Instructs the Interners.InternerBuilder to build a weak interner.
WEAK - Enum constant in enum class com.google.common.cache.LocalCache.EntryFactory
 
WEAK - Enum constant in enum class com.google.common.cache.LocalCache.Strength
 
WEAK - Enum constant in enum class com.google.common.collect.MapMakerInternalMap.Strength
 
WEAK_ACCESS - Enum constant in enum class com.google.common.cache.LocalCache.EntryFactory
 
WEAK_ACCESS_WRITE - Enum constant in enum class com.google.common.cache.LocalCache.EntryFactory
 
WEAK_MASK - Static variable in enum class com.google.common.cache.LocalCache.EntryFactory
 
WEAK_WRITE - Enum constant in enum class com.google.common.cache.LocalCache.EntryFactory
 
WeakAccessEntry(ReferenceQueue<K>, K, int, ReferenceEntry<K, V>) - Constructor for class com.google.common.cache.LocalCache.WeakAccessEntry
 
WeakAccessWriteEntry(ReferenceQueue<K>, K, int, 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, ReferenceEntry<K, V>) - Constructor for class com.google.common.cache.LocalCache.WeakEntry
 
weakHashLength32WithSeeds(byte[], int, long, long, long[]) - Static method in class com.google.common.hash.FarmHashFingerprint64
Computes intermediate hash of 32 bytes of byte array from the given offset.
weakHashLength32WithSeeds(byte[], int, long, long, long[]) - Static method in class com.google.common.hash.Fingerprint2011
Computes intermediate hash of 32 bytes of byte array from the given offset.
WeakKeyDummyValueEntry(ReferenceQueue<K>, K, int) - Constructor for class com.google.common.collect.MapMakerInternalMap.WeakKeyDummyValueEntry
 
WeakKeyDummyValueSegment(MapMakerInternalMap<K, MapMaker.Dummy, MapMakerInternalMap.WeakKeyDummyValueEntry<K>, MapMakerInternalMap.WeakKeyDummyValueSegment<K>>, int) - Constructor for class com.google.common.collect.MapMakerInternalMap.WeakKeyDummyValueSegment
 
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.MapMaker
Specifies that each key (not value) stored in the map should be wrapped in a WeakReference (by default, strong references are used).
WeakKeyStrongValueEntry(ReferenceQueue<K>, K, int) - Constructor for class com.google.common.collect.MapMakerInternalMap.WeakKeyStrongValueEntry
 
WeakKeyStrongValueSegment(MapMakerInternalMap<K, V, MapMakerInternalMap.WeakKeyStrongValueEntry<K, V>, MapMakerInternalMap.WeakKeyStrongValueSegment<K, V>>, int) - Constructor for class com.google.common.collect.MapMakerInternalMap.WeakKeyStrongValueSegment
 
WeakKeyWeakValueEntry(ReferenceQueue<K>, K, int) - Constructor for class com.google.common.collect.MapMakerInternalMap.WeakKeyWeakValueEntry
 
WeakKeyWeakValueSegment(MapMakerInternalMap<K, V, MapMakerInternalMap.WeakKeyWeakValueEntry<K, V>, MapMakerInternalMap.WeakKeyWeakValueSegment<K, V>>, int) - Constructor for class com.google.common.collect.MapMakerInternalMap.WeakKeyWeakValueSegment
 
WeakSafeCondition(Condition, Striped.WeakSafeReadWriteLock) - Constructor for class com.google.common.util.concurrent.Striped.WeakSafeCondition
 
WeakSafeLock(Lock, Striped.WeakSafeReadWriteLock) - Constructor for class com.google.common.util.concurrent.Striped.WeakSafeLock
 
WeakSafeReadWriteLock() - Constructor for class com.google.common.util.concurrent.Striped.WeakSafeReadWriteLock
 
weakSetValidator() - Static method in class com.google.common.util.concurrent.FuturesGetChecked
 
WeakSetValidator() - Constructor for enum class com.google.common.util.concurrent.FuturesGetChecked.GetCheckedTypeValidatorHolder.WeakSetValidator
 
WeakValueReference(ReferenceQueue<V>, V, ReferenceEntry<K, V>) - Constructor for class com.google.common.cache.LocalCache.WeakValueReference
 
WeakValueReferenceImpl(ReferenceQueue<V>, V, E) - Constructor for class com.google.common.collect.MapMakerInternalMap.WeakValueReferenceImpl
 
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.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, 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 class 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 - Variable in class com.google.common.cache.LocalCache.ManualSerializationProxy
 
weigher - Variable in class com.google.common.cache.LocalCache
Weigher to weigh cache entries.
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<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, 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, ReferenceEntry<K, V>, int) - Constructor for class com.google.common.cache.LocalCache.WeightedWeakValueReference
 
whenAllComplete(ClosingFuture<?>, ClosingFuture<?>...) - Static method in class com.google.common.util.concurrent.ClosingFuture
Starts specifying how to combine ClosingFutures into a single pipeline.
whenAllComplete(ListenableFuture<? extends V>...) - Static method in class com.google.common.util.concurrent.Futures
Creates a Futures.FutureCombiner that processes the completed futures whether or not they're successful.
whenAllComplete(Iterable<? extends ClosingFuture<?>>) - Static method in class com.google.common.util.concurrent.ClosingFuture
Starts specifying how to combine ClosingFutures into a single pipeline.
whenAllComplete(Iterable<? extends ListenableFuture<? extends V>>) - Static method in class com.google.common.util.concurrent.Futures
Creates a Futures.FutureCombiner that processes the completed futures whether or not they're successful.
whenAllSucceed(ClosingFuture<?>, ClosingFuture<?>, ClosingFuture<?>, ClosingFuture<?>, ClosingFuture<?>, ClosingFuture<?>, ClosingFuture<?>...) - Static method in class com.google.common.util.concurrent.ClosingFuture
Starts specifying how to combine ClosingFutures into a single pipeline, assuming they all succeed.
whenAllSucceed(ClosingFuture<V1>, ClosingFuture<V2>) - Static method in class com.google.common.util.concurrent.ClosingFuture
Starts specifying how to combine two ClosingFutures into a single pipeline, assuming they all succeed.
whenAllSucceed(ClosingFuture<V1>, ClosingFuture<V2>, ClosingFuture<V3>) - Static method in class com.google.common.util.concurrent.ClosingFuture
Starts specifying how to combine three ClosingFutures into a single pipeline, assuming they all succeed.
whenAllSucceed(ClosingFuture<V1>, ClosingFuture<V2>, ClosingFuture<V3>, ClosingFuture<V4>) - Static method in class com.google.common.util.concurrent.ClosingFuture
Starts specifying how to combine four ClosingFutures into a single pipeline, assuming they all succeed.
whenAllSucceed(ClosingFuture<V1>, ClosingFuture<V2>, ClosingFuture<V3>, ClosingFuture<V4>, ClosingFuture<V5>) - Static method in class com.google.common.util.concurrent.ClosingFuture
Starts specifying how to combine five ClosingFutures into a single pipeline, assuming they all succeed.
whenAllSucceed(ListenableFuture<? extends V>...) - Static method in class com.google.common.util.concurrent.Futures
Creates a Futures.FutureCombiner requiring that all passed in futures are successful.
whenAllSucceed(Iterable<? extends ClosingFuture<?>>) - Static method in class com.google.common.util.concurrent.ClosingFuture
Starts specifying how to combine ClosingFutures into a single pipeline, assuming they all succeed.
whenAllSucceed(Iterable<? extends ListenableFuture<? extends V>>) - Static method in class com.google.common.util.concurrent.Futures
Creates a Futures.FutureCombiner requiring that all passed in futures are successful.
whenClosed - Variable in class com.google.common.util.concurrent.ClosingFuture.CloseableList
 
whenClosedCountDown() - Method in class com.google.common.util.concurrent.ClosingFuture.CloseableList
Returns a latch that reaches zero when this objects' deferred closeables have been closed.
whenClosedCountDown() - Method in class com.google.common.util.concurrent.ClosingFuture
Returns an object that can be used to wait until this objects' deferred closeables have all had Runnables that close them submitted to each one's closing Executor.
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.
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.TypeTable
Returns a new TypeResolver with variable mapping to type.
where(Map<TypeResolver.TypeVariableKey, ? extends Type>) - Method in class com.google.common.reflect.TypeResolver
Returns a new TypeResolver with variable mapping to type.
whitespace() - Static method in class com.google.common.base.CharMatcher
Determines whether a character is whitespace according to the latest Unicode standard, as illustrated here.
Whitespace() - Constructor for class com.google.common.base.CharMatcher.Whitespace
 
wholeRow - Variable in class com.google.common.collect.TreeBasedTable.TreeRow
 
WIDTH - Static variable in class com.google.common.net.HttpHeaders
The HTTP Width header field name.
WILDCARD - Static variable in class com.google.common.net.MediaType
 
WildcardCapturer() - Constructor for class com.google.common.reflect.TypeResolver.WildcardCapturer
 
WildcardCapturer(AtomicInteger) - Constructor for class com.google.common.reflect.TypeResolver.WildcardCapturer
 
WildcardTypeImpl(Type[], Type[]) - Constructor for class com.google.common.reflect.Types.WildcardTypeImpl
 
WILL_CLOSE - Enum constant in enum class com.google.common.util.concurrent.ClosingFuture.State
Some ListenableFuture has a callback attached that will close the ClosingFuture.CloseableList, but it has not yet run.
WILL_CREATE_VALUE_AND_CLOSER - Enum constant in enum class com.google.common.util.concurrent.ClosingFuture.State
WITH_STRING_PARAM_THEN_WITH_THROWABLE_PARAM - Static variable in class com.google.common.util.concurrent.FuturesGetChecked
 
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
 
withFeatures(Feature<?>...) - Method in class com.google.common.collect.testing.FeatureSpecificTestSuiteBuilder
Configures this builder to produce tests appropriate for the given features.
withFeatures(Iterable<? extends Feature<?>>) - Method in class com.google.common.collect.testing.FeatureSpecificTestSuiteBuilder
 
withKeyValueSeparator(char) - 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(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.
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.
withLowerBoundType(BoundType, DiscreteDomain<C>) - Method in class com.google.common.collect.Cut.AboveValue
 
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
 
withLowerBoundType(BoundType, DiscreteDomain<Comparable<?>>) - Method in class com.google.common.collect.Cut.AboveAll
 
withLowerBoundType(BoundType, DiscreteDomain<Comparable<?>>) - Method in class com.google.common.collect.Cut.BelowAll
 
withNarrowedType() - Method in class com.google.common.base.Predicates.IsEqualToPredicate
 
withNarrowedType() - Method in enum class com.google.common.base.Predicates.ObjectPredicate
 
withoutCloser(AsyncFunction<V, U>) - Static method in class com.google.common.util.concurrent.ClosingFuture
Returns an ClosingFuture.AsyncClosingFunction that applies an AsyncFunction to an input, ignoring the DeferredCloser and returning a ClosingFuture derived from the returned ListenableFuture.
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.
withParameters(String, Iterable<String>) - Method in class com.google.common.net.MediaType
Replaces all parameters with the given attribute with parameters using the given values.
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.
withSetUp(Runnable) - Method in class com.google.common.collect.testing.FeatureSpecificTestSuiteBuilder
 
withSlope(double) - Method in class com.google.common.math.LinearTransformation.LinearTransformationBuilder
Finish building an instance with the given slope, i.e.
withTearDown(Runnable) - Method in class com.google.common.collect.testing.FeatureSpecificTestSuiteBuilder
 
withTimeout(long, TimeUnit, ScheduledExecutorService) - Method in class com.google.common.util.concurrent.FluentFuture
Returns a future that delegates to this future but will finish early (via a TimeoutException wrapped in an ExecutionException) if the specified timeout expires.
withTimeout(ListenableFuture<V>, long, TimeUnit, ScheduledExecutorService) - Static method in class com.google.common.util.concurrent.Futures
Returns a future that delegates to another but will finish early (via a TimeoutException wrapped in an ExecutionException) if the specified duration expires.
withTimeout(ListenableFuture<V>, Duration, ScheduledExecutorService) - Static method in class com.google.common.util.concurrent.Futures
Returns a future that delegates to another but will finish early (via a TimeoutException wrapped in an ExecutionException) if the specified duration expires.
withTimeout(Duration, ScheduledExecutorService) - Method in class com.google.common.util.concurrent.FluentFuture
Returns a future that delegates to this future but will finish early (via a TimeoutException wrapped in an ExecutionException) if the specified timeout expires.
withType() - Static method in class com.google.common.base.Absent
 
withUpperBoundType(BoundType, DiscreteDomain<C>) - Method in class com.google.common.collect.Cut.AboveValue
 
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
 
withUpperBoundType(BoundType, DiscreteDomain<Comparable<?>>) - Method in class com.google.common.collect.Cut.AboveAll
 
withUpperBoundType(BoundType, DiscreteDomain<Comparable<?>>) - Method in class com.google.common.collect.Cut.BelowAll
 
WMA_AUDIO - Static variable in class com.google.common.net.MediaType
Windows Media Audio.
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
RFC 8081 declares font/woff to be the correct media type for WOFF, but this may be necessary in certain situations for compatibility.
WOFF2 - Static variable in class com.google.common.net.MediaType
RFC 8081 declares font/woff2 to be the correct media type for WOFF2, but this may be necessary in certain situations for compatibility.
wordBoundary - Variable in enum class com.google.common.base.CaseFormat
 
wordSeparator - Variable in enum class com.google.common.base.CaseFormat
 
worker - Variable in class com.google.common.util.concurrent.SequentialExecutor
 
workerRunCount - Variable in class com.google.common.util.concurrent.SequentialExecutor
This counter prevents an ABA issue where a thread may successfully schedule the worker, the worker runs and exhausts the queue, another thread enqueues a task and fails to schedule the worker, and then the first thread's call to delegate.execute() returns.
workerRunningState - Variable in class com.google.common.util.concurrent.SequentialExecutor
WorkerRunningState() - Constructor for enum class com.google.common.util.concurrent.SequentialExecutor.WorkerRunningState
 
workOnQueue() - Method in class com.google.common.util.concurrent.SequentialExecutor.QueueWorker
Continues executing tasks from SequentialExecutor.queue until it is empty.
wrap() - Method in class com.google.common.reflect.TypeToken
Returns the corresponding wrapper type if this is a primitive type; otherwise returns this itself.
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(NavigableSet<V>) - Method in class com.google.common.collect.AbstractMapBasedMultimap.WrappedNavigableSet
 
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).
wrapAndThrowExceptionOrError(Throwable, Class<X>) - Static method in class com.google.common.util.concurrent.FuturesGetChecked
 
wrapAndThrowExecutionExceptionOrError(Throwable) - Method in class com.google.common.util.concurrent.SimpleTimeLimiter
 
wrapAndThrowRuntimeExecutionExceptionOrError(Throwable) - Method in class com.google.common.util.concurrent.SimpleTimeLimiter
 
wrapAndThrowUnchecked(Throwable) - Static method in class com.google.common.util.concurrent.Futures
 
wrapCollection(K, Collection<V>) - Method in class com.google.common.collect.AbstractListMultimap
 
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.AbstractSetMultimap
 
wrapCollection(K, Collection<V>) - Method in class com.google.common.collect.AbstractSortedSetMultimap
 
wrapCollection(K, Collection<V>) - Method in class com.google.common.collect.Multimaps.CustomMultimap
 
wrapCollection(K, Collection<V>) - Method in class com.google.common.collect.Multimaps.CustomSetMultimap
 
wrapEntry(TreeMultiset.AvlNode<E>) - Method in class com.google.common.collect.TreeMultiset
 
wrapEntry(Map.Entry<C, V>) - Method in class com.google.common.collect.StandardTable.Row
 
wrapEntry(Map.Entry<K, Collection<V>>) - Method in class com.google.common.collect.AbstractMapBasedMultimap.AsMap
 
wrapList(K, List<V>, AbstractMapBasedMultimap.WrappedCollection) - Method in class com.google.common.collect.AbstractMapBasedMultimap
 
WrappedCollection(K, Collection<V>, AbstractMapBasedMultimap.WrappedCollection) - Constructor for class com.google.common.collect.AbstractMapBasedMultimap.WrappedCollection
 
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.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.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.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(Runnable) - Method in class com.google.common.util.concurrent.WrappingExecutorService
Wraps a Runnable for submission to the underlying executor.
wrapTask(Callable<T>) - Method in class com.google.common.util.concurrent.WrappingExecutorService
Wraps a Callable 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(byte[]) - Method in class com.google.common.hash.Funnels.SinkAsStream
 
write(byte[]) - 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(byte[]) - Method in class com.google.common.io.ByteStreams.ByteArrayDataOutputStream
 
write(byte[]) - Method in class com.google.common.io.FileBackedOutputStream
 
write(byte[], int, int) - Method in class com.google.common.hash.Funnels.SinkAsStream
 
write(byte[], int, int) - Method in class com.google.common.hash.HashingOutputStream
 
write(byte[], int, int) - Method in interface com.google.common.io.ByteArrayDataOutput
 
write(byte[], int, int) - Method in class com.google.common.io.ByteStreams.ByteArrayDataOutputStream
 
write(byte[], int, int) - Method in class com.google.common.io.CountingOutputStream
 
write(byte[], int, int) - Method in class com.google.common.io.FileBackedOutputStream
 
write(byte[], int, int) - Method in class com.google.common.io.LittleEndianDataOutputStream
 
write(byte[], File) - Static method in class com.google.common.io.Files
Overwrites a file with the contents of a byte array.
write(char[]) - Method in class com.google.common.io.CharStreams.NullWriter
 
write(char[], int, int) - Method in class com.google.common.io.AppendableWriter
 
write(char[], int, int) - Method in class com.google.common.io.CharStreams.NullWriter
 
write(int) - Method in class com.google.common.hash.Funnels.SinkAsStream
 
write(int) - Method in class com.google.common.hash.HashingOutputStream
 
write(int) - Method in class com.google.common.io.AppendableWriter
 
write(int) - Method in interface com.google.common.io.ByteArrayDataOutput
 
write(int) - Method in class com.google.common.io.ByteStreams.ByteArrayDataOutputStream
 
write(int) - Method in class com.google.common.io.CharStreams.NullWriter
 
write(int) - Method in class com.google.common.io.CountingOutputStream
 
write(int) - Method in class com.google.common.io.FileBackedOutputStream
 
write(CharSequence) - Method in class com.google.common.io.CharSink
Writes the given character sequence to this sink.
write(CharSequence, File, Charset) - Static method in class com.google.common.io.Files
Deprecated.
Prefer asCharSink(to, charset).write(from).
write(String) - Method in class com.google.common.io.AppendableWriter
 
write(String) - Method in class com.google.common.io.CharStreams.NullWriter
 
write(String, int, int) - Method in class com.google.common.io.AppendableWriter
 
write(String, int, int) - Method in class com.google.common.io.CharStreams.NullWriter
 
write(ByteBuffer) - Method in class com.google.common.hash.AbstractNonStreamingHashFunction.ExposedByteArrayOutputStream
 
WRITE_MASK - Static variable in enum class 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(StandardCharsets.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.
writeLines(Iterator<? extends CharSequence>, String) - Method in class com.google.common.io.CharSink
 
writeLines(Stream<? 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(Stream<? 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
 
writeLock() - Method in class com.google.common.util.concurrent.Striped.WeakSafeReadWriteLock
 
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.CompactHashMap
 
writeObject(ObjectOutputStream) - Method in class com.google.common.collect.CompactHashSet
 
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.hash.LongAdder
 
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.ContiguousSet
 
writeReplace() - Method in class com.google.common.collect.DenseImmutableTable.Column
 
writeReplace() - Method in class com.google.common.collect.DenseImmutableTable.ColumnMap
 
writeReplace() - Method in class com.google.common.collect.DenseImmutableTable.ImmutableArrayMap
 
writeReplace() - Method in class com.google.common.collect.DenseImmutableTable.Row
 
writeReplace() - Method in class com.google.common.collect.DenseImmutableTable.RowMap
 
writeReplace() - Method in class com.google.common.collect.DenseImmutableTable
 
writeReplace() - Method in class com.google.common.collect.DescendingImmutableSortedMultiset
 
writeReplace() - Method in class com.google.common.collect.DescendingImmutableSortedSet
 
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.ReverseImmutableList
 
writeReplace() - Method in class com.google.common.collect.ImmutableList.SubList
 
writeReplace() - Method in class com.google.common.collect.ImmutableList
 
writeReplace() - Method in class com.google.common.collect.ImmutableMap.IteratorBasedImmutableMap
 
writeReplace() - Method in class com.google.common.collect.ImmutableMap.MapViewOfValuesAsSingletonSets
 
writeReplace() - Method in class com.google.common.collect.ImmutableMap
Returns a serializable form of this object.
writeReplace() - Method in class com.google.common.collect.ImmutableMapEntrySet.RegularEntrySet
 
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.ImmutableMultimap.EntryCollection
 
writeReplace() - Method in class com.google.common.collect.ImmutableMultimap.Keys
 
writeReplace() - Method in class com.google.common.collect.ImmutableMultimap.Values
 
writeReplace() - Method in class com.google.common.collect.ImmutableMultiset.ElementSet
 
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.ImmutableRangeMap
 
writeReplace() - Method in class com.google.common.collect.ImmutableRangeSet.AsSet
 
writeReplace() - Method in class com.google.common.collect.ImmutableRangeSet.ComplementRanges
 
writeReplace() - Method in class com.google.common.collect.ImmutableRangeSet
 
writeReplace() - Method in class com.google.common.collect.ImmutableSet.CachingAsList
 
writeReplace() - Method in class com.google.common.collect.ImmutableSet.Indexed
 
writeReplace() - Method in class com.google.common.collect.ImmutableSet
 
writeReplace() - Method in class com.google.common.collect.ImmutableSetMultimap.EntrySet
 
writeReplace() - Method in class com.google.common.collect.ImmutableSortedAsList
 
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.ImmutableTable
 
writeReplace() - Method in class com.google.common.collect.IndexedImmutableSet
 
writeReplace() - Method in class com.google.common.collect.JdkBackedImmutableBiMap.InverseEntries
 
writeReplace() - Method in class com.google.common.collect.JdkBackedImmutableBiMap
 
writeReplace() - Method in class com.google.common.collect.JdkBackedImmutableMap
 
writeReplace() - Method in class com.google.common.collect.JdkBackedImmutableMultiset
 
writeReplace() - Method in class com.google.common.collect.JdkBackedImmutableSet
 
writeReplace() - Method in class com.google.common.collect.Lists.StringAsImmutableList
 
writeReplace() - Method in class com.google.common.collect.MapMakerInternalMap
 
writeReplace() - Method in class com.google.common.collect.MutableClassToInstanceMap
 
writeReplace() - Method in class com.google.common.collect.RegularContiguousSet
 
writeReplace() - Method in class com.google.common.collect.RegularImmutableAsList
 
writeReplace() - Method in class com.google.common.collect.RegularImmutableBiMap.Inverse.InverseEntrySet
 
writeReplace() - Method in class com.google.common.collect.RegularImmutableBiMap.Inverse
 
writeReplace() - Method in class com.google.common.collect.RegularImmutableBiMap
 
writeReplace() - Method in class com.google.common.collect.RegularImmutableList
 
writeReplace() - Method in class com.google.common.collect.RegularImmutableMap.KeySet
 
writeReplace() - Method in class com.google.common.collect.RegularImmutableMap.Values
 
writeReplace() - Method in class com.google.common.collect.RegularImmutableMap
 
writeReplace() - Method in class com.google.common.collect.RegularImmutableMultiset
 
writeReplace() - Method in class com.google.common.collect.RegularImmutableSet
 
writeReplace() - Method in class com.google.common.collect.RegularImmutableSortedMultiset
 
writeReplace() - Method in class com.google.common.collect.RegularImmutableSortedSet
 
writeReplace() - Method in class com.google.common.collect.RegularImmutableTable.CellSet
 
writeReplace() - Method in class com.google.common.collect.RegularImmutableTable.Values
 
writeReplace() - Method in class com.google.common.collect.RegularImmutableTable
 
writeReplace() - Method in class com.google.common.collect.SingletonImmutableBiMap
 
writeReplace() - Method in class com.google.common.collect.SingletonImmutableList
 
writeReplace() - Method in class com.google.common.collect.SingletonImmutableSet
 
writeReplace() - Method in class com.google.common.collect.SingletonImmutableTable
 
writeReplace() - Method in class com.google.common.collect.SparseImmutableTable
 
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.primitives.ImmutableDoubleArray
 
writeReplace() - Method in class com.google.common.primitives.ImmutableIntArray
 
writeReplace() - Method in class com.google.common.primitives.ImmutableLongArray
 
writeReplace() - Method in class com.google.common.reflect.TypeToken
Implemented to support serialization of subclasses.
writeReplace() - Method in class com.google.common.testing.DummyProxy.DummyHandler
 
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(ByteBuffer) - Method in class com.google.common.math.Stats
Writes to the given ByteBuffer a byte representation of this instance.
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
 
WrongType - Enum Class in com.google.common.collect.testing
A type which will never be used as the element type of any collection in our tests, and so can be used to test how a Collection behaves when given input of the wrong type.
WrongType() - Constructor for enum class com.google.common.collect.testing.WrongType
 
WWW_AUTHENTICATE - Static variable in class com.google.common.net.HttpHeaders
The HTTP WWW-Authenticate header field name.

X

x - Variable in class com.google.common.math.LinearTransformation.VerticalLinearTransformation
 
X_CONTENT_SECURITY_POLICY - Static variable in class com.google.common.net.HttpHeaders
The HTTP nonstandard X-Content-Security-Policy header field name.
X_CONTENT_SECURITY_POLICY_REPORT_ONLY - Static variable in class com.google.common.net.HttpHeaders
The HTTP nonstandard X-Content-Security-Policy-Report-Only header field name.
X_CONTENT_TYPE_OPTIONS - Static variable in class com.google.common.net.HttpHeaders
The HTTP X-Content-Type-Options header field name.
X_DEVICE_ACCEPT_LANGUAGE - Static variable in class com.google.common.net.HttpHeaders
The HTTP X-Device-Accept-Language header field name.
X_DEVICE_IP - Static variable in class com.google.common.net.HttpHeaders
The HTTP X-Device-IP header field name.
X_DEVICE_REFERER - Static variable in class com.google.common.net.HttpHeaders
The HTTP X-Device-Referer header field name.
X_DEVICE_REQUESTED_WITH - Static variable in class com.google.common.net.HttpHeaders
The HTTP X-Device-Requested-With header field name.
X_DNS_PREFETCH_CONTROL - Static variable in class com.google.common.net.HttpHeaders
The HTTP X-DNS-Prefetch-Control header controls DNS prefetch behavior.
X_DO_NOT_TRACK - Static variable in class com.google.common.net.HttpHeaders
The HTTP X-Do-Not-Track header field name.
X_DOWNLOAD_OPTIONS - Static variable in class com.google.common.net.HttpHeaders
The HTTP X-Download-Options header field name.
X_FORWARDED_FOR - Static variable in class com.google.common.net.HttpHeaders
The HTTP X-Forwarded-For header field name (superseded by Forwarded).
X_FORWARDED_HOST - Static variable in class com.google.common.net.HttpHeaders
The HTTP X-Forwarded-Host header field name.
X_FORWARDED_PORT - Static variable in class com.google.common.net.HttpHeaders
The HTTP X-Forwarded-Port 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_MOZ - Static variable in class com.google.common.net.HttpHeaders
The HTTP X-Moz header field name.
X_POWERED_BY - Static variable in class com.google.common.net.HttpHeaders
The HTTP X-Powered-By header field name.
X_PURPOSE - Static variable in class com.google.common.net.HttpHeaders
The HTTP X-Purpose header field name.
X_REQUEST_ID - Static variable in class com.google.common.net.HttpHeaders
The HTTP X-Request-ID 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_WEBKIT_CSP - Static variable in class com.google.common.net.HttpHeaders
The HTTP nonstandard X-WebKit-CSP header field name.
X_WEBKIT_CSP_REPORT_ONLY - Static variable in class com.google.common.net.HttpHeaders
The HTTP nonstandard X-WebKit-CSP-Report-Only header field name.
X_XSS_PROTECTION - Static variable in class com.google.common.net.HttpHeaders
The HTTP X-XSS-Protection header field name.
x1 - Variable in class com.google.common.math.LinearTransformation.LinearTransformationBuilder
 
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
Extensible Resource Descriptors.
xStats - Variable in class com.google.common.math.PairedStats
 
xStats - Variable in class com.google.common.math.PairedStatsAccumulator
 
xStats() - Method in class com.google.common.math.PairedStats
Returns the statistics on the x values alone.
xStats() - Method in class com.google.common.math.PairedStatsAccumulator
Returns an immutable snapshot of the statistics on the x values alone.

Y

y1 - Variable in class com.google.common.math.LinearTransformation.LinearTransformationBuilder
 
yIntercept - Variable in class com.google.common.math.LinearTransformation.RegularLinearTransformation
 
yStats - Variable in class com.google.common.math.PairedStats
 
yStats - Variable in class com.google.common.math.PairedStatsAccumulator
 
yStats() - Method in class com.google.common.math.PairedStats
Returns the statistics on the y values alone.
yStats() - Method in class com.google.common.math.PairedStatsAccumulator
Returns an immutable snapshot of the statistics on the y values alone.

Z

ZERO - Enum constant in enum class com.google.common.collect.testing.features.CollectionSize
Test an empty collection.
ZERO - Static variable in class com.google.common.primitives.UnsignedInteger
 
ZERO - Static variable in class com.google.common.primitives.UnsignedLong
 
ZERO_COPY_CHUNK_SIZE - Static variable in class com.google.common.io.ByteStreams
There are three methods to implement FileChannel.transferTo(long, long, WritableByteChannel): Use sendfile(2) or equivalent.
ZERO_CUMULATIVE_COUNTS - Static variable in class com.google.common.collect.RegularImmutableSortedMultiset
 
zeroes() - Static method in class com.google.common.base.CharMatcher.Digit
 
ZEROES - Static variable in class com.google.common.base.CharMatcher.Digit
 
zip(Stream<A>, Stream<B>, BiFunction<? super A, ? super B, R>) - Static method in class com.google.common.collect.Streams
Returns a stream in which each element is the result of passing the corresponding element of each of streamA and streamB to function.
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 Y Z 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form