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

A

AAC_AUDIO - Static variable in class com.google.common.net.MediaType
Media type for Advanced Audio Coding.
absent() - Static method in class com.google.common.base.Optional
Returns an Optional instance with no contained reference.
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().
AbstractCheckedFuture<V,X extends Exception> - Class in com.google.common.util.concurrent
Deprecated.
CheckedFuture cannot properly support the chained operations that are the primary goal of ListenableFuture. CheckedFuture also encourages users to rethrow exceptions from one thread in another thread, producing misleading stack traces. Additionally, it has a surprising policy about which exceptions to map and which to leave untouched. Guava users who want a CheckedFuture can fork the classes for their own use, possibly specializing them to the particular exception type they use. We recommend that most people use ListenableFuture and perform any exception wrapping themselves. This class is scheduled for removal from Guava in February 2018.
AbstractCheckedFuture(ListenableFuture<V>) - Constructor for class com.google.common.util.concurrent.AbstractCheckedFuture
Deprecated.
Constructs an AbstractCheckedFuture that wraps a delegate.
AbstractExecutionThreadService - Class in com.google.common.util.concurrent
AbstractExecutionThreadService() - Constructor for class com.google.common.util.concurrent.AbstractExecutionThreadService
Constructor for use by subclasses.
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.
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
 
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.
AbstractInvocationHandler - Class in com.google.common.reflect
AbstractInvocationHandler() - Constructor for class com.google.common.reflect.AbstractInvocationHandler
 
AbstractIterator<T> - Class in com.google.common.collect
This class provides a skeletal implementation of the Iterator interface, to make this interface easier to implement for certain types of data sources.
AbstractIterator() - Constructor for class com.google.common.collect.AbstractIterator
Constructor for use by subclasses.
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
 
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.
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
 
AbstractScheduledService - Class in com.google.common.util.concurrent
Base class for services that can implement AbstractScheduledService.startUp() and AbstractScheduledService.shutDown() but while in the "running" state need to perform a periodic task.
AbstractScheduledService() - Constructor for class com.google.common.util.concurrent.AbstractScheduledService
Constructor for use by subclasses.
AbstractScheduledService.CustomScheduler - Class in com.google.common.util.concurrent
A AbstractScheduledService.Scheduler that provides a convenient way for the AbstractScheduledService to use a dynamically changing schedule.
AbstractScheduledService.CustomScheduler.Schedule - Class in com.google.common.util.concurrent
A value object that represents an absolute delay until a task should be invoked.
AbstractScheduledService.Scheduler - Class in com.google.common.util.concurrent
A scheduler defines the policy for how the AbstractScheduledService should run its task.
AbstractSequentialIterator<T> - Class in com.google.common.collect
This class provides a skeletal implementation of the Iterator interface for sequences whose next element can always be derived from the previous element.
AbstractSequentialIterator(T) - Constructor for class com.google.common.collect.AbstractSequentialIterator
Creates a new iterator with the given first element, or, if firstOrNull is null, creates a new empty iterator.
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.
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
 
accept(File, String) - Method in class com.google.common.io.PatternFilenameFilter
 
ACCEPT - Static variable in class com.google.common.net.HttpHeaders
The HTTP Accept header field name.
ACCEPT_CHARSET - Static variable in class com.google.common.net.HttpHeaders
The HTTP Accept-Charset header field name.
ACCEPT_ENCODING - Static variable in class com.google.common.net.HttpHeaders
The HTTP Accept-Encoding header field name.
ACCEPT_LANGUAGE - Static variable in class com.google.common.net.HttpHeaders
The HTTP Accept-Language header field name.
ACCEPT_RANGES - Static variable in class com.google.common.net.HttpHeaders
The HTTP Accept-Ranges header field name.
ACCESS_CONTROL_ALLOW_CREDENTIALS - Static variable in class com.google.common.net.HttpHeaders
The HTTP Access-Control-Allow-Credentials header field name.
ACCESS_CONTROL_ALLOW_HEADERS - Static variable in class com.google.common.net.HttpHeaders
The HTTP Access-Control-Allow-Headers header field name.
ACCESS_CONTROL_ALLOW_METHODS - Static variable in class com.google.common.net.HttpHeaders
The HTTP Access-Control-Allow-Methods header field name.
ACCESS_CONTROL_ALLOW_ORIGIN - Static variable in class com.google.common.net.HttpHeaders
The HTTP Access-Control-Allow-Origin header field name.
ACCESS_CONTROL_EXPOSE_HEADERS - Static variable in class com.google.common.net.HttpHeaders
The HTTP Access-Control-Expose-Headers header field name.
ACCESS_CONTROL_MAX_AGE - Static variable in class com.google.common.net.HttpHeaders
The HTTP Access-Control-Max-Age header field name.
ACCESS_CONTROL_REQUEST_HEADERS - Static variable in class com.google.common.net.HttpHeaders
The HTTP Access-Control-Request-Headers header field name.
ACCESS_CONTROL_REQUEST_METHOD - Static variable in class com.google.common.net.HttpHeaders
The HTTP Access-Control-Request-Method header field name.
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.
add(String, Object) - Method in class com.google.common.base.MoreObjects.ToStringHelper
Adds a name/value pair to the formatted output in name=value format.
add(String, boolean) - Method in class com.google.common.base.MoreObjects.ToStringHelper
Adds a name/value pair to the formatted output in name=value format.
add(String, char) - Method in class com.google.common.base.MoreObjects.ToStringHelper
Adds a name/value pair to the formatted output in name=value format.
add(String, double) - Method in class com.google.common.base.MoreObjects.ToStringHelper
Adds a name/value pair to the formatted output in name=value format.
add(String, float) - Method in class com.google.common.base.MoreObjects.ToStringHelper
Adds a name/value pair to the formatted output in name=value format.
add(String, int) - Method in class com.google.common.base.MoreObjects.ToStringHelper
Adds a name/value pair to the formatted output in name=value format.
add(String, long) - Method in class com.google.common.base.MoreObjects.ToStringHelper
Adds a name/value pair to the formatted output in name=value format.
add(E, int) - Method in class com.google.common.collect.ConcurrentHashMultiset
Adds a number of occurrences of the specified element to this multiset.
add(E) - Method in class com.google.common.collect.EvictingQueue
Adds the given element to this queue.
add(E) - Method in class com.google.common.collect.ForwardingCollection
 
add(int, E) - Method in class com.google.common.collect.ForwardingList
 
add(E) - Method in class com.google.common.collect.ForwardingListIterator
 
add(E, int) - Method in class com.google.common.collect.ForwardingMultiset
 
add(E) - Method in class com.google.common.collect.ImmutableCollection
Deprecated.
Unsupported operation.
add(E) - Method in class com.google.common.collect.ImmutableCollection.Builder
Adds element to the ImmutableCollection being built.
add(E...) - Method in class com.google.common.collect.ImmutableCollection.Builder
Adds each element of elements to the ImmutableCollection being built.
add(int, E) - Method in class com.google.common.collect.ImmutableList
Deprecated.
Unsupported operation.
add(E) - Method in class com.google.common.collect.ImmutableList.Builder
Adds element to the ImmutableList.
add(E...) - Method in class com.google.common.collect.ImmutableList.Builder
Adds each element of elements to the ImmutableList.
add(E, int) - Method in class com.google.common.collect.ImmutableMultiset
Deprecated.
Unsupported operation.
add(E) - Method in class com.google.common.collect.ImmutableMultiset.Builder
Adds element to the ImmutableMultiset.
add(E...) - Method in class com.google.common.collect.ImmutableMultiset.Builder
Adds each element of elements to the ImmutableMultiset.
add(Range<C>) - Method in class com.google.common.collect.ImmutableRangeSet
Deprecated.
Unsupported operation.
add(Range<C>) - Method in class com.google.common.collect.ImmutableRangeSet.Builder
Add the specified range to this builder.
add(E) - Method in class com.google.common.collect.ImmutableSet.Builder
Adds element to the ImmutableSet.
add(E...) - Method in class com.google.common.collect.ImmutableSet.Builder
Adds each element of elements to the ImmutableSet, ignoring duplicate elements (only the first duplicate element is added).
add(E) - Method in class com.google.common.collect.ImmutableSortedMultiset.Builder
Adds element to the ImmutableSortedMultiset.
add(E...) - Method in class com.google.common.collect.ImmutableSortedMultiset.Builder
Adds each element of elements to the ImmutableSortedMultiset.
add(E) - Method in class com.google.common.collect.ImmutableSortedSet.Builder
Adds element to the ImmutableSortedSet.
add(E...) - Method in class com.google.common.collect.ImmutableSortedSet.Builder
Adds each element of elements to the ImmutableSortedSet, ignoring duplicate elements (only the first duplicate element is added).
add(E) - Method in class com.google.common.collect.MinMaxPriorityQueue
Adds the given element to this queue.
add(E, int) - Method in interface com.google.common.collect.Multiset
Adds a number of occurrences of an element to this multiset.
add(E) - Method in interface com.google.common.collect.Multiset
Adds a single occurrence of the specified element to this multiset.
add(Range<C>) - Method in interface com.google.common.collect.RangeSet
Adds the specified range to this RangeSet (optional operation).
add(E) - Method in class com.google.common.collect.Sets.SetView
Deprecated.
Unsupported operation.
add(E, int) - Method in class com.google.common.collect.TreeMultiset
 
add(Range<C>) - Method in class com.google.common.collect.TreeRangeSet
 
add(E) - Method in class com.google.common.collect.UnmodifiableListIterator
Deprecated.
Unsupported operation.
add(double, double) - Method in class com.google.common.math.PairedStatsAccumulator
Adds the given pair of values to the dataset.
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(int) - Method in class com.google.common.primitives.ImmutableIntArray.Builder
Appends value to the end of the values the built ImmutableIntArray will contain.
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(Runnable, Executor) - Method in class com.google.common.util.concurrent.ExecutionList
Adds the Runnable and accompanying Executor to the list of listeners to execute.
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(int, Collection<? extends E>) - Method in class com.google.common.collect.ForwardingList
 
addAll(Collection<? extends E>) - Method in class com.google.common.collect.ImmutableCollection
Deprecated.
Unsupported operation.
addAll(Iterable<? extends E>) - Method in class com.google.common.collect.ImmutableCollection.Builder
Adds each element of elements to the ImmutableCollection being built.
addAll(Iterator<? extends E>) - Method in class com.google.common.collect.ImmutableCollection.Builder
Adds each element of elements to the ImmutableCollection being built.
addAll(int, Collection<? extends E>) - Method in class com.google.common.collect.ImmutableList
Deprecated.
Unsupported operation.
addAll(Iterable<? extends E>) - Method in class com.google.common.collect.ImmutableList.Builder
Adds each element of elements to the ImmutableList.
addAll(Iterator<? extends E>) - Method in class com.google.common.collect.ImmutableList.Builder
Adds each element of elements to the ImmutableList.
addAll(Iterable<? extends E>) - Method in class com.google.common.collect.ImmutableMultiset.Builder
Adds each element of elements to the ImmutableMultiset.
addAll(Iterator<? extends E>) - Method in class com.google.common.collect.ImmutableMultiset.Builder
Adds each element of elements to the ImmutableMultiset.
addAll(RangeSet<C>) - Method in class com.google.common.collect.ImmutableRangeSet
Deprecated.
Unsupported operation.
addAll(Iterable<Range<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(Iterable<Range<C>>) - Method in class com.google.common.collect.ImmutableRangeSet.Builder
Add all of the specified ranges to this builder.
addAll(Iterable<? extends E>) - Method in class com.google.common.collect.ImmutableSet.Builder
Adds each element of elements to the ImmutableSet, ignoring duplicate elements (only the first duplicate element is added).
addAll(Iterator<? extends E>) - Method in class com.google.common.collect.ImmutableSet.Builder
Adds each element of elements to the ImmutableSet, ignoring duplicate elements (only the first duplicate element is added).
addAll(Iterable<? extends E>) - Method in class com.google.common.collect.ImmutableSortedMultiset.Builder
Adds each element of elements to the ImmutableSortedMultiset.
addAll(Iterator<? extends E>) - Method in class com.google.common.collect.ImmutableSortedMultiset.Builder
Adds each element of elements to the ImmutableSortedMultiset.
addAll(Iterable<? extends E>) - Method in class com.google.common.collect.ImmutableSortedSet.Builder
Adds each element of elements to the ImmutableSortedSet, ignoring duplicate elements (only the first duplicate element is added).
addAll(Iterator<? extends E>) - Method in class com.google.common.collect.ImmutableSortedSet.Builder
Adds each element of elements to the ImmutableSortedSet, ignoring duplicate elements (only the first duplicate element is added).
addAll(Collection<T>, Iterable<? extends T>) - Static method in class com.google.common.collect.Iterables
Adds all elements in iterable to collection.
addAll(Collection<T>, Iterator<? extends T>) - Static method in class com.google.common.collect.Iterators
Adds all elements in iterator to collection.
addAll(Collection<? extends E>) - Method in class com.google.common.collect.MinMaxPriorityQueue
 
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(Iterable<Range<C>>) - Method in interface com.google.common.collect.RangeSet
Adds all of the specified ranges to this range set (optional operation).
addAll(Collection<? extends E>) - Method in class com.google.common.collect.Sets.SetView
Deprecated.
Unsupported 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(Iterable<? extends Number>) - Method in class com.google.common.math.StatsAccumulator
Adds the given values to the dataset.
addAll(Iterator<? extends Number>) - Method in class com.google.common.math.StatsAccumulator
Adds the given values to the dataset.
addAll(double...) - Method in class com.google.common.math.StatsAccumulator
Adds the given values to the dataset.
addAll(int...) - Method in class com.google.common.math.StatsAccumulator
Adds the given values to the dataset.
addAll(long...) - Method in class com.google.common.math.StatsAccumulator
Adds the given values to the dataset.
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(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<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<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(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(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(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(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(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(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(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(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(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<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(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.
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.
addAndGet(double) - Method in class com.google.common.util.concurrent.AtomicDouble
Atomically adds the given value to the current value.
addAndGet(int, double) - Method in class com.google.common.util.concurrent.AtomicDoubleArray
Atomically adds the given value to the element at index i.
addAndGet(K, long) - Method in class com.google.common.util.concurrent.AtomicLongMap
Adds delta to the value currently associated with key, and returns the new value.
addCallback(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>) - Static method in class com.google.common.util.concurrent.Futures
Deprecated.
Use the overload that requires an executor. For identical behavior, pass MoreExecutors.directExecutor(), but consider whether another executor would be safer, as discussed in the ListenableFuture.addListener documentation. This method is scheduled to be removed in April 2018.
addCallback(ListenableFuture<V>, FutureCallback<? super V>, Executor) - Static method in class com.google.common.util.concurrent.Futures
Registers separate success and failure callbacks to be run when the Future's computation is complete or, if the computation is already complete, immediately.
addCopies(E, int) - Method in class com.google.common.collect.ImmutableMultiset.Builder
Adds a number of occurrences of an element to this ImmutableMultiset.
addCopies(E, int) - Method in class com.google.common.collect.ImmutableSortedMultiset.Builder
Adds a number of occurrences of an element to this ImmutableSortedMultiset.
addDelayedShutdownHook(ExecutorService, long, TimeUnit) - Static method in class com.google.common.util.concurrent.MoreExecutors
Add a shutdown hook to wait for thread completion in the given service.
addEdge(N, N, E) - Method in interface com.google.common.graph.MutableNetwork
Adds edge connecting nodeU to nodeV.
addEscape(char, String) - Method in class com.google.common.escape.CharEscaperBuilder
Add a new mapping from an index to an object to the escaping.
addEscape(char, String) - Method in class com.google.common.escape.Escapers.Builder
Adds a replacement string for the given input character.
addEscapes(char[], String) - Method in class com.google.common.escape.CharEscaperBuilder
Add multiple mappings at once for a particular index.
addFirst(E) - Method in class com.google.common.collect.ForwardingDeque
 
addLast(E) - Method in class com.google.common.collect.ForwardingDeque
 
addListener(Service.Listener, Executor) - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
 
addListener(Runnable, Executor) - Method in class com.google.common.util.concurrent.AbstractFuture
Registers a listener to be run on the given executor.
addListener(Service.Listener, Executor) - Method in class com.google.common.util.concurrent.AbstractIdleService
 
addListener(Service.Listener, Executor) - Method in class com.google.common.util.concurrent.AbstractScheduledService
 
addListener(Service.Listener, Executor) - Method in class com.google.common.util.concurrent.AbstractService
 
addListener(Runnable, Executor) - Method in class com.google.common.util.concurrent.ForwardingListenableFuture
 
addListener(Runnable, Executor) - Method in interface com.google.common.util.concurrent.ListenableFuture
Registers a listener to be run on the given executor.
addListener(Runnable, Executor) - Method in class com.google.common.util.concurrent.ListenableFutureTask
 
addListener(Service.Listener, Executor) - Method in interface com.google.common.util.concurrent.Service
Registers a Service.Listener to be executed on the given executor.
addListener(ServiceManager.Listener, Executor) - Method in class com.google.common.util.concurrent.ServiceManager
Registers a ServiceManager.Listener to be executed on the given executor.
addListener(ServiceManager.Listener) - Method in class com.google.common.util.concurrent.ServiceManager
Registers a ServiceManager.Listener to be run when this ServiceManager changes state.
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.
addValue(Object) - Method in class com.google.common.base.MoreObjects.ToStringHelper
Adds an unnamed value to the formatted output.
addValue(boolean) - Method in class com.google.common.base.MoreObjects.ToStringHelper
Adds an unnamed value to the formatted output.
addValue(char) - Method in class com.google.common.base.MoreObjects.ToStringHelper
Adds an unnamed value to the formatted output.
addValue(double) - Method in class com.google.common.base.MoreObjects.ToStringHelper
Adds an unnamed value to the formatted output.
addValue(float) - Method in class com.google.common.base.MoreObjects.ToStringHelper
Adds an unnamed value to the formatted output.
addValue(int) - Method in class com.google.common.base.MoreObjects.ToStringHelper
Adds an unnamed value to the formatted output.
addValue(long) - Method in class com.google.common.base.MoreObjects.ToStringHelper
Adds an unnamed value to the formatted output.
adjacentEdges(E) - Method in class com.google.common.graph.AbstractNetwork
 
adjacentEdges(E) - Method in interface com.google.common.graph.Network
Returns the edges which have an incident node in common with edge.
adjacentNode(Object) - Method in class com.google.common.graph.EndpointPair
Returns the node that is adjacent to node along the origin edge.
adjacentNodes(N) - Method in interface com.google.common.graph.Graph
Returns 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 the nodes which have an incident edge in common with node in this network.
adjacentNodes(N) - Method in interface com.google.common.graph.ValueGraph
Returns the nodes which have an incident edge in common with node in this graph.
adler32() - Static method in class com.google.common.hash.Hashing
Returns a hash function implementing the Adler-32 checksum algorithm (32 hash bits).
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.
afterDone() - Method in class com.google.common.util.concurrent.AbstractFuture
Callback method that is called exactly once after the future is completed.
AGE - Static variable in class com.google.common.net.HttpHeaders
The HTTP Age header field name.
all(Iterable<T>, Predicate<? super T>) - Static method in class com.google.common.collect.Iterables
Returns true if every element in iterable satisfies the predicate.
all(Iterator<T>, Predicate<? super T>) - Static method in class com.google.common.collect.Iterators
Returns true if every element returned by iterator satisfies the given predicate.
all() - Static method in class com.google.common.collect.Range
Returns a range that contains every value of type C.
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.
allMatch(Predicate<? super E>) - Method in class com.google.common.collect.FluentIterable
Returns true if every element in this fluent iterable satisfies the predicate.
ALLOW - Static variable in class com.google.common.net.HttpHeaders
The HTTP Allow header field name.
AllowConcurrentEvents - Annotation Type in com.google.common.eventbus
Marks an event subscriber method as being thread-safe.
allowsParallelEdges() - Method in interface com.google.common.graph.Network
Returns true if this network allows parallel edges.
allowsParallelEdges(boolean) - Method in class com.google.common.graph.NetworkBuilder
Specifies whether the network will allow parallel edges.
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(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() - Method in interface com.google.common.graph.Network
Returns true if this network allows 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() - 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.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).
allWrapperTypes() - Static method in class com.google.common.primitives.Primitives
Returns an immutable set of all nine primitive-wrapper types (including Void).
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.
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(Iterable<? extends Predicate<? super T>>) - Static method in class com.google.common.base.Predicates
Returns a predicate that evaluates to true if each of its components evaluates to true.
and(Predicate<? super T>...) - Static method in class com.google.common.base.Predicates
Returns a predicate that evaluates to true if each of its components evaluates to true.
and(Predicate<? super T>, Predicate<? super T>) - Static method in class com.google.common.base.Predicates
Returns a predicate that evaluates to true if both of its components evaluate to true.
and(double, double) - Method in class com.google.common.math.LinearTransformation.LinearTransformationBuilder
Finish building an instance which also maps x = x2 to y = y2.
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.
ANY - Static variable in class com.google.common.base.CharMatcher
Deprecated.
Use CharMatcher.any() instead. This constant is scheduled to be removed in June 2018.
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(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_APPLICATION_TYPE - Static variable in class com.google.common.net.MediaType
 
ANY_AUDIO_TYPE - Static variable in class com.google.common.net.MediaType
 
ANY_IMAGE_TYPE - Static variable in class com.google.common.net.MediaType
 
ANY_TEXT_TYPE - Static variable in class com.google.common.net.MediaType
 
ANY_TYPE - Static variable in class com.google.common.net.MediaType
 
ANY_VIDEO_TYPE - Static variable in class com.google.common.net.MediaType
 
anyMatch(Predicate<? super E>) - Method in class com.google.common.collect.FluentIterable
Returns true if any element in this fluent iterable satisfies the predicate.
anyOf(CharSequence) - Static method in class com.google.common.base.CharMatcher
Returns a char matcher that matches any character present in the given character sequence.
append(Iterable<? extends E>) - Method in class com.google.common.collect.FluentIterable
Returns a fluent iterable whose iterators traverse first the elements of this fluent iterable, followed by those of other.
append(E...) - Method in class com.google.common.collect.FluentIterable
Returns a fluent iterable whose iterators traverse first the elements of this fluent iterable, followed by elements.
append(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 January 2019.
appendTo(A, Iterable<?>) - Method in class com.google.common.base.Joiner
Appends the string representation of each of parts, using the previously configured separator between each, to appendable.
appendTo(A, Iterator<?>) - Method in class com.google.common.base.Joiner
Appends the string representation of each of parts, using the previously configured separator between each, to appendable.
appendTo(A, Object[]) - Method in class com.google.common.base.Joiner
Appends the string representation of each of parts, using the previously configured separator between each, to appendable.
appendTo(A, Object, Object, Object...) - Method in class com.google.common.base.Joiner
Appends to appendable the string representation of each of the remaining arguments.
appendTo(StringBuilder, Iterable<?>) - Method in class com.google.common.base.Joiner
Appends the string representation of each of parts, using the previously configured separator between each, to builder.
appendTo(StringBuilder, Iterator<?>) - Method in class com.google.common.base.Joiner
Appends the string representation of each of parts, using the previously configured separator between each, to builder.
appendTo(StringBuilder, Object[]) - Method in class com.google.common.base.Joiner
Appends the string representation of each of parts, using the previously configured separator between each, to builder.
appendTo(StringBuilder, Object, Object, Object...) - Method in class com.google.common.base.Joiner
Appends to builder the string representation of each of the remaining arguments.
appendTo(A, Map<?, ?>) - Method in class com.google.common.base.Joiner.MapJoiner
Appends the string representation of each entry of map, using the previously configured separator and key-value separator, to appendable.
appendTo(StringBuilder, Map<?, ?>) - Method in class com.google.common.base.Joiner.MapJoiner
Appends the string representation of each entry of map, using the previously configured separator and key-value separator, to builder.
appendTo(A, Iterable<? extends Map.Entry<?, ?>>) - Method in class com.google.common.base.Joiner.MapJoiner
Appends the string representation of each entry in entries, using the previously configured separator and key-value separator, to appendable.
appendTo(A, Iterator<? extends Map.Entry<?, ?>>) - Method in class com.google.common.base.Joiner.MapJoiner
Appends the string representation of each entry in entries, using the previously configured separator and key-value separator, to appendable.
appendTo(StringBuilder, Iterable<? extends Map.Entry<?, ?>>) - Method in class com.google.common.base.Joiner.MapJoiner
Appends the string representation of each entry in entries, using the previously configured separator and key-value separator, to builder.
appendTo(StringBuilder, Iterator<? extends Map.Entry<?, ?>>) - Method in class com.google.common.base.Joiner.MapJoiner
Appends the string representation of each entry in entries, using the previously configured separator and key-value separator, to builder.
APPLE_MOBILE_CONFIG - Static variable in class com.google.common.net.MediaType
APPLE_PASSBOOK - Static variable in class com.google.common.net.MediaType
Media type for Apple Passbook.
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_XML_UTF_8 - Static variable in class com.google.common.net.MediaType
As described in RFC 3023, this constant (application/xml) is used for XML documents that are "unreadable by casual users." MediaType.XML_UTF_8 is provided for documents that may be read by users.
apply(Character) - Method in class com.google.common.base.CharMatcher
Deprecated.
Provided only to satisfy the Predicate interface; use CharMatcher.matches(char) instead.
apply(A) - Method in class com.google.common.base.Converter
Deprecated.
Provided to satisfy the Function interface; use Converter.convert(A) instead.
apply(F) - Method in interface com.google.common.base.Function
 
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(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(C) - Method in class com.google.common.collect.Range
Deprecated.
Provided only to satisfy the Predicate interface; use Range.contains(C) instead.
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(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(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(T) - Method in class com.google.common.hash.BloomFilter
Deprecated.
Provided only to satisfy the Predicate interface; use BloomFilter.mightContain(T) instead.
apply(I) - Method in interface com.google.common.util.concurrent.AsyncFunction
Returns an output Future to use in place of the given input.
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).
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.
ArrayBasedCharEscaper - Class in com.google.common.escape
A CharEscaper that uses an array to quickly look up replacement characters for a given char value.
ArrayBasedCharEscaper(Map<Character, String>, char, char) - Constructor for class com.google.common.escape.ArrayBasedCharEscaper
Creates a new ArrayBasedCharEscaper instance with the given replacement map and specified safe range.
ArrayBasedCharEscaper(ArrayBasedEscaperMap, char, char) - Constructor for class com.google.common.escape.ArrayBasedCharEscaper
Creates a new ArrayBasedCharEscaper instance with the given replacement map and specified safe range.
ArrayBasedEscaperMap - Class in com.google.common.escape
An implementation-specific parameter class suitable for initializing ArrayBasedCharEscaper or ArrayBasedUnicodeEscaper instances.
ArrayBasedUnicodeEscaper - Class in com.google.common.escape
A UnicodeEscaper that uses an array to quickly look up replacement characters for a given code point.
ArrayBasedUnicodeEscaper(Map<Character, String>, int, int, String) - Constructor for class com.google.common.escape.ArrayBasedUnicodeEscaper
Creates a new ArrayBasedUnicodeEscaper instance with the given replacement map and specified safe range.
ArrayBasedUnicodeEscaper(ArrayBasedEscaperMap, int, int, String) - Constructor for class com.google.common.escape.ArrayBasedUnicodeEscaper
Creates a new ArrayBasedUnicodeEscaper instance with the given replacement map and specified safe range.
ArrayListMultimap<K,V> - Class in com.google.common.collect
Implementation of Multimap that uses an ArrayList to store the values for a given key.
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.
ArrayTable<R,C,V> - Class in com.google.common.collect
Fixed-size Table implementation backed by a two-dimensional array.
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.
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(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() - Method in class com.google.common.io.FileBackedOutputStream
Returns a readable ByteSource view of the data that has been written to this stream.
asByteSource(File) - Static method in class com.google.common.io.Files
Returns a new ByteSource for reading bytes from the given file.
asByteSource(Path, OpenOption...) - Static method in class com.google.common.io.MoreFiles
Returns a view of the given path as a ByteSource.
asByteSource(URL) - Static method in class com.google.common.io.Resources
Returns a ByteSource that reads from the given URL.
asByteSource() - Method in class com.google.common.reflect.ClassPath.ResourceInfo
Returns a ByteSource view of the resource from which its bytes can be read.
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(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(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.
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(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(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(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.reflect.ClassPath.ResourceInfo
Returns a CharSource view of the resource from which its bytes can be read as characters decoded with the given charset.
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 - Static variable in class com.google.common.base.CharMatcher
Deprecated.
Use CharMatcher.ascii() instead. This constant is scheduled to be removed in June 2018.
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.
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
 
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
 
asEnumeration(Iterator<T>) - Static method in class com.google.common.collect.Iterators
Adapts an Iterator to the Enumeration interface.
asFunction(Interner<E>) - Static method in class com.google.common.collect.Interners
Returns a function that delegates to the Interner.intern(E) method of the given interner.
asFunction() - Method in class com.google.common.escape.Escaper
Returns a Function that invokes Escaper.escape(String) on this escaper.
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.
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.
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
Returns this list instance.
asList() - Method in class com.google.common.collect.ImmutableMultiset
 
asList() - Method in class com.google.common.collect.ImmutableSet
 
asList(E, E[]) - Static method in class com.google.common.collect.Lists
Returns an unmodifiable list containing the specified first element and backed by the specified array of additional elements.
asList(E, E, E[]) - Static method in class com.google.common.collect.Lists
Returns an unmodifiable list containing the specified first and second element, and backed by the specified array of additional elements.
asList(boolean...) - Static method in class com.google.common.primitives.Booleans
Returns a fixed-size list backed by the specified array, similar to Arrays.asList(Object[]).
asList(byte...) - Static method in class com.google.common.primitives.Bytes
Returns a fixed-size list backed by the specified array, similar to Arrays.asList(Object[]).
asList(char...) - Static method in class com.google.common.primitives.Chars
Returns a fixed-size list backed by the specified array, similar to Arrays.asList(Object[]).
asList(double...) - Static method in class com.google.common.primitives.Doubles
Returns a fixed-size list backed by the specified array, similar to Arrays.asList(Object[]).
asList(float...) - Static method in class com.google.common.primitives.Floats
Returns a fixed-size list backed by the specified array, similar to Arrays.asList(Object[]).
asList() - 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(int...) - Static method in class com.google.common.primitives.Ints
Returns a fixed-size list backed by the specified array, similar to Arrays.asList(Object[]).
asList(long...) - Static method in class com.google.common.primitives.Longs
Returns a fixed-size list backed by the specified array, similar to Arrays.asList(Object[]).
asList(short...) - Static method in class com.google.common.primitives.Shorts
Returns a fixed-size list backed by the specified array, similar to Arrays.asList(Object[]).
asLong() - Method in class com.google.common.hash.HashCode
Returns the first eight bytes of this hashcode's bytes, converted to a long value in little-endian order.
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.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(Set<K>, Function<? super K, V>) - Static method in class com.google.common.collect.Maps
Returns a live Map view whose keys are the contents of set and whose values are computed on demand using function.
asMap(SortedSet<K>, Function<? super K, V>) - Static method in class com.google.common.collect.Maps
Returns a view of the sorted set as a map, mapping keys from the set according to the specified function.
asMap(NavigableSet<K>, Function<? super K, V>) - Static method in class com.google.common.collect.Maps
Returns a view of the navigable set as a map, mapping keys from the set according to the specified function.
asMap() - Method in interface com.google.common.collect.Multimap
Returns a view of this multimap as a Map from each distinct key to the nonempty collection of that key's associated values.
asMap(ListMultimap<K, V>) - Static method in class com.google.common.collect.Multimaps
Returns multimap.asMap(), with its type corrected from Map<K, Collection<V>> to Map<K, List<V>>.
asMap(SetMultimap<K, V>) - Static method in class com.google.common.collect.Multimaps
Returns multimap.asMap(), with its type corrected from Map<K, Collection<V>> to Map<K, Set<V>>.
asMap(SortedSetMultimap<K, V>) - Static method in class com.google.common.collect.Multimaps
Returns multimap.asMap(), with its type corrected from Map<K, Collection<V>> to Map<K, SortedSet<V>>.
asMap(Multimap<K, V>) - Static method in class com.google.common.collect.Multimaps
asMap() - 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.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.
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
 
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() - 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
 
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(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.
assignableFrom(Class<?>) - Static method in class com.google.common.base.Predicates
Deprecated.
Use the correctly-named method Predicates.subtypeOf(java.lang.Class<?>) instead.
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.
AsyncEventBus - Class in com.google.common.eventbus
An EventBus that takes the Executor of your choice and uses it to dispatch events, allowing dispatch to occur asynchronously.
AsyncEventBus(String, Executor) - Constructor for class com.google.common.eventbus.AsyncEventBus
Creates a new AsyncEventBus that will use executor to dispatch events.
AsyncEventBus(Executor, SubscriberExceptionHandler) - Constructor for class com.google.common.eventbus.AsyncEventBus
Creates a new AsyncEventBus that will use executor to dispatch events.
AsyncEventBus(Executor) - Constructor for class com.google.common.eventbus.AsyncEventBus
Creates a new AsyncEventBus that will use executor to dispatch events.
AsyncFunction<I,O> - Interface in com.google.common.util.concurrent
Transforms a value, possibly asynchronously.
asynchronous(RemovalListener<K, V>, Executor) - Static method in class com.google.common.cache.RemovalListeners
Returns a RemovalListener which processes all eviction notifications using executor.
asyncReloading(CacheLoader<K, V>, Executor) - Static method in class com.google.common.cache.CacheLoader
Returns a CacheLoader which wraps loader, executing calls to CacheLoader.reload(K, V) using executor.
at(int, int) - Method in class com.google.common.collect.ArrayTable
Returns the value corresponding to the specified row and column indices.
atLeast(C) - Static method in class com.google.common.collect.Range
Returns a range that contains all values greater than or equal to endpoint.
atMost(C) - Static method in class com.google.common.collect.Range
Returns a range that contains all values less than or equal to endpoint.
ATOM_UTF_8 - Static variable in class com.google.common.net.MediaType
 
AtomicDouble - Class in com.google.common.util.concurrent
A double value that may be updated atomically.
AtomicDouble(double) - Constructor for class com.google.common.util.concurrent.AtomicDouble
Creates a new AtomicDouble with the given initial value.
AtomicDouble() - Constructor for class com.google.common.util.concurrent.AtomicDouble
Creates a new AtomicDouble with initial value 0.0.
AtomicDoubleArray - Class in com.google.common.util.concurrent
A double array in which elements may be updated atomically.
AtomicDoubleArray(int) - Constructor for class com.google.common.util.concurrent.AtomicDoubleArray
Creates a new AtomicDoubleArray of the given length, with all elements initially zero.
AtomicDoubleArray(double[]) - Constructor for class com.google.common.util.concurrent.AtomicDoubleArray
Creates a new AtomicDoubleArray with the same length as, and all elements copied from, the given array.
AtomicLongMap<K> - Class in com.google.common.util.concurrent
A map containing long values that can be atomically updated.
Atomics - Class in com.google.common.util.concurrent
Static utility methods pertaining to classes in the java.util.concurrent.atomic package.
AUTHORIZATION - Static variable in class com.google.common.net.HttpHeaders
The HTTP Authorization header field name.
averageLoadPenalty() - Method in class com.google.common.cache.CacheStats
Returns the average time spent loading new values.
awaitHealthy() - Method in class com.google.common.util.concurrent.ServiceManager
Waits for the ServiceManager to become healthy.
awaitHealthy(long, TimeUnit) - Method in class com.google.common.util.concurrent.ServiceManager
Waits for the ServiceManager to become healthy for no more than the given time.
awaitRunning() - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
 
awaitRunning(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
 
awaitRunning() - Method in class com.google.common.util.concurrent.AbstractIdleService
 
awaitRunning(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractIdleService
 
awaitRunning() - Method in class com.google.common.util.concurrent.AbstractScheduledService
 
awaitRunning(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractScheduledService
 
awaitRunning() - Method in class com.google.common.util.concurrent.AbstractService
 
awaitRunning(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractService
 
awaitRunning() - Method in interface com.google.common.util.concurrent.Service
Waits for the Service to reach the running state.
awaitRunning(long, TimeUnit) - Method in interface com.google.common.util.concurrent.Service
Waits for the Service to reach the running state for no more than the given time.
awaitStopped() - Method in class com.google.common.util.concurrent.ServiceManager
Waits for the all the services to reach a terminal state.
awaitStopped(long, TimeUnit) - Method in class com.google.common.util.concurrent.ServiceManager
Waits for the all the services to reach a terminal state for no more than the given time.
awaitTerminated() - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
 
awaitTerminated(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
 
awaitTerminated() - Method in class com.google.common.util.concurrent.AbstractIdleService
 
awaitTerminated(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractIdleService
 
awaitTerminated() - Method in class com.google.common.util.concurrent.AbstractScheduledService
 
awaitTerminated(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractScheduledService
 
awaitTerminated() - Method in class com.google.common.util.concurrent.AbstractService
 
awaitTerminated(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractService
 
awaitTerminated() - Method in interface com.google.common.util.concurrent.Service
Waits for the Service to reach the terminated state.
awaitTerminated(long, TimeUnit) - Method in interface com.google.common.util.concurrent.Service
Waits for the Service to reach a terminal state (either terminated or failed) for no more than the given time.
awaitTermination(long, TimeUnit) - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
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.

B

base16() - Static method in class com.google.common.io.BaseEncoding
The "base16" encoding specified by RFC 4648 section 8, Base 16 Encoding.
base32() - Static method in class com.google.common.io.BaseEncoding
The "base32" encoding specified by RFC 4648 section 6, Base 32 Encoding.
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.
base64Url() - Static method in class com.google.common.io.BaseEncoding
The "base64url" encoding specified by RFC 4648 section 5, Base 64 Encoding with URL and Filename Safe Alphabet, also sometimes referred to as the "web safe Base64." (This is the same as the base 64 encoding with URL and filename safe alphabet from RFC 3548.)
BaseEncoding - Class in com.google.common.io
A binary encoding scheme for reversibly translating between byte sequences and printable ASCII strings.
BaseEncoding.DecodingException - Exception in com.google.common.io
Exception indicating invalid base-encoded input encountered while decoding.
BASIC_AUDIO - Static variable in class com.google.common.net.MediaType
Media type for Basic Audio, as defined by RFC 2046.
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.
Beta - Annotation Type in com.google.common.annotations
Signifies that a public API (public class, method or field) is subject to incompatible changes, or even removal, in a future release.
BigIntegerMath - Class in com.google.common.math
A class for arithmetic on values of type BigInteger.
bigIntegers() - Static method in class com.google.common.collect.DiscreteDomain
Returns the discrete domain for values of type BigInteger.
bigIntegerValue() - Method in class com.google.common.primitives.UnsignedInteger
Returns the value of this UnsignedInteger as a BigInteger.
bigIntegerValue() - Method in class com.google.common.primitives.UnsignedLong
Returns the value of this UnsignedLong as a BigInteger.
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.
binarySearch(List<? extends T>, T) - Method in class com.google.common.collect.Ordering
Deprecated.
Use Collections.binarySearch(List, Object, Comparator) directly. This method is scheduled for deletion in June 2018.
BinaryTreeTraverser<T> - Class in com.google.common.collect
A variant of TreeTraverser for binary trees, providing additional traversals specific to binary trees.
BinaryTreeTraverser() - Constructor for class com.google.common.collect.BinaryTreeTraverser
 
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.
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 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.
BloomFilter<T> - Class in com.google.common.hash
A Bloom filter for instances of T.
BMP - Static variable in class com.google.common.net.MediaType
 
Booleans - Class in com.google.common.primitives
Static utility methods pertaining to boolean primitives, that are not already found in either Boolean or Arrays.
BoundType - Enum in com.google.common.collect
Indicates whether an endpoint of some range is contained in the range itself ("closed") or not ("open").
breadthFirstTraversal(T) - Method in class com.google.common.collect.TreeTraverser
Returns an unmodifiable iterable over the nodes in a tree structure, using breadth-first traversal.
BREAKING_WHITESPACE - Static variable in class com.google.common.base.CharMatcher
Deprecated.
Use CharMatcher.breakingWhitespace() instead. This constant is scheduled to be removed in June 2018.
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).
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.
build(CacheLoader<? super K1, V1>) - Method in class com.google.common.cache.CacheBuilder
Builds a cache, which either returns an already-loaded value for a given key or atomically computes or retrieves it using the supplied CacheLoader.
build() - Method in class com.google.common.cache.CacheBuilder
Builds a cache which does not automatically load values when keys are requested.
build() - Method in class com.google.common.collect.ImmutableBiMap.Builder
Returns a newly-created immutable bimap.
build() - Method in class com.google.common.collect.ImmutableClassToInstanceMap.Builder
Returns a new immutable class-to-instance map containing the entries provided to this builder.
build() - Method in class com.google.common.collect.ImmutableCollection.Builder
Returns a newly-created ImmutableCollection of the appropriate type, containing the elements provided to this builder.
build() - Method in class com.google.common.collect.ImmutableList.Builder
Returns a newly-created ImmutableList based on the contents of the Builder.
build() - Method in class com.google.common.collect.ImmutableListMultimap.Builder
Returns a newly-created immutable list multimap.
build() - Method in class com.google.common.collect.ImmutableMap.Builder
Returns a newly-created immutable map.
build() - Method in class com.google.common.collect.ImmutableMultimap.Builder
Returns a newly-created immutable multimap.
build() - Method in class com.google.common.collect.ImmutableMultiset.Builder
Returns a newly-created ImmutableMultiset based on the contents of the Builder.
build() - Method in class com.google.common.collect.ImmutableRangeMap.Builder
Returns an ImmutableRangeMap containing the associations previously added to this builder.
build() - Method in class com.google.common.collect.ImmutableRangeSet.Builder
Returns an ImmutableRangeSet containing the ranges added to this builder.
build() - Method in class com.google.common.collect.ImmutableSet.Builder
Returns a newly-created ImmutableSet based on the contents of the Builder.
build() - Method in class com.google.common.collect.ImmutableSetMultimap.Builder
Returns a newly-created immutable set multimap.
build() - Method in class com.google.common.collect.ImmutableSortedMap.Builder
Returns a newly-created immutable sorted map.
build() - Method in class com.google.common.collect.ImmutableSortedMultiset.Builder
Returns a newly-created ImmutableSortedMultiset based on the contents of the Builder.
build() - Method in class com.google.common.collect.ImmutableSortedSet.Builder
Returns a newly-created ImmutableSortedSet based on the contents of the Builder and its comparator.
build() - Method in class com.google.common.collect.ImmutableTable.Builder
Returns a newly-created immutable table.
build() - Method in class com.google.common.collect.Interners.InternerBuilder
 
build() - Method in class com.google.common.collect.MultimapBuilder
Returns a new, empty Multimap with the specified implementation.
build(Multimap<? extends K, ? extends V>) - Method in class com.google.common.collect.MultimapBuilder
Returns a Multimap with the specified implementation, initialized with the entries of multimap.
build() - Method in class com.google.common.collect.MultimapBuilder.ListMultimapBuilder
 
build(Multimap<? extends K, ? extends V>) - Method in class com.google.common.collect.MultimapBuilder.ListMultimapBuilder
 
build() - Method in class com.google.common.collect.MultimapBuilder.SetMultimapBuilder
 
build(Multimap<? extends K, ? extends V>) - Method in class com.google.common.collect.MultimapBuilder.SetMultimapBuilder
 
build() - Method in class com.google.common.collect.MultimapBuilder.SortedSetMultimapBuilder
 
build(Multimap<? extends K, ? extends V>) - Method in class com.google.common.collect.MultimapBuilder.SortedSetMultimapBuilder
 
build() - Method in class com.google.common.escape.Escapers.Builder
Returns a new escaper based on the current state of the builder.
build() - Method in class com.google.common.graph.GraphBuilder
Returns an empty MutableGraph with the properties of this GraphBuilder.
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.
builder() - Static method in class com.google.common.collect.ContiguousSet
builder() - Static method in class com.google.common.collect.ImmutableBiMap
Returns a new builder.
Builder() - Constructor for class com.google.common.collect.ImmutableBiMap.Builder
Creates a new builder.
builder() - Static method in class com.google.common.collect.ImmutableClassToInstanceMap
Returns a new builder.
Builder() - Constructor for class com.google.common.collect.ImmutableClassToInstanceMap.Builder
 
builder() - Static method in class com.google.common.collect.ImmutableList
Returns a new builder.
Builder() - Constructor for class com.google.common.collect.ImmutableList.Builder
Creates a new builder.
builder() - Static method in class com.google.common.collect.ImmutableListMultimap
Returns a new builder.
Builder() - Constructor for class com.google.common.collect.ImmutableListMultimap.Builder
Creates a new builder.
builder() - Static method in class com.google.common.collect.ImmutableMap
Returns a new builder.
Builder() - Constructor for class com.google.common.collect.ImmutableMap.Builder
Creates a new builder.
builder() - Static method in class com.google.common.collect.ImmutableMultimap
Returns a new builder.
Builder() - Constructor for class com.google.common.collect.ImmutableMultimap.Builder
Creates a new builder.
builder() - Static method in class com.google.common.collect.ImmutableMultiset
Returns a new builder.
Builder() - Constructor for class com.google.common.collect.ImmutableMultiset.Builder
Creates a new builder.
builder() - Static method in class com.google.common.collect.ImmutableRangeMap
Returns a new builder for an immutable range map.
Builder() - Constructor for class com.google.common.collect.ImmutableRangeMap.Builder
 
builder() - Static method in class com.google.common.collect.ImmutableRangeSet
Returns a new builder for an immutable range set.
Builder() - Constructor for class com.google.common.collect.ImmutableRangeSet.Builder
 
builder() - Static method in class com.google.common.collect.ImmutableSet
Returns a new builder.
Builder() - Constructor for class com.google.common.collect.ImmutableSet.Builder
Creates a new builder.
builder() - Static method in class com.google.common.collect.ImmutableSetMultimap
Builder() - Constructor for class com.google.common.collect.ImmutableSetMultimap.Builder
Creates a new builder.
Builder(Comparator<? super K>) - Constructor for class com.google.common.collect.ImmutableSortedMap.Builder
Creates a new builder.
Builder(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() - Static method in class com.google.common.collect.ImmutableTable
Returns a new builder.
Builder() - Constructor for class com.google.common.collect.ImmutableTable.Builder
Creates a new builder.
builder() - Static method in class com.google.common.escape.Escapers
Returns a builder for creating simple, fast escapers.
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() - Static method in class com.google.common.primitives.ImmutableDoubleArray
Returns a new, empty builder for ImmutableDoubleArray instances, with a default initial capacity.
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() - Static method in class com.google.common.primitives.ImmutableIntArray
Returns a new, empty builder for ImmutableIntArray instances, with a default initial capacity.
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() - 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.
bulkGet(Iterable<?>) - Method in class com.google.common.util.concurrent.Striped
Returns the stripes that correspond to the passed objects, in ascending (as per Striped.getAt(int)) order.
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.
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.
byteArrayFunnel() - Static method in class com.google.common.hash.Funnels
Returns a funnel that extracts the bytes from a byte array.
ByteProcessor<T> - Interface in com.google.common.io
A callback interface to process bytes from a stream.
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 - 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.
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.
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.
ByteStreams - Class in com.google.common.io
Provides utility methods for working with byte arrays and I/O streams.
BZIP2 - Static variable in class com.google.common.net.MediaType
 

C

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
 
CacheBuilder<K,V> - Class in com.google.common.cache
A builder of LoadingCache and Cache instances having any combination of the following features: automatic loading of entries into the cache least-recently-used eviction when a maximum size is exceeded time-based expiration of entries, measured since last access or last write keys automatically wrapped in weak references values automatically wrapped in weak or soft references notification of evicted (or otherwise removed) entries accumulation of cache access statistics
CacheBuilderSpec - Class in com.google.common.cache
A specification of a CacheBuilder configuration.
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.InvalidCacheLoadException - Exception in com.google.common.cache
Thrown to indicate that an invalid response was returned from a call to CacheLoader.
CacheLoader.UnsupportedLoadingOperationException - Exception 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.
call() - Method in interface com.google.common.util.concurrent.AsyncCallable
Computes a result Future.
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(Callable<C>) - Method in class com.google.common.util.concurrent.Futures.FutureCombiner
Deprecated.
Use the overload that requires an executor. For identical behavior, pass MoreExecutors.directExecutor(), but consider whether another executor would be safer, as discussed in the ListenableFuture.addListener documentation. This method is scheduled to be removed in April 2018.
Callables - Class in com.google.common.util.concurrent
Static utility methods pertaining to the Callable interface.
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(AsyncCallable<C>) - Method in class com.google.common.util.concurrent.Futures.FutureCombiner
Deprecated.
Use the overload that requires an executor. For identical behavior, pass MoreExecutors.directExecutor(), but consider whether another executor would be safer, as discussed in the ListenableFuture.addListener documentation. This method is scheduled to be removed in April 2018.
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.
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.
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.
cancel(boolean) - Method in class com.google.common.util.concurrent.AbstractFuture
cancel(boolean) - Method in class com.google.common.util.concurrent.ForwardingFuture
 
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.
canonical(DiscreteDomain<C>) - Method in class com.google.common.collect.Range
Returns the canonical form of this range in the given domain.
cartesianProduct(List<? extends List<? extends B>>) - Static method in class com.google.common.collect.Lists
Returns every possible list that can be formed by choosing one element from each of the given lists in order; the "n-ary Cartesian product" of the lists.
cartesianProduct(List<? extends B>...) - Static method in class com.google.common.collect.Lists
Returns every possible list that can be formed by choosing one element from each of the given lists in order; the "n-ary Cartesian product" of the lists.
cartesianProduct(List<? extends Set<? extends B>>) - Static method in class com.google.common.collect.Sets
Returns every possible list that can be formed by choosing one element from each of the given sets in order; the "n-ary Cartesian product" of the sets.
cartesianProduct(Set<? extends B>...) - Static method in class com.google.common.collect.Sets
Returns every possible list that can be formed by choosing one element from each of the given sets in order; the "n-ary Cartesian product" of the sets.
CaseFormat - Enum in com.google.common.base
Utility class for converting between various ASCII case formats.
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(ListenableFuture<? extends V>, Class<X>, Function<? super X, ? extends V>) - Static method in class com.google.common.util.concurrent.Futures
Deprecated.
Use the overload that requires an executor. For identical behavior, pass MoreExecutors.directExecutor(), but consider whether another executor would be safer, as discussed in the ListenableFuture.addListener documentation. This method is scheduled to be removed in April 2018.
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.
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 the this Future fails with the given exceptionType, from the result provided by the fallback.
catchingAsync(ListenableFuture<? extends V>, Class<X>, AsyncFunction<? super X, ? extends V>) - Static method in class com.google.common.util.concurrent.Futures
Deprecated.
Use the overload that requires an executor. For identical behavior, pass MoreExecutors.directExecutor(), but consider whether another executor would be safer, as discussed in the ListenableFuture.addListener documentation. This method is scheduled to be removed in April 2018.
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.
ceiling(E) - Method in class com.google.common.collect.ForwardingNavigableSet
 
ceiling(E) - Method in class com.google.common.collect.ImmutableSortedSet
 
ceilingEntry(K) - Method in class com.google.common.collect.ForwardingNavigableMap
 
ceilingEntry(K) - Method in class com.google.common.collect.ImmutableSortedMap
 
ceilingKey(K) - Method in class com.google.common.collect.ForwardingNavigableMap
 
ceilingKey(K) - Method in class com.google.common.collect.ImmutableSortedMap
 
ceilingPowerOfTwo(BigInteger) - Static method in class com.google.common.math.BigIntegerMath
Returns the smallest power of two greater than or equal to x.
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.
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 interface com.google.common.collect.Table
Returns a set of all row key / column key / value triplets.
charactersOf(String) - Static method in class com.google.common.collect.Lists
Returns a view of the specified string as an immutable list of Character values.
charactersOf(CharSequence) - Static method in class com.google.common.collect.Lists
Returns a view of the specified CharSequence as a List<Character>, viewing sequence as a sequence of Unicode code units.
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.
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.
Chars - Class in com.google.common.primitives
Static utility methods pertaining to char primitives, that are not already found in either Character or Arrays.
charset() - Method in class com.google.common.net.MediaType
Returns an optional charset for the value of the charset parameter if it is specified.
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.
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.
CharStreams - Class in com.google.common.io
Provides utility methods for working with character streams.
checkArgument(boolean) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, Object) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, Object...) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
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, 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) - 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, 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, 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, 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, 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.
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.
CheckedFuture<V,X extends Exception> - Interface in com.google.common.util.concurrent
Deprecated.
CheckedFuture cannot properly support the chained operations that are the primary goal of ListenableFuture. CheckedFuture also encourages users to rethrow exceptions from one thread in another thread, producing misleading stack traces. Additionally, it has a surprising policy about which exceptions to map and which to leave untouched. Guava users who want a CheckedFuture can fork the classes for their own use, possibly specializing them to the particular exception type they use. We recommend that most people use ListenableFuture and perform any exception wrapping themselves. This class is scheduled for removal from Guava in February 2018.
checkedGet() - Method in class com.google.common.util.concurrent.AbstractCheckedFuture
Deprecated.
Exception checking version of Future.get() that will translate InterruptedException, CancellationException and ExecutionException into application-specific exceptions.
checkedGet(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractCheckedFuture
Deprecated.
Exception checking version of Future.get(long, TimeUnit) that will translate InterruptedException, CancellationException and ExecutionException into application-specific exceptions.
checkedGet() - Method in interface com.google.common.util.concurrent.CheckedFuture
Deprecated.
Exception checking version of Future.get() that will translate InterruptedException, CancellationException and ExecutionException into application-specific exceptions.
checkedGet(long, TimeUnit) - Method in interface com.google.common.util.concurrent.CheckedFuture
Deprecated.
Exception checking version of Future.get(long, TimeUnit) that will translate InterruptedException, CancellationException and ExecutionException into application-specific exceptions.
checkedGet() - Method in class com.google.common.util.concurrent.ForwardingCheckedFuture
Deprecated.
 
checkedGet(long, TimeUnit) - Method in class com.google.common.util.concurrent.ForwardingCheckedFuture
Deprecated.
 
checkedMultiply(int, int) - Static method in class com.google.common.math.IntMath
Returns the product of a and b, provided it does not overflow.
checkedMultiply(long, long) - Static method in class com.google.common.math.LongMath
Returns the product of a and b, provided it does not overflow.
checkedPow(int, int) - Static method in class com.google.common.math.IntMath
Returns the b to the kth power, provided it does not overflow.
checkedPow(long, int) - Static method in class com.google.common.math.LongMath
Returns the b to the kth power, provided it does not overflow.
checkedSubtract(int, int) - Static method in class com.google.common.math.IntMath
Returns the difference of a and b, provided it does not overflow.
checkedSubtract(long, long) - Static method in class com.google.common.math.LongMath
Returns the difference of a and b, provided it does not overflow.
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.
checkNotNull(T) - Static method in class com.google.common.base.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, Object) - Static method in class com.google.common.base.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, Object...) - Static method in class com.google.common.base.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
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, 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) - 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, 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, 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, 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, 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.
checkPositionIndex(int, int) - Static method in class com.google.common.base.Preconditions
Ensures that index specifies a valid position in an array, list or string of size size.
checkPositionIndex(int, int, String) - Static method in class com.google.common.base.Preconditions
Ensures that index specifies a valid position in an array, list or string of size size.
checkPositionIndexes(int, int, int) - Static method in class com.google.common.base.Preconditions
Ensures that start and end specify a valid positions in an array, list or string of size size, and are in order.
checkState(boolean) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, Object) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, Object...) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
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, 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) - 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, 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, 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, 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, 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.
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.
children(T) - Method in class com.google.common.collect.BinaryTreeTraverser
Returns the children of this node, in left-to-right order.
children(T) - Method in class com.google.common.collect.TreeTraverser
Returns the children of the specified node.
classes() - Method in class com.google.common.reflect.TypeToken.TypeSet
Returns the types that are classes.
ClassPath - Class in com.google.common.reflect
Scans the source of a ClassLoader and finds all loadable classes and resources.
ClassPath.ClassInfo - Class in com.google.common.reflect
Represents a class that can be loaded through ClassPath.ClassInfo.load().
ClassPath.ResourceInfo - Class in com.google.common.reflect
Represents a class path resource that can be either a class file or any other resource file loadable from the class path.
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.
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
 
clear() - Method in class com.google.common.collect.ArrayTable
Deprecated.
clear() - Method in class com.google.common.collect.ConcurrentHashMultiset
 
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.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.LinkedListMultimap
 
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 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 interface com.google.common.collect.Table
Removes all mappings from the table.
clear() - Method in class com.google.common.collect.TreeRangeMap
 
clear() - Method in class com.google.common.util.concurrent.AtomicLongMap
Removes all of the mappings from this map.
close() - Method in class com.google.common.base.FinalizableReferenceQueue
 
close() - Method in class com.google.common.hash.HashingOutputStream
 
close(Closeable, boolean) - Static method in class com.google.common.io.Closeables
Closes a Closeable, with control over whether an IOException may be thrown.
close() - Method in class com.google.common.io.Closer
Closes all Closeable instances that have been added to this Closer.
close() - Method in class com.google.common.io.CountingOutputStream
 
close() - Method in class com.google.common.io.FileBackedOutputStream
 
close() - Method in class com.google.common.io.LittleEndianDataOutputStream
 
Closeables - Class in com.google.common.io
Utility methods for working with Closeable objects.
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.
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.
closeQuietly(InputStream) - Static method in class com.google.common.io.Closeables
Closes the given InputStream, logging any IOException that's thrown rather than propagating it.
closeQuietly(Reader) - Static method in class com.google.common.io.Closeables
Closes the given Reader, logging any IOException that's thrown rather than propagating it.
Closer - Class in com.google.common.io
A Closeable that collects Closeable resources and closes them all when it is closed.
codePointAt(CharSequence, int, int) - Static method in class com.google.common.escape.UnicodeEscaper
Returns the Unicode code point of the character at the given index.
coerceToInteger(InetAddress) - Static method in class com.google.common.net.InetAddresses
Returns an integer representing an IPv4 address regardless of whether the supplied argument is an IPv4 address or not.
collapseFrom(CharSequence, char) - Method in class com.google.common.base.CharMatcher
Returns a string copy of the input character sequence, with each group of consecutive characters that match this matcher replaced by a single replacement character.
Collections2 - Class in com.google.common.collect
Provides static methods for working with Collection instances.
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 interface com.google.common.collect.Table
Returns a view of all mappings that have the given column key.
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();. This method is scheduled for removal in April 2019.
columnKeyList() - Method in class com.google.common.collect.ArrayTable
Returns, as an immutable list, the column keys provided when the table was constructed, including those that are mapped to null values only.
columnKeySet() - Method in class com.google.common.collect.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 interface com.google.common.collect.Table
Returns a set of column keys that have one or more values in the table.
columnMap() - Method in class com.google.common.collect.ArrayTable
 
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 interface com.google.common.collect.Table
Returns a view that associates each column key with the corresponding map from row keys to values.
com.google.common.annotations - package com.google.common.annotations
Common annotation types.
com.google.common.base - package com.google.common.base
Basic utility libraries and interfaces.
com.google.common.cache - package com.google.common.cache
This package contains caching utilities.
com.google.common.collect - package com.google.common.collect
This package contains generic collection interfaces and implementations, and other utilities for working with collections.
com.google.common.escape - package com.google.common.escape
Interfaces, utilities, and simple implementations of escapers and encoders.
com.google.common.eventbus - package com.google.common.eventbus
The EventBus allows publish-subscribe-style communication between components without requiring the components to explicitly register with one another (and thus be aware of each other).
com.google.common.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
This package contains utility methods and classes for working with Java I/O; for example input streams, output streams, readers, writers, and files.
com.google.common.math - package com.google.common.math
Arithmetic functions operating on primitive values and BigInteger instances.
com.google.common.net - package com.google.common.net
This package contains utility methods and classes for working with net addresses (numeric IP and domain names).
com.google.common.primitives - package com.google.common.primitives
Static utilities for working with the eight primitive types and void, and value types for treating them as unsigned.
com.google.common.reflect - package com.google.common.reflect
This package contains utilities to work with Java reflection.
com.google.common.util.concurrent - package com.google.common.util.concurrent
Concurrency utilities.
com.google.common.xml - package com.google.common.xml
Escapers for XML.
combinations(Set<E>, int) - Static method in class com.google.common.collect.Sets
Returns the set of all subsets of set of size size.
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.
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.
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.
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.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.MinMaxPriorityQueue
Returns the comparator used to order the elements in this queue.
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.graph.ElementOrder
Returns the Comparator used.
Comparators - Class in com.google.common.collect
Provides static methods for working with Comparator instances.
compare(Comparable<?>, Comparable<?>) - Method in class com.google.common.collect.ComparisonChain
Compares two comparable objects as specified by Comparable.compareTo(T), if the result of this comparison chain has not already been determined.
compare(T, T, Comparator<T>) - Method in class com.google.common.collect.ComparisonChain
Compares two objects using a comparator, if the result of this comparison chain has not already been determined.
compare(int, int) - Method in class com.google.common.collect.ComparisonChain
Compares two int values as specified by Ints.compare(int, int), if the result of this comparison chain has not already been determined.
compare(long, long) - Method in class com.google.common.collect.ComparisonChain
Compares two long values as specified by Longs.compare(long, long), if the result of this comparison chain has not already been determined.
compare(float, float) - Method in class com.google.common.collect.ComparisonChain
Compares two float values as specified by Float.compare(float, float), if the result of this comparison chain has not already been determined.
compare(double, double) - Method in class com.google.common.collect.ComparisonChain
Compares two double values as specified by Double.compare(double, double), if the result of this comparison chain has not already been determined.
compare(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(T, T) - Method in class com.google.common.collect.Ordering
 
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(char, char) - Static method in class com.google.common.primitives.Chars
Compares the two specified char values.
compare(double, double) - Static method in class com.google.common.primitives.Doubles
Compares the two specified double values.
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) - Static method in class com.google.common.primitives.Ints
Compares the two specified int values.
compare(long, long) - Static method in class com.google.common.primitives.Longs
Compares the two specified long values.
compare(short, short) - Static method in class com.google.common.primitives.Shorts
Compares the two specified short values.
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(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) - 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.
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.
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.
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
 
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.
ComparisonChain - Class in com.google.common.collect
A utility for performing a chained comparison statement.
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
 
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.
compose(Function<B, C>, Function<A, ? extends B>) - Static method in class com.google.common.base.Functions
Returns the composition of two functions.
compose(Predicate<B>, Function<A, ? extends B>) - Static method in class com.google.common.base.Predicates
Returns the composition of a function and a predicate.
compose(Function<? super F, T>, Supplier<F>) - Static method in class com.google.common.base.Suppliers
Returns a new supplier which is the composition of the provided function and supplier.
compound(Comparator<? super U>) - Method in class com.google.common.collect.Ordering
Returns an ordering which first uses the ordering this, but which in the event of a "tie", then delegates to secondaryComparator.
compound(Iterable<? extends Comparator<? super T>>) - Static method in class com.google.common.collect.Ordering
Returns an ordering which tries each given comparator in order until a non-zero result is found, returning that result, and returning zero only if all comparators return zero.
ComputationException - Exception in com.google.common.collect
Wraps an exception that occurred during a computation.
ComputationException(Throwable) - Constructor for exception com.google.common.collect.ComputationException
Creates a new instance with the given cause.
compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class com.google.common.collect.ImmutableMap
Deprecated.
Unsupported operation.
compute(Collection<? extends Number>) - 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.ScaleAndIndex
Computes the quantile value of the given dataset.
compute(long...) - 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.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(double...) - 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.ScaleAndIndexes
Computes the quantile values of the given dataset.
compute(int...) - Method in class com.google.common.math.Quantiles.ScaleAndIndexes
Computes the quantile values of the given dataset.
computeIfAbsent(K, Function<? super K, ? 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.ImmutableMap
Deprecated.
Unsupported operation.
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.
computeNext() - Method in class com.google.common.collect.AbstractIterator
Returns the next element.
computeNext(T) - Method in class com.google.common.collect.AbstractSequentialIterator
Returns the element that follows previous, or returns null if no elements remain.
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.
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>, 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>, Iterable<? extends T>) - Static method in class com.google.common.collect.FluentIterable
Returns a fluent iterable that combines four iterables.
concat(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.FluentIterable
Returns a fluent iterable that combines several 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.Iterables
Combines three iterables into a single iterable.
concat(Iterable<? extends T>, Iterable<? extends T>, Iterable<? extends T>, Iterable<? extends T>) - Static method in class com.google.common.collect.Iterables
Combines four iterables into a single iterable.
concat(Iterable<? extends T>...) - Static method in class com.google.common.collect.Iterables
Combines multiple iterables into a single iterable.
concat(Iterable<? extends Iterable<? extends T>>) - Static method in class com.google.common.collect.Iterables
Combines multiple iterables into a single iterable.
concat(Iterator<? extends T>, Iterator<? extends T>) - Static method in class com.google.common.collect.Iterators
Combines two iterators into a single iterator.
concat(Iterator<? extends T>, Iterator<? extends T>, Iterator<? extends T>) - Static method in class com.google.common.collect.Iterators
Combines three iterators into a single iterator.
concat(Iterator<? extends T>, Iterator<? extends T>, Iterator<? extends T>, Iterator<? extends T>) - Static method in class com.google.common.collect.Iterators
Combines four iterators into a single iterator.
concat(Iterator<? extends T>...) - Static method in class com.google.common.collect.Iterators
Combines multiple iterators into a single iterator.
concat(Iterator<? extends Iterator<? extends T>>) - Static method in class com.google.common.collect.Iterators
Combines multiple iterators into a single iterator.
concat(T[], T[], Class<T>) - Static method in class com.google.common.collect.ObjectArrays
Returns a new array that contains the concatenated contents of two arrays.
concat(T, T[]) - Static method in class com.google.common.collect.ObjectArrays
Returns a new array that prepends element to array.
concat(T[], T) - Static method in class com.google.common.collect.ObjectArrays
Returns a new array that appends element to array.
concat(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(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(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(Iterable<? extends ByteSource>) - Static method in class com.google.common.io.ByteSource
Concatenates multiple ByteSource instances into a single source.
concat(Iterator<? extends ByteSource>) - Static method in class com.google.common.io.ByteSource
Concatenates multiple ByteSource instances into a single source.
concat(ByteSource...) - Static method in class com.google.common.io.ByteSource
Concatenates multiple ByteSource instances into a single source.
concat(Iterable<? extends CharSource>) - Static method in class com.google.common.io.CharSource
Concatenates multiple CharSource instances into a single source.
concat(Iterator<? extends CharSource>) - Static method in class com.google.common.io.CharSource
Concatenates multiple CharSource instances into a single source.
concat(CharSource...) - Static method in class com.google.common.io.CharSource
Concatenates multiple CharSource instances into a single source.
concat(boolean[]...) - Static method in class com.google.common.primitives.Booleans
Returns the values from each provided array combined into a single array.
concat(byte[]...) - Static method in class com.google.common.primitives.Bytes
Returns the values from each provided array combined into a single array.
concat(char[]...) - Static method in class com.google.common.primitives.Chars
Returns the values from each provided array combined into a single array.
concat(double[]...) - Static method in class com.google.common.primitives.Doubles
Returns the values from each provided array combined into a single array.
concat(float[]...) - Static method in class com.google.common.primitives.Floats
Returns the values from each provided array combined into a single array.
concat(int[]...) - Static method in class com.google.common.primitives.Ints
Returns the values from each provided array combined into a single array.
concat(long[]...) - Static method in class com.google.common.primitives.Longs
Returns the values from each provided array combined into a single array.
concat(short[]...) - Static method in class com.google.common.primitives.Shorts
Returns the values from each provided array combined into a single array.
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.
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.
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).
CONNECTION - Static variable in class com.google.common.net.HttpHeaders
The HTTP Connection header field name.
consistentHash(HashCode, int) - Static method in class com.google.common.hash.Hashing
Assigns to hashCode a "bucket" in the range [0, buckets), in a uniform manner that minimizes the need for remapping as buckets grows.
consistentHash(long, int) - Static method in class com.google.common.hash.Hashing
Assigns to input a "bucket" in the range [0, buckets), in a uniform manner that minimizes the need for remapping as buckets grows.
constant(E) - Static method in class com.google.common.base.Functions
Returns a function that ignores its input and always returns value.
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].
constructor(Constructor<?>) - Method in class com.google.common.reflect.TypeToken
Returns the Invokable for constructor, which must be a member of T.
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.
contains(Pattern) - Static method in class com.google.common.base.Predicates
Returns a predicate that evaluates to true if the CharSequence being tested contains any match for the given regular expression pattern.
contains(Object, Object) - Method in class com.google.common.collect.ArrayTable
Returns true if the provided keys are among the keys provided when the table was constructed.
contains(Object) - Method in class com.google.common.collect.EvictingQueue
 
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, Object) - Method in class com.google.common.collect.ForwardingTable
 
contains(Object, Object) - Method in class com.google.common.collect.HashBasedTable
 
contains(Object) - Method in class com.google.common.collect.ImmutableCollection
 
contains(Object) - Method in class com.google.common.collect.ImmutableList
 
contains(Object) - Method in class com.google.common.collect.ImmutableMultiset
 
contains(Object, Object) - Method in class com.google.common.collect.ImmutableTable
 
contains(Iterable<?>, Object) - Static method in class com.google.common.collect.Iterables
Returns true if iterable contains any element o for which Objects.equals(o, element) would return true.
contains(Iterator<?>, Object) - Static method in class com.google.common.collect.Iterators
Returns true if iterator contains element.
contains(Object) - Method in interface com.google.common.collect.Multiset
Determines whether this multiset contains the specified element.
contains(C) - Method in class com.google.common.collect.Range
Returns true if value is within the bounds of this range.
contains(C) - Method in interface com.google.common.collect.RangeSet
Determines whether any of this range set's member ranges contains value.
contains(Object, 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(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[], 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(double) - Method in class com.google.common.primitives.ImmutableDoubleArray
Returns true if target is present at any index in this array.
contains(int) - Method in class com.google.common.primitives.ImmutableIntArray
Returns true if target is present at any index in this array.
contains(long) - Method in class com.google.common.primitives.ImmutableLongArray
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[], 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.
containsAll(Collection<?>) - Method in class com.google.common.collect.ForwardingCollection
 
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(Iterable<? extends C>) - Method in class com.google.common.collect.Range
Returns true if every element in values is contained in this range.
containsColumn(Object) - Method in class com.google.common.collect.ArrayTable
Returns true if the provided column key is among the column keys provided when the table was constructed.
containsColumn(Object) - Method in class com.google.common.collect.ForwardingTable
 
containsColumn(Object) - Method in class com.google.common.collect.HashBasedTable
 
containsColumn(Object) - Method in interface com.google.common.collect.Table
Returns true if the table contains a mapping with the specified column.
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.
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.ImmutableMap
 
containsKey(Object) - Method in class com.google.common.collect.ImmutableMultimap
 
containsKey(Object) - Method in class com.google.common.collect.LinkedListMultimap
 
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.util.concurrent.AtomicLongMap
Returns true if this map contains a mapping for the specified key.
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.
containsRow(Object) - Method in class com.google.common.collect.ArrayTable
Returns true if the provided row key is among the row keys provided when the table was constructed.
containsRow(Object) - Method in class com.google.common.collect.ForwardingTable
 
containsRow(Object) - Method in class com.google.common.collect.HashBasedTable
 
containsRow(Object) - Method in interface com.google.common.collect.Table
Returns true if the table contains a mapping with the specified row key.
containsValue(Object) - Method in class com.google.common.collect.ArrayTable
 
containsValue(Object) - Method in class com.google.common.collect.ForwardingMap
 
containsValue(Object) - Method in class com.google.common.collect.ForwardingMultimap
 
containsValue(Object) - Method in class com.google.common.collect.ForwardingTable
 
containsValue(Object) - Method in class com.google.common.collect.HashBasedTable
 
containsValue(Object) - Method in class com.google.common.collect.HashBiMap
 
containsValue(Object) - Method in class com.google.common.collect.ImmutableMap
 
containsValue(Object) - Method in class com.google.common.collect.ImmutableMultimap
 
containsValue(Object) - Method in class com.google.common.collect.ImmutableTable
 
containsValue(Object) - Method in class com.google.common.collect.LinkedListMultimap
 
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 interface com.google.common.collect.Table
Returns true if the table contains a mapping with the specified value.
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.
ContiguousSet<C extends Comparable> - Class in com.google.common.collect
A sorted set of contiguous values in a given DiscreteDomain.
convert(A) - Method in class com.google.common.base.Converter
Returns a representation of a as an instance of type B.
convertAll(Iterable<? extends A>) - Method in class com.google.common.base.Converter
Returns an iterable that applies convert to each element of fromIterable.
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.
converterTo(CaseFormat) - Method in enum com.google.common.base.CaseFormat
Returns a Converter that converts strings from this format to targetFormat.
COOKIE - Static variable in class com.google.common.net.HttpHeaders
The HTTP Cookie header field name.
copy() - Method in class com.google.common.hash.BloomFilter
Creates a new BloomFilter that's a copy of this instance.
copy(InputStream, OutputStream) - Static method in class com.google.common.io.ByteStreams
Copies all bytes from the input stream to the output stream.
copy(ReadableByteChannel, WritableByteChannel) - Static method in class com.google.common.io.ByteStreams
Copies all bytes from the readable channel to the writable channel.
copy(Readable, Appendable) - Static method in class com.google.common.io.CharStreams
Copies all characters between the Readable and Appendable objects.
copy(File, OutputStream) - Static method in class com.google.common.io.Files
Copies all bytes from a file to an output stream.
copy(File, File) - Static method in class com.google.common.io.Files
Copies all the bytes from one file to another.
copy(File, Charset, Appendable) - Static method in class com.google.common.io.Files
Deprecated.
Prefer asCharSource(from, charset).copyTo(to). This method is scheduled to be removed in January 2019.
copy(URL, OutputStream) - Static method in class com.google.common.io.Resources
Copies all bytes from a URL to an output stream.
copyHighestCountFirst(Multiset<E>) - Static method in class com.google.common.collect.Multisets
Returns a copy of multiset as an ImmutableMultiset whose iteration order is highest count first, with ties broken by the iteration order of the original multiset.
copyInto(C) - Method in class com.google.common.collect.FluentIterable
Copies all the elements from this fluent iterable to collection.
copyInto(S) - Method in class com.google.common.collect.Sets.SetView
Copies the current contents of this set view into an existing set.
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(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(Map<? extends Class<? extends S>, ? extends S>) - Static method in class com.google.common.collect.ImmutableClassToInstanceMap
Returns an immutable map containing the same entries as map.
copyOf(Iterable<? extends E>) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing the given elements, in order.
copyOf(Collection<? extends E>) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing the given elements, in order.
copyOf(Iterator<? extends E>) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing the given elements, in order.
copyOf(E[]) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing the given elements, in order.
copyOf(Multimap<? extends K, ? extends V>) - Static method in class com.google.common.collect.ImmutableListMultimap
Returns an immutable multimap containing the same mappings as multimap.
copyOf(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(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(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(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(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(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.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.ImmutableMultiset
Returns an immutable multiset containing the given elements, in the "grouped iteration order" described in the class documentation.
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(Iterable<Range<C>>) - Static method in class com.google.common.collect.ImmutableRangeSet
Returns an ImmutableRangeSet containing each of the specified disjoint ranges.
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(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(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(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(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(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(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(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 the provided comparator.
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(E[]) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns an immutable sorted multiset containing the given elements sorted by their natural ordering.
copyOf(Iterable<? extends E>) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns an immutable sorted multiset containing the given elements sorted by their natural ordering.
copyOf(Iterator<? extends E>) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns an immutable sorted multiset containing the given elements sorted by their natural ordering.
copyOf(Comparator<? super E>, Iterator<? extends E>) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns an immutable sorted multiset containing the given elements sorted by the given Comparator.
copyOf(Comparator<? super E>, Iterable<? extends E>) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns an immutable sorted multiset containing the given elements sorted by the given Comparator.
copyOf(E[]) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by their natural ordering.
copyOf(Iterable<? extends E>) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by their natural ordering.
copyOf(Collection<? extends E>) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by their natural ordering.
copyOf(Iterator<? extends E>) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by their natural ordering.
copyOf(Comparator<? super E>, Iterator<? extends E>) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by the given Comparator.
copyOf(Comparator<? super E>, Iterable<? extends E>) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by the given Comparator.
copyOf(Comparator<? super E>, Collection<? extends E>) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by the given Comparator.
copyOf(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(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(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(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(Network<N, E>) - Static method in class com.google.common.graph.ImmutableNetwork
Returns an immutable copy of network.
copyOf(ImmutableNetwork<N, E>) - Static method in class com.google.common.graph.ImmutableNetwork
Deprecated.
no need to use this
copyOf(ValueGraph<N, V>) - Static method in class com.google.common.graph.ImmutableValueGraph
Returns an immutable copy of graph.
copyOf(ImmutableValueGraph<N, V>) - Static method in class com.google.common.graph.ImmutableValueGraph
Deprecated.
no need to use this
copyOf(double[]) - Static method in class com.google.common.primitives.ImmutableDoubleArray
Returns an immutable array containing the given values, in order.
copyOf(Collection<Double>) - Static method in class com.google.common.primitives.ImmutableDoubleArray
Returns an immutable array containing the given values, in order.
copyOf(Iterable<Double>) - Static method in class com.google.common.primitives.ImmutableDoubleArray
Returns an immutable array containing the given values, in order.
copyOf(DoubleStream) - Static method in class com.google.common.primitives.ImmutableDoubleArray
Returns an immutable array containing all the values from stream, in order.
copyOf(int[]) - Static method in class com.google.common.primitives.ImmutableIntArray
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(Iterable<Integer>) - Static method in class com.google.common.primitives.ImmutableIntArray
Returns an immutable array containing the given values, 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(long[]) - Static method in class com.google.common.primitives.ImmutableLongArray
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(Iterable<Long>) - Static method in class com.google.common.primitives.ImmutableLongArray
Returns an immutable array containing the given values, 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.
copyOfSorted(SortedMap<K, ? extends V>) - Static method in class com.google.common.collect.ImmutableSortedMap
Returns an immutable map containing the same entries as the provided sorted map, with the same ordering.
copyOfSorted(SortedMultiset<E>) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns an immutable sorted multiset containing the elements of a sorted multiset, sorted by the same Comparator.
copyOfSorted(SortedSet<E>) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing the elements of a sorted set, sorted by the same Comparator.
copyTo(OutputStream) - Method in class com.google.common.io.ByteSource
Copies the contents of this byte source to the given OutputStream.
copyTo(ByteSink) - Method in class com.google.common.io.ByteSource
Copies the contents of this byte source to the given ByteSink.
copyTo(Appendable) - Method in class com.google.common.io.CharSource
Appends the contents of this source to the given Appendable (such as a Writer).
copyTo(CharSink) - Method in class com.google.common.io.CharSource
Copies the contents of this source to the given sink.
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.ForwardingMultiset
 
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.TreeMultiset
 
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.
countIn(CharSequence) - Method in class com.google.common.base.CharMatcher
Returns the number of matching characters found in a character sequence.
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.
countTrue(boolean...) - Static method in class com.google.common.primitives.Booleans
Returns the number of values that are true.
CR - Static variable in class com.google.common.base.Ascii
Carriage Return ('\r'): A format effector which controls the movement of the printing position to the first printing position on the same printing line.
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.
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() - Static method in class com.google.common.collect.ArrayListMultimap
Creates a new, empty ArrayListMultimap with the default initial capacities.
create(int, int) - Static method in class com.google.common.collect.ArrayListMultimap
Constructs an empty ArrayListMultimap with enough capacity to hold the specified numbers of keys and values without resizing.
create(Multimap<? extends K, ? extends V>) - Static method in class com.google.common.collect.ArrayListMultimap
Constructs an ArrayListMultimap with the same mappings as the specified multimap.
create(Iterable<? extends R>, Iterable<? extends C>) - Static method in class com.google.common.collect.ArrayTable
Creates an empty ArrayTable.
create(Table<R, C, V>) - Static method in class com.google.common.collect.ArrayTable
Creates an ArrayTable with the mappings in the provided table.
create() - Static method in class com.google.common.collect.ConcurrentHashMultiset
Creates a new, empty ConcurrentHashMultiset using the default initial capacity, load factor, and concurrency settings.
create(Iterable<? extends E>) - Static method in class com.google.common.collect.ConcurrentHashMultiset
Creates a new ConcurrentHashMultiset containing the specified elements, using the default initial capacity, load factor, and concurrency settings.
create(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(Range<C>, DiscreteDomain<C>) - Static method in class com.google.common.collect.ContiguousSet
Returns a ContiguousSet containing the same values in the given domain contained by the range.
create(Class<K>, Class<V>) - Static method in class com.google.common.collect.EnumBiMap
Returns a new, empty EnumBiMap using the specified key and value types.
create(Map<K, V>) - Static method in class com.google.common.collect.EnumBiMap
Returns a new bimap with the same mappings as the specified map.
create(Class<K>) - Static method in class com.google.common.collect.EnumHashBiMap
Returns a new, empty EnumHashBiMap using the specified key type.
create(Map<K, ? extends V>) - Static method in class com.google.common.collect.EnumHashBiMap
Constructs a new bimap with the same mappings as the specified map.
create(Class<E>) - Static method in class com.google.common.collect.EnumMultiset
Creates an empty EnumMultiset.
create(Iterable<E>) - Static method in class com.google.common.collect.EnumMultiset
Creates a new EnumMultiset containing the specified elements.
create(Iterable<E>, Class<E>) - Static method in class com.google.common.collect.EnumMultiset
Returns a new EnumMultiset instance containing the given elements.
create(int) - Static method in class com.google.common.collect.EvictingQueue
Creates and returns a new evicting queue that will hold up to maxSize elements.
create() - Static method in class com.google.common.collect.HashBasedTable
Creates an empty HashBasedTable.
create(int, int) - Static method in class com.google.common.collect.HashBasedTable
Creates an empty HashBasedTable with the specified map sizes.
create(Table<? extends R, ? extends C, ? extends V>) - Static method in class com.google.common.collect.HashBasedTable
Creates a HashBasedTable with the same mappings as the specified table.
create() - Static method in class com.google.common.collect.HashBiMap
Returns a new, empty HashBiMap with the default initial capacity (16).
create(int) - Static method in class com.google.common.collect.HashBiMap
Constructs a new, empty bimap with the specified expected size.
create(Map<? extends K, ? extends V>) - Static method in class com.google.common.collect.HashBiMap
Constructs a new bimap containing initial values from map.
create() - Static method in class com.google.common.collect.HashMultimap
Creates a new, empty HashMultimap with the default initial capacities.
create(int, int) - Static method in class com.google.common.collect.HashMultimap
Constructs an empty HashMultimap with enough capacity to hold the specified numbers of keys and values without rehashing.
create(Multimap<? extends K, ? extends V>) - Static method in class com.google.common.collect.HashMultimap
Constructs a HashMultimap with the same mappings as the specified multimap.
create() - Static method in class com.google.common.collect.HashMultiset
Creates a new, empty HashMultiset using the default initial capacity.
create(int) - Static method in class com.google.common.collect.HashMultiset
Creates a new, empty HashMultiset with the specified expected number of distinct elements.
create(Iterable<? extends E>) - Static method in class com.google.common.collect.HashMultiset
Creates a new HashMultiset containing the specified elements.
create() - Static method in class com.google.common.collect.LinkedHashMultimap
Creates a new, empty LinkedHashMultimap with the default initial capacities.
create(int, int) - Static method in class com.google.common.collect.LinkedHashMultimap
Constructs an empty LinkedHashMultimap with enough capacity to hold the specified numbers of keys and values without rehashing.
create(Multimap<? extends K, ? extends V>) - Static method in class com.google.common.collect.LinkedHashMultimap
Constructs a LinkedHashMultimap with the same mappings as the specified multimap.
create() - Static method in class com.google.common.collect.LinkedHashMultiset
Creates a new, empty LinkedHashMultiset using the default initial capacity.
create(int) - Static method in class com.google.common.collect.LinkedHashMultiset
Creates a new, empty LinkedHashMultiset with the specified expected number of distinct elements.
create(Iterable<? extends E>) - Static method in class com.google.common.collect.LinkedHashMultiset
Creates a new LinkedHashMultiset containing the specified elements.
create() - Static method in class com.google.common.collect.LinkedListMultimap
Creates a new, empty LinkedListMultimap with the default initial capacity.
create(int) - Static method in class com.google.common.collect.LinkedListMultimap
Constructs an empty LinkedListMultimap with enough capacity to hold the specified number of keys without rehashing.
create(Multimap<? extends K, ? extends V>) - Static method in class com.google.common.collect.LinkedListMultimap
Constructs a LinkedListMultimap with the same mappings as the specified Multimap.
create() - Method in class com.google.common.collect.MinMaxPriorityQueue.Builder
Builds a new min-max priority queue using the previously specified options, and having no initial contents.
create(Iterable<? extends T>) - Method in class com.google.common.collect.MinMaxPriorityQueue.Builder
Builds a new min-max priority queue using the previously specified options, and having the given initial elements.
create() - Static method in class com.google.common.collect.MinMaxPriorityQueue
Creates a new min-max priority queue with default settings: natural order, no maximum size, no initial contents, and an initial expected size of 11.
create(Iterable<? extends E>) - Static method in class com.google.common.collect.MinMaxPriorityQueue
Creates a new min-max priority queue using natural order, no maximum size, and initially containing the given elements.
create() - Static method in class com.google.common.collect.MutableClassToInstanceMap
Returns a new MutableClassToInstanceMap instance backed by a HashMap using the default initial capacity and load factor.
create(Map<Class<? extends B>, B>) - Static method in class com.google.common.collect.MutableClassToInstanceMap
Returns a new MutableClassToInstanceMap instance backed by a given empty backingMap.
create() - Static method in class com.google.common.collect.TreeBasedTable
Creates an empty TreeBasedTable that uses the natural orderings of both row and column keys.
create(Comparator<? super R>, Comparator<? super C>) - Static method in class com.google.common.collect.TreeBasedTable
Creates an empty TreeBasedTable that is ordered by the specified comparators.
create(TreeBasedTable<R, C, ? extends V>) - Static method in class com.google.common.collect.TreeBasedTable
Creates a TreeBasedTable with the same mappings and sort order as the specified TreeBasedTable.
create() - Static method in class com.google.common.collect.TreeMultimap
Creates an empty TreeMultimap ordered by the natural ordering of its keys and values.
create(Comparator<? super K>, Comparator<? super V>) - Static method in class com.google.common.collect.TreeMultimap
Creates an empty TreeMultimap instance using explicit comparators.
create(Multimap<? extends K, ? extends V>) - Static method in class com.google.common.collect.TreeMultimap
Constructs a TreeMultimap, ordered by the natural ordering of its keys and values, with the same mappings as the specified multimap.
create() - Static method in class com.google.common.collect.TreeMultiset
Creates a new, empty multiset, sorted according to the elements' natural order.
create(Comparator<? super E>) - Static method in class com.google.common.collect.TreeMultiset
Creates a new, empty multiset, sorted according to the specified comparator.
create(Iterable<? extends E>) - Static method in class com.google.common.collect.TreeMultiset
Creates an empty multiset containing the given initial elements, sorted according to the elements' natural order.
create() - Static method in class com.google.common.collect.TreeRangeMap
 
create() - Static method in class com.google.common.collect.TreeRangeSet
Creates an empty TreeRangeSet instance.
create(RangeSet<C>) - Static method in class com.google.common.collect.TreeRangeSet
Returns a TreeRangeSet initialized with the ranges in the specified range set.
create(Iterable<Range<C>>) - Static method in class com.google.common.collect.TreeRangeSet
Returns a TreeRangeSet representing the union of the specified ranges.
create(Map<Character, String>) - Static method in class com.google.common.escape.ArrayBasedEscaperMap
Returns a new ArrayBasedEscaperMap for creating ArrayBasedCharEscaper or ArrayBasedUnicodeEscaper instances.
create(Funnel<? super T>, int, double) - Static method in class com.google.common.hash.BloomFilter
Creates a BloomFilter with the expected number of insertions and expected false positive probability.
create(Funnel<? super T>, 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>, 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>, 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() - Static method in class com.google.common.io.Closer
Creates a new Closer.
create(String, String) - Static method in class com.google.common.net.MediaType
Creates a new media type with the given type and subtype.
create() - Static method in class com.google.common.util.concurrent.AtomicLongMap
Creates an AtomicLongMap.
create(Map<? extends K, ? extends Long>) - Static method in class com.google.common.util.concurrent.AtomicLongMap
Creates an AtomicLongMap with the same mappings as the specified Map.
create(Callable<V>) - Static method in class com.google.common.util.concurrent.ListenableFutureTask
Creates a ListenableFutureTask that will upon running, execute the given Callable.
create(Runnable, V) - Static method in class com.google.common.util.concurrent.ListenableFutureTask
Creates a ListenableFutureTask that will upon running, execute the given Runnable, and arrange that get will return the given result on successful completion.
create(double) - Static method in class com.google.common.util.concurrent.RateLimiter
Creates a RateLimiter with the specified stable throughput, given as "permits per second" (commonly referred to as QPS, queries per second).
create(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() - 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(ExecutorService) - Static method in class com.google.common.util.concurrent.SimpleTimeLimiter
Creates a TimeLimiter instance using the given executor service to execute method calls.
createEntrySet() - Method in class com.google.common.collect.ConcurrentHashMultiset
 
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.
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.
createTempDir() - Static method in class com.google.common.io.Files
Atomically creates a new directory somewhere beneath the system's temporary directory (as defined by the java.io.tmpdir system property), and returns its name.
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.
CRW - Static variable in class com.google.common.net.MediaType
The media type for the Canon Image File Format (crw files), a widely-used "raw image" format for cameras.
CSS_UTF_8 - Static variable in class com.google.common.net.MediaType
 
CSV_UTF_8 - Static variable in class com.google.common.net.MediaType
 
CustomScheduler() - Constructor for class com.google.common.util.concurrent.AbstractScheduledService.CustomScheduler
 
cycle() - Method in class com.google.common.collect.FluentIterable
Returns a fluent iterable whose Iterator cycles indefinitely over the elements of this fluent iterable.
cycle(Iterable<T>) - Static method in class com.google.common.collect.Iterables
Returns an iterable whose iterators cycle indefinitely over the elements of iterable.
cycle(T...) - Static method in class com.google.common.collect.Iterables
Returns an iterable whose iterators cycle indefinitely over the provided elements.
cycle(Iterable<T>) - Static method in class com.google.common.collect.Iterators
Returns an iterator that cycles indefinitely over the elements of iterable.
cycle(T...) - Static method in class com.google.common.collect.Iterators
Returns an iterator that cycles indefinitely over the provided elements.
CycleDetectingLockFactory - Class in com.google.common.util.concurrent
The CycleDetectingLockFactory creates ReentrantLock instances and ReentrantReadWriteLock instances that detect potential deadlock by checking for cycles in lock acquisition order.
CycleDetectingLockFactory.Policies - Enum in com.google.common.util.concurrent
Pre-defined CycleDetectingLockFactory.Policy implementations.
CycleDetectingLockFactory.Policy - Interface in com.google.common.util.concurrent
Encapsulates the action to be taken when a potential deadlock is encountered.
CycleDetectingLockFactory.PotentialDeadlockException - Exception in com.google.common.util.concurrent
Represents a detected cycle in lock acquisition ordering.
CycleDetectingLockFactory.WithExplicitOrdering<E extends Enum<E>> - Class in com.google.common.util.concurrent
A CycleDetectingLockFactory.WithExplicitOrdering provides the additional enforcement of an application-specified ordering of lock acquisitions.

D

DART_UTF_8 - Static variable in class com.google.common.net.MediaType
Media type for dart files.
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.
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.
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.
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.
Defaults - Class in com.google.common.base
This class provides default values for all Java types, as defined by the JLS.
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.
degree(N) - Method in class com.google.common.graph.AbstractNetwork
 
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.
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.collect.EvictingQueue
 
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.MutableClassToInstanceMap
 
delegate() - Method in class com.google.common.graph.ImmutableGraph
 
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.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.ForwardingCheckedFuture
Deprecated.
 
delegate() - Method in class com.google.common.util.concurrent.ForwardingCheckedFuture.SimpleForwardingCheckedFuture
Deprecated.
 
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
 
deleteDirectoryContents(Path, RecursiveDeleteOption...) - Static method in class com.google.common.io.MoreFiles
Deletes all files within the directory at the given path recursively.
deleteRecursively(Path, RecursiveDeleteOption...) - Static method in class com.google.common.io.MoreFiles
Deletes the file or directory at the given path recursively.
dereference(ListenableFuture<? extends ListenableFuture<? extends V>>) - Static method in class com.google.common.util.concurrent.Futures
Returns a new ListenableFuture whose result is the product of calling get() on the Future nested within the given Future, effectively chaining the futures one after the other.
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.ImmutableSortedSet
 
descendingKeySet() - Method in class com.google.common.collect.ForwardingNavigableMap
 
descendingKeySet() - Method in class com.google.common.collect.ImmutableSortedMap
 
descendingMap() - Method in class com.google.common.collect.ForwardingNavigableMap
 
descendingMap() - Method in class com.google.common.collect.ImmutableSortedMap
 
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.
descendingSet() - Method in class com.google.common.collect.ForwardingNavigableSet
 
descendingSet() - Method in class com.google.common.collect.ImmutableSortedSet
 
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(SortedMap<K, ? extends V>, Map<? extends K, ? extends V>) - Static method in class com.google.common.collect.Maps
Computes the difference between two sorted maps, using the comparator of the left map, or Ordering.natural() if the left map uses the natural ordering of its elements.
difference(Multiset<E>, Multiset<?>) - Static method in class com.google.common.collect.Multisets
Returns an unmodifiable view of the difference of two multisets.
difference(Set<E>, Set<?>) - Static method in class com.google.common.collect.Sets
Returns an unmodifiable view of the difference of two sets.
DIGIT - Static variable in class com.google.common.base.CharMatcher
Deprecated.
Use CharMatcher.digit() instead. This constant is scheduled to be removed in June 2018.
digit() - Static method in class com.google.common.base.CharMatcher
Determines whether a character is a digit according to Unicode.
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.
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.
directoryTreeTraverser() - Static method in class com.google.common.io.MoreFiles
Returns a TreeTraverser for traversing a directory tree.
disableCaching() - Static method in class com.google.common.cache.CacheBuilderSpec
Returns a CacheBuilderSpec that will prevent caching.
DiscreteDomain<C extends Comparable> - Class in com.google.common.collect
A descriptor for a discrete Comparable domain such as all Integer instances.
DiscreteDomain() - Constructor for class com.google.common.collect.DiscreteDomain
Constructor for use by subclasses.
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.
divide(BigInteger, BigInteger, RoundingMode) - Static method in class com.google.common.math.BigIntegerMath
Returns the result of dividing p by q, rounding using the specified RoundingMode.
divide(int, int, RoundingMode) - Static method in class com.google.common.math.IntMath
Returns the result of dividing p by q, rounding using the specified RoundingMode.
divide(long, long, RoundingMode) - Static method in class com.google.common.math.LongMath
Returns the result of dividing p by q, rounding using the specified RoundingMode.
divide(int, int) - Static method in class com.google.common.primitives.UnsignedInts
Returns dividend / divisor, where the dividend and divisor are treated as unsigned 32-bit quantities.
divide(long, long) - Static method in class com.google.common.primitives.UnsignedLongs
Returns dividend / divisor, where the dividend and divisor are treated as unsigned 64-bit quantities.
dividedBy(UnsignedInteger) - Method in class com.google.common.primitives.UnsignedInteger
Returns the result of dividing this by val.
dividedBy(UnsignedLong) - Method in class com.google.common.primitives.UnsignedLong
Returns the result of dividing this by val.
DLE - Static variable in class com.google.common.base.Ascii
Data Link Escape: A communication control character which will change the meaning of a limited number of contiguously following characters.
DNT - Static variable in class com.google.common.net.HttpHeaders
The HTTP DNT header field name.
doBackward(B) - Method in class com.google.common.base.Converter
Returns a representation of b as an instance of type A.
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).
doForward(A) - Method in class com.google.common.base.Converter
Returns a representation of a as an instance of type B.
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).
done() - Method in class com.google.common.util.concurrent.ListenableFutureTask
Internal implementation detail used to invoke the listeners.
doNothing() - Static method in class com.google.common.util.concurrent.Runnables
Returns a Runnable instance that does nothing when run.
doStart() - Method in class com.google.common.util.concurrent.AbstractService
This method is called by AbstractService.startAsync() to initiate service startup.
doStop() - Method in class com.google.common.util.concurrent.AbstractService
This method should be used to initiate service shutdown.
DoubleMath - Class in com.google.common.math
A class for arithmetic on doubles that is not covered by Math.
Doubles - Class in com.google.common.primitives
Static utility methods pertaining to double primitives, that are not already found in either Double or Arrays.
doubleValue() - Method in class com.google.common.primitives.UnsignedInteger
Returns the value of this UnsignedInteger as a float, analogous to a widening primitive conversion from int to double, and correctly rounded.
doubleValue() - Method in class com.google.common.primitives.UnsignedLong
Returns the value of this UnsignedLong as a double, analogous to a widening primitive conversion from long to double, and correctly rounded.
doubleValue() - Method in class com.google.common.util.concurrent.AtomicDouble
Returns the value of this AtomicDouble as a double.
downTo(C, BoundType) - Static method in class com.google.common.collect.Range
Returns a range from the given endpoint, which may be either inclusive (closed) or exclusive (open), with no upper bound.
drain(BlockingQueue<E>, Collection<? super E>, int, long, TimeUnit) - Static method in class com.google.common.collect.Queues
Drains the queue as BlockingQueue.drainTo(Collection, int), but if the requested numElements elements are not available, it will wait for them up to the specified timeout.
drainTo(Collection<? super E>) - Method in class com.google.common.collect.ForwardingBlockingDeque
Deprecated.
 
drainTo(Collection<? super E>, int) - 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>, int) - Method in class com.google.common.util.concurrent.ForwardingBlockingDeque
 
drainTo(Collection<? super E>, int) - Method in class com.google.common.util.concurrent.ForwardingBlockingQueue
 
drainTo(Collection<? super E>) - Method in class com.google.common.util.concurrent.ForwardingBlockingQueue
 
drainUninterruptibly(BlockingQueue<E>, Collection<? super E>, int, long, TimeUnit) - Static method in class com.google.common.collect.Queues
Drains the queue as Queues.drain(BlockingQueue, Collection, int, long, TimeUnit), but with a different behavior in case it is interrupted while waiting.

E

edgeConnecting(N, N) - Method in class com.google.common.graph.AbstractNetwork
 
edgeConnecting(N, N) - Method in interface com.google.common.graph.Network
Returns the single edge directly connecting nodeU to nodeV, if one is present, or Optional.empty() if no such edge exists.
edgeConnectingOrNull(N, N) - Method in class com.google.common.graph.AbstractNetwork
 
edgeConnectingOrNull(N, N) - Method in interface com.google.common.graph.Network
Returns the single edge directly connecting nodeU to nodeV, if one is present, or null if no such edge exists.
edgeOrder() - Method in interface com.google.common.graph.Network
Returns the order of iteration for the elements of Network.edges().
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 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 interface com.google.common.graph.ValueGraph
Returns all edges in this graph.
edgesConnecting(N, N) - Method in class com.google.common.graph.AbstractNetwork
 
edgesConnecting(N, N) - Method in interface com.google.common.graph.Network
Returns the set of edges directly connecting nodeU to nodeV.
edgeValue(N, N) - Method in class com.google.common.graph.AbstractValueGraph
 
edgeValue(N, N) - Method in interface com.google.common.graph.ValueGraph
Returns the value of the edge connecting nodeU to nodeV, if one is present; otherwise, returns Optional.empty().
edgeValueOrDefault(N, N, V) - Method in interface com.google.common.graph.ValueGraph
Returns the value of the edge connecting nodeU to nodeV, if one is present; otherwise, returns defaultValue.
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.
elapsed() - Method in class com.google.common.base.Stopwatch
Returns the current elapsed time shown on this stopwatch as a Duration.
element() - Method in class com.google.common.collect.ForwardingQueue
 
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.Type - Enum in com.google.common.graph
The type of ordering that this object specifies.
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() - 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.ImmutableMultiset
 
elementSet() - Method in class com.google.common.collect.ImmutableSortedMultiset
 
elementSet() - Method in interface com.google.common.collect.Multiset
Returns the set of distinct elements contained in this multiset.
elementSet() - Method in interface com.google.common.collect.SortedMultiset
Returns a NavigableSet view of the distinct elements in this multiset.
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<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<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() - 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.
emptyToNull(String) - Static method in class com.google.common.base.Strings
Returns the given string if it is nonempty; null otherwise.
encloseAll(Iterable<C>) - Static method in class com.google.common.collect.Range
Returns the minimal range that contains all of the given values.
encloses(Range<C>) - Method in class com.google.common.collect.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
 
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.
encodedLength(CharSequence) - Static method in class com.google.common.base.Utf8
Returns the number of bytes in the UTF-8-encoded form of sequence.
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.
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.
EndpointPair<N> - Class in com.google.common.graph
An immutable pair representing the two endpoints of an edge in a graph.
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.
ensureCapacity(boolean[], int, int) - Static method in class com.google.common.primitives.Booleans
Returns an array containing the same values as array, but guaranteed to be of a specified minimum length.
ensureCapacity(byte[], int, int) - Static method in class com.google.common.primitives.Bytes
Returns an array containing the same values as array, but guaranteed to be of a specified minimum length.
ensureCapacity(char[], int, int) - Static method in class com.google.common.primitives.Chars
Returns an array containing the same values as array, but guaranteed to be of a specified minimum length.
ensureCapacity(double[], int, int) - Static method in class com.google.common.primitives.Doubles
Returns an array containing the same values as array, but guaranteed to be of a specified minimum length.
ensureCapacity(float[], int, int) - Static method in class com.google.common.primitives.Floats
Returns an array containing the same values as array, but guaranteed to be of a specified minimum length.
ensureCapacity(int[], int, int) - Static method in class com.google.common.primitives.Ints
Returns an array containing the same values as array, but guaranteed to be of a specified minimum length.
ensureCapacity(long[], int, int) - Static method in class com.google.common.primitives.Longs
Returns an array containing the same values as array, but guaranteed to be of a specified minimum length.
ensureCapacity(short[], int, int) - Static method in class com.google.common.primitives.Shorts
Returns an array containing the same values as array, but guaranteed to be of a specified minimum length.
enter() - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor.
enter(long, TimeUnit) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor.
enterIf(Monitor.Guard) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor if the guard is satisfied.
enterIf(Monitor.Guard, long, TimeUnit) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor if the guard is satisfied.
enterIfInterruptibly(Monitor.Guard) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor if the guard is satisfied.
enterIfInterruptibly(Monitor.Guard, long, TimeUnit) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor if the guard is satisfied.
enterInterruptibly() - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor.
enterInterruptibly(long, TimeUnit) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor.
enterWhen(Monitor.Guard) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor when the guard is satisfied.
enterWhen(Monitor.Guard, long, TimeUnit) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor when the guard is satisfied.
enterWhenUninterruptibly(Monitor.Guard) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor when the guard is satisfied.
enterWhenUninterruptibly(Monitor.Guard, long, TimeUnit) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor when the guard is satisfied.
entries() - Method in class com.google.common.collect.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 interface com.google.common.collect.SetMultimap
Returns a view collection of all key-value pairs contained in this multimap, as Map.Entry instances.
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 interface com.google.common.collect.SortedMapDifference
 
entriesInCommon() - Method in interface com.google.common.collect.MapDifference
Returns an unmodifiable map containing the entries that appear in both maps; that is, the intersection of the two maps.
entriesInCommon() - Method in 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 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 interface com.google.common.collect.SortedMapDifference
 
entryIterator() - Method in class com.google.common.collect.ForwardingNavigableMap.StandardDescendingMap
 
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 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.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.reflect.MutableTypeToInstanceMap
 
EnumBiMap<K extends Enum<K>,V extends Enum<V>> - Class in com.google.common.collect
A BiMap backed by two EnumMap instances.
EnumHashBiMap<K extends Enum<K>,V> - Class in com.google.common.collect
A BiMap backed by an EnumMap instance for keys-to-values, and a HashMap instance for values-to-keys.
enumKeys(Class<K0>) - Static method in class com.google.common.collect.MultimapBuilder
Uses an EnumMap to map keys to value collections.
EnumMultiset<E extends Enum<E>> - Class in com.google.common.collect
Multiset implementation backed by an EnumMap.
Enums - Class in com.google.common.base
Utility methods for working with Enum instances.
enumSetValues(Class<V0>) - Method in class com.google.common.collect.MultimapBuilder.MultimapBuilderWithKeys
Uses an EnumSet to store value collections.
EOT - Static variable in class com.google.common.base.Ascii
End of Transmission: A communication control character used to indicate the conclusion of a transmission, which may have contained one or more texts and any associated headings.
EOT - Static variable in class com.google.common.net.MediaType
Media type for Embedded OpenType fonts.
EPUB - Static variable in class com.google.common.net.MediaType
As described in the International Digital Publishing Forum EPUB is the distribution and interchange format standard for digital publications and documents.
equal(Object, Object) - Static method in class com.google.common.base.Objects
Determines whether two possibly-null objects are equal.
equal(File, File) - Static method in class com.google.common.io.Files
Returns true if the given files exist, are not directories, and contain the same bytes.
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.
equals(Object) - Method in class com.google.common.base.Converter
Indicates whether another object is equal to this converter.
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.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.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 interface com.google.common.base.Predicate
Indicates whether another object is equal to this predicate.
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.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.HashBasedTable
 
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 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 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.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 interface com.google.common.collect.SetMultimap
Compares the specified object to this multimap for equality.
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.TreeRangeMap
 
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.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 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.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.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.ImmutableDoubleArray
 
equals(Object) - Method in class com.google.common.primitives.ImmutableIntArray
 
equals(Object) - Method in class com.google.common.primitives.ImmutableLongArray
 
equals(Object) - Method in class com.google.common.primitives.UnsignedInteger
 
equals(Object) - Method in class com.google.common.primitives.UnsignedLong
 
equals(Object) - Method in class com.google.common.reflect.AbstractInvocationHandler
By default delegates to Object.equals(java.lang.Object) so instances are only equal if they are identical.
equals(Object) - Method in class com.google.common.reflect.ClassPath.ResourceInfo
 
equals(Object) - Method in class com.google.common.reflect.Parameter
 
equals(Object) - Method in class com.google.common.reflect.TypeParameter
 
equals(Object) - Method in class com.google.common.reflect.TypeToken
Returns true if o is another TypeToken that represents the same Type.
equalsIgnoreCase(CharSequence, CharSequence) - Static method in class com.google.common.base.Ascii
Indicates whether the contents of the given character sequences s1 and s2 are equal, ignoring the case of any ASCII alphabetic characters between 'a' and 'z' or 'A' and 'Z' inclusive.
equalTo(T) - Static method in class com.google.common.base.Predicates
Returns a predicate that evaluates to true if the object being tested equals() the given target or both are null.
Equivalence<T> - Class in com.google.common.base
A strategy for determining whether two instances are considered equivalent, 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.Wrapper<T> - Class in com.google.common.base
equivalent(T, T) - Method in class com.google.common.base.Equivalence
Returns true if the given objects are considered equivalent.
equivalent(Graph<?>, Graph<?>) - Static method in class com.google.common.graph.Graphs
Deprecated.
Use Graph.equals(Object) instead. This method will be removed in late 2017.
equivalent(ValueGraph<?, ?>, ValueGraph<?, ?>) - Static method in class com.google.common.graph.Graphs
Deprecated.
Use ValueGraph.equals(Object) instead. This method will be removed in late 2017.
equivalent(Network<?, ?>, Network<?, ?>) - Static method in class com.google.common.graph.Graphs
Deprecated.
Use Network.equals(Object) instead. This method will be removed in late 2017.
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.
erase(Object, Object) - Method in class com.google.common.collect.ArrayTable
Associates the value null with the specified keys, assuming both keys are valid.
eraseAll() - Method in class com.google.common.collect.ArrayTable
Associates the value null with every pair of allowed row and column keys.
ESC - Static variable in class com.google.common.base.Ascii
Escape: A control character intended to provide code extension (supplementary characters) in general information interchange.
escape(String) - Method in class com.google.common.escape.ArrayBasedCharEscaper
 
escape(char) - Method in class com.google.common.escape.ArrayBasedCharEscaper
Escapes a single character using the replacement array and safe range values.
escape(String) - Method in class com.google.common.escape.ArrayBasedUnicodeEscaper
 
escape(int) - Method in class com.google.common.escape.ArrayBasedUnicodeEscaper
Escapes a single Unicode code point using the replacement array and safe range values.
escape(String) - Method in class com.google.common.escape.CharEscaper
Returns the escaped form of a given literal string.
escape(char) - Method in class com.google.common.escape.CharEscaper
Returns the escaped form of the given character, or null if this character does not need to be escaped.
escape(String) - Method in class com.google.common.escape.Escaper
Returns the escaped form of a given literal string.
escape(int) - Method in class com.google.common.escape.UnicodeEscaper
Returns the escaped form of the given Unicode code point, or null if this code point does not need to be escaped.
escape(String) - Method in class com.google.common.escape.UnicodeEscaper
Returns the escaped form of a given literal string.
escape(String) - Method in class com.google.common.net.PercentEscaper
 
escape(int) - Method in class com.google.common.net.PercentEscaper
Escapes the given Unicode code point in UTF-8.
Escaper - Class in com.google.common.escape
An object that converts literal text into a format safe for inclusion in a particular context (such as an XML document).
Escaper() - Constructor for class com.google.common.escape.Escaper
Constructor for use by subclasses.
Escapers - Class in com.google.common.escape
Static utility methods pertaining to Escaper instances.
Escapers.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.
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.
EventBus - Class in com.google.common.eventbus
Dispatches events to listeners, and provides ways for listeners to register themselves.
EventBus() - Constructor for class com.google.common.eventbus.EventBus
Creates a new EventBus named "default".
EventBus(String) - Constructor for class com.google.common.eventbus.EventBus
Creates a new EventBus with the given identifier.
EventBus(SubscriberExceptionHandler) - Constructor for class com.google.common.eventbus.EventBus
Creates a new EventBus with the given SubscriberExceptionHandler.
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.
evictionCount() - Method in class com.google.common.cache.CacheStats
Returns the number of times an entry has been evicted.
execute() - Method in class com.google.common.util.concurrent.ExecutionList
Runs this execution list, executing all existing pairs in the order they were added.
execute(Runnable) - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
ExecutionError - Error in com.google.common.util.concurrent
ExecutionError() - Constructor for error com.google.common.util.concurrent.ExecutionError
Creates a new instance with null as its detail message.
ExecutionError(String) - Constructor for error com.google.common.util.concurrent.ExecutionError
Creates a new instance with the given detail message.
ExecutionError(String, Error) - Constructor for error com.google.common.util.concurrent.ExecutionError
Creates a new instance with the given detail message and cause.
ExecutionError(Error) - Constructor for error com.google.common.util.concurrent.ExecutionError
Creates a new instance with the given cause.
ExecutionList - 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.
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
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.
EXPECT - Static variable in class com.google.common.net.HttpHeaders
The HTTP Expect header field name.
expectedEdgeCount(int) - Method in class com.google.common.graph.NetworkBuilder
Specifies the expected number of edges in the network.
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.
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(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.
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.
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.
EXPIRES - Static variable in class com.google.common.net.HttpHeaders
The HTTP Expires header field name.
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.

F

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.
failed(Service.State, Throwable) - Method in class com.google.common.util.concurrent.Service.Listener
Called when the service transitions to the FAILED state.
failure(Service) - Method in class com.google.common.util.concurrent.ServiceManager.Listener
Called when a component service has failed.
failureCause() - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
 
failureCause() - Method in class com.google.common.util.concurrent.AbstractIdleService
 
failureCause() - Method in class com.google.common.util.concurrent.AbstractScheduledService
 
failureCause() - Method in class com.google.common.util.concurrent.AbstractService
 
failureCause() - Method in interface com.google.common.util.concurrent.Service
Returns the Throwable that caused this service to fail.
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
 
falseFirst() - Static method in class com.google.common.primitives.Booleans
Returns a Comparator<Boolean> that sorts false before true.
farmHashFingerprint64() - Static method in class com.google.common.hash.Hashing
Returns a hash function implementing FarmHash's Fingerprint64, an open-source algorithm.
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.
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.
Files - Class in com.google.common.io
Provides utility methods for working with files.
fileTreeTraverser() - Static method in class com.google.common.io.Files
Returns a TreeTraverser instance for File trees.
FileWriteMode - Enum in com.google.common.io
Modes for opening a file for writing.
filter(Collection<E>, Predicate<? super E>) - Static method in class com.google.common.collect.Collections2
Returns the elements of unfiltered that satisfy a predicate.
filter(Predicate<? super E>) - Method in class com.google.common.collect.FluentIterable
Returns the elements from this fluent iterable that satisfy a predicate.
filter(Class<T>) - Method in class com.google.common.collect.FluentIterable
Returns the elements from this fluent iterable that are instances of class type.
filter(Iterable<T>, Predicate<? super T>) - Static method in class com.google.common.collect.Iterables
Returns a view of unfiltered containing all elements that satisfy the input predicate retainIfTrue.
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(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(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(Multiset<E>, Predicate<? super E>) - Static method in class com.google.common.collect.Multisets
Returns a view of the elements of unfiltered that satisfy a predicate.
filter(Set<E>, Predicate<? super E>) - Static method in class com.google.common.collect.Sets
Returns the elements of unfiltered that satisfy a predicate.
filter(SortedSet<E>, Predicate<? super E>) - Static method in class com.google.common.collect.Sets
Returns the elements of a SortedSet, unfiltered, that satisfy a predicate.
filter(NavigableSet<E>, Predicate<? super E>) - Static method in class com.google.common.collect.Sets
Returns the elements of a NavigableSet, unfiltered, that satisfy a predicate.
filterEntries(Map<K, V>, Predicate<? super Map.Entry<K, V>>) - Static method in class com.google.common.collect.Maps
Returns a map containing the mappings in unfiltered that satisfy a predicate.
filterEntries(SortedMap<K, V>, Predicate<? super Map.Entry<K, V>>) - Static method in class com.google.common.collect.Maps
Returns a sorted map containing the mappings in unfiltered that satisfy a predicate.
filterEntries(NavigableMap<K, V>, Predicate<? super Map.Entry<K, V>>) - Static method in class com.google.common.collect.Maps
Returns a sorted map containing the mappings in unfiltered that satisfy a predicate.
filterEntries(BiMap<K, V>, Predicate<? super Map.Entry<K, V>>) - Static method in class com.google.common.collect.Maps
Returns a bimap containing the mappings in unfiltered that satisfy a predicate.
filterEntries(Multimap<K, V>, Predicate<? super Map.Entry<K, V>>) - Static method in class com.google.common.collect.Multimaps
Returns a multimap containing the mappings in unfiltered that satisfy a predicate.
filterEntries(SetMultimap<K, V>, Predicate<? super Map.Entry<K, V>>) - Static method in class com.google.common.collect.Multimaps
Returns a multimap containing the mappings in unfiltered that satisfy a predicate.
filterKeys(Map<K, V>, Predicate<? super K>) - Static method in class com.google.common.collect.Maps
Returns a map containing the mappings in unfiltered whose keys satisfy a predicate.
filterKeys(SortedMap<K, V>, Predicate<? super K>) - Static method in class com.google.common.collect.Maps
Returns a sorted map containing the mappings in unfiltered whose keys satisfy a predicate.
filterKeys(NavigableMap<K, V>, Predicate<? super K>) - Static method in class com.google.common.collect.Maps
Returns a navigable map containing the mappings in unfiltered whose keys satisfy a predicate.
filterKeys(BiMap<K, V>, Predicate<? super K>) - Static method in class com.google.common.collect.Maps
Returns a bimap containing the mappings in unfiltered whose keys satisfy a predicate.
filterKeys(Multimap<K, V>, Predicate<? super K>) - Static method in class com.google.common.collect.Multimaps
Returns a multimap containing the mappings in unfiltered whose keys satisfy a predicate.
filterKeys(SetMultimap<K, V>, Predicate<? super K>) - Static method in class com.google.common.collect.Multimaps
Returns a multimap containing the mappings in unfiltered whose keys satisfy a predicate.
filterKeys(ListMultimap<K, V>, Predicate<? super K>) - Static method in class com.google.common.collect.Multimaps
Returns a multimap containing the mappings in unfiltered whose keys satisfy a predicate.
filterValues(Map<K, V>, Predicate<? super V>) - Static method in class com.google.common.collect.Maps
Returns a map containing the mappings in unfiltered whose values satisfy a predicate.
filterValues(SortedMap<K, V>, Predicate<? super V>) - Static method in class com.google.common.collect.Maps
Returns a sorted map containing the mappings in unfiltered whose values satisfy a predicate.
filterValues(NavigableMap<K, V>, Predicate<? super V>) - Static method in class com.google.common.collect.Maps
Returns a navigable map containing the mappings in unfiltered whose values satisfy a predicate.
filterValues(BiMap<K, V>, Predicate<? super V>) - Static method in class com.google.common.collect.Maps
Returns a bimap containing the mappings in unfiltered whose values satisfy a predicate.
filterValues(Multimap<K, V>, Predicate<? super V>) - Static method in class com.google.common.collect.Multimaps
Returns a multimap containing the mappings in unfiltered whose values satisfy a predicate.
filterValues(SetMultimap<K, V>, Predicate<? super V>) - Static method in class com.google.common.collect.Multimaps
Returns a multimap containing the mappings in unfiltered whose values satisfy a predicate.
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.
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.
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.
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.
find(Iterable<T>, Predicate<? super T>) - Static method in class com.google.common.collect.Iterables
Returns the first element in iterable that satisfies the given predicate; use this method only when such an element is known to exist.
find(Iterable<? extends T>, Predicate<? super T>, T) - Static method in class com.google.common.collect.Iterables
Returns the first element in iterable that satisfies the given predicate, or defaultValue if none found.
find(Iterator<T>, Predicate<? super T>) - Static method in class com.google.common.collect.Iterators
Returns the first element in iterator that satisfies the given predicate; use this method only when such an element is known to exist.
find(Iterator<? extends T>, Predicate<? super T>, T) - Static method in class com.google.common.collect.Iterators
Returns the first element in iterator that satisfies the given predicate.
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.
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(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.
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
 
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 interface com.google.common.collect.SortedMultiset
Returns the entry of the first element in this multiset, or null if this multiset is empty.
firstKey() - Method in class com.google.common.collect.ForwardingSortedMap
 
firstKey() - Method in class com.google.common.collect.ImmutableSortedMap
 
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.
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.
fixedLength(int) - Static method in class com.google.common.base.Splitter
Returns a splitter that divides strings into pieces of the given length.
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.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.Multimaps
Returns a Collector accumulating entries into a Multimap generated from the specified supplier.
Floats - Class in com.google.common.primitives
Static utility methods pertaining to float primitives, that are not already found in either Float or Arrays.
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.ForwardingNavigableSet
 
floor(E) - Method in class com.google.common.collect.ImmutableSortedSet
 
floorEntry(K) - Method in class com.google.common.collect.ForwardingNavigableMap
 
floorEntry(K) - Method in class com.google.common.collect.ImmutableSortedMap
 
floorKey(K) - Method in class com.google.common.collect.ForwardingNavigableMap
 
floorKey(K) - Method in class com.google.common.collect.ImmutableSortedMap
 
floorPowerOfTwo(BigInteger) - Static method in class com.google.common.math.BigIntegerMath
Returns the largest power of two less than or equal to x.
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.
FluentFuture<V> - Class in com.google.common.util.concurrent
A ListenableFuture that supports fluent chains of operations.
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.
flush() - Method in class com.google.common.io.FileBackedOutputStream
 
flush(Flushable, boolean) - Static method in class com.google.common.io.Flushables
Flush a Flushable, with control over whether an IOException may be thrown.
Flushables - Class in com.google.common.io
Utility methods for working with Flushable objects.
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
Media type for Flash video.
FOLLOW_ONLY_WHEN_PRERENDER_SHOWN - Static variable in class com.google.common.net.HttpHeaders
The HTTP Follow-Only-When-Prerender-Shown header field name.
forArray(T...) - Static method in class com.google.common.collect.Iterators
Returns an iterator containing the elements of array in order.
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.
forEach(BiConsumer<? super K, ? super V>) - Method in class com.google.common.collect.HashBiMap
 
forEach(Consumer<? super E>) - Method in class com.google.common.collect.ImmutableList
 
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 interface com.google.common.collect.Multimap
Performs the given action for all key-value pairs contained in this multimap.
forEach(Consumer<? super E>) - Method in interface com.google.common.collect.Multiset
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(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.
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.
forEnumeration(Enumeration<T>) - Static method in class com.google.common.collect.Iterators
Adapts an Enumeration to the Iterator interface.
FORM_DATA - Static variable in class com.google.common.net.MediaType
 
forMap(Map<K, V>) - Static method in class com.google.common.base.Functions
Returns a function which performs a map lookup.
forMap(Map<K, ? extends V>, V) - Static method in class com.google.common.base.Functions
Returns a function which performs a map lookup with a default value.
forMap(Map<K, V>) - Static method in class com.google.common.collect.Multimaps
Returns a multimap view of the specified map.
forNaN() - Static method in class com.google.common.math.LinearTransformation
Builds an instance for datasets which contains Double.NaN.
forPredicate(Predicate<? super Character>) - Static method in class com.google.common.base.CharMatcher
Returns a matcher with identical behavior to the given Character-based predicate, but which operates on primitive char instances instead.
forPredicate(Predicate<T>) - Static method in class com.google.common.base.Functions
Creates a function that returns the same boolean output as the given predicate for all inputs.
forString(String) - Static method in class com.google.common.net.InetAddresses
Returns the InetAddress having the given string representation.
forSupplier(Supplier<T>) - Static method in class com.google.common.base.Functions
Returns a function that ignores its input and returns the result of supplier.get().
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.
FORWARDED - Static variable in class com.google.common.net.HttpHeaders
The HTTP Forwarded header field name.
ForwardingBlockingDeque<E> - Class in com.google.common.collect
Deprecated.
This class has moved to com.google.common.util.concurrent. Please use ForwardingBlockingDeque instead. This class is scheduled for deletion in January 2019.
ForwardingBlockingDeque() - Constructor for class com.google.common.collect.ForwardingBlockingDeque
Deprecated.
Constructor for use by subclasses.
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.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.
ForwardingCheckedFuture<V,X extends Exception> - Class in com.google.common.util.concurrent
Deprecated.
CheckedFuture cannot properly support the chained operations that are the primary goal of ListenableFuture. CheckedFuture also encourages users to rethrow exceptions from one thread in another thread, producing misleading stack traces. Additionally, it has a surprising policy about which exceptions to map and which to leave untouched. Guava users who want a CheckedFuture can fork the classes for their own use, possibly specializing them to the particular exception type they use. We recommend that most people use ListenableFuture and perform any exception wrapping themselves. This class is scheduled for removal from Guava in February 2018.
ForwardingCheckedFuture() - Constructor for class com.google.common.util.concurrent.ForwardingCheckedFuture
Deprecated.
 
ForwardingCheckedFuture.SimpleForwardingCheckedFuture<V,X extends Exception> - Class in com.google.common.util.concurrent
Deprecated.
CheckedFuture cannot properly support the chained operations that are the primary goal of ListenableFuture. CheckedFuture also encourages users to rethrow exceptions from one thread in another thread, producing misleading stack traces. Additionally, it has a surprising policy about which exceptions to map and which to leave untouched. Guava users who want a CheckedFuture can fork the classes for their own use, possibly specializing them to the particular exception type they use. We recommend that most people use ListenableFuture and perform any exception wrapping themselves. This class is scheduled for removal from Guava in February 2018.
ForwardingCollection<E> - Class in com.google.common.collect
A collection which forwards all its method calls to another collection.
ForwardingCollection() - Constructor for class com.google.common.collect.ForwardingCollection
Constructor for use by subclasses.
ForwardingConcurrentMap<K,V> - Class in com.google.common.collect
A concurrent map which forwards all its method calls to another concurrent map.
ForwardingConcurrentMap() - Constructor for class com.google.common.collect.ForwardingConcurrentMap
Constructor for use by subclasses.
ForwardingDeque<E> - Class in com.google.common.collect
A deque which forwards all its method calls to another deque.
ForwardingDeque() - Constructor for class com.google.common.collect.ForwardingDeque
Constructor for use by subclasses.
ForwardingExecutorService - Class in com.google.common.util.concurrent
An executor service which forwards all its method calls to another executor service.
ForwardingExecutorService() - Constructor for class com.google.common.util.concurrent.ForwardingExecutorService
Constructor for use by subclasses.
ForwardingFuture<V> - Class in com.google.common.util.concurrent
A Future which forwards all its method calls to another future.
ForwardingFuture() - Constructor for class com.google.common.util.concurrent.ForwardingFuture
Constructor for use by subclasses.
ForwardingFuture.SimpleForwardingFuture<V> - Class in com.google.common.util.concurrent
A simplified version of ForwardingFuture where subclasses can pass in an already constructed Future as the delegate.
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.
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().
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.
frequency(Iterable<?>, Object) - Static method in class com.google.common.collect.Iterables
Returns the number of elements in the specified iterable that equal the specified object.
frequency(Iterator<?>, Object) - Static method in class com.google.common.collect.Iterators
Returns the number of elements in the specified iterator that equal the specified object.
from(Function<? super A, ? extends B>, Function<? super B, ? extends A>) - Static method in class com.google.common.base.Converter
Returns a converter based on separate forward and backward functions.
from(CacheBuilderSpec) - Static method in class com.google.common.cache.CacheBuilder
Constructs a new CacheBuilder instance with the settings specified in spec.
from(String) - Static method in class com.google.common.cache.CacheBuilder
Constructs a new CacheBuilder instance with the settings specified in spec.
from(Function<K, V>) - Static method in class com.google.common.cache.CacheLoader
Returns a cache loader 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(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(E[]) - Static method in class com.google.common.collect.FluentIterable
Returns a fluent iterable containing elements in the specified order.
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(Comparator<T>) - Static method in class com.google.common.collect.Ordering
Returns an ordering based on an existing comparator instance.
from(Ordering<T>) - Static method in class com.google.common.collect.Ordering
Deprecated.
no need to use this
from(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(String) - Static method in class com.google.common.net.HostSpecifier
Attempts to return a HostSpecifier for the given string, throwing an exception if parsing fails.
FROM - Static variable in class com.google.common.net.HttpHeaders
The HTTP From header field name.
from(String) - Static method in class com.google.common.net.InternetDomainName
Returns an instance of InternetDomainName after lenient validation.
from(ClassLoader) - Static method in class com.google.common.reflect.ClassPath
Returns a ClassPath representing all classes and resources loadable from classloader and its parent class loaders.
from(Method) - Static method in class com.google.common.reflect.Invokable
Returns Invokable of method.
from(Constructor<T>) - Static method in class com.google.common.reflect.Invokable
Returns Invokable of constructor.
from(ListenableFuture<V>) - Static method in class com.google.common.util.concurrent.FluentFuture
Converts the given ListenableFuture to an equivalent FluentFuture.
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, byte, byte) - Static method in class com.google.common.primitives.Ints
Returns the int value whose byte representation is the given 4 bytes, in big-endian order; equivalent to Ints.fromByteArray(new byte[] {b1, b2, b3, b4}).
fromBytes(byte, byte, byte, byte, byte, byte, byte, byte) - Static method in class com.google.common.primitives.Longs
Returns the long value whose byte representation is the given 8 bytes, in big-endian order; equivalent to Longs.fromByteArray(new byte[] {b1, b2, b3, b4, b5, b6, b7, b8}).
fromBytes(byte, byte) - Static method in class com.google.common.primitives.Shorts
Returns the short value whose byte representation is the given 2 bytes, in big-endian order; equivalent to Shorts.fromByteArray(new byte[] {b1, b2}).
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.
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.
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.
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.
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.
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.
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.
Function<F,T> - Interface in com.google.common.base
Legacy version of Function.
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.
Funnel<T> - Interface in com.google.common.hash
An object which can send data from an object of type T into a PrimitiveSink.
funnel(T, PrimitiveSink) - Method in interface com.google.common.hash.Funnel
Sends a stream of data from the from object into the sink into.
Funnels - Class in com.google.common.hash
Funnels for common types.
FutureCallback<V> - Interface in com.google.common.util.concurrent
A callback for accepting the results of a Future computation asynchronously.
Futures - Class in com.google.common.util.concurrent
Static utility methods pertaining to the Future interface.
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.
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

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.
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 interface com.google.common.base.Supplier
Retrieves an instance of the appropriate type.
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) - Method in class com.google.common.cache.ForwardingLoadingCache
 
get(K) - Method in interface com.google.common.cache.LoadingCache
Returns the value associated with key in this cache, first loading that value if necessary.
get(Object, Object) - Method in class com.google.common.collect.ArrayTable
 
get(int) - Method in class com.google.common.collect.FluentIterable
Returns the element at the specified position in this fluent iterable.
get(int) - Method in class com.google.common.collect.ForwardingList
 
get(K) - Method in class com.google.common.collect.ForwardingListMultimap
 
get(Object) - Method in class com.google.common.collect.ForwardingMap
 
get(K) - Method in class com.google.common.collect.ForwardingMultimap
 
get(K) - Method in class com.google.common.collect.ForwardingSetMultimap
 
get(K) - Method in class com.google.common.collect.ForwardingSortedSetMultimap
 
get(Object, Object) - Method in class com.google.common.collect.ForwardingTable
 
get(Object, Object) - Method in class com.google.common.collect.HashBasedTable
 
get(Object) - Method in class com.google.common.collect.HashBiMap
 
get(K) - Method in class com.google.common.collect.ImmutableListMultimap
Returns an immutable list of the values for the given key.
get(Object) - Method in class com.google.common.collect.ImmutableMap
 
get(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(Object) - Method in class com.google.common.collect.ImmutableSortedMap
 
get(Iterable<T>, int) - Static method in class com.google.common.collect.Iterables
Returns the element at the specified position in an iterable.
get(Iterable<? extends T>, int, T) - Static method in class com.google.common.collect.Iterables
Returns the element at the specified position in an iterable or a default value otherwise.
get(Iterator<T>, int) - Static method in class com.google.common.collect.Iterators
Advances iterator position + 1 times, returning the element at the positionth position.
get(Iterator<? extends T>, int, T) - Static method in class com.google.common.collect.Iterators
Advances iterator position + 1 times, returning the element at the positionth position or defaultValue otherwise.
get(K) - Method in class com.google.common.collect.LinkedListMultimap
Returns a view collection of the values associated with key in this multimap, if any.
get(K) - Method in interface com.google.common.collect.ListMultimap
Returns a view collection of the values associated with key in this multimap, if any.
get(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 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(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(K) - Method in class com.google.common.collect.TreeMultimap
 
get(K) - Method in class com.google.common.collect.TreeRangeMap
 
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
Returns the int value present at the given index.
get(int) - Method in class com.google.common.primitives.ImmutableLongArray
Returns the long value present at the given index.
get(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractFuture
get() - Method in class com.google.common.util.concurrent.AbstractFuture
get() - Method in class com.google.common.util.concurrent.AtomicDouble
Gets the current value.
get(int) - Method in class com.google.common.util.concurrent.AtomicDoubleArray
Gets the current value at position i.
get(K) - Method in class com.google.common.util.concurrent.AtomicLongMap
Returns the value associated with key, or zero if there is no value associated with key.
get() - Method in class com.google.common.util.concurrent.ForwardingFuture
 
get(long, TimeUnit) - Method in class com.google.common.util.concurrent.ForwardingFuture
 
get(Object) - Method in class com.google.common.util.concurrent.Striped
Returns the stripe that corresponds to the passed key.
get6to4IPv4Address(Inet6Address) - Static method in class com.google.common.net.InetAddresses
Returns the IPv4 address embedded in a 6to4 address.
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.
getAllClasses() - Method in class com.google.common.reflect.ClassPath
Returns all classes loadable from the current class path.
getAllPresent(Iterable<?>) - Method in class com.google.common.cache.AbstractCache
Returns a map of the values associated with keys in this cache.
getAllPresent(Iterable<?>) - Method in interface com.google.common.cache.Cache
Returns a map of the values associated with keys in this cache.
getAllPresent(Iterable<?>) - Method in class com.google.common.cache.ForwardingCache
 
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.
getAndSet(double) - Method in class com.google.common.util.concurrent.AtomicDouble
Atomically sets to the given value and returns the old value.
getAndSet(int, double) - Method in class com.google.common.util.concurrent.AtomicDoubleArray
Atomically sets the element at position i to the given value and returns the old value.
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.
getAnnotation(Class<A>) - Method in class com.google.common.reflect.Parameter
 
getAnnotations() - Method in class com.google.common.reflect.Parameter
 
getAnnotationsByType(Class<A>) - Method in class com.google.common.reflect.Parameter
 
getAt(int) - Method in class com.google.common.util.concurrent.Striped
Returns the stripe at the specified index.
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.
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>, 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.
getClient() - Method in class com.google.common.net.InetAddresses.TeredoInfo
 
getCoercedIPv4Address(InetAddress) - Static method in class com.google.common.net.InetAddresses
Coerces an IPv6 address into an IPv4 address.
getColumnKey() - Method in interface com.google.common.collect.Table.Cell
Returns the column key of this cell.
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.
getConflictingStackTrace() - Method in exception com.google.common.util.concurrent.CycleDetectingLockFactory.PotentialDeadlockException
 
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.io.CountingInputStream
Returns the number of bytes read.
getCount() - Method in class com.google.common.io.CountingOutputStream
Returns the number of bytes written.
getDeclaredAnnotation(Class<A>) - Method in class com.google.common.reflect.Parameter
 
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
 
getDeclaringInvokable() - Method in class com.google.common.reflect.Parameter
Returns the Invokable that declares this parameter.
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.
getElement() - Method in interface com.google.common.collect.Multiset.Entry
Returns the multiset element corresponding to this entry.
getEmbeddedIPv4ClientAddress(Inet6Address) - Static method in class com.google.common.net.InetAddresses
Examines the Inet6Address to extract the embedded IPv4 client address if the InetAddress is an IPv6 address of one of the specified address types that contain an embedded IPv4 address.
getEntry(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
 
getEvent() - Method in class com.google.common.eventbus.DeadEvent
Returns the wrapped, 'dead' event, which the system was unable to deliver to any registered subscriber.
getEvent() - Method in class com.google.common.eventbus.SubscriberExceptionContext
 
getEventBus() - Method in class com.google.common.eventbus.SubscriberExceptionContext
 
getExceptionTypes() - Method in class com.google.common.reflect.Invokable
Returns all declared exception types of this Invokable.
getExitingExecutorService(ThreadPoolExecutor, long, TimeUnit) - Static method in class com.google.common.util.concurrent.MoreExecutors
Converts the given ThreadPoolExecutor into an ExecutorService that exits when the application is complete.
getExitingExecutorService(ThreadPoolExecutor) - Static method in class com.google.common.util.concurrent.MoreExecutors
Converts the given ThreadPoolExecutor into an ExecutorService that exits when the application is complete.
getExitingScheduledExecutorService(ScheduledThreadPoolExecutor, long, TimeUnit) - Static method in class com.google.common.util.concurrent.MoreExecutors
Converts the given ScheduledThreadPoolExecutor into a ScheduledExecutorService that exits when the application is complete.
getExitingScheduledExecutorService(ScheduledThreadPoolExecutor) - Static method in class com.google.common.util.concurrent.MoreExecutors
Converts the given ScheduledThreadPoolExecutor into a ScheduledExecutorService that exits when the application is complete.
getField(Enum<?>) - Static method in class com.google.common.base.Enums
Returns the Field in which enumValue is defined.
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.
getFirst() - Method in class com.google.common.collect.ForwardingDeque
 
getFirst(Iterable<? extends T>, T) - Static method in class com.google.common.collect.Iterables
Returns the first element in iterable or defaultValue if the iterable is empty.
getFlags() - Method in class com.google.common.net.InetAddresses.TeredoInfo
 
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.
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
 
getInstance(Class<T>) - Method in interface com.google.common.collect.ClassToInstanceMap
Returns the value the specified class is mapped to, or null if no entry for this class is present.
getInstance(Class<T>) - Method in class com.google.common.collect.ImmutableClassToInstanceMap
 
getInstance(Class<T>) - Method in class com.google.common.collect.MutableClassToInstanceMap
 
getInstance(TypeToken<T>) - Method in class com.google.common.reflect.ImmutableTypeToInstanceMap
 
getInstance(Class<T>) - Method in class com.google.common.reflect.ImmutableTypeToInstanceMap
 
getInstance(Class<T>) - Method in class com.google.common.reflect.MutableTypeToInstanceMap
 
getInstance(TypeToken<T>) - Method in class com.google.common.reflect.MutableTypeToInstanceMap
 
getInstance(Class<T>) - Method in interface com.google.common.reflect.TypeToInstanceMap
Returns the value the specified class is mapped to, or null if no entry for this class is present.
getInstance(TypeToken<T>) - Method in interface com.google.common.reflect.TypeToInstanceMap
Returns the value the specified type is mapped to, or null if no entry for this type is present.
getIsatapIPv4Address(Inet6Address) - Static method in class com.google.common.net.InetAddresses
Returns the IPv4 address embedded in an ISATAP address.
getKey() - Method in class com.google.common.collect.ForwardingMapEntry
 
getLast() - Method in class com.google.common.collect.ForwardingDeque
 
getLast(Iterable<T>) - Static method in class com.google.common.collect.Iterables
Returns the last element of iterable.
getLast(Iterable<? extends T>, T) - Static method in class com.google.common.collect.Iterables
Returns the last element of iterable or defaultValue if the iterable is empty.
getLast(Iterator<T>) - Static method in class com.google.common.collect.Iterators
Advances iterator to the end, returning the last element.
getLast(Iterator<? extends T>, T) - Static method in class com.google.common.collect.Iterators
Advances iterator to the end, returning the last element or defaultValue if the iterator is empty.
getMessage() - Method in exception com.google.common.util.concurrent.CycleDetectingLockFactory.PotentialDeadlockException
Appends the chain of messages from the conflictingStackTrace to the original message.
getName() - Method in class com.google.common.reflect.ClassPath.ClassInfo
Returns the fully qualified name of the class.
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(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.
getNextSchedule() - Method in class com.google.common.util.concurrent.AbstractScheduledService.CustomScheduler
Calculates the time at which to next invoke the task.
getOccupiedDepth() - Method in class com.google.common.util.concurrent.Monitor
Returns the number of times the current thread has entered this monitor in excess of the number of times it has left.
getOnlyElement(Iterable<T>) - Static method in class com.google.common.collect.Iterables
Returns the single element contained in iterable.
getOnlyElement(Iterable<? extends T>, T) - Static method in class com.google.common.collect.Iterables
Returns the single element contained in iterable, or defaultValue if the iterable is empty.
getOnlyElement(Iterator<T>) - Static method in class com.google.common.collect.Iterators
Returns the single element contained in iterator.
getOnlyElement(Iterator<? extends T>, T) - Static method in class com.google.common.collect.Iterators
Returns the single element contained in iterator, or defaultValue if the iterator is empty.
getOrDefault(Object, V) - Method in class com.google.common.collect.ImmutableMap
 
getOwnerType() - Method in class com.google.common.reflect.Invokable
Returns the type of T.
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).
getParameters() - Method in class com.google.common.reflect.Invokable
Returns all declared parameters of this Invokable.
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.
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.TypeToken
Returns the raw type of T.
getResource(String) - Static method in class com.google.common.io.Resources
Returns a URL pointing to resourceName if the resource is found using the context class loader.
getResource(Class<?>, String) - Static method in class com.google.common.io.Resources
Given a resourceName that is relative to contextClass, returns a URL pointing to the named resource.
getResourceName() - Method in class com.google.common.reflect.ClassPath.ResourceInfo
Returns the fully qualified name of the resource.
getResources() - Method in class com.google.common.reflect.ClassPath
Returns all resources loadable from the current class path, including the class files of all loadable classes but excluding the "META-INF/MANIFEST.MF" file.
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.
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.
getServer() - Method in class com.google.common.net.InetAddresses.TeredoInfo
 
getSimpleName() - Method in class com.google.common.reflect.ClassPath.ClassInfo
Returns the simple name of the underlying class as given in the source code.
getSource() - Method in class com.google.common.eventbus.DeadEvent
Returns the object that originated this event (not the object that originated the wrapped event).
getStackTraceAsString(Throwable) - Static method in class com.google.common.base.Throwables
Returns a string containing the result of toString(), followed by the full, recursive stack trace of throwable.
getSubscriber() - Method in class com.google.common.eventbus.SubscriberExceptionContext
 
getSubscriberMethod() - Method in class com.google.common.eventbus.SubscriberExceptionContext
 
getSubtype(Class<?>) - Method in class com.google.common.reflect.TypeToken
Returns subtype of this with subclass as the raw class.
getSupertype(Class<? super T>) - Method in class com.google.common.reflect.TypeToken
Returns the generic form of superclass.
getTeredoInfo(Inet6Address) - Static method in class com.google.common.net.InetAddresses
Returns the Teredo information embedded in a Teredo address.
getTopLevelClasses() - Method in class com.google.common.reflect.ClassPath
Returns all top level classes loadable from the current class path.
getTopLevelClasses(String) - Method in class com.google.common.reflect.ClassPath
Returns all top level classes whose package name is packageName.
getTopLevelClassesRecursive(String) - Method in class com.google.common.reflect.ClassPath
Returns all top level classes whose package name is packageName or starts with packageName followed by a '.'.
getType() - Method in class com.google.common.reflect.Parameter
Returns the type of the parameter.
getType() - Method in class com.google.common.reflect.TypeToken
Returns the represented type.
getTypes() - Method in class com.google.common.reflect.TypeToken
Returns the set of interfaces and classes that this type is or is a subtype of.
getUnchecked(K) - Method in class com.google.common.cache.AbstractLoadingCache
 
getUnchecked(K) - Method in class com.google.common.cache.ForwardingLoadingCache
 
getUnchecked(K) - Method in interface com.google.common.cache.LoadingCache
Returns the value associated with key in this cache, first loading that value if necessary.
getUnchecked(Future<V>) - Static method in class com.google.common.util.concurrent.Futures
Returns the result of calling Future.get() uninterruptibly on a task known not to throw a checked exception.
getUninterruptibly(Future<V>) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes future.get() uninterruptibly.
getUninterruptibly(Future<V>, long, TimeUnit) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes future.get(timeout, unit) uninterruptibly.
getValue() - Method in class com.google.common.collect.ForwardingMapEntry
 
getValue() - Method in interface com.google.common.collect.Table.Cell
Returns the value of this cell.
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.
GIF - Static variable in class com.google.common.net.MediaType
 
goodFastHash(int) - Static method in class com.google.common.hash.Hashing
Returns a general-purpose, temporary-use, non-cryptographic hash function.
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 with user-defined properties.
Graphs - Class in com.google.common.graph
Static utility methods for Graph, ValueGraph, and Network instances.
greaterThan(C) - Static method in class com.google.common.collect.Range
Returns a range that contains all values strictly greater than endpoint.
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.
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.
GS - Static variable in class com.google.common.base.Ascii
Group Separator: These four information separators may be used within data in optional fashion, except that their hierarchical relationship shall be: FS is the most inclusive, then GS, then RS, and US is least inclusive.
Guard(Monitor) - Constructor for class com.google.common.util.concurrent.Monitor.Guard
 
GwtCompatible - Annotation Type in com.google.common.annotations
The presence of this annotation on a type indicates that the type may be used with the Google Web Toolkit (GWT).
GwtIncompatible - Annotation Type in com.google.common.annotations
The presence of this annotation on an API indicates that the method may not be used with the Google Web Toolkit (GWT).
GZIP - Static variable in class com.google.common.net.MediaType
 

H

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
handlePotentialDeadlock(CycleDetectingLockFactory.PotentialDeadlockException) - Method in interface com.google.common.util.concurrent.CycleDetectingLockFactory.Policy
Called when a potential deadlock is encountered.
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(N, N) - Method in class com.google.common.graph.AbstractNetwork
 
hasEdgeConnecting(N, N) - Method in interface com.google.common.graph.Graph
Returns true if there is an edge directly connecting nodeU to nodeV.
hasEdgeConnecting(N, N) - Method in interface com.google.common.graph.Network
Returns true if there is an edge directly connecting nodeU to nodeV.
hasEdgeConnecting(N, N) - Method in interface com.google.common.graph.ValueGraph
Returns true if there is an edge directly connecting nodeU to nodeV.
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(T) - Method in class com.google.common.base.Equivalence
Returns a hash code for t.
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(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). This method is scheduled to be removed in January 2019.
HashBasedTable<R,C,V> - Class in com.google.common.collect
Implementation of Table using linked hash tables.
HashBiMap<K,V> - Class in com.google.common.collect
A BiMap backed by two hash tables.
hashBytes(byte[]) - Method in interface com.google.common.hash.HashFunction
Shortcut for newHasher().putBytes(input).hash().
hashBytes(byte[], int, int) - Method in interface com.google.common.hash.HashFunction
Shortcut for newHasher().putBytes(input, off, len).hash().
hashBytes(ByteBuffer) - Method in interface com.google.common.hash.HashFunction
Shortcut for newHasher().putBytes(input).hash().
hashCode() - Method in class com.google.common.base.Equivalence.Wrapper
Returns the result of Equivalence.hash(Object) applied to the wrapped reference.
hashCode(Object...) - Static method in class com.google.common.base.Objects
Generates a hash code for multiple values.
hashCode() - Method in class com.google.common.base.Optional
Returns a hash code for this instance.
hashCode() - Method in class com.google.common.cache.CacheBuilderSpec
 
hashCode() - Method in class com.google.common.cache.CacheStats
 
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.ImmutableList
 
hashCode() - Method in class com.google.common.collect.ImmutableMap
 
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 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 interface com.google.common.collect.Multimap
Returns the hash code for this multimap.
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.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 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.TreeRangeMap
 
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.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 interface com.google.common.graph.Graph
Returns the hash code for this graph.
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 - Class in com.google.common.hash
An immutable hash code of arbitrary bit length.
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.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(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() - 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
Returns an unspecified hash code for the contents of this immutable array.
hashCode() - Method in class com.google.common.primitives.ImmutableLongArray
Returns an unspecified hash code for the contents of this immutable array.
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() - Method in class com.google.common.primitives.UnsignedInteger
 
hashCode() - Method in class com.google.common.primitives.UnsignedLong
 
hashCode() - Method in class com.google.common.reflect.AbstractInvocationHandler
By default delegates to Object.hashCode().
hashCode() - Method in class com.google.common.reflect.ClassPath.ResourceInfo
 
hashCode() - Method in class com.google.common.reflect.Parameter
 
hashCode() - Method in class com.google.common.reflect.TypeParameter
 
hashCode() - Method in class com.google.common.reflect.TypeToken
 
Hasher - Interface in com.google.common.hash
A PrimitiveSink that can compute a hash code after reading the input.
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.hash
Static methods to obtain HashFunction instances, and other static hashing-related utilities.
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 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.
hashKeys() - Static method in class com.google.common.collect.MultimapBuilder
Uses a HashMap to map keys to value collections.
hashKeys(int) - Static method in class com.google.common.collect.MultimapBuilder
Uses a HashMap to map keys to value collections, initialized to expect the specified number of keys.
hashLong(long) - Method in 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.
HashMultimap<K,V> - Class in com.google.common.collect
Implementation of Multimap using hash tables.
HashMultiset<E> - Class in com.google.common.collect
Multiset implementation backed by a HashMap.
hashObject(T, Funnel<? super T>) - Method in interface com.google.common.hash.HashFunction
Shortcut for newHasher().putObject(instance, funnel).hash().
hashSetValues() - Method in class com.google.common.collect.MultimapBuilder.MultimapBuilderWithKeys
Uses a HashSet to store value collections.
hashSetValues(int) - Method in class com.google.common.collect.MultimapBuilder.MultimapBuilderWithKeys
Uses a HashSet to store value collections, initialized to expect the specified number of values per key.
hashString(CharSequence, Charset) - Method in interface com.google.common.hash.HashFunction
Shortcut for newHasher().putString(input, charset).hash().
hashUnencodedChars(CharSequence) - Method in interface com.google.common.hash.HashFunction
Shortcut for newHasher().putUnencodedChars(input).hash().
hasLowerBound() - Method in class com.google.common.collect.Range
Returns true if this range has a lower endpoint.
hasNext() - Method in class com.google.common.collect.AbstractIterator
 
hasNext() - Method in class com.google.common.collect.AbstractSequentialIterator
 
hasNext() - Method in class com.google.common.collect.ForwardingIterator
 
hasParent() - Method in class com.google.common.net.InternetDomainName
Indicates whether this domain is composed of two or more parts.
hasPort() - Method in class com.google.common.net.HostAndPort
Return true if this instance has a defined port.
hasPrevious() - Method in class com.google.common.collect.ForwardingListIterator
 
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.
hasUpperBound() - Method in class com.google.common.collect.Range
Returns true if this range has an upper endpoint.
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.
headMap(K, boolean) - Method in class com.google.common.collect.ForwardingNavigableMap
 
headMap(K) - Method in class com.google.common.collect.ForwardingSortedMap
 
headMap(K) - Method in class com.google.common.collect.ImmutableSortedMap
This method returns a ImmutableSortedMap, consisting of the entries whose keys are less than toKey.
headMap(K, boolean) - Method in class com.google.common.collect.ImmutableSortedMap
This method returns a ImmutableSortedMap, consisting of the entries whose keys are less than (or equal to, if inclusive) toKey.
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 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
 
headSet(C) - Method in class com.google.common.collect.ContiguousSet
 
headSet(C, boolean) - Method in class com.google.common.collect.ContiguousSet
 
headSet(E, boolean) - Method in class com.google.common.collect.ForwardingNavigableSet
 
headSet(E) - Method in class com.google.common.collect.ForwardingSortedSet
 
headSet(E) - Method in class com.google.common.collect.ImmutableSortedSet
headSet(E, boolean) - Method in class com.google.common.collect.ImmutableSortedSet
 
healthy() - Method in class com.google.common.util.concurrent.ServiceManager.Listener
Called when the service initially becomes healthy.
higher(E) - Method in class com.google.common.collect.ForwardingNavigableSet
 
higher(E) - Method in class com.google.common.collect.ImmutableSortedSet
 
higherEntry(K) - Method in class com.google.common.collect.ForwardingNavigableMap
 
higherEntry(K) - Method in class com.google.common.collect.ImmutableSortedMap
 
higherKey(K) - Method in class com.google.common.collect.ForwardingNavigableMap
 
higherKey(K) - Method in class com.google.common.collect.ImmutableSortedMap
 
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(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.
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.
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.
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.
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.
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.
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.
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.
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 - 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.
HostSpecifier - Class in com.google.common.net
A syntactically valid host specifier, suitable for use in a URI.
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_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.
HttpHeaders - Class in com.google.common.net
Contains constant definitions for the HTTP header field names.

I

I_CALENDAR_UTF_8 - Static variable in class com.google.common.net.MediaType
 
ICO - Static variable in class com.google.common.net.MediaType
 
identifier() - Method in class com.google.common.eventbus.EventBus
Returns the identifier for this event bus.
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.
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.
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.
immediateCheckedFuture(V) - Static method in class com.google.common.util.concurrent.Futures
Deprecated.
CheckedFuture cannot properly support the chained operations that are the primary goal of ListenableFuture. CheckedFuture also encourages users to rethrow exceptions from one thread in another thread, producing misleading stack traces. Additionally, it has a surprising policy about which exceptions to map and which to leave untouched. Guava users who want a CheckedFuture can fork the classes for their own use, possibly specializing them to the particular exception type they use. We recommend that most people use ListenableFuture and perform any exception wrapping themselves. This method is scheduled for removal from Guava in February 2018.
immediateFailedCheckedFuture(X) - Static method in class com.google.common.util.concurrent.Futures
Deprecated.
CheckedFuture cannot properly support the chained operations that are the primary goal of ListenableFuture. CheckedFuture also encourages users to rethrow exceptions from one thread in another thread, producing misleading stack traces. Additionally, it has a surprising policy about which exceptions to map and which to leave untouched. Guava users who want a CheckedFuture can fork the classes for their own use, possibly specializing them to the particular exception type they use. We recommend that most people use ListenableFuture and perform any exception wrapping themselves. This method is scheduled for removal from Guava in February 2018.
immediateFailedFuture(Throwable) - Static method in class com.google.common.util.concurrent.Futures
Returns a ListenableFuture which has an exception set immediately upon construction.
immediateFuture(V) - Static method in class com.google.common.util.concurrent.Futures
Creates a ListenableFuture which has its value set immediately upon construction.
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.Builder<K,V> - Class in com.google.common.collect
A builder for creating immutable bimap instances, especially public static final bimaps ("constant bimaps").
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.
ImmutableClassToInstanceMap<B> - Class in com.google.common.collect
A ClassToInstanceMap whose contents will never change, with many other important properties detailed at ImmutableCollection.
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.Builder<E> - Class in com.google.common.collect
Abstract base class for builders of ImmutableCollection types.
immutableCopy() - Method in class com.google.common.collect.Sets.SetView
Returns an immutable copy of the current contents of this set view.
ImmutableDoubleArray - Class in com.google.common.primitives
An immutable array of double values, with an API resembling List.
ImmutableDoubleArray.Builder - Class in com.google.common.primitives
A builder for ImmutableDoubleArray instances; obtained using ImmutableDoubleArray.builder(int).
immutableEntry(K, V) - Static method in class com.google.common.collect.Maps
Returns an immutable map entry with the specified key and value.
immutableEntry(E, int) - Static method in class com.google.common.collect.Multisets
Returns an immutable multiset entry with the specified element and count.
immutableEnumMap(Map<K, ? extends V>) - Static method in class com.google.common.collect.Maps
Returns an immutable map instance containing the given entries.
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.
ImmutableGraph<N> - Class in com.google.common.graph
A Graph whose elements and structural relationships will never change.
ImmutableIntArray - Class in com.google.common.primitives
An immutable array of int values, with an API resembling List.
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.Builder<E> - Class in com.google.common.collect
A builder for creating immutable list instances, especially public static final lists ("constant lists").
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.Builder<K,V> - Class in com.google.common.collect
A builder for creating immutable ListMultimap instances, especially public static final multimaps ("constant multimaps").
ImmutableLongArray - Class in com.google.common.primitives
An immutable array of long values, with an API resembling List.
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.Builder<K,V> - Class in com.google.common.collect
A builder for creating immutable map instances, especially public static final maps ("constant maps").
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.Builder<K,V> - Class in com.google.common.collect
A builder for creating immutable multimap instances, especially public static final multimaps ("constant multimaps").
ImmutableMultiset<E> - Class in com.google.common.collect
A Multiset whose contents will never change, with many other important properties detailed at ImmutableCollection.
ImmutableMultiset.Builder<E> - Class in com.google.common.collect
A builder for creating immutable multiset instances, especially public static final multisets ("constant multisets").
ImmutableNetwork<N,E> - Class in com.google.common.graph
A Network whose elements and structural relationships will never change.
ImmutableRangeMap<K extends Comparable<?>,V> - Class in com.google.common.collect
A RangeMap whose contents will never change, with many other important properties detailed at ImmutableCollection.
ImmutableRangeMap.Builder<K extends Comparable<?>,V> - Class in com.google.common.collect
A builder for immutable range maps.
ImmutableRangeSet<C extends Comparable> - Class in com.google.common.collect
A RangeSet whose contents will never change, with many other important properties detailed at ImmutableCollection.
ImmutableRangeSet.Builder<C extends Comparable<?>> - Class in com.google.common.collect
A builder for immutable range sets.
ImmutableSet<E> - Class in com.google.common.collect
A Set whose contents will never change, with many other important properties detailed at ImmutableCollection.
ImmutableSet.Builder<E> - Class in com.google.common.collect
A builder for creating ImmutableSet instances.
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.Builder<K,V> - Class in com.google.common.collect
A builder for creating immutable SetMultimap instances, especially public static final multimaps ("constant multimaps").
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.Builder<K,V> - Class in com.google.common.collect
A builder for creating immutable sorted map instances, especially public static final maps ("constant maps").
ImmutableSortedMultiset<E> - Class in com.google.common.collect
A SortedMultiset whose contents will never change, with many other important properties detailed at ImmutableCollection.
ImmutableSortedMultiset.Builder<E> - Class in com.google.common.collect
A builder for creating immutable multiset instances, especially public static final multisets ("constant multisets").
ImmutableSortedSet<E> - Class in com.google.common.collect
A NavigableSet whose contents will never change, with many other important properties detailed at ImmutableCollection.
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.
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.Builder<R,C,V> - Class in com.google.common.collect
A builder for creating immutable table instances, especially public static final tables ("constant tables").
ImmutableTypeToInstanceMap<B> - Class in com.google.common.reflect
A type-to-instance map backed by an ImmutableMap.
ImmutableTypeToInstanceMap.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.
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.
incidentEdges(N) - Method in interface com.google.common.graph.Network
Returns the edges whose incident nodes in this network include node.
incidentNodes(E) - Method in interface com.google.common.graph.Network
Returns the nodes which are the endpoints of edge in this network.
inCompletionOrder(Iterable<? extends ListenableFuture<? extends T>>) - Static method in class com.google.common.util.concurrent.Futures
Returns a list of delegate futures that correspond to the futures received in the order that they complete.
increment(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.
inDegree(N) - Method in class com.google.common.graph.AbstractNetwork
 
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 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(Function<? super E, K>) - Method in class com.google.common.collect.FluentIterable
Creates an index ImmutableListMultimap that contains the results of applying a specified function to each item in this FluentIterable of values.
index(Iterable<V>, Function<? super V, K>) - Static method in class com.google.common.collect.Multimaps
Creates an index ImmutableListMultimap that contains the results of applying a specified function to each item in an Iterable of values.
index(Iterator<V>, Function<? super V, K>) - Static method in class com.google.common.collect.Multimaps
Creates an index ImmutableListMultimap that contains the results of applying a specified function to each item in an Iterator of values.
index(int) - Method in class com.google.common.math.Quantiles.Scale
Specifies a single quantile index to be calculated, i.e.
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.
indexIn(CharSequence) - Method in class com.google.common.base.CharMatcher
Returns the index of the first matching character in a character sequence, or -1 if no matching character is present.
indexIn(CharSequence, int) - Method in class com.google.common.base.CharMatcher
Returns the index of the first matching character in a character sequence, starting from a given position, or -1 if no character matches after that position.
indexOf(Object) - Method in class com.google.common.collect.ForwardingList
 
indexOf(Object) - Method in class com.google.common.collect.ImmutableList
 
indexOf(Iterable<T>, Predicate<? super T>) - Static method in class com.google.common.collect.Iterables
Returns the index in iterable of the first element that satisfies the provided predicate, or -1 if the Iterable has no such elements.
indexOf(Iterator<T>, Predicate<? super T>) - Static method in class com.google.common.collect.Iterators
Returns the index in iterator of the first element that satisfies the provided predicate, or -1 if the Iterator has no such elements.
indexOf(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(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(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(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(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(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(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(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(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(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(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.
inducedSubgraph(Graph<N>, Iterable<? extends N>) - Static method in class com.google.common.graph.Graphs
Returns the subgraph of graph 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.
inducedSubgraph(Network<N, E>, Iterable<? extends N>) - Static method in class com.google.common.graph.Graphs
Returns the subgraph of network induced by nodes.
inEdges(N) - Method in interface com.google.common.graph.Network
Returns all edges in this network which can be traversed in the direction (if any) of the edge to end at node.
InetAddresses - Class in com.google.common.net
Static utility methods pertaining to InetAddress instances.
InetAddresses.TeredoInfo - Class in com.google.common.net
A simple immutable data class to encapsulate the information to be found in a Teredo address.
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.
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.
inOrderTraversal(T) - Method in class com.google.common.collect.BinaryTreeTraverser
 
inRange(char, char) - Static method in class com.google.common.base.CharMatcher
Returns a char matcher that matches any character in a given range (both endpoints are inclusive).
InsecureRecursiveDeleteException - Exception 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 com.google.common.io.InsecureRecursiveDeleteException
 
insertion() - Static method in class com.google.common.graph.ElementOrder
Returns an instance which specifies that insertion ordering is guaranteed.
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.
integerFunnel() - Static method in class com.google.common.hash.Funnels
Returns a funnel for integers.
integers() - Static method in class com.google.common.collect.DiscreteDomain
Returns the discrete domain for values of type Integer.
interfaces() - Method in class com.google.common.reflect.TypeToken.TypeSet
Returns the types that are interfaces implemented by this type.
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.
Interner<E> - Interface in com.google.common.collect
Provides equivalent behavior to String.intern() for other immutable types.
Interners - Class in com.google.common.collect
Contains static methods pertaining to instances of Interner.
Interners.InternerBuilder - Class in com.google.common.collect
Builder for Interner instances.
InternetDomainName - Class in com.google.common.net
An immutable well-formed internet domain name, such as com or foo.co.uk.
interruptTask() - Method in class com.google.common.util.concurrent.AbstractFuture
Subclasses can override this method to implement interruption of the future's computation.
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(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(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(Set<E>, Set<?>) - Static method in class com.google.common.collect.Sets
Returns an unmodifiable view of the intersection of two sets.
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
 
IntMath - Class in com.google.common.math
A class for arithmetic on values of type int.
Ints - Class in com.google.common.primitives
Static utility methods pertaining to int primitives, that are not already found in either Integer or Arrays.
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.
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
 
invalidateAll(Iterable<?>) - Method in class com.google.common.cache.AbstractCache
 
invalidateAll() - Method in class com.google.common.cache.AbstractCache
 
invalidateAll(Iterable<?>) - Method in interface com.google.common.cache.Cache
Discards any cached values for keys keys.
invalidateAll() - Method in interface com.google.common.cache.Cache
Discards all entries in the cache.
invalidateAll(Iterable<?>) - Method in class com.google.common.cache.ForwardingCache
 
invalidateAll() - Method in class com.google.common.cache.ForwardingCache
 
InvalidCacheLoadException(String) - Constructor for exception com.google.common.cache.CacheLoader.InvalidCacheLoadException
 
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.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.math.LinearTransformation
Returns the inverse linear transformation.
invertFrom(Multimap<? extends V, ? extends K>, M) - Static method in class com.google.common.collect.Multimaps
Copies each key-value mapping in source into dest, with its key and value reversed.
INVISIBLE - Static variable in class com.google.common.base.CharMatcher
Deprecated.
Use CharMatcher.invisible() instead. This constant is scheduled to be removed in June 2018.
invisible() - Static method in class com.google.common.base.CharMatcher
Determines whether a character is invisible; that is, if its Unicode category is any of SPACE_SEPARATOR, LINE_SEPARATOR, PARAGRAPH_SEPARATOR, CONTROL, FORMAT, SURROGATE, and PRIVATE_USE according to ICU4J.
Invokable<T,R> - Class in com.google.common.reflect
Wrapper around either a Method or a Constructor.
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(T, Object...) - Method in class com.google.common.reflect.Invokable
Invokes with receiver as 'this' and args passed to the underlying method and returns the return value; or calls the underlying constructor with args and returns the constructed instance.
invokeAll(Collection<? extends Callable<T>>) - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
invokeAll(Collection<? extends Callable<T>>) - Method in interface com.google.common.util.concurrent.ListeningExecutorService
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in interface com.google.common.util.concurrent.ListeningExecutorService
invokeAny(Collection<? extends Callable<T>>) - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
is(char) - Static method in class com.google.common.base.CharMatcher
Returns a char matcher that matches only one specified character.
is(MediaType) - Method in class com.google.common.net.MediaType
Returns true if this instance falls within the range (as defined by the HTTP Accept header) given by the argument according to three criteria: The type of the argument is the wildcard or equal to the type of this instance.
is6to4Address(Inet6Address) - Static method in class com.google.common.net.InetAddresses
Evaluates whether the argument is a 6to4 address.
isAnnotationPresent(Class<? extends Annotation>) - Method in class com.google.common.reflect.Parameter
 
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.ForwardingFuture
 
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.
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 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.
isDone() - Method in class com.google.common.util.concurrent.AbstractFuture
 
isDone() - Method in class com.google.common.util.concurrent.ForwardingFuture
 
isEmpty() - Method in class com.google.common.collect.ArrayTable
Always returns false.
isEmpty() - Method in class com.google.common.collect.ConcurrentHashMultiset
 
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.ImmutableMap
 
isEmpty() - Method in class com.google.common.collect.ImmutableRangeSet
 
isEmpty(Iterable<?>) - Static method in class com.google.common.collect.Iterables
Determines if the given iterable contains no elements.
isEmpty() - Method in class com.google.common.collect.LinkedListMultimap
 
isEmpty() - Method in interface com.google.common.collect.Multimap
Returns true if this multimap contains no key-value pairs.
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 interface com.google.common.collect.Table
Returns true if the table contains no mappings.
isEmpty() - Method in class com.google.common.io.ByteSource
Returns whether the source has zero bytes.
isEmpty() - Method in class com.google.common.io.CharSource
Returns whether the source has zero chars.
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.util.concurrent.AtomicLongMap
Returns true if this map contains no key-value mappings.
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.
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.
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.
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.
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.
isIsatapAddress(Inet6Address) - Static method in class com.google.common.net.InetAddresses
Evaluates whether the argument is an ISATAP address.
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.
isNot(char) - Static method in class com.google.common.base.CharMatcher
Returns a char matcher that matches any character except the one specified.
isNull() - Static method in class com.google.common.base.Predicates
Returns a predicate that evaluates to true if the object reference being tested is null.
isNullOrEmpty(String) - Static method in class com.google.common.base.Strings
Returns true if the given string is null or is the empty string.
ISO_8859_1 - Static variable in class com.google.common.base.Charsets
ISO-8859-1: ISO Latin Alphabet Number 1 (ISO-LATIN-1).
isOccupied() - Method in class com.google.common.util.concurrent.Monitor
Returns whether this monitor is occupied by any thread.
isOccupiedByCurrentThread() - Method in class com.google.common.util.concurrent.Monitor
Returns whether the current thread is occupying this monitor (has entered more times than it has left).
isOrdered(Iterable<? extends T>) - Method in class com.google.common.collect.Ordering
Returns true if each element in iterable after the first is greater than or equal to the element that preceded it, according to this ordering.
isOrdered() - Method in class com.google.common.graph.EndpointPair
Returns true if this EndpointPair is an ordered pair (i.e.
isOverridable() - Method in class com.google.common.reflect.Invokable
Returns true if this is an overridable method.
isPowerOfTwo(BigInteger) - Static method in class com.google.common.math.BigIntegerMath
Returns true if x represents a power of two.
isPowerOfTwo(double) - Static method in class com.google.common.math.DoubleMath
Returns true if x is exactly equal to 2^k for some finite integer k.
isPowerOfTwo(int) - Static method in class com.google.common.math.IntMath
Returns true if x represents a power of two.
isPowerOfTwo(long) - Static method in class com.google.common.math.LongMath
Returns true if x represents a power of two.
isPresent() - Method in class com.google.common.base.Optional
Returns true if this holder contains a (non-null) instance.
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).
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).
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.
isRunning() - Method in class com.google.common.base.Stopwatch
Returns true if Stopwatch.start() has been called on this stopwatch, and Stopwatch.stop() has not been called since the last call to start().
isRunning() - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
 
isRunning() - Method in class com.google.common.util.concurrent.AbstractIdleService
 
isRunning() - Method in class com.google.common.util.concurrent.AbstractScheduledService
 
isRunning() - Method in class com.google.common.util.concurrent.AbstractService
 
isRunning() - Method in interface com.google.common.util.concurrent.Service
Returns true if this service is running.
isSatisfied() - Method in class com.google.common.util.concurrent.Monitor.Guard
Evaluates this guard's boolean condition.
isShutdown() - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
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
Returns true if this type is a subtype of the given type.
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
Returns true if this type is a supertype of the given type.
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.ForwardingExecutorService
 
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.
isUnderPublicSuffix() - Method in class com.google.common.net.InternetDomainName
Indicates whether this domain name ends in a public suffix, while not being a public suffix itself.
isUpperCase(char) - Static method in class com.google.common.base.Ascii
Indicates whether c is one of the twenty-six uppercase ASCII alphabetic characters between 'A' and 'Z' inclusive.
isUriInetAddress(String) - Static method in class com.google.common.net.InetAddresses
Returns true if the supplied string is a valid URI IP string literal, false otherwise.
isValid(String) - Static method in class com.google.common.net.HostSpecifier
Determines whether specifier represents a valid HostSpecifier as described in the documentation for HostSpecifier.fromValid(String).
isValid(String) - Static method in class com.google.common.net.InternetDomainName
Indicates whether the argument is a syntactically valid domain name using lenient validation.
isVarArgs() - Method in class com.google.common.reflect.Invokable
Returns true if this was declared to take a variable number of arguments.
isVertical() - Method in class com.google.common.math.LinearTransformation
Returns whether this is a vertical transformation.
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[]).
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.
Iterables - Class in com.google.common.collect
An assortment of mainly legacy static utility methods that operate on or return objects of type Iterable.
iterator() - Method in class com.google.common.collect.ForwardingCollection
 
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.ImmutableList
 
iterator() - Method in class com.google.common.collect.ImmutableMultiset
 
iterator() - Method in class com.google.common.collect.ImmutableSet
 
iterator() - Method in class com.google.common.collect.ImmutableSortedSet
 
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 interface com.google.common.collect.Multiset
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 interface com.google.common.collect.SortedMultiset
iterator() - Method in class com.google.common.graph.EndpointPair
Iterators - Class in com.google.common.collect
This class contains static utility methods that operate on or return objects of type Iterator.

J

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

K

key() - Method in enum com.google.common.base.StandardSystemProperty
Returns the key used to lookup this system property.
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.
keyComparator() - Method in class com.google.common.collect.TreeMultimap
Deprecated.
Use ((NavigableSet<K>) multimap.keySet()).comparator() instead. This method is scheduled for removal in April 2019.
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.
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
 
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 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.TreeMultimap
Returns a view collection of all distinct keys contained in this multimap.
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.
KML - Static variable in class com.google.common.net.MediaType
 
KMZ - Static variable in class com.google.common.net.MediaType
 

L

L24_AUDIO - Static variable in class com.google.common.net.MediaType
Media type for L24 audio, as defined by RFC 3190.
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_EVENT_ID - Static variable in class com.google.common.net.HttpHeaders
The HTTP Last-Event-ID header field name.
LAST_MODIFIED - Static variable in class com.google.common.net.HttpHeaders
The HTTP Last-Modified header field name.
lastEntry() - Method in class com.google.common.collect.ForwardingNavigableMap
 
lastEntry() - Method in class com.google.common.collect.ForwardingSortedMultiset
 
lastEntry() - Method in class com.google.common.collect.ImmutableSortedMap
 
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.
lastIndexIn(CharSequence) - Method in class com.google.common.base.CharMatcher
Returns the index of the last matching character in a character sequence, or -1 if no matching character is present.
lastIndexOf(Object) - Method in class com.google.common.collect.ForwardingList
 
lastIndexOf(Object) - Method in class com.google.common.collect.ImmutableList
 
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(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(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(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(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(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(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(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(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(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(short[], short) - Static method in class com.google.common.primitives.Shorts
Returns the index of the last appearance of the value target in array.
lastKey() - Method in class com.google.common.collect.ForwardingSortedMap
 
lastKey() - Method in class com.google.common.collect.ImmutableSortedMap
 
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
Returns the stack trace of throwable, possibly providing slower iteration over the full trace but faster iteration over parts of the trace.
lazyStackTraceIsLazy() - Static method in class com.google.common.base.Throwables
Returns whether Throwables.lazyStackTrace(java.lang.Throwable) will use the special implementation described in its documentation.
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.
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.
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.
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.
leave() - Method in class com.google.common.util.concurrent.Monitor
Leaves this monitor.
leftChild(T) - Method in class com.google.common.collect.BinaryTreeTraverser
Returns the left child of the specified node, or Optional.absent() if the specified node has no left child.
leftValue() - Method in interface com.google.common.collect.MapDifference.ValueDifference
Returns the value from the left map (possibly null).
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
Returns the size of this source in chars, if the size can be easily determined without actually opening the data stream.
lessThan(C) - Static method in class com.google.common.collect.Range
Returns a range that contains all values strictly less than endpoint.
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.
lexicographical() - Method in class com.google.common.collect.Ordering
Returns a new ordering which sorts iterables by comparing corresponding elements pairwise until a nonzero result is found; imposes "dictionary order".
lexicographicalComparator() - Static method in class com.google.common.primitives.Booleans
Returns a comparator that compares two boolean arrays lexicographically.
lexicographicalComparator() - Static method in class com.google.common.primitives.Chars
Returns a comparator that compares two char arrays lexicographically.
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.
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(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(Iterable<T>, int) - Static method in class com.google.common.collect.Iterables
Returns a view of iterable containing its first limitSize elements.
limit(Iterator<T>, int) - Static method in class com.google.common.collect.Iterators
Returns a view containing the first limitSize elements of iterator.
limit(InputStream, long) - Static method in class com.google.common.io.ByteStreams
Wraps a InputStream, limiting the number of bytes which can be read.
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.
LineProcessor<T> - Interface in com.google.common.io
A callback to be used with the streaming readLines methods.
LineReader - Class in com.google.common.io
A class for reading lines of text.
LineReader(Readable) - Constructor for class com.google.common.io.LineReader
Creates a new instance that will read lines from the given Readable object.
lines() - Method in class com.google.common.io.CharSource
Opens a new Stream for reading text one line at a time from this source.
LINK - Static variable in class com.google.common.net.HttpHeaders
The HTTP Link header field name.
linkedHashKeys() - Static method in class com.google.common.collect.MultimapBuilder
Uses a LinkedHashMap to map keys to value collections.
linkedHashKeys(int) - Static method in class com.google.common.collect.MultimapBuilder
Uses a LinkedHashMap to map keys to value collections, initialized to expect the specified number of keys.
LinkedHashMultimap<K,V> - Class in com.google.common.collect
Implementation of Multimap that does not allow duplicate key-value entries and that returns collections whose iterators follow the ordering in which the data was added to the multimap.
LinkedHashMultiset<E> - Class in com.google.common.collect
A Multiset implementation with predictable iteration order.
linkedHashSetValues() - Method in class com.google.common.collect.MultimapBuilder.MultimapBuilderWithKeys
Uses a LinkedHashSet to store value collections.
linkedHashSetValues(int) - Method in class com.google.common.collect.MultimapBuilder.MultimapBuilderWithKeys
Uses a LinkedHashSet to store value collections, initialized to expect the specified number of values per key.
LinkedListMultimap<K,V> - Class in com.google.common.collect
An implementation of ListMultimap that supports deterministic iteration order for both keys and values.
linkedListValues() - Method in class com.google.common.collect.MultimapBuilder.MultimapBuilderWithKeys
Uses a LinkedList to store value collections.
ListenableFuture<V> - Interface in com.google.common.util.concurrent
A Future that accepts completion listeners.
ListenableFutureTask<V> - Class in com.google.common.util.concurrent
A FutureTask that also implements the ListenableFuture interface.
ListenableScheduledFuture<V> - Interface in com.google.common.util.concurrent
Helper interface to implement both ListenableFuture and ScheduledFuture.
Listener() - Constructor for class com.google.common.util.concurrent.Service.Listener
 
Listener() - Constructor for class com.google.common.util.concurrent.ServiceManager.Listener
 
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.
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.
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.
listIterator() - Method in class com.google.common.collect.ForwardingList
 
listIterator(int) - Method in class com.google.common.collect.ForwardingList
 
listIterator() - Method in class com.google.common.collect.ImmutableList
 
listIterator(int) - Method in class com.google.common.collect.ImmutableList
 
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.
Lists - Class in com.google.common.collect
Static utility methods pertaining to List instances.
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.
load(K) - Method in class com.google.common.cache.CacheLoader
Computes or retrieves the value corresponding to key.
load() - Method in class com.google.common.reflect.ClassPath.ClassInfo
Loads (but doesn't link or initialize) the class.
loadAll(Iterable<? extends K>) - Method in class com.google.common.cache.CacheLoader
Computes or retrieves the values corresponding to keys.
loadCount() - Method in class com.google.common.cache.CacheStats
Returns the total number of times that Cache lookup methods attempted to load new values.
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.
LoadingCache<K,V> - Interface in com.google.common.cache
A semi-persistent mapping from keys to values.
loadSuccessCount() - Method in class com.google.common.cache.CacheStats
Returns the number of times Cache lookup methods have successfully loaded a new value.
LOCATION - Static variable in class com.google.common.net.HttpHeaders
The HTTP Location header field name.
lock(int) - Static method in class com.google.common.util.concurrent.Striped
Creates a Striped<Lock> with eagerly initialized, strongly referenced locks.
log10(BigInteger, RoundingMode) - Static method in class com.google.common.math.BigIntegerMath
Returns the base-10 logarithm of x, rounded according to the specified rounding mode.
log10(int, RoundingMode) - Static method in class com.google.common.math.IntMath
Returns the base-10 logarithm of x, rounded according to the specified rounding mode.
log10(long, RoundingMode) - Static method in class com.google.common.math.LongMath
Returns the base-10 logarithm of x, rounded according to the specified rounding mode.
log2(BigInteger, RoundingMode) - Static method in class com.google.common.math.BigIntegerMath
Returns the base-2 logarithm of x, rounded according to the specified rounding mode.
log2(double) - Static method in class com.google.common.math.DoubleMath
Returns the base 2 logarithm of a double value.
log2(double, RoundingMode) - Static method in class com.google.common.math.DoubleMath
Returns the base 2 logarithm of a double value, rounded with the specified rounding mode to an int.
log2(int, RoundingMode) - Static method in class com.google.common.math.IntMath
Returns the base-2 logarithm of x, rounded according to the specified rounding mode.
log2(long, RoundingMode) - Static method in class com.google.common.math.LongMath
Returns the base-2 logarithm of x, rounded according to the specified rounding mode.
longFunnel() - Static method in class com.google.common.hash.Funnels
Returns a funnel for longs.
LongMath - Class in com.google.common.math
A class for arithmetic on values of type long.
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.
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.
lower(E) - Method in class com.google.common.collect.ForwardingNavigableSet
 
lower(E) - Method in class com.google.common.collect.ImmutableSortedSet
 
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.
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.
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.ForwardingNavigableMap
 
lowerEntry(K) - Method in class com.google.common.collect.ImmutableSortedMap
 
lowerKey(K) - Method in class com.google.common.collect.ForwardingNavigableMap
 
lowerKey(K) - Method in class com.google.common.collect.ImmutableSortedMap
 

M

makeChecked(ListenableFuture<V>, Function<? super Exception, X>) - Static method in class com.google.common.util.concurrent.Futures
Deprecated.
CheckedFuture cannot properly support the chained operations that are the primary goal of ListenableFuture. CheckedFuture also encourages users to rethrow exceptions from one thread in another thread, producing misleading stack traces. Additionally, it has a surprising policy about which exceptions to map and which to leave untouched. Guava users who want a CheckedFuture can fork the classes for their own use, possibly specializing them to the particular exception type they use. We recommend that most people use ListenableFuture and perform any exception wrapping themselves. This method is scheduled for removal from Guava in February 2018.
makeMap() - Method in class com.google.common.collect.MapMaker
Builds a thread-safe map.
MANIFEST_JSON_UTF_8 - Static variable in class com.google.common.net.MediaType
Media type for the Manifest for a web application.
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
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.
mapException(Exception) - Method in class com.google.common.util.concurrent.AbstractCheckedFuture
Deprecated.
Translates from an InterruptedException, CancellationException or ExecutionException thrown by get to an exception of type X to be thrown by checkedGet.
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.
mapping(double, double) - Static method in class com.google.common.math.LinearTransformation
Start building an instance which maps x = x1 to y = y1.
Maps - Class in com.google.common.collect
Static utility methods pertaining to Map instances (including instances of SortedMap, BiMap, etc.).
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.
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.
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(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.
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.CountingInputStream
 
markSupported() - Method in class com.google.common.hash.HashingInputStream
mark() is not supported for HashingInputStream
matches(char) - Method in class com.google.common.base.CharMatcher
Determines a true or false value for the given character.
matchesAllOf(CharSequence) - Method in class com.google.common.base.CharMatcher
Returns true if a character sequence contains only matching characters.
matchesAnyOf(CharSequence) - Method in class com.google.common.base.CharMatcher
Returns true if a character sequence contains at least one matching character.
matchesNoneOf(CharSequence) - Method in class com.google.common.base.CharMatcher
Returns true if a character sequence contains no matching characters.
MAX - Static variable in class com.google.common.base.Ascii
The maximum value of an ASCII character.
max(Iterator<E>) - Method in class com.google.common.collect.Ordering
Returns the greatest of the specified values according to this ordering.
max(Iterable<E>) - Method in class com.google.common.collect.Ordering
Returns the greatest of the specified values according to this ordering.
max(E, E) - Method in class com.google.common.collect.Ordering
Returns the greater of the two values according to this ordering.
max(E, E, E, E...) - Method in class com.google.common.collect.Ordering
Returns the greatest of the specified values according to this ordering.
max() - 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(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(long...) - Static method in class com.google.common.primitives.Longs
Returns the greatest value present in array.
max(short...) - Static method in class com.google.common.primitives.Shorts
Returns the greatest value present in array.
max(byte...) - Static method in class com.google.common.primitives.SignedBytes
Returns the greatest value present in array.
max(byte...) - Static method in class com.google.common.primitives.UnsignedBytes
Returns the greatest value present in array.
max(int...) - Static method in class com.google.common.primitives.UnsignedInts
Returns the greatest value present in array, treating values as unsigned.
max(long...) - Static method in class com.google.common.primitives.UnsignedLongs
Returns the greatest value present in array, treating values as unsigned.
MAX_FORWARDS - Static variable in class com.google.common.net.HttpHeaders
The HTTP Max-Forwards header field name.
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_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
 
maximumSize(long) - Method in class com.google.common.cache.CacheBuilder
Specifies the maximum number of entries the cache may contain.
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.
maximumWeight(long) - Method in class com.google.common.cache.CacheBuilder
Specifies the maximum weight of entries the cache may contain.
maxValue() - Method in class com.google.common.collect.DiscreteDomain
Returns the maximum value of type C, if it has one.
MBOX - Static variable in class com.google.common.net.MediaType
 
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:
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. This method will be removed in February 2018.
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. This method will be removed in February 2018.
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. This method will be removed in February 2018.
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. This method will be removed in February 2018.
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. This method will be removed in February 2018.
mean(int, int) - Static method in class com.google.common.math.IntMath
Returns the arithmetic mean of x and y, rounded towards negative infinity.
mean(long, long) - Static method in class com.google.common.math.LongMath
Returns the arithmetic mean of x and y, rounded toward negative infinity.
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.
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.
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.
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).
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.
merge(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class com.google.common.collect.ImmutableMap
Deprecated.
Unsupported operation.
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.
method(Method) - Method in class com.google.common.reflect.TypeToken
Returns the Invokable for method, which must be a member of T.
MICROSOFT_EXCEL - Static variable in class com.google.common.net.MediaType
 
MICROSOFT_POWERPOINT - Static variable in class com.google.common.net.MediaType
 
MICROSOFT_WORD - Static variable in class com.google.common.net.MediaType
 
mightContain(T) - Method in class com.google.common.hash.BloomFilter
Returns true if the element might have been put in this Bloom filter, false if this is definitely not the case.
MIN - Static variable in class com.google.common.base.Ascii
The minimum value of an ASCII character.
min(Iterator<E>) - Method in class com.google.common.collect.Ordering
Returns the least of the specified values according to this ordering.
min(Iterable<E>) - Method in class com.google.common.collect.Ordering
Returns the least of the specified values according to this ordering.
min(E, E) - Method in class com.google.common.collect.Ordering
Returns the lesser of the two values according to this ordering.
min(E, E, E, E...) - Method in class com.google.common.collect.Ordering
Returns the least of the specified values according to this ordering.
min() - 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(char...) - Static method in class com.google.common.primitives.Chars
Returns the least value present in array.
min(double...) - Static method in class com.google.common.primitives.Doubles
Returns the least value present in array, using the same rules of comparison as Math.min(double, double).
min(float...) - Static method in class com.google.common.primitives.Floats
Returns the least value present in array, using the same rules of comparison as Math.min(float, float).
min(int...) - Static method in class com.google.common.primitives.Ints
Returns the least value present in array.
min(long...) - Static method in class com.google.common.primitives.Longs
Returns the least value present in array.
min(short...) - Static method in class com.google.common.primitives.Shorts
Returns the least value present in array.
min(byte...) - Static method in class com.google.common.primitives.SignedBytes
Returns the least value present in array.
min(byte...) - Static method in class com.google.common.primitives.UnsignedBytes
Returns the least value present in array.
min(int...) - Static method in class com.google.common.primitives.UnsignedInts
Returns the least value present in array, treating values as unsigned.
min(long...) - Static method in class com.google.common.primitives.UnsignedLongs
Returns the least value present in array, treating values as unsigned.
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.Builder<B> - Class in com.google.common.collect
The builder class used in creation of min-max priority queues.
minus(CacheStats) - Method in class com.google.common.cache.CacheStats
Returns a new CacheStats representing the difference between this CacheStats and other.
minus(UnsignedInteger) - Method in class com.google.common.primitives.UnsignedInteger
Returns the result of subtracting this and val.
minus(UnsignedLong) - Method in class com.google.common.primitives.UnsignedLong
Returns the result of subtracting this and val.
minValue() - Method in class com.google.common.collect.DiscreteDomain
Returns the minimum value of type C, if it has one.
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.
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.
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.
MoreExecutors - Class in com.google.common.util.concurrent
Factory and utility methods for Executor, ExecutorService, and ThreadFactory.
MoreFiles - Class in com.google.common.io
Static utilities for use with Path instances, intended to complement Files.
MoreObjects - Class in com.google.common.base
Helper functions that operate on any Object, and are not already provided in Objects.
MoreObjects.ToStringHelper - Class in com.google.common.base
move(File, File) - Static method in class com.google.common.io.Files
Moves a file from one path to another.
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
 
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.
MultimapBuilder<K0,V0> - Class in com.google.common.collect
A builder for a multimap implementation that allows customization of the backing map and value collection implementations used in a particular multimap.
MultimapBuilder.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.
Multimaps - Class in com.google.common.collect
Provides static methods acting on or generating a Multimap.
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.
Multisets - Class in com.google.common.collect
Provides static utility methods for creating and working with Multiset instances.
murmur3_128(int) - Static method in class com.google.common.hash.Hashing
Returns a hash function implementing the 128-bit murmur3 algorithm, x64 variant (little-endian variant), using the given seed value.
murmur3_128() - Static method in class com.google.common.hash.Hashing
Returns a hash function implementing the 128-bit murmur3 algorithm, x64 variant (little-endian variant), using a seed value of zero.
murmur3_32(int) - Static method in class com.google.common.hash.Hashing
Returns a hash function implementing the 32-bit murmur3 algorithm, x86 variant (little-endian variant), using the given seed value.
murmur3_32() - Static method in class com.google.common.hash.Hashing
Returns a hash function implementing the 32-bit murmur3 algorithm, x86 variant (little-endian variant), using a seed value of zero.
MutableClassToInstanceMap<B> - Class in com.google.common.collect
A mutable class-to-instance map backed by an arbitrary user-provided map.
MutableGraph<N> - Interface in com.google.common.graph
A subinterface of Graph which adds mutation methods.
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
 
MutableValueGraph<N,V> - Interface in com.google.common.graph
A subinterface of ValueGraph which adds mutation methods.

N

NACL_APPLICATION - Static variable in class com.google.common.net.MediaType
Media type for NaCl applications.
NACL_PORTABLE_APPLICATION - Static variable in class com.google.common.net.MediaType
Media type for 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.
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.
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.
navigableKeySet() - Method in class com.google.common.collect.ForwardingNavigableMap
 
navigableKeySet() - Method in class com.google.common.collect.ImmutableSortedMap
 
negate() - Method in class com.google.common.base.CharMatcher
Returns a matcher that matches any character not matched by this matcher.
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 with user-defined properties.
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.
newArrayBlockingQueue(int) - Static method in class com.google.common.collect.Queues
Creates an empty ArrayBlockingQueue with the given (fixed) capacity and nonfair access policy.
newArrayDeque() - Static method in class com.google.common.collect.Queues
Creates an empty ArrayDeque.
newArrayDeque(Iterable<? extends E>) - Static method in class com.google.common.collect.Queues
Creates an ArrayDeque containing the elements of the specified iterable, in the order they are returned by the iterable's iterator.
newArrayList() - Static method in class com.google.common.collect.Lists
Creates a mutable, empty ArrayList instance (for Java 6 and earlier).
newArrayList(E...) - Static method in class com.google.common.collect.Lists
Creates a mutable ArrayList instance containing the given elements.
newArrayList(Iterable<? extends E>) - Static method in class com.google.common.collect.Lists
Creates a mutable ArrayList instance containing the given elements; a very thin shortcut for creating an empty list then calling Iterables.addAll(java.util.Collection<T>, java.lang.Iterable<? extends T>).
newArrayList(Iterator<? extends E>) - Static method in class com.google.common.collect.Lists
Creates a mutable ArrayList instance containing the given elements; a very thin shortcut for creating an empty list and then calling Iterators.addAll(java.util.Collection<T>, java.util.Iterator<? extends T>).
newArrayListWithCapacity(int) - Static method in class com.google.common.collect.Lists
Creates an ArrayList instance backed by an array with the specified initial size; simply delegates to ArrayList.ArrayList(int).
newArrayListWithExpectedSize(int) - Static method in class com.google.common.collect.Lists
Creates an ArrayList instance to hold estimatedSize elements, plus an unspecified amount of padding; you almost certainly mean to call Lists.newArrayListWithCapacity(int) (see that method for further advice on usage).
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.
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.
newCopyOnWriteArrayList() - Static method in class com.google.common.collect.Lists
Creates an empty CopyOnWriteArrayList instance.
newCopyOnWriteArrayList(Iterable<? extends E>) - Static method in class com.google.common.collect.Lists
Creates a CopyOnWriteArrayList instance containing the given elements.
newCopyOnWriteArraySet() - Static method in class com.google.common.collect.Sets
Creates an empty CopyOnWriteArraySet instance.
newCopyOnWriteArraySet(Iterable<? extends E>) - Static method in class com.google.common.collect.Sets
Creates a CopyOnWriteArraySet instance containing the given elements.
newCustomTable(Map<R, Map<C, V>>, Supplier<? extends Map<C, V>>) - Static method in class com.google.common.collect.Tables
Creates a table that uses the specified backing map and factory.
newDataInput(byte[]) - Static method in class com.google.common.io.ByteStreams
Returns a new ByteArrayDataInput instance to read from the bytes array from the beginning.
newDataInput(byte[], int) - Static method in class com.google.common.io.ByteStreams
Returns a new ByteArrayDataInput instance to read from the bytes array, starting at the given position.
newDataInput(ByteArrayInputStream) - Static method in class com.google.common.io.ByteStreams
Returns a new ByteArrayDataInput instance to read from the given ByteArrayInputStream.
newDataOutput() - Static method in class com.google.common.io.ByteStreams
Returns a new ByteArrayDataOutput instance with a default size.
newDataOutput(int) - Static method in class com.google.common.io.ByteStreams
Returns a new ByteArrayDataOutput instance sized to hold size bytes before resizing.
newDataOutput(ByteArrayOutputStream) - Static method in class com.google.common.io.ByteStreams
Returns a new ByteArrayDataOutput instance which writes to the given ByteArrayOutputStream.
newDirectExecutorService() - Static method in class com.google.common.util.concurrent.MoreExecutors
Creates an executor service that runs each task in the thread that invokes execute/submit, as in ThreadPoolExecutor.CallerRunsPolicy This applies both to individually submitted tasks and to collections of tasks submitted via invokeAll or invokeAny.
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
newFixedRateSchedule(long, long, TimeUnit) - Static method in class com.google.common.util.concurrent.AbstractScheduledService.Scheduler
newGuard(BooleanSupplier) - Method in class com.google.common.util.concurrent.Monitor
Creates a new Monitor.Guard for this monitor.
newHasher() - Method in interface com.google.common.hash.HashFunction
Begins a new hash code computation by returning an initialized, stateful Hasher instance that is ready to receive data.
newHasher(int) - Method in interface com.google.common.hash.HashFunction
Begins a new hash code computation as HashFunction.newHasher(), but provides a hint of the expected size of the input (in bytes).
newHashMap() - Static method in class com.google.common.collect.Maps
Creates a mutable, empty HashMap instance.
newHashMap(Map<? extends K, ? extends V>) - Static method in class com.google.common.collect.Maps
Creates a mutable HashMap instance with the same mappings as the specified map.
newHashMapWithExpectedSize(int) - Static method in class com.google.common.collect.Maps
Creates a HashMap instance, with a high enough "initial capacity" that it should hold expectedSize elements without growth.
newHashSet() - Static method in class com.google.common.collect.Sets
Creates a mutable, 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.Sets
Returns a new hash set using the smallest initial table size that can hold expectedSize elements without resizing.
newIdentityHashMap() - Static method in class com.google.common.collect.Maps
Creates an IdentityHashMap instance.
newIdentityHashSet() - Static method in class com.google.common.collect.Sets
Creates an empty Set that uses identity to determine equality.
newInstance(CycleDetectingLockFactory.Policy) - Static method in class com.google.common.util.concurrent.CycleDetectingLockFactory
Creates a new factory with the specified policy.
newInstanceWithExplicitOrdering(Class<E>, CycleDetectingLockFactory.Policy) - Static method in class com.google.common.util.concurrent.CycleDetectingLockFactory
Creates a CycleDetectingLockFactory.WithExplicitOrdering<E>.
newLinkedBlockingDeque() - Static method in class com.google.common.collect.Queues
Creates an empty LinkedBlockingDeque with a capacity of Integer.MAX_VALUE.
newLinkedBlockingDeque(int) - Static method in class com.google.common.collect.Queues
Creates an empty LinkedBlockingDeque with the given (fixed) capacity.
newLinkedBlockingDeque(Iterable<? extends E>) - Static method in class com.google.common.collect.Queues
Creates a LinkedBlockingDeque with a capacity of Integer.MAX_VALUE, containing the elements of the specified iterable, in the order they are returned by the iterable's iterator.
newLinkedBlockingQueue() - Static method in class com.google.common.collect.Queues
Creates an empty LinkedBlockingQueue with a capacity of Integer.MAX_VALUE.
newLinkedBlockingQueue(int) - Static method in class com.google.common.collect.Queues
Creates an empty LinkedBlockingQueue with the given (fixed) capacity.
newLinkedBlockingQueue(Iterable<? extends E>) - Static method in class com.google.common.collect.Queues
Creates a LinkedBlockingQueue with a capacity of Integer.MAX_VALUE, containing the elements of the specified iterable, in the order they are returned by the iterable's iterator.
newLinkedHashMap() - Static method in class com.google.common.collect.Maps
Creates a mutable, empty, insertion-ordered LinkedHashMap instance.
newLinkedHashMap(Map<? extends K, ? extends V>) - Static method in class com.google.common.collect.Maps
Creates a mutable, insertion-ordered LinkedHashMap instance with the same mappings as the specified map.
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.
newLinkedHashSet() - Static method in class com.google.common.collect.Sets
Creates a mutable, empty LinkedHashSet instance.
newLinkedHashSet(Iterable<? extends E>) - Static method in class com.google.common.collect.Sets
Creates a mutable LinkedHashSet instance containing the given elements in order.
newLinkedHashSetWithExpectedSize(int) - Static method in class com.google.common.collect.Sets
Creates a LinkedHashSet instance, with a high enough "initial capacity" that it should hold expectedSize elements without growth.
newLinkedList() - Static method in class com.google.common.collect.Lists
Creates a mutable, empty LinkedList instance (for Java 6 and earlier).
newLinkedList(Iterable<? extends E>) - Static method in class com.google.common.collect.Lists
Creates a mutable LinkedList instance containing the given elements; a very thin shortcut for creating an empty list then calling Iterables.addAll(java.util.Collection<T>, java.lang.Iterable<? extends T>).
newListMultimap(Map<K, Collection<V>>, Supplier<? extends List<V>>) - Static method in class com.google.common.collect.Multimaps
Creates a new ListMultimap that uses the provided map and factory.
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.
newPriorityBlockingQueue() - Static method in class com.google.common.collect.Queues
Creates an empty PriorityBlockingQueue with the ordering given by its elements' natural ordering.
newPriorityBlockingQueue(Iterable<? extends E>) - Static method in class com.google.common.collect.Queues
Creates a PriorityBlockingQueue containing the given elements.
newPriorityQueue() - Static method in class com.google.common.collect.Queues
Creates an empty PriorityQueue with the ordering given by its elements' natural ordering.
newPriorityQueue(Iterable<? extends E>) - Static method in class com.google.common.collect.Queues
Creates a PriorityQueue containing the given elements.
newProxy(Class<T>, InvocationHandler) - Static method in class com.google.common.reflect.Reflection
Returns a proxy instance that implements interfaceType by dispatching method invocations to handler.
newProxy(T, Class<T>, long, TimeUnit) - Method in class com.google.common.util.concurrent.FakeTimeLimiter
 
newProxy(T, Class<T>, long, TimeUnit) - Method in class com.google.common.util.concurrent.SimpleTimeLimiter
 
newProxy(T, Class<T>, long, TimeUnit) - Method in interface com.google.common.util.concurrent.TimeLimiter
Returns an instance of interfaceType that delegates all method calls to the target object, enforcing the specified time limit on each call.
newReader(File, Charset) - Static method in class com.google.common.io.Files
Returns a buffered reader that reads from a file using the given character set.
newReentrantLock(String) - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory
Equivalent to newReentrantLock(lockName, false).
newReentrantLock(String, boolean) - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory
Creates a ReentrantLock with the given fairness policy.
newReentrantLock(E) - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory.WithExplicitOrdering
Equivalent to newReentrantLock(rank, false).
newReentrantLock(E, boolean) - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory.WithExplicitOrdering
Creates a ReentrantLock with the given fairness policy and rank.
newReentrantReadWriteLock(String) - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory
Equivalent to newReentrantReadWriteLock(lockName, false).
newReentrantReadWriteLock(String, boolean) - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory
Creates a ReentrantReadWriteLock with the given fairness policy.
newReentrantReadWriteLock(E) - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory.WithExplicitOrdering
Equivalent to newReentrantReadWriteLock(rank, false).
newReentrantReadWriteLock(E, boolean) - Method in class com.google.common.util.concurrent.CycleDetectingLockFactory.WithExplicitOrdering
Creates a ReentrantReadWriteLock with the given fairness policy and rank.
newReference() - Static method in class com.google.common.util.concurrent.Atomics
Creates an AtomicReference instance with no initial value.
newReference(V) - Static method in class com.google.common.util.concurrent.Atomics
Creates an AtomicReference instance with the given initial value.
newReferenceArray(int) - Static method in class com.google.common.util.concurrent.Atomics
Creates an AtomicReferenceArray instance of given length.
newReferenceArray(E[]) - Static method in class com.google.common.util.concurrent.Atomics
Creates an AtomicReferenceArray instance with the same length as, and all elements copied from, the given array.
newSetFromMap(Map<E, Boolean>) - Static method in class com.google.common.collect.Sets
Deprecated.
Use Collections.newSetFromMap(java.util.Map<E, java.lang.Boolean>) instead. This method will be removed in December 2017.
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.
newStrongInterner() - Static method in class com.google.common.collect.Interners
Returns a new thread-safe interner which retains a strong reference to each instance it has interned, thus preventing these instances from being garbage-collected.
newSynchronousQueue() - Static method in class com.google.common.collect.Queues
Creates an empty SynchronousQueue with nonfair access policy.
newTaskFor(Runnable, T) - Method in class com.google.common.util.concurrent.AbstractListeningExecutorService
 
newTaskFor(Callable<T>) - Method in class com.google.common.util.concurrent.AbstractListeningExecutorService
 
newTreeMap() - Static method in class com.google.common.collect.Maps
Creates a mutable, empty TreeMap instance using the natural ordering of its elements.
newTreeMap(SortedMap<K, ? extends V>) - Static method in class com.google.common.collect.Maps
Creates a mutable TreeMap instance with the same mappings as the specified map and using the same ordering as the specified map.
newTreeMap(Comparator<C>) - Static method in class com.google.common.collect.Maps
Creates a mutable, empty TreeMap instance using the given comparator.
newTreeSet() - Static method in class com.google.common.collect.Sets
Creates a mutable, empty TreeSet instance sorted by the natural sort ordering of its elements.
newTreeSet(Iterable<? extends E>) - Static method in class com.google.common.collect.Sets
Creates a mutable TreeSet instance containing the given elements sorted by their natural ordering.
newTreeSet(Comparator<? super E>) - Static method in class com.google.common.collect.Sets
Creates a mutable, empty TreeSet instance with the given comparator.
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.
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() - Method in class com.google.common.collect.AbstractIterator
 
next() - Method in class com.google.common.collect.AbstractSequentialIterator
 
next(C) - Method in class com.google.common.collect.DiscreteDomain
Returns the unique least value of type C that is greater than value, or null if none exists.
next() - Method in class com.google.common.collect.ForwardingIterator
 
next() - Method in interface com.google.common.collect.PeekingIterator
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
 
nextIndex() - Method in class com.google.common.collect.ForwardingListIterator
 
NL - Static variable in class com.google.common.base.Ascii
Alternate name for Ascii.LF.
nodeOrder() - Method in interface com.google.common.graph.Graph
Returns the order of iteration for the elements of BaseGraph.nodes().
nodeOrder(ElementOrder<N1>) - Method in class com.google.common.graph.GraphBuilder
Specifies 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(ElementOrder<N1>) - Method in class com.google.common.graph.NetworkBuilder
Specifies the order of iteration for the elements of Network.nodes().
nodeOrder() - Method in interface com.google.common.graph.ValueGraph
Returns the order of iteration for the elements of BaseGraph.nodes().
nodeOrder(ElementOrder<N1>) - Method in class com.google.common.graph.ValueGraphBuilder
Specifies the order of iteration for the elements of Graph.nodes().
nodes() - Method in interface com.google.common.graph.Graph
Returns all nodes in this graph, in the order specified by BaseGraph.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 interface com.google.common.graph.ValueGraph
Returns all nodes in this graph, in the order specified by BaseGraph.nodeOrder().
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() - Method in class com.google.common.graph.EndpointPair
Returns the node adjacent to EndpointPair.nodeU() along the origin edge.
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.
NONE - Static variable in class com.google.common.base.CharMatcher
Deprecated.
Use CharMatcher.none() instead. This constant is scheduled to be removed in June 2018.
none() - Static method in class com.google.common.base.CharMatcher
Matches no characters.
noneOf(CharSequence) - Static method in class com.google.common.base.CharMatcher
Returns a char matcher that matches any character not present in the given character sequence.
not(Predicate<T>) - Static method in class com.google.common.base.Predicates
Returns a predicate that evaluates to true if the given predicate evaluates to false.
notifyFailed(Throwable) - Method in class com.google.common.util.concurrent.AbstractService
Invoke this method to transition the service to the Service.State.FAILED.
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.
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.
nullEscaper() - Static method in class com.google.common.escape.Escapers
Returns an Escaper that does no escaping, passing all character data through unchanged.
nullOutputStream() - Static method in class com.google.common.io.ByteStreams
Returns an OutputStream that simply discards written bytes.
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.
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.
nullToEmpty(String) - Static method in class com.google.common.base.Strings
Returns the given string if it is non-null; the empty string otherwise.
nullWriter() - Static method in class com.google.common.io.CharStreams
Returns a Writer that simply discards written chars.

O

ObjectArrays - Class in com.google.common.collect
Static utility methods pertaining to object arrays.
Objects - Class in com.google.common.base
Helper functions that can operate on any Object.
OCTET_STREAM - Static variable in class com.google.common.net.MediaType
 
of(T) - Static method in class com.google.common.base.Optional
Returns an Optional instance containing the given non-null reference.
of() - Static method in class com.google.common.collect.FluentIterable
Returns a fluent iterable containing no elements.
of(E, E...) - Static method in class com.google.common.collect.FluentIterable
Returns a fluent iterable containing the specified elements in order.
of() - Static method in class com.google.common.collect.ImmutableBiMap
Returns the empty bimap.
of(K, V) - Static method in class com.google.common.collect.ImmutableBiMap
Returns an immutable bimap containing a single entry.
of(K, V, K, V) - Static method in class com.google.common.collect.ImmutableBiMap
Returns an immutable map containing the given entries, in order.
of(K, V, K, V, K, V) - Static method in class com.google.common.collect.ImmutableBiMap
Returns an immutable map containing the given entries, in order.
of(K, V, K, V, K, V, K, V) - Static method in class com.google.common.collect.ImmutableBiMap
Returns an immutable map containing the given entries, in order.
of(K, V, K, V, K, V, K, V, K, V) - Static method in class com.google.common.collect.ImmutableBiMap
Returns an immutable map containing the given entries, in order.
of() - Static method in class com.google.common.collect.ImmutableClassToInstanceMap
Returns an empty ImmutableClassToInstanceMap.
of(Class<T>, T) - Static method in class com.google.common.collect.ImmutableClassToInstanceMap
Returns an ImmutableClassToInstanceMap containing a single entry.
of() - Static method in class com.google.common.collect.ImmutableList
Returns the empty immutable list.
of(E) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing a single element.
of(E, E) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing the given elements, in order.
of(E, E, E) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing the given elements, in order.
of(E, E, E, E) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing the given elements, in order.
of(E, E, E, E, E) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing the given elements, in order.
of(E, E, E, E, E, E) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing the given elements, in order.
of(E, E, E, E, E, E, E) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing the given elements, in order.
of(E, E, E, E, E, E, E, E) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing the given elements, in order.
of(E, E, E, E, E, E, E, E, E) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing the given elements, in order.
of(E, E, E, E, E, E, E, E, E, E) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing the given elements, in order.
of(E, E, E, E, E, E, E, E, E, E, E) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing the given elements, in order.
of(E, E, E, E, E, E, E, E, E, E, E, E, E...) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing the given elements, in order.
of() - Static method in class com.google.common.collect.ImmutableListMultimap
Returns the empty multimap.
of(K, V) - Static method in class com.google.common.collect.ImmutableListMultimap
Returns an immutable multimap containing a single entry.
of(K, V, K, V) - Static method in class com.google.common.collect.ImmutableListMultimap
Returns an immutable multimap containing the given entries, in order.
of(K, V, K, V, K, V) - Static method in class com.google.common.collect.ImmutableListMultimap
Returns an immutable multimap containing the given entries, in order.
of(K, V, K, V, K, V, K, V) - Static method in class com.google.common.collect.ImmutableListMultimap
Returns an immutable multimap containing the given entries, in order.
of(K, V, K, V, K, V, K, V, K, V) - Static method in class com.google.common.collect.ImmutableListMultimap
Returns an immutable multimap containing the given entries, in order.
of() - Static method in class com.google.common.collect.ImmutableMap
Returns the empty map.
of(K, V) - Static method in class com.google.common.collect.ImmutableMap
Returns an immutable map containing a single entry.
of(K, V, K, V) - Static method in class com.google.common.collect.ImmutableMap
Returns an immutable map containing the given entries, in order.
of(K, V, K, V, K, V) - Static method in class com.google.common.collect.ImmutableMap
Returns an immutable map containing the given entries, in order.
of(K, V, K, V, K, V, K, V) - Static method in class com.google.common.collect.ImmutableMap
Returns an immutable map containing the given entries, in order.
of(K, V, K, V, K, V, K, V, K, V) - Static method in class com.google.common.collect.ImmutableMap
Returns an immutable map containing the given entries, in order.
of() - Static method in class com.google.common.collect.ImmutableMultimap
Returns an empty multimap.
of(K, V) - Static method in class com.google.common.collect.ImmutableMultimap
Returns an immutable multimap containing a single entry.
of(K, V, K, V) - Static method in class com.google.common.collect.ImmutableMultimap
Returns an immutable multimap containing the given entries, in order.
of(K, V, K, V, K, V) - Static method in class com.google.common.collect.ImmutableMultimap
Returns an immutable multimap containing the given entries, in 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.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.ImmutableMultimap
Returns an immutable multimap containing the given entries, in the "key-grouped" insertion order described in the class documentation.
of() - Static method in class com.google.common.collect.ImmutableMultiset
Returns the empty immutable multiset.
of(E) - Static method in class com.google.common.collect.ImmutableMultiset
Returns an immutable multiset containing a single element.
of(E, E) - Static method in class com.google.common.collect.ImmutableMultiset
Returns an immutable multiset containing the given elements, in order.
of(E, E, E) - Static method in class com.google.common.collect.ImmutableMultiset
Returns an immutable multiset containing the given elements, in the "grouped iteration order" described in the class documentation.
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, 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.ImmutableMultiset
Returns an immutable multiset containing the given elements, in the "grouped iteration order" described in the class documentation.
of() - Static method in class com.google.common.collect.ImmutableRangeMap
Returns an empty immutable range map.
of(Range<K>, V) - Static method in class com.google.common.collect.ImmutableRangeMap
Returns an immutable range map mapping a single range to a single value.
of() - Static method in class com.google.common.collect.ImmutableRangeSet
Returns an empty immutable range set.
of(Range<C>) - Static method in class com.google.common.collect.ImmutableRangeSet
Returns an immutable range set containing the specified single range.
of() - Static method in class com.google.common.collect.ImmutableSet
Returns the empty immutable set.
of(E) - Static method in class com.google.common.collect.ImmutableSet
Returns an immutable set containing element.
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, 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.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.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.ImmutableSet
Returns an immutable set containing the given elements, minus duplicates, in the order each was first specified.
of() - Static method in class com.google.common.collect.ImmutableSetMultimap
Returns the empty multimap.
of(K, V) - Static method in class com.google.common.collect.ImmutableSetMultimap
Returns an immutable multimap containing a single entry.
of(K, V, K, V) - Static method in class com.google.common.collect.ImmutableSetMultimap
Returns an immutable multimap containing the given entries, in order.
of(K, V, K, V, K, V) - Static method in class com.google.common.collect.ImmutableSetMultimap
Returns an immutable multimap containing the given entries, in order.
of(K, V, K, V, K, V, K, V) - Static method in class com.google.common.collect.ImmutableSetMultimap
Returns an immutable multimap containing the given entries, in order.
of(K, V, K, V, K, V, K, V, K, V) - Static method in class com.google.common.collect.ImmutableSetMultimap
Returns an immutable multimap containing the given entries, in order.
of() - Static method in class com.google.common.collect.ImmutableSortedMap
Returns the empty sorted map.
of(K, V) - Static method in class com.google.common.collect.ImmutableSortedMap
Returns an immutable map containing a single entry.
of(K, V, K, V) - Static method in class com.google.common.collect.ImmutableSortedMap
Returns an immutable sorted map containing the given entries, sorted by the natural ordering of their keys.
of(K, V, K, V, K, V) - Static method in class com.google.common.collect.ImmutableSortedMap
Returns an immutable sorted map containing the given entries, sorted by the natural ordering of their keys.
of(K, V, K, V, K, V, K, V) - Static method in class com.google.common.collect.ImmutableSortedMap
Returns an immutable sorted map containing the given entries, sorted by the natural ordering of their keys.
of(K, V, K, V, K, V, K, V, K, V) - Static method in class com.google.common.collect.ImmutableSortedMap
Returns an immutable sorted map containing the given entries, sorted by the natural ordering of their keys.
of() - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns the empty immutable sorted multiset.
of(E) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns an immutable sorted multiset containing a single element.
of(E, E) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns an immutable sorted multiset containing the given elements sorted by their natural ordering.
of(E, E, E) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns an immutable sorted multiset containing the given elements sorted by their natural ordering.
of(E, E, E, E) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns an immutable sorted multiset containing the given elements sorted by their natural ordering.
of(E, E, E, E, E) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns an immutable sorted multiset containing the given elements sorted by their natural ordering.
of(E, E, E, E, E, E, E...) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns an immutable sorted multiset containing the given elements sorted by their natural ordering.
of() - Static method in class com.google.common.collect.ImmutableSortedSet
Returns the empty immutable sorted set.
of(E) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing a single element.
of(E, E) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by their natural ordering.
of(E, E, E) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by their natural ordering.
of(E, E, E, E) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by their natural ordering.
of(E, E, E, E, E) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by their natural ordering.
of(E, E, E, E, E, E, E...) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by their natural ordering.
of() - Static method in class com.google.common.collect.ImmutableTable
Returns an empty immutable table.
of(R, C, V) - Static method in class com.google.common.collect.ImmutableTable
Returns an immutable table containing a single cell.
of(Iterable<? extends Number>) - Static method in class com.google.common.math.Stats
Returns statistics over a dataset containing the given values.
of(Iterator<? extends Number>) - Static method in class com.google.common.math.Stats
Returns statistics over a dataset containing the given values.
of(double...) - Static method in class com.google.common.math.Stats
Returns statistics over a dataset containing the given values.
of(int...) - Static method in class com.google.common.math.Stats
Returns statistics over a dataset containing the given values.
of(long...) - Static method in class com.google.common.math.Stats
Returns statistics over a dataset containing the given values.
of() - Static method in class com.google.common.primitives.ImmutableDoubleArray
Returns the empty array.
of(double) - Static method in class com.google.common.primitives.ImmutableDoubleArray
Returns an immutable array containing a single value.
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(double, double...) - Static method in class com.google.common.primitives.ImmutableDoubleArray
Returns an immutable array containing the given values, in order.
of() - Static method in class com.google.common.primitives.ImmutableIntArray
Returns the empty array.
of(int) - Static method in class com.google.common.primitives.ImmutableIntArray
Returns an immutable array containing a single value.
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(int, int...) - Static method in class com.google.common.primitives.ImmutableIntArray
Returns an immutable array containing the given values, in order.
of() - Static method in class com.google.common.primitives.ImmutableLongArray
Returns the empty array.
of(long) - Static method in class com.google.common.primitives.ImmutableLongArray
Returns an immutable array containing a single value.
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(long, long...) - Static method in class com.google.common.primitives.ImmutableLongArray
Returns an immutable array containing the given values, in order.
of() - Static method in class com.google.common.reflect.ImmutableTypeToInstanceMap
Returns an empty type to instance map.
of(Class<T>) - Static method in class com.google.common.reflect.TypeToken
Returns an instance of type token that wraps type.
of(Type) - Static method in class com.google.common.reflect.TypeToken
Returns an instance of type token that wraps type.
offer(E) - Method in class com.google.common.collect.EvictingQueue
Adds the given element to this queue.
offer(E, long, TimeUnit) - Method in class com.google.common.collect.ForwardingBlockingDeque
Deprecated.
 
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, long, TimeUnit) - Method in class com.google.common.util.concurrent.ForwardingBlockingDeque
 
offer(E, long, TimeUnit) - Method in class com.google.common.util.concurrent.ForwardingBlockingQueue
 
offerFirst(E, long, TimeUnit) - Method in class com.google.common.collect.ForwardingBlockingDeque
Deprecated.
 
offerFirst(E) - Method in class com.google.common.collect.ForwardingDeque
 
offerFirst(E, long, TimeUnit) - Method in class com.google.common.util.concurrent.ForwardingBlockingDeque
 
offerLast(E, long, TimeUnit) - Method in class com.google.common.collect.ForwardingBlockingDeque
Deprecated.
 
offerLast(E) - Method in class com.google.common.collect.ForwardingDeque
 
offerLast(E, long, TimeUnit) - Method in class com.google.common.util.concurrent.ForwardingBlockingDeque
 
ofInstance(T) - Static method in class com.google.common.base.Suppliers
Returns a supplier that always supplies instance.
OGG_AUDIO - Static variable in class com.google.common.net.MediaType
 
OGG_CONTAINER - Static variable in class com.google.common.net.MediaType
 
OGG_VIDEO - Static variable in class com.google.common.net.MediaType
 
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.
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.
on(String) - Static method in class com.google.common.base.Joiner
Returns a joiner which automatically places separator between consecutive elements.
on(char) - Static method in class com.google.common.base.Joiner
Returns a joiner which automatically places separator between consecutive elements.
on(char) - Static method in class com.google.common.base.Splitter
Returns a splitter that uses the given single-character separator.
on(CharMatcher) - Static method in class com.google.common.base.Splitter
Returns a splitter that considers any single character matched by the given CharMatcher to be a separator.
on(String) - Static method in class com.google.common.base.Splitter
Returns a splitter that uses the given fixed string as a separator.
on(Pattern) - Static method in class com.google.common.base.Splitter
Returns a splitter that considers any subsequence matching pattern to be a separator.
ONE - Static variable in class com.google.common.primitives.UnsignedInteger
 
ONE - Static variable in class com.google.common.primitives.UnsignedLong
 
onFailure(Throwable) - Method in interface com.google.common.util.concurrent.FutureCallback
Invoked when a Future computation fails or is canceled.
onlyElement() - Static method in class com.google.common.collect.MoreCollectors
A collector that takes a stream containing exactly one element and returns that element.
onPattern(String) - Static method in class com.google.common.base.Splitter
Returns a splitter that considers any subsequence matching a given pattern (regular expression) to be a separator.
onRemoval(RemovalNotification<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<F, ? extends T>) - Method in class com.google.common.base.Equivalence
Returns a new equivalence relation for F which evaluates equivalence by first applying function to the argument, then evaluating using this.
onResultOf(Function<F, ? extends T>) - Method in class com.google.common.collect.Ordering
Returns a new ordering on F which orders elements by first applying a function to them, then comparing those results using this.
onSuccess(V) - Method in interface com.google.common.util.concurrent.FutureCallback
Invoked with the result of the Future computation when it is successful.
OOXML_DOCUMENT - Static variable in class com.google.common.net.MediaType
 
OOXML_PRESENTATION - Static variable in class com.google.common.net.MediaType
 
OOXML_SHEET - Static variable in class com.google.common.net.MediaType
 
open(C, C) - Static method in class com.google.common.collect.Range
Returns a range that contains all values strictly greater than lower and strictly less than upper.
openBufferedStream() - Method in class com.google.common.io.ByteSink
Opens a new buffered OutputStream for writing to this sink.
openBufferedStream() - Method in class com.google.common.io.ByteSource
Opens a new buffered InputStream for reading from this source.
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
 
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
Opens a new InputStream for reading from this source.
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
Opens a new Reader for reading from this source.
Optional<T> - Class in com.google.common.base
An immutable object that may contain a non-null reference to another object.
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(T) - Method in class com.google.common.base.Optional
Returns the contained instance if it is present; defaultValue otherwise.
or(Optional<? extends T>) - Method in class com.google.common.base.Optional
Returns this Optional if it has a value present; secondChoice otherwise.
or(Supplier<? extends T>) - Method in class com.google.common.base.Optional
Returns the contained instance if it is present; supplier.get() otherwise.
or(Iterable<? extends Predicate<? super T>>) - Static method in class com.google.common.base.Predicates
Returns a predicate that evaluates to true if any one of its components evaluates to true.
or(Predicate<? super T>...) - Static method in class com.google.common.base.Predicates
Returns a predicate that evaluates to true if any one of its components evaluates to true.
or(Predicate<? super T>, Predicate<? super T>) - Static method in class com.google.common.base.Predicates
Returns a predicate that evaluates to true if either of its components evaluates to true.
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.
orderedBy(Comparator<K>) - Static method in class com.google.common.collect.ImmutableSortedMap
Returns a builder that creates immutable sorted maps with an explicit comparator.
orderedBy(Comparator<E>) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns a builder that creates immutable sorted multisets with an explicit comparator.
orderedBy(Comparator<E>) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns a builder that creates immutable sorted sets with an explicit comparator.
orderedBy(Comparator<B>) - Static method in class com.google.common.collect.MinMaxPriorityQueue
Creates and returns a new builder, configured to build MinMaxPriorityQueue instances that use comparator to determine the least and greatest elements.
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.
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<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).
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.
ORIGIN - Static variable in class com.google.common.net.HttpHeaders
The HTTP Origin header field name.
orNull() - Method in class com.google.common.base.Optional
Returns the contained instance if it is present; null otherwise.
outDegree(N) - Method in class com.google.common.graph.AbstractNetwork
 
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 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.
outEdges(N) - Method in interface com.google.common.graph.Network
Returns all edges in this network which can be traversed in the direction (if any) of the edge starting from node.

P

P3P - Static variable in class com.google.common.net.HttpHeaders
The HTTP P3P header field name.
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.
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
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.
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.
Parameter - Class in com.google.common.reflect
Represents a method or constructor parameter.
parameters() - Method in class com.google.common.net.MediaType
Returns a multimap containing the parameters of this media type.
parent() - Method in class com.google.common.net.InternetDomainName
Returns an InternetDomainName that is the immediate ancestor of this one; that is, the current domain with the leftmost part removed.
parse(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.
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.
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).
parts() - Method in class com.google.common.net.InternetDomainName
Returns the individual components of this domain name, normalized to all lower case.
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.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.MinMaxPriorityQueue
 
peek() - Method in interface com.google.common.collect.PeekingIterator
Returns the next element in the iteration, without advancing the iteration.
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.
peekingIterator(Iterator<? extends T>) - Static method in class com.google.common.collect.Iterators
Returns a PeekingIterator backed by the given iterator.
peekingIterator(PeekingIterator<T>) - Static method in class com.google.common.collect.Iterators
Deprecated.
no need to use this
PeekingIterator<E> - Interface in com.google.common.collect
An iterator that supports a one-element lookahead while iterating.
peekLast() - Method in class com.google.common.collect.ForwardingDeque
 
peekLast() - Method in class com.google.common.collect.MinMaxPriorityQueue
Retrieves, but does not remove, the greatest element of this queue, or returns null if the queue is empty.
pendingToString() - Method in class com.google.common.util.concurrent.AbstractFuture
Provide a human-readable explanation of why this future has not yet completed.
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.
permutations(Collection<E>) - Static method in class com.google.common.collect.Collections2
Returns a Collection of all the permutations of the specified Collection.
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
 
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.
PNG - Static variable in class com.google.common.net.MediaType
 
poll(long, TimeUnit) - Method in class com.google.common.collect.ForwardingBlockingDeque
Deprecated.
 
poll() - Method in class com.google.common.collect.ForwardingQueue
 
poll() - Method in class com.google.common.collect.MinMaxPriorityQueue
 
poll(long, TimeUnit) - Method in class com.google.common.util.concurrent.ForwardingBlockingDeque
 
poll(long, TimeUnit) - Method in class com.google.common.util.concurrent.ForwardingBlockingQueue
 
pollFirst(long, TimeUnit) - Method in class com.google.common.collect.ForwardingBlockingDeque
Deprecated.
 
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.MinMaxPriorityQueue
Removes and returns the least element of this queue, or returns null if the queue is empty.
pollFirst(long, TimeUnit) - Method in class com.google.common.util.concurrent.ForwardingBlockingDeque
 
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 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.
pollLast(long, TimeUnit) - Method in class com.google.common.collect.ForwardingBlockingDeque
Deprecated.
 
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.MinMaxPriorityQueue
Removes and returns the greatest element of this queue, or returns null if the queue is empty.
pollLast(long, TimeUnit) - Method in class com.google.common.util.concurrent.ForwardingBlockingDeque
 
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 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.
pop() - Method in class com.google.common.collect.ForwardingDeque
 
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.
post(Object) - Method in class com.google.common.eventbus.EventBus
Posts an event to all registered subscribers.
postOrderTraversal(T) - Method in class com.google.common.collect.TreeTraverser
Returns an unmodifiable iterable over the nodes in a tree structure, using post-order traversal.
POSTSCRIPT - Static variable in class com.google.common.net.MediaType
 
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.
powerSet(Set<E>) - Static method in class com.google.common.collect.Sets
Returns the set of all possible subsets of set.
PRAGMA - Static variable in class com.google.common.net.HttpHeaders
The HTTP Pragma header field name.
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.
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).
predecessors(N) - Method in interface com.google.common.graph.Graph
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 interface com.google.common.graph.Network
Returns 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 interface com.google.common.graph.ValueGraph
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.
PredecessorsFunction<N> - Interface in com.google.common.graph
A functional interface for graph-structured data.
Predicate<T> - Interface in com.google.common.base
Legacy version of Predicate.
Predicates - Class in com.google.common.base
Static utility methods pertaining to Predicate instances.
preOrderTraversal(T) - Method in class com.google.common.collect.TreeTraverser
Returns an unmodifiable iterable over the nodes in a tree structure, using pre-order traversal.
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().
previous(C) - Method in class com.google.common.collect.DiscreteDomain
Returns the unique greatest value of type C that is less than value, or null if none exists.
previous() - Method in class com.google.common.collect.ForwardingListIterator
 
previousIndex() - Method in class com.google.common.collect.ForwardingListIterator
 
Primitives - Class in com.google.common.primitives
Contains static utility methods pertaining to primitive types and their corresponding wrapper types.
PrimitiveSink - Interface in com.google.common.hash
An object which can receive a stream of primitive values.
processBytes(byte[], int, int) - Method in interface com.google.common.io.ByteProcessor
This method will be called for each chunk of bytes in an input stream.
processLine(String) - Method in interface com.google.common.io.LineProcessor
This method will be called once for each line.
propagate(Throwable) - Static method in class com.google.common.base.Throwables
Deprecated.
Use throw e or throw new RuntimeException(e) directly, or use a combination of Throwables.throwIfUnchecked(java.lang.Throwable) and throw new RuntimeException(e). For background on the deprecation, read Why we deprecated Throwables.propagate. This method is scheduled to be removed in July 2018.
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. This method is scheduled to be removed in July 2018.
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. This method is scheduled to be removed in July 2018.
propagateIfPossible(Throwable, Class<X>) - Static method in class com.google.common.base.Throwables
Propagates throwable exactly as-is, if and only if it is an instance of RuntimeException, Error, or declaredType.
propagateIfPossible(Throwable, Class<X1>, Class<X2>) - Static method in class com.google.common.base.Throwables
Propagates throwable exactly as-is, if and only if it is an instance of RuntimeException, Error, declaredType1, or declaredType2.
PROTOBUF - Static variable in class com.google.common.net.MediaType
PROXY_AUTHENTICATE - Static variable in class com.google.common.net.HttpHeaders
The HTTP Proxy-Authenticate header field name.
PROXY_AUTHORIZATION - Static variable in class com.google.common.net.HttpHeaders
The HTTP Proxy-Authorization header field name.
PSD - Static variable in class com.google.common.net.MediaType
The media type for the Photoshop File Format (psd files) as defined by IANA, and found in /etc/mime.types, e.g.
PUBLIC_KEY_PINS - Static variable in class com.google.common.net.HttpHeaders
The HTTP Public-Key-Pins header field name.
PUBLIC_KEY_PINS_REPORT_ONLY - Static variable in class com.google.common.net.HttpHeaders
The HTTP Public-Key-Pins-Report-Only header field name.
publicSuffix() - Method in class com.google.common.net.InternetDomainName
Returns the public suffix portion of the domain name, or null if no public suffix is present.
push(E) - Method in class com.google.common.collect.ForwardingDeque
 
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(R, C, V) - Method in class com.google.common.collect.ArrayTable
Associates the specified value with the specified keys.
put(K, V) - Method in interface com.google.common.collect.BiMap
put(K, V) - Method in class com.google.common.collect.EnumHashBiMap
 
put(E) - Method in class com.google.common.collect.ForwardingBlockingDeque
Deprecated.
 
put(K, V) - Method in class com.google.common.collect.ForwardingMap
 
put(K, V) - Method in class com.google.common.collect.ForwardingMultimap
 
put(R, C, V) - Method in class com.google.common.collect.ForwardingTable
 
put(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(Map.Entry<? extends K, ? extends V>) - Method in class com.google.common.collect.ImmutableBiMap.Builder
Adds the given entry to the bimap.
put(Class<T>, T) - Method in class com.google.common.collect.ImmutableClassToInstanceMap.Builder
Associates key with value in the built map.
put(K, V) - Method in class com.google.common.collect.ImmutableListMultimap.Builder
 
put(Map.Entry<? extends K, ? extends V>) - Method in class com.google.common.collect.ImmutableListMultimap.Builder
Adds an entry to the built multimap.
put(K, V) - Method in class com.google.common.collect.ImmutableMap.Builder
Associates key with value in the built map.
put(Map.Entry<? extends K, ? extends V>) - Method in class com.google.common.collect.ImmutableMap.Builder
Adds the given entry to the map, making it immutable if necessary.
put(K, V) - Method in class com.google.common.collect.ImmutableMap
Deprecated.
Unsupported operation.
put(K, V) - Method in class com.google.common.collect.ImmutableMultimap.Builder
Adds a key-value mapping to the built multimap.
put(Map.Entry<? extends K, ? extends V>) - Method in class com.google.common.collect.ImmutableMultimap.Builder
Adds an entry to the built multimap.
put(K, V) - Method in class com.google.common.collect.ImmutableMultimap
Deprecated.
Unsupported operation.
put(Range<K>, V) - Method in class com.google.common.collect.ImmutableRangeMap.Builder
Associates the specified range with the specified value.
put(Range<K>, V) - Method in class com.google.common.collect.ImmutableRangeMap
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(Map.Entry<? extends K, ? extends V>) - Method in class com.google.common.collect.ImmutableSetMultimap.Builder
Adds an entry to the built multimap if it is not already present.
put(K, V) - Method in class com.google.common.collect.ImmutableSortedMap.Builder
Associates key with value in the built map.
put(Map.Entry<? extends K, ? extends V>) - Method in class com.google.common.collect.ImmutableSortedMap.Builder
Adds the given entry to the map, making it immutable if necessary.
put(R, C, V) - Method in class com.google.common.collect.ImmutableTable.Builder
Associates the (rowKey, columnKey) pair with value in the built table.
put(Table.Cell<? extends R, ? extends C, ? extends V>) - Method in class com.google.common.collect.ImmutableTable.Builder
Adds the given cell to the table, making it immutable if necessary.
put(R, C, V) - Method in class com.google.common.collect.ImmutableTable
Deprecated.
Unsupported operation.
put(K, V) - Method in class com.google.common.collect.LinkedListMultimap
Stores a key-value pair in the multimap.
put(K, V) - Method in interface com.google.common.collect.Multimap
Stores a key-value pair in this multimap.
put(Class<? extends B>, B) - Method in class com.google.common.collect.MutableClassToInstanceMap
 
put(Range<K>, V) - Method in interface com.google.common.collect.RangeMap
Maps a range to a specified value (optional operation).
put(R, C, V) - Method in interface com.google.common.collect.Table
Associates the specified value with the specified keys.
put(Range<K>, V) - Method in class com.google.common.collect.TreeRangeMap
 
put(T) - Method in class com.google.common.hash.BloomFilter
Puts an element into this BloomFilter.
put(Class<T>, T) - Method in class com.google.common.reflect.ImmutableTypeToInstanceMap.Builder
Associates key with value in the built map.
put(TypeToken<T>, T) - Method in class com.google.common.reflect.ImmutableTypeToInstanceMap.Builder
Associates key with value in the built map.
put(TypeToken<? extends B>, B) - Method in class com.google.common.reflect.ImmutableTypeToInstanceMap
Deprecated.
unsupported operation
put(TypeToken<? extends B>, B) - Method in class com.google.common.reflect.MutableTypeToInstanceMap
Deprecated.
unsupported operation
put(K, long) - Method in class com.google.common.util.concurrent.AtomicLongMap
Associates newValue with key in this map, and returns the value previously associated with key, or zero if there was no such value.
put(E) - Method in class com.google.common.util.concurrent.ForwardingBlockingDeque
 
put(E) - Method in class com.google.common.util.concurrent.ForwardingBlockingQueue
 
putAll(Map<? extends K, ? extends V>) - Method in class com.google.common.cache.AbstractCache
 
putAll(Map<? extends K, ? extends V>) - Method in interface com.google.common.cache.Cache
Copies all of the mappings from the specified map to the cache.
putAll(Map<? extends K, ? extends V>) - Method in class com.google.common.cache.ForwardingCache
 
putAll(Table<? extends R, ? extends C, ? extends V>) - Method in class com.google.common.collect.ArrayTable
Copies all mappings from the specified table to this table.
putAll(Map<? extends K, ? extends V>) - Method in interface com.google.common.collect.BiMap
putAll(Map<? extends K, ? extends V>) - Method in class com.google.common.collect.ForwardingMap
 
putAll(K, Iterable<? extends V>) - Method in class com.google.common.collect.ForwardingMultimap
 
putAll(Multimap<? extends K, ? extends V>) - Method in class com.google.common.collect.ForwardingMultimap
 
putAll(Table<? extends R, ? extends C, ? extends V>) - Method in class com.google.common.collect.ForwardingTable
 
putAll(Map<? extends K, ? extends V>) - Method in class com.google.common.collect.ImmutableBiMap.Builder
Associates all of the given map's keys and values in the built bimap.
putAll(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(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(Iterable<? extends Map.Entry<? extends K, ? extends V>>) - Method in class com.google.common.collect.ImmutableListMultimap.Builder
Adds entries to the built multimap.
putAll(K, Iterable<? extends V>) - Method in class com.google.common.collect.ImmutableListMultimap.Builder
 
putAll(K, V...) - Method in class com.google.common.collect.ImmutableListMultimap.Builder
 
putAll(Multimap<? extends K, ? extends V>) - Method in class com.google.common.collect.ImmutableListMultimap.Builder
 
putAll(Map<? extends K, ? extends V>) - Method in class com.google.common.collect.ImmutableMap.Builder
Associates all of the given map's keys and values in the built map.
putAll(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(Map<? extends K, ? extends V>) - Method in class com.google.common.collect.ImmutableMap
Deprecated.
Unsupported operation.
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(K, Iterable<? extends V>) - Method in class com.google.common.collect.ImmutableMultimap.Builder
Stores a collection of values with the same key in the built multimap.
putAll(K, V...) - Method in class com.google.common.collect.ImmutableMultimap.Builder
Stores an array of values with the same key in the built multimap.
putAll(Multimap<? extends K, ? extends V>) - Method in class com.google.common.collect.ImmutableMultimap.Builder
Stores another multimap's entries in the built multimap.
putAll(K, Iterable<? extends V>) - Method in class com.google.common.collect.ImmutableMultimap
Deprecated.
Unsupported operation.
putAll(Multimap<? extends K, ? extends V>) - Method in class com.google.common.collect.ImmutableMultimap
Deprecated.
Unsupported operation.
putAll(RangeMap<K, ? extends V>) - Method in class com.google.common.collect.ImmutableRangeMap.Builder
Copies all associations from the specified range map into this builder.
putAll(RangeMap<K, V>) - Method in class com.google.common.collect.ImmutableRangeMap
Deprecated.
Unsupported operation.
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(K, Iterable<? extends V>) - Method in class com.google.common.collect.ImmutableSetMultimap.Builder
 
putAll(K, V...) - Method in class com.google.common.collect.ImmutableSetMultimap.Builder
 
putAll(Multimap<? extends K, ? extends V>) - Method in class com.google.common.collect.ImmutableSetMultimap.Builder
 
putAll(Map<? extends K, ? extends V>) - Method in class com.google.common.collect.ImmutableSortedMap.Builder
Associates all of the given map's keys and values in the built map.
putAll(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(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(K, Iterable<? extends V>) - Method in interface com.google.common.collect.Multimap
Stores a key-value pair in this multimap for each of values, all using the same key, key.
putAll(Multimap<? extends K, ? extends V>) - Method in interface com.google.common.collect.Multimap
Stores all key-value pairs of multimap in this multimap, in the order returned by multimap.entries().
putAll(Map<? extends Class<? extends B>, ? extends B>) - Method in class com.google.common.collect.MutableClassToInstanceMap
 
putAll(RangeMap<K, V>) - Method in interface com.google.common.collect.RangeMap
Puts all the associations from rangeMap into this range map (optional operation).
putAll(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(RangeMap<K, V>) - Method in class com.google.common.collect.TreeRangeMap
 
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(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 K, ? extends Long>) - Method in class com.google.common.util.concurrent.AtomicLongMap
Copies all of the mappings from the specified map to this map.
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 interface com.google.common.hash.Hasher
 
putByte(byte) - Method in interface com.google.common.hash.PrimitiveSink
Puts a byte into this sink.
putBytes(byte[]) - Method in interface com.google.common.hash.Hasher
 
putBytes(byte[], int, int) - Method in interface com.google.common.hash.Hasher
 
putBytes(ByteBuffer) - Method in interface com.google.common.hash.Hasher
 
putBytes(byte[]) - Method in interface com.google.common.hash.PrimitiveSink
Puts an array of bytes into this sink.
putBytes(byte[], int, int) - Method in interface com.google.common.hash.PrimitiveSink
Puts a chunk of an array of bytes into this sink.
putBytes(ByteBuffer) - Method in interface com.google.common.hash.PrimitiveSink
Puts the remaining bytes of a byte buffer into this sink.
putChar(char) - Method in interface com.google.common.hash.Hasher
 
putChar(char) - Method in interface com.google.common.hash.PrimitiveSink
Puts a character into this sink.
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
 
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(N, N) - Method in interface com.google.common.graph.MutableGraph
Adds an edge connecting nodeU to nodeV if one is not already present.
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; associate that edge with value.
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 interface com.google.common.hash.Hasher
Equivalent to putInt(Float.floatToRawIntBits(f)).
putFloat(float) - Method in interface com.google.common.hash.PrimitiveSink
Puts a float into this sink.
putIfAbsent(K, V) - Method in class com.google.common.collect.ForwardingConcurrentMap
 
putIfAbsent(K, V) - Method in class com.google.common.collect.ImmutableMap
Deprecated.
Unsupported operation.
putInstance(Class<T>, T) - Method in interface com.google.common.collect.ClassToInstanceMap
Maps the specified class to the specified value.
putInstance(Class<T>, T) - Method in class com.google.common.collect.ImmutableClassToInstanceMap
Deprecated.
Unsupported operation.
putInstance(Class<T>, T) - Method in class com.google.common.collect.MutableClassToInstanceMap
 
putInstance(TypeToken<T>, T) - Method in class com.google.common.reflect.ImmutableTypeToInstanceMap
Deprecated.
unsupported operation
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(TypeToken<T>, T) - Method in class com.google.common.reflect.MutableTypeToInstanceMap
 
putInstance(Class<T>, T) - Method in interface com.google.common.reflect.TypeToInstanceMap
Maps the specified class to the specified value.
putInstance(TypeToken<T>, T) - Method in interface com.google.common.reflect.TypeToInstanceMap
Maps the specified type to the specified value.
putInt(int) - Method in interface com.google.common.hash.Hasher
 
putInt(int) - Method in interface com.google.common.hash.PrimitiveSink
Puts an int into this sink.
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 interface com.google.common.hash.Hasher
 
putLong(long) - Method in interface com.google.common.hash.PrimitiveSink
Puts a long into this sink.
putObject(T, Funnel<? super T>) - Method in interface com.google.common.hash.Hasher
A simple convenience for funnel.funnel(object, this).
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 interface com.google.common.hash.Hasher
Equivalent to putBytes(charSequence.toString().getBytes(charset)).
putString(CharSequence, Charset) - Method in interface com.google.common.hash.PrimitiveSink
Puts a string into this sink using the given charset.
putUnencodedChars(CharSequence) - Method in 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

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.
Queues - Class in com.google.common.collect
Static utility methods pertaining to Queue and Deque instances.
QUICKTIME - Static variable in class com.google.common.net.MediaType
 

R

range() - Method in class com.google.common.collect.ContiguousSet
Returns a range, closed on both ends, whose endpoints are the minimum and maximum values contained in this set.
range(BoundType, BoundType) - Method in class com.google.common.collect.ContiguousSet
Returns the minimal range with the given boundary types for which all values in this set are contained within the range.
Range<C extends Comparable> - Class in com.google.common.collect
A range (or "interval") defines the boundaries around a contiguous span of values of some Comparable type; for example, "integers from 1 to 100 inclusive." Note that it is not possible to iterate over these contained values.
range(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 - Static variable in class com.google.common.net.HttpHeaders
The HTTP Range header field name.
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
 
RangeMap<K extends Comparable,V> - Interface in com.google.common.collect
A mapping from disjoint nonempty ranges to non-null values.
RangeSet<C extends Comparable> - Interface in com.google.common.collect
A set comprising zero or more nonempty, disconnected ranges of type C.
RateLimiter - Class in com.google.common.util.concurrent
A rate limiter.
rawTypes() - Method in class com.google.common.reflect.TypeToken.TypeSet
Returns the raw types of the types in this set, in the same order.
RDF_XML_UTF_8 - Static variable in class com.google.common.net.MediaType
 
reachableNodes(Graph<N>, N) - Static method in class com.google.common.graph.Graphs
Returns the set of nodes that are reachable from node.
read() - Method in class com.google.common.base.Ticker
Returns the number of nanoseconds elapsed since this ticker's fixed point of reference.
read() - Method in class com.google.common.hash.HashingInputStream
Reads the next byte of data from the underlying input stream and updates the hasher with the byte read.
read(byte[], int, int) - Method in class com.google.common.hash.HashingInputStream
Reads the specified bytes of data from the underlying input stream and updates the hasher with the bytes read.
read() - Method in class com.google.common.io.ByteSource
Reads the full contents of this byte source as a byte array.
read(ByteProcessor<T>) - Method in class com.google.common.io.ByteSource
Reads the contents of this byte source using the given processor to process bytes as they are read.
read(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() - Method in class com.google.common.io.CharSource
Reads the contents of this source as a string.
read() - Method in class com.google.common.io.CountingInputStream
 
read(byte[], int, int) - Method in class com.google.common.io.CountingInputStream
 
readBoolean() - Method in interface com.google.common.io.ByteArrayDataInput
 
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.LittleEndianDataInputStream
 
readBytes(InputStream, ByteProcessor<T>) - Static method in class com.google.common.io.ByteStreams
Process the bytes of the given input stream using the given processor.
readBytes(File, ByteProcessor<T>) - Static method in class com.google.common.io.Files
Deprecated.
Prefer asByteSource(file).read(processor). This method is scheduled to be removed in January 2019.
readChar() - Method in interface com.google.common.io.ByteArrayDataInput
 
readChar() - Method in class com.google.common.io.LittleEndianDataInputStream
Reads a char as specified by DataInputStream.readChar(), except using little-endian byte order.
readDouble() - Method in interface com.google.common.io.ByteArrayDataInput
 
readDouble() - Method in class com.google.common.io.LittleEndianDataInputStream
Reads a double as specified by DataInputStream.readDouble(), except using little-endian byte order.
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(). This method is scheduled to be removed in January 2019.
readFloat() - Method in interface com.google.common.io.ByteArrayDataInput
 
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.
readFully(byte[]) - Method in interface com.google.common.io.ByteArrayDataInput
 
readFully(byte[], int, int) - Method in interface com.google.common.io.ByteArrayDataInput
 
readFully(InputStream, byte[]) - Static method in class com.google.common.io.ByteStreams
Attempts to read enough bytes from the stream to fill the given byte array, with the same behavior as DataInput.readFully(byte[]).
readFully(InputStream, byte[], int, int) - Static method in class com.google.common.io.ByteStreams
Attempts to read len bytes from the stream into the given array starting at off, with the same behavior as DataInput.readFully(byte[], int, int).
readFully(byte[]) - Method in class com.google.common.io.LittleEndianDataInputStream
 
readFully(byte[], int, int) - Method in class com.google.common.io.LittleEndianDataInputStream
 
readInt() - Method in interface com.google.common.io.ByteArrayDataInput
 
readInt() - Method in class com.google.common.io.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.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
Reads all the lines of this source as a list of strings.
readLines(LineProcessor<T>) - Method in class com.google.common.io.CharSource
Reads lines of text from this source, processing each line as it is read using the given processor.
readLines(Readable) - Static method in class com.google.common.io.CharStreams
Reads all of the lines from a Readable object.
readLines(Readable, LineProcessor<T>) - Static method in class com.google.common.io.CharStreams
Streams lines from a Readable object, stopping when the processor returns false or all lines have been read and returning the result produced by the processor.
readLines(File, Charset) - Static method in class com.google.common.io.Files
Reads all of the lines from a file.
readLines(File, Charset, LineProcessor<T>) - Static method in class com.google.common.io.Files
Deprecated.
Prefer asCharSource(file, charset).readLines(callback). This method is scheduled to be removed in January 2019.
readLines(URL, Charset, LineProcessor<T>) - Static method in class com.google.common.io.Resources
Streams lines from a URL, stopping when our callback returns false, or we have read all of the lines.
readLines(URL, Charset) - Static method in class com.google.common.io.Resources
Reads all of the lines from a URL.
readLong() - Method in interface com.google.common.io.ByteArrayDataInput
 
readLong() - Method in class com.google.common.io.LittleEndianDataInputStream
Reads a long as specified by DataInputStream.readLong(), except using little-endian byte order.
readShort() - Method in interface com.google.common.io.ByteArrayDataInput
 
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.LittleEndianDataInputStream
 
readUnsignedShort() - Method in interface com.google.common.io.ByteArrayDataInput
 
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.LittleEndianDataInputStream
 
readWriteLock(int) - Static method in class com.google.common.util.concurrent.Striped
Creates a Striped<ReadWriteLock> with eagerly initialized, strongly referenced read-write locks.
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.
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.
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.
recordStats() - Method in class com.google.common.cache.CacheBuilder
Enable the accumulation of CacheStats during the operation of the cache.
RecursiveDeleteOption - Enum in com.google.common.io
REFERER - Static variable in class com.google.common.net.HttpHeaders
The HTTP Referer header field name.
Reflection - Class in com.google.common.reflect
Static utilities relating to Java reflection.
refresh(K) - Method in class com.google.common.cache.AbstractLoadingCache
 
refresh(K) - Method in class com.google.common.cache.ForwardingLoadingCache
 
refresh(K) - Method in interface com.google.common.cache.LoadingCache
Loads a new value for key key, possibly asynchronously.
REFRESH - 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.
register(Object) - Method in class com.google.common.eventbus.EventBus
Registers all subscriber methods on object to receive events.
register(C) - Method in class com.google.common.io.Closer
Registers the given closeable to be closed when this Closer is closed.
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.
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
 
RemovalCause - Enum in com.google.common.cache
The reason why a cached entry was removed.
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.
RemovalNotification<K,V> - Class in com.google.common.cache
A notification of the removal of a single entry.
remove(Object, Object) - Method in class com.google.common.collect.ArrayTable
remove(Object, int) - Method in class com.google.common.collect.ConcurrentHashMultiset
Removes a number of occurrences of the specified element from this multiset.
remove(Object) - Method in class com.google.common.collect.EvictingQueue
 
remove(Object) - Method in class com.google.common.collect.ForwardingCollection
 
remove(Object, Object) - Method in class com.google.common.collect.ForwardingConcurrentMap
 
remove() - Method in class com.google.common.collect.ForwardingIterator
 
remove(int) - Method in class com.google.common.collect.ForwardingList
 
remove(Object) - Method in class com.google.common.collect.ForwardingMap
 
remove(Object, Object) - Method in class com.google.common.collect.ForwardingMultimap
 
remove(Object, int) - Method in class com.google.common.collect.ForwardingMultiset
 
remove() - Method in class com.google.common.collect.ForwardingQueue
 
remove(Object, Object) - Method in class com.google.common.collect.ForwardingTable
 
remove(Object, Object) - Method in class com.google.common.collect.HashBasedTable
 
remove(Object) - Method in class com.google.common.collect.HashBiMap
 
remove(Object) - Method in class com.google.common.collect.ImmutableCollection
Deprecated.
Unsupported operation.
remove(int) - Method in class com.google.common.collect.ImmutableList
Deprecated.
Unsupported operation.
remove(Object) - Method in class com.google.common.collect.ImmutableMap
Deprecated.
Unsupported operation.
remove(Object, Object) - Method in class com.google.common.collect.ImmutableMap
Deprecated.
Unsupported operation.
remove(Object, Object) - Method in class com.google.common.collect.ImmutableMultimap
Deprecated.
Unsupported operation.
remove(Object, int) - Method in class com.google.common.collect.ImmutableMultiset
Deprecated.
Unsupported operation.
remove(Range<K>) - Method in class com.google.common.collect.ImmutableRangeMap
Deprecated.
Unsupported operation.
remove(Range<C>) - Method in class com.google.common.collect.ImmutableRangeSet
Deprecated.
Unsupported operation.
remove(Object, Object) - Method in class com.google.common.collect.ImmutableTable
Deprecated.
Unsupported operation.
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, int) - Method in interface com.google.common.collect.Multiset
Removes a number of occurrences of the specified element from this multiset.
remove(Object) - Method in interface com.google.common.collect.Multiset
Removes a single occurrence of the specified element from this multiset, if present.
remove() - Method in interface com.google.common.collect.PeekingIterator
remove(Range<K>) - Method in interface com.google.common.collect.RangeMap
Removes all associations from this range map in the specified range (optional operation).
remove(Range<C>) - Method in interface com.google.common.collect.RangeSet
Removes the specified range from this RangeSet (optional operation).
remove(Object) - Method in class com.google.common.collect.Sets.SetView
Deprecated.
Unsupported operation.
remove(Object, Object) - Method in interface com.google.common.collect.Table
Removes the mapping, if any, associated with the given keys.
remove(Object, int) - Method in class com.google.common.collect.TreeMultiset
 
remove(Range<K>) - Method in class com.google.common.collect.TreeRangeMap
 
remove(Range<C>) - Method in class com.google.common.collect.TreeRangeSet
 
remove() - Method in class com.google.common.collect.UnmodifiableIterator
Deprecated.
Unsupported operation.
remove(K) - Method in class com.google.common.util.concurrent.AtomicLongMap
Removes and returns the value associated with key.
removeAll(Collection<?>) - Method in class com.google.common.collect.ForwardingCollection
 
removeAll(Object) - Method in class com.google.common.collect.ForwardingListMultimap
 
removeAll(Object) - Method in class com.google.common.collect.ForwardingMultimap
 
removeAll(Object) - Method in class com.google.common.collect.ForwardingSetMultimap
 
removeAll(Object) - Method in class com.google.common.collect.ForwardingSortedSetMultimap
 
removeAll(Collection<?>) - Method in class com.google.common.collect.ImmutableCollection
Deprecated.
Unsupported operation.
removeAll(Object) - Method in class com.google.common.collect.ImmutableListMultimap
Deprecated.
Unsupported operation.
removeAll(Object) - Method in class com.google.common.collect.ImmutableMultimap
Deprecated.
Unsupported operation.
removeAll(RangeSet<C>) - Method in class com.google.common.collect.ImmutableRangeSet
Deprecated.
Unsupported operation.
removeAll(Iterable<Range<C>>) - Method in class com.google.common.collect.ImmutableRangeSet
Deprecated.
Unsupported operation.
removeAll(Object) - Method in class com.google.common.collect.ImmutableSetMultimap
Deprecated.
Unsupported operation.
removeAll(Iterable<?>, Collection<?>) - Static method in class com.google.common.collect.Iterables
Removes, from an iterable, every element that belongs to the provided collection.
removeAll(Iterator<?>, Collection<?>) - Static method in class com.google.common.collect.Iterators
Traverses an iterator and removes every element that belongs to the provided collection.
removeAll(Object) - Method in class com.google.common.collect.LinkedListMultimap
Removes all values associated with the key key.
removeAll(Object) - Method in interface com.google.common.collect.ListMultimap
Removes all values associated with the key key.
removeAll(Object) - Method in interface com.google.common.collect.Multimap
Removes all values associated with the key key.
removeAll(Collection<?>) - Method in interface com.google.common.collect.Multiset
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<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 interface com.google.common.collect.SetMultimap
Removes all values associated with the key key.
removeAll(Collection<?>) - Method in class com.google.common.collect.Sets.SetView
Deprecated.
Unsupported operation.
removeAll(Object) - Method in interface com.google.common.collect.SortedSetMultimap
Removes all values associated with a given key.
removeAllZeros() - Method in class com.google.common.util.concurrent.AtomicLongMap
Removes all mappings from this map whose values are zero.
removeEdge(N, N) - Method in interface com.google.common.graph.MutableGraph
Removes the edge connecting nodeU to nodeV, if it is present.
removeEdge(E) - Method in interface com.google.common.graph.MutableNetwork
Removes edge from this network, 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.
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.
removeFirstOccurrence(Object) - Method in class com.google.common.collect.ForwardingDeque
 
removeFrom(CharSequence) - Method in class com.google.common.base.CharMatcher
Returns a string containing all non-matching characters of a character sequence, in order.
removeIf(Predicate<? super E>) - Method in class com.google.common.collect.ImmutableCollection
Deprecated.
Unsupported operation.
removeIf(Iterable<T>, Predicate<? super T>) - Static method in class com.google.common.collect.Iterables
Removes, from an iterable, every element that satisfies the provided predicate.
removeIf(Iterator<T>, Predicate<? super T>) - Static method in class com.google.common.collect.Iterators
Removes every element that satisfies the provided predicate from the iterator.
removeIf(Predicate<? super E>) - Method in class com.google.common.collect.Sets.SetView
Deprecated.
Unsupported operation.
removeIfZero(K) - Method in class com.google.common.util.concurrent.AtomicLongMap
Atomically remove key from the map iff its associated value is 0.
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.
removeLastOccurrence(Object) - Method in class com.google.common.collect.ForwardingDeque
 
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.
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.
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.
repeat(String, int) - Static method in class com.google.common.base.Strings
Returns a string consisting of a specific number of concatenated copies of an input string.
replace(K, V) - Method in class com.google.common.collect.ForwardingConcurrentMap
 
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) - 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.ForwardingNavigableMap.StandardDescendingMap
 
replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in class com.google.common.collect.HashBiMap
 
replaceAll(UnaryOperator<E>) - Method in class com.google.common.collect.ImmutableList
Deprecated.
Unsupported operation.
replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in class com.google.common.collect.ImmutableMap
Deprecated.
Unsupported operation.
replaceFrom(CharSequence, char) - Method in class com.google.common.base.CharMatcher
Returns a string copy of the input character sequence, with each character that matches this matcher replaced by a given replacement character.
replaceFrom(CharSequence, CharSequence) - Method in class com.google.common.base.CharMatcher
Returns a string copy of the input character sequence, with each character that matches this matcher replaced by a given replacement sequence.
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 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.
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.
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.hash.HashingInputStream
reset() is not supported for HashingInputStream.
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.
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.
Resources - Class in com.google.common.io
Provides utility methods for working with resources in the classpath.
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.
retainAll(Collection<?>) - Method in class com.google.common.collect.ForwardingCollection
 
retainAll(Collection<?>) - Method in class com.google.common.collect.ImmutableCollection
Deprecated.
Unsupported operation.
retainAll(Iterable<?>, Collection<?>) - Static method in class com.google.common.collect.Iterables
Removes, from an iterable, every element that does not belong to the provided collection.
retainAll(Iterator<?>, Collection<?>) - Static method in class com.google.common.collect.Iterators
Traverses an iterator and removes every element that does not belong to the provided collection.
retainAll(Collection<?>) - Method in interface com.google.common.collect.Multiset
retainAll(Collection<?>) - Method in class com.google.common.collect.Sets.SetView
Deprecated.
Unsupported operation.
retainFrom(CharSequence) - Method in class com.google.common.base.CharMatcher
Returns a string containing all matching characters of a character sequence, in order.
retainOccurrences(Multiset<?>, Multiset<?>) - Static method in class com.google.common.collect.Multisets
Modifies multisetToModify so that its count for an element e is at most multisetToRetain.count(e).
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.
returning(Class<R1>) - Method in class com.google.common.reflect.Invokable
Explicitly specifies the return type of this Invokable.
returning(TypeToken<R1>) - Method in class com.google.common.reflect.Invokable
Explicitly specifies the return type of this Invokable.
returning(T) - Static method in class com.google.common.util.concurrent.Callables
Creates a Callable which immediately returns a preset value each time it is called.
reverse() - Method in class com.google.common.base.Converter
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.collect.ImmutableList
Returns a view of this immutable list in reverse order.
reverse(List<T>) - Static method in class com.google.common.collect.Lists
Returns a reversed view of the specified list.
reverse() - Method in class com.google.common.collect.Ordering
Returns the reverse of this ordering; the Ordering equivalent to Collections.reverseOrder(Comparator).
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.
rightChild(T) - Method in class com.google.common.collect.BinaryTreeTraverser
Returns the right child of the specified node, or Optional.absent() if the specified node has no right child.
rightValue() - Method in interface com.google.common.collect.MapDifference.ValueDifference
Returns the value from the right map (possibly null).
roundToBigInteger(double, RoundingMode) - Static method in class com.google.common.math.DoubleMath
Returns the BigInteger value that is equal to x rounded with the specified rounding mode, if possible.
roundToInt(double, RoundingMode) - Static method in class com.google.common.math.DoubleMath
Returns the int value that is equal to x rounded with the specified rounding mode, if possible.
roundToLong(double, RoundingMode) - Static method in class com.google.common.math.DoubleMath
Returns the long value that is equal to x rounded with the specified rounding mode, if possible.
row(R) - Method in class com.google.common.collect.ArrayTable
Returns a view of all mappings that have the given row key.
row(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 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.TreeBasedTable
Returns a view of all mappings that have the given row key.
rowComparator() - Method in class com.google.common.collect.TreeBasedTable
Deprecated.
Use table.rowKeySet().comparator() instead. This method is scheduled for removal in April 2019.
rowKeyList() - Method in class com.google.common.collect.ArrayTable
Returns, as an immutable list, the row keys provided when the table was constructed, including those that are mapped to null values only.
rowKeySet() - Method in class com.google.common.collect.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 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.TreeBasedTable
 
rowMap() - Method in class com.google.common.collect.ArrayTable
 
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 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.TreeBasedTable
 
RowSortedTable<R,C,V> - Interface in com.google.common.collect
Interface that extends Table and whose rows are sorted.
RS - Static variable in class com.google.common.base.Ascii
Record Separator: These four information separators may be used within data in optional fashion, except that their hierarchical relationship shall be: FS is the most inclusive, then GS, then RS, and US is least inclusive.
RTF_UTF_8 - Static variable in class com.google.common.net.MediaType
 
run() - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
Run the service.
Runnables - Class in com.google.common.util.concurrent
Static utility methods pertaining to the Runnable interface.
running() - Method in class com.google.common.util.concurrent.Service.Listener
Called when the service transitions from STARTING to RUNNING.
runOneIteration() - Method in class com.google.common.util.concurrent.AbstractScheduledService
Run one iteration of the scheduled task.
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.
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.

S

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.
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.
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.
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.
scale(int) - Static method in class com.google.common.math.Quantiles
Specifies the computation of q-quantiles.
Schedule(long, TimeUnit) - Constructor for class com.google.common.util.concurrent.AbstractScheduledService.CustomScheduler.Schedule
 
schedule(Runnable, long, TimeUnit) - Method in interface com.google.common.util.concurrent.ListeningScheduledExecutorService
 
schedule(Callable<V>, long, TimeUnit) - Method in interface com.google.common.util.concurrent.ListeningScheduledExecutorService
 
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.
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in interface com.google.common.util.concurrent.ListeningScheduledExecutorService
 
scheduler() - Method in class com.google.common.util.concurrent.AbstractScheduledService
Returns the AbstractScheduledService.Scheduler object used to configure this service.
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in interface com.google.common.util.concurrent.ListeningScheduledExecutorService
 
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.
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.
SERVER - Static variable in class com.google.common.net.HttpHeaders
The HTTP Server header field name.
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.Listener - Class in com.google.common.util.concurrent
A listener for the various state changes that a Service goes through in its lifecycle.
Service.State - Enum in com.google.common.util.concurrent
The lifecycle states of a service.
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.
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.Listener - Class in com.google.common.util.concurrent
A listener for the aggregate state changes of the services that are under management.
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.
servicesByState() - Method in class com.google.common.util.concurrent.ServiceManager
Provides a snapshot of the current state of all the services under management.
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(E) - Method in class com.google.common.collect.ForwardingListIterator
 
set(int, E) - Method in class com.google.common.collect.ImmutableList
Deprecated.
Unsupported operation.
set(E) - Method in class com.google.common.collect.UnmodifiableListIterator
Deprecated.
Unsupported operation.
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(double) - Method in class com.google.common.util.concurrent.AtomicDouble
Sets to the given value.
set(int, double) - Method in class com.google.common.util.concurrent.AtomicDoubleArray
Sets the element at position i to the given value.
set(V) - Method in class com.google.common.util.concurrent.SettableFuture
 
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.
setCount(E, int) - Method in class com.google.common.collect.ConcurrentHashMultiset
Adds or removes occurrences of element such that the ConcurrentHashMultiset.count(java.lang.Object) of the element becomes count.
setCount(E, int, int) - Method in class com.google.common.collect.ConcurrentHashMultiset
Sets the number of occurrences of element to newCount, but only if the count is currently expectedOldCount.
setCount(E, int) - Method in class com.google.common.collect.ForwardingMultiset
 
setCount(E, int, int) - Method in class com.google.common.collect.ForwardingMultiset
 
setCount(E, int) - Method in class com.google.common.collect.ImmutableMultiset.Builder
Adds or removes the necessary occurrences of an element such that the element attains the desired count.
setCount(E, int) - Method in class com.google.common.collect.ImmutableMultiset
Deprecated.
Unsupported operation.
setCount(E, int, int) - Method in class com.google.common.collect.ImmutableMultiset
Deprecated.
Unsupported operation.
setCount(E, int) - Method in class com.google.common.collect.ImmutableSortedMultiset.Builder
Adds or removes the necessary occurrences of an element such that the element attains the desired count.
setCount(E, int) - Method in interface com.google.common.collect.Multiset
Adds or removes the necessary occurrences of an element such that the element attains the desired count.
setCount(E, int, int) - Method in interface com.google.common.collect.Multiset
Conditionally sets the count of an element to a new value, as described in Multiset.setCount(Object, int), provided that the element has the expected current count.
setCount(E, int) - Method in class com.google.common.collect.TreeMultiset
 
setCount(E, int, int) - Method in class com.google.common.collect.TreeMultiset
 
setDaemon(boolean) - Method in class com.google.common.util.concurrent.ThreadFactoryBuilder
Sets daemon or not for new threads created with this ThreadFactory.
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
 
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
 
SetMultimap<K,V> - Interface in com.google.common.collect
A Multimap that cannot hold duplicate key-value pairs.
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.
setPriority(int) - Method in class com.google.common.util.concurrent.ThreadFactoryBuilder
Sets the priority for new threads created with this ThreadFactory.
setRate(double) - Method in class com.google.common.util.concurrent.RateLimiter
Updates the stable rate of this RateLimiter, that is, the permitsPerSecond argument provided in the factory method that constructed the RateLimiter.
Sets - Class in com.google.common.collect
Static utility methods pertaining to Set instances.
Sets.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.
setSafeRange(char, char) - Method in class com.google.common.escape.Escapers.Builder
Sets the safe range of characters for the escaper.
SettableFuture<V> - Class in com.google.common.util.concurrent
setThreadFactory(ThreadFactory) - Method in class com.google.common.util.concurrent.ThreadFactoryBuilder
Sets the backing ThreadFactory for new threads created with this ThreadFactory.
setUncaughtExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class com.google.common.util.concurrent.ThreadFactoryBuilder
Sets the Thread.UncaughtExceptionHandler for new threads created with this ThreadFactory.
setUnsafeReplacement(String) - Method in class com.google.common.escape.Escapers.Builder
Sets the replacement string for any characters outside the 'safe' range that have no explicit replacement.
setValue(V) - Method in class com.google.common.collect.ForwardingMapEntry
 
SFNT - Static variable in class com.google.common.net.MediaType
Media type for SFNT fonts (which includes TrueType and OpenType fonts).
sha1() - Static method in class com.google.common.hash.Hashing
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:
sha256() - Static method in class com.google.common.hash.Hashing
Returns a hash function implementing the SHA-256 algorithm (256 hash bits).
sha384() - Static method in class com.google.common.hash.Hashing
Returns a hash function implementing the SHA-384 algorithm (384 hash bits).
sha512() - Static method in class com.google.common.hash.Hashing
Returns a hash function implementing the SHA-512 algorithm (512 hash bits).
SHOCKWAVE_FLASH - Static variable in class com.google.common.net.MediaType
 
Shorts - Class in com.google.common.primitives
Static utility methods pertaining to short primitives, that are not already found in either Short or Arrays.
shutDown() - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
Stop the service.
shutDown() - Method in class com.google.common.util.concurrent.AbstractIdleService
Stop the service.
shutDown() - Method in class com.google.common.util.concurrent.AbstractScheduledService
Stop the service.
shutdown() - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
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.
shutdownNow() - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
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.
SignedBytes - Class in com.google.common.primitives
Static utility methods pertaining to byte primitives that interpret values as signed.
SimpleForwardingCache(Cache<K, V>) - Constructor for class com.google.common.cache.ForwardingCache.SimpleForwardingCache
 
SimpleForwardingCheckedFuture(CheckedFuture<V, X>) - Constructor for class com.google.common.util.concurrent.ForwardingCheckedFuture.SimpleForwardingCheckedFuture
Deprecated.
 
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.
simplifyPath(String) - Static method in class com.google.common.io.Files
Returns the lexically cleaned form of the path name, usually (but not always) equivalent to the original.
SINGLE_WIDTH - Static variable in class com.google.common.base.CharMatcher
Deprecated.
Use CharMatcher.singleWidth() instead. This constant is scheduled to be removed in June 2018.
singleton(C) - Static method in class com.google.common.collect.Range
Returns a range that contains only the given value.
singletonIterator(T) - Static method in class com.google.common.collect.Iterators
Returns an iterator containing only value.
singleWidth() - Static method in class com.google.common.base.CharMatcher
Determines whether a character is single-width (not double-width).
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.
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.collect.ArrayTable
 
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.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
 
size() - Method in class com.google.common.collect.ImmutableMultimap
 
size() - Method in class com.google.common.collect.ImmutableSortedMap
 
size(Iterable<?>) - Static method in class com.google.common.collect.Iterables
Returns the number of elements in iterable.
size(Iterator<?>) - Static method in class com.google.common.collect.Iterators
Returns the number of elements remaining in iterator.
size() - Method in class com.google.common.collect.LinkedListMultimap
 
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 interface com.google.common.collect.Multiset
Returns the total number of all occurrences of all elements in this multiset.
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.TreeMultiset
 
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.util.concurrent.AtomicLongMap
Returns the number of key-value mappings in this map.
size() - Method in class com.google.common.util.concurrent.Striped
Returns the total number of stripes in this instance.
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.
SKETCHUP - Static variable in class com.google.common.net.MediaType
 
skip(int) - Method in class com.google.common.collect.FluentIterable
Returns a view of this fluent iterable that skips its first numberToSkip elements.
skip(Iterable<T>, int) - Static method in class com.google.common.collect.Iterables
Returns a view of iterable that skips its first numberToSkip elements.
skip(long) - Method in class com.google.common.io.CountingInputStream
 
skipBytes(int) - Method in interface com.google.common.io.ByteArrayDataInput
 
skipBytes(int) - Method in class com.google.common.io.LittleEndianDataInputStream
 
skipFully(InputStream, long) - Static method in class com.google.common.io.ByteStreams
Discards n bytes of data from the input stream.
skipFully(Reader, long) - Static method in class com.google.common.io.CharStreams
Discards n characters of data from the reader.
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.
sleepUninterruptibly(long, TimeUnit) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes unit.sleep(sleepFor) uninterruptibly.
slice(long, long) - Method in class com.google.common.io.ByteSource
Returns a view of a slice of this byte source that is at most length bytes long starting at the given offset.
slope() - Method in class com.google.common.math.LinearTransformation
Returns the slope of the transformation, i.e.
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.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.
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.
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.
sort(Comparator<? super E>) - Method in class com.google.common.collect.ImmutableList
Deprecated.
Unsupported operation.
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.
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.
SortedMapDifference<K,V> - Interface in com.google.common.collect
An object representing the differences between two sorted maps.
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.
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.
source() - Method in class com.google.common.graph.EndpointPair
If this EndpointPair EndpointPair.isOrdered(), returns the node which is the source.
SP - Static variable in class com.google.common.base.Ascii
Space: A normally non-printing graphic character used to separate words.
SPACE - Static variable in class com.google.common.base.Ascii
Alternate name for Ascii.SP.
span() - Method in class com.google.common.collect.ImmutableRangeMap
 
span() - Method in class com.google.common.collect.ImmutableRangeSet
 
span(Range<C>) - Method in class com.google.common.collect.Range
Returns the minimal range that encloses both this range and other.
span() - Method in interface com.google.common.collect.RangeMap
Returns the minimal range enclosing the ranges in this RangeMap.
span() - Method in interface com.google.common.collect.RangeSet
Returns the minimal range which encloses all ranges in this range set.
span() - Method in class com.google.common.collect.TreeRangeMap
 
span() - Method in class com.google.common.collect.TreeRangeSet
 
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() - Method in class com.google.common.collect.ImmutableCollection
 
spliterator() - Method in class com.google.common.collect.ImmutableList
 
spliterator() - Method in class com.google.common.collect.ImmutableSortedSet
 
spliterator() - Method in interface com.google.common.collect.Multiset
 
Splitter - Class in com.google.common.base
Extracts non-overlapping substrings from an input string, typically by recognizing appearances of a separator sequence.
Splitter.MapSplitter - Class in com.google.common.base
An object that splits strings into maps as Splitter splits iterables and lists.
splitToList(CharSequence) - Method in class com.google.common.base.Splitter
Splits sequence into string components and returns them as an immutable list.
sqrt(BigInteger, RoundingMode) - Static method in class com.google.common.math.BigIntegerMath
Returns the square root of x, rounded with the specified rounding mode.
sqrt(int, RoundingMode) - Static method in class com.google.common.math.IntMath
Returns the square root of x, rounded with the specified rounding mode.
sqrt(long, RoundingMode) - Static method in class com.google.common.math.LongMath
Returns the square root of x, rounded with the specified rounding mode.
standardAdd(E) - Method in class com.google.common.collect.ForwardingList
A sensible default implementation of ForwardingCollection.add(Object), in terms of ForwardingList.add(int, Object).
standardAdd(E) - Method in class com.google.common.collect.ForwardingMultiset
standardAddAll(Collection<? extends E>) - Method in class com.google.common.collect.ForwardingCollection
standardAddAll(int, Iterable<? extends E>) - Method in class com.google.common.collect.ForwardingList
A sensible default implementation of ForwardingList.addAll(int, Collection), in terms of the add method of ForwardingList.listIterator(int).
standardAddAll(Collection<? extends E>) - Method in class com.google.common.collect.ForwardingMultiset
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.
StandardNavigableKeySet() - Constructor for class com.google.common.collect.ForwardingNavigableMap.StandardNavigableKeySet
Constructor for use by subclasses.
standardOffer(E) - Method in class com.google.common.collect.ForwardingQueue
A sensible definition of ForwardingQueue.offer(E) in terms of ForwardingCollection.add(E).
standardPeek() - Method in class com.google.common.collect.ForwardingQueue
A sensible definition of ForwardingQueue.peek() in terms of ForwardingQueue.element().
standardPoll() - Method in class com.google.common.collect.ForwardingQueue
A sensible definition of ForwardingQueue.poll() in terms of ForwardingQueue.remove().
standardPollFirst() - Method in class com.google.common.collect.ForwardingNavigableSet
A sensible definition of ForwardingNavigableSet.pollFirst() in terms of the iterator method.
standardPollFirstEntry() - Method in class com.google.common.collect.ForwardingNavigableMap
A sensible definition of ForwardingNavigableMap.pollFirstEntry() in terms of the iterator of entrySet.
standardPollFirstEntry() - Method in class com.google.common.collect.ForwardingSortedMultiset
A sensible definition of ForwardingSortedMultiset.pollFirstEntry() in terms of entrySet().iterator().
standardPollLast() - Method in class com.google.common.collect.ForwardingNavigableSet
A sensible definition of ForwardingNavigableSet.pollLast() in terms of the descendingIterator method.
standardPollLastEntry() - Method in class com.google.common.collect.ForwardingNavigableMap
A sensible definition of ForwardingNavigableMap.pollFirstEntry() in terms of the iterator of the entrySet of descendingMap.
standardPollLastEntry() - Method in class com.google.common.collect.ForwardingSortedMultiset
A sensible definition of ForwardingSortedMultiset.pollLastEntry() in terms of descendingMultiset().entrySet().iterator().
standardPutAll(Map<? extends K, ? extends V>) - Method in class com.google.common.collect.ForwardingMap
A sensible definition of ForwardingMap.putAll(Map) in terms of ForwardingMap.put(Object, Object).
standardRemove(Object) - Method in class com.google.common.collect.ForwardingCollection
A sensible definition of ForwardingCollection.remove(java.lang.Object) in terms of ForwardingCollection.iterator(), using the iterator's remove method.
standardRemove(Object) - Method in class com.google.common.collect.ForwardingMap
A sensible, albeit inefficient, definition of ForwardingMap.remove(java.lang.Object) in terms of the iterator method of ForwardingMap.entrySet().
standardRemove(Object) - Method in class com.google.common.collect.ForwardingMultiset
standardRemove(Object) - Method in class com.google.common.collect.ForwardingSortedSet
A sensible definition of ForwardingCollection.remove(java.lang.Object) in terms of the iterator() method of ForwardingSortedSet.tailSet(E).
standardRemoveAll(Collection<?>) - Method in class com.google.common.collect.ForwardingCollection
A sensible definition of ForwardingCollection.removeAll(java.util.Collection<?>) in terms of ForwardingCollection.iterator(), using the iterator's remove method.
standardRemoveAll(Collection<?>) - Method in class com.google.common.collect.ForwardingMultiset
A sensible definition of ForwardingCollection.removeAll(java.util.Collection<?>) in terms of the removeAll method of ForwardingMultiset.elementSet().
standardRemoveAll(Collection<?>) - Method in class com.google.common.collect.ForwardingSet
standardRetainAll(Collection<?>) - Method in class com.google.common.collect.ForwardingCollection
A sensible definition of ForwardingCollection.retainAll(java.util.Collection<?>) in terms of ForwardingCollection.iterator(), using the iterator's remove method.
standardRetainAll(Collection<?>) - Method in class com.google.common.collect.ForwardingMultiset
A sensible definition of ForwardingCollection.retainAll(java.util.Collection<?>) in terms of the retainAll method of ForwardingMultiset.elementSet().
standardSetCount(E, int) - Method in class com.google.common.collect.ForwardingMultiset
standardSetCount(E, int, int) - Method in class com.google.common.collect.ForwardingMultiset
standardSize() - Method in class com.google.common.collect.ForwardingMultiset
A sensible, albeit inefficient, definition of ForwardingCollection.size() in terms of ForwardingMultiset.entrySet().
standardSubList(int, int) - Method in class com.google.common.collect.ForwardingList
A sensible default implementation of ForwardingList.subList(int, int).
standardSubMap(K, K) - Method in class com.google.common.collect.ForwardingNavigableMap
standardSubMap(K, K) - Method in class com.google.common.collect.ForwardingSortedMap
standardSubMultiset(E, BoundType, E, BoundType) - Method in class com.google.common.collect.ForwardingSortedMultiset
standardSubSet(E, boolean, E, boolean) - Method in class com.google.common.collect.ForwardingNavigableSet
A sensible definition of ForwardingNavigableSet.subSet(Object, boolean, Object, boolean) in terms of the headSet and tailSet methods.
standardSubSet(E, E) - Method in class com.google.common.collect.ForwardingNavigableSet
standardSubSet(E, E) - Method in class com.google.common.collect.ForwardingSortedSet
StandardSystemProperty - Enum in com.google.common.base
standardTailMap(K) - Method in class com.google.common.collect.ForwardingNavigableMap
standardTailSet(E) - Method in class com.google.common.collect.ForwardingNavigableSet
standardToArray() - Method in class com.google.common.collect.ForwardingCollection
standardToArray(T[]) - Method in class com.google.common.collect.ForwardingCollection
standardToString() - Method in class com.google.common.collect.ForwardingCollection
A sensible definition of ForwardingObject.toString() in terms of ForwardingCollection.iterator().
standardToString() - Method in class com.google.common.collect.ForwardingMap
A sensible definition of ForwardingObject.toString() in terms of the iterator method of ForwardingMap.entrySet().
standardToString() - Method in class com.google.common.collect.ForwardingMapEntry
standardToString() - Method in class com.google.common.collect.ForwardingMultiset
A sensible definition of ForwardingObject.toString() as entrySet().toString() .
StandardValues() - Constructor for class com.google.common.collect.ForwardingMap.StandardValues
Constructor for use by subclasses.
start() - Method in class com.google.common.base.Stopwatch
Starts the stopwatch.
start() - Static method in class com.google.common.collect.ComparisonChain
Begins a new chained comparison statement.
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.
starting() - Method in class com.google.common.util.concurrent.Service.Listener
Called when the service transitions from NEW to STARTING.
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.
startupTimes() - Method in class com.google.common.util.concurrent.ServiceManager
Returns the service load times.
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.
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 - 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.
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
 
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.
stopping(Service.State) - Method in class com.google.common.util.concurrent.Service.Listener
Called when the service transitions to the STOPPING state.
Stopwatch - Class in com.google.common.base
An object that measures elapsed time in nanoseconds.
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(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(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(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.
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() - 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.
Streams - Class in com.google.common.collect
Static utility methods related to Stream instances.
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.
STRICT_TRANSPORT_SECURITY - Static variable in class com.google.common.net.HttpHeaders
The HTTP Strict-Transport-Security header field name.
stringConverter(Class<T>) - Static method in class com.google.common.base.Enums
Returns a converter that converts between strings and enum values of type enumClass using Enum.valueOf(Class, String) and Enum.name().
stringConverter() - Static method in class com.google.common.primitives.Doubles
Returns a serializable converter object that converts between strings and doubles using Double.valueOf(java.lang.String) and Double.toString().
stringConverter() - Static method in class com.google.common.primitives.Floats
Returns a serializable converter object that converts between strings and floats using Float.valueOf(java.lang.String) and Float.toString().
stringConverter() - Static method in class com.google.common.primitives.Ints
Returns a serializable converter object that converts between strings and integers using Integer.decode(java.lang.String) and Integer.toString().
stringConverter() - Static method in class com.google.common.primitives.Longs
Returns a serializable converter object that converts between strings and longs using Long.decode(java.lang.String) and Long.toString().
stringConverter() - Static method in class com.google.common.primitives.Shorts
Returns a serializable converter object that converts between strings and shorts using Short.decode(java.lang.String) and Short.toString().
stringFunnel(Charset) - Static method in class com.google.common.hash.Funnels
Returns a funnel that encodes the characters of a CharSequence with the specified Charset.
Strings - Class in com.google.common.base
Static utility methods pertaining to String or CharSequence instances.
Striped<L> - Class in com.google.common.util.concurrent
A striped Lock/Semaphore/ReadWriteLock.
strong() - Method in class com.google.common.collect.Interners.InternerBuilder
Instructs the Interners.InternerBuilder to build a strong interner.
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.
subList(int, int) - Method in class com.google.common.collect.ForwardingList
 
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.
subMap(K, boolean, K, boolean) - Method in class com.google.common.collect.ForwardingNavigableMap
 
subMap(K, K) - Method in class com.google.common.collect.ForwardingSortedMap
 
subMap(K, K) - Method in class com.google.common.collect.ImmutableSortedMap
This method returns a ImmutableSortedMap, consisting of the entries whose keys ranges from fromKey, inclusive, to toKey, exclusive.
subMap(K, boolean, K, boolean) - Method in class com.google.common.collect.ImmutableSortedMap
This method returns a ImmutableSortedMap, consisting of the entries whose keys ranges from fromKey to toKey, inclusive or exclusive as indicated by the boolean flags.
subMap(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.
submit(Runnable) - Method in class com.google.common.util.concurrent.AbstractListeningExecutorService
 
submit(Runnable, T) - Method in class com.google.common.util.concurrent.AbstractListeningExecutorService
 
submit(Callable<T>) - Method in class com.google.common.util.concurrent.AbstractListeningExecutorService
 
submit(Callable<T>) - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
submit(Runnable) - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
submit(Runnable, T) - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
submit(Callable<T>) - Method in class com.google.common.util.concurrent.ForwardingListeningExecutorService
 
submit(Runnable) - Method in class com.google.common.util.concurrent.ForwardingListeningExecutorService
 
submit(Runnable, T) - Method in class com.google.common.util.concurrent.ForwardingListeningExecutorService
 
submit(Callable<T>) - Method in interface com.google.common.util.concurrent.ListeningExecutorService
 
submit(Runnable) - Method in interface com.google.common.util.concurrent.ListeningExecutorService
 
submit(Runnable, T) - Method in interface com.google.common.util.concurrent.ListeningExecutorService
 
submitAsync(AsyncCallable<O>, Executor) - Static method in class com.google.common.util.concurrent.Futures
Executes callable on the specified executor, returning a Future.
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.
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
 
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
 
Subscribe - Annotation Type in com.google.common.eventbus
Marks a method as an event subscriber.
SubscriberExceptionContext - Class in com.google.common.eventbus
Context for an exception thrown by a subscriber.
SubscriberExceptionHandler - Interface in com.google.common.eventbus
Handler for exceptions thrown by event subscribers.
subSet(C, C) - Method in class com.google.common.collect.ContiguousSet
 
subSet(C, boolean, C, boolean) - Method in class com.google.common.collect.ContiguousSet
 
subSet(E, boolean, E, boolean) - Method in class com.google.common.collect.ForwardingNavigableSet
 
subSet(E, E) - Method in class com.google.common.collect.ForwardingSortedSet
 
subSet(E, E) - Method in class com.google.common.collect.ImmutableSortedSet
subSet(E, boolean, E, boolean) - Method in class com.google.common.collect.ImmutableSortedSet
 
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.
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.
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.
successors(N) - Method in interface com.google.common.graph.Graph
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.Network
Returns 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 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 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.
sum(Multiset<? extends E>, Multiset<? extends E>) - Static method in class com.google.common.collect.Multisets
Returns an unmodifiable view of the sum of two multisets.
sum() - Method in class com.google.common.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.
Supplier<T> - Interface in com.google.common.base
Legacy version of java.util.function.Supplier.
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.
Suppliers - Class in com.google.common.base
Useful suppliers.
SVG_UTF_8 - Static variable in class com.google.common.net.MediaType
 
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.
synchronizedBiMap(BiMap<K, V>) - Static method in class com.google.common.collect.Maps
Returns a synchronized (thread-safe) bimap backed by the specified bimap.
synchronizedDeque(Deque<E>) - Static method in class com.google.common.collect.Queues
Returns a synchronized (thread-safe) deque backed by the specified deque.
synchronizedListMultimap(ListMultimap<K, V>) - Static method in class com.google.common.collect.Multimaps
Returns a synchronized (thread-safe) ListMultimap backed by the specified multimap.
synchronizedMultimap(Multimap<K, V>) - Static method in class com.google.common.collect.Multimaps
Returns a synchronized (thread-safe) multimap backed by the specified multimap.
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.
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.
synchronizedQueue(Queue<E>) - Static method in class com.google.common.collect.Queues
Returns a synchronized (thread-safe) queue backed by the specified queue.
synchronizedSetMultimap(SetMultimap<K, V>) - Static method in class com.google.common.collect.Multimaps
Returns a synchronized (thread-safe) SetMultimap backed by the specified multimap.
synchronizedSortedSetMultimap(SortedSetMultimap<K, V>) - Static method in class com.google.common.collect.Multimaps
Returns a synchronized (thread-safe) SortedSetMultimap backed by the specified multimap.
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.
systemExit() - Static method in class com.google.common.util.concurrent.UncaughtExceptionHandlers
Returns an exception handler that exits the system.
systemTicker() - Static method in class com.google.common.base.Ticker
A ticker that reads the current time using System.nanoTime().

T

Table<R,C,V> - Interface in com.google.common.collect
A collection that associates an ordered pair of keys, called a row key and a column key, with a single value.
Table.Cell<R,C,V> - Interface in com.google.common.collect
Row key / column key / value triplet corresponding to a mapping in a table.
Tables - Class in com.google.common.collect
Provides static methods that involve a Table.
tailMap(K, boolean) - Method in class com.google.common.collect.ForwardingNavigableMap
 
tailMap(K) - Method in class com.google.common.collect.ForwardingSortedMap
 
tailMap(K) - Method in class com.google.common.collect.ImmutableSortedMap
This method returns a ImmutableSortedMap, consisting of the entries whose keys are greater than or equals to fromKey.
tailMap(K, boolean) - Method in class com.google.common.collect.ImmutableSortedMap
This method returns a ImmutableSortedMap, consisting of the entries whose keys are greater than (or equal to, if inclusive) fromKey.
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 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
 
tailSet(C) - Method in class com.google.common.collect.ContiguousSet
 
tailSet(C, boolean) - Method in class com.google.common.collect.ContiguousSet
 
tailSet(E, boolean) - Method in class com.google.common.collect.ForwardingNavigableSet
 
tailSet(E) - Method in class com.google.common.collect.ForwardingSortedSet
 
tailSet(E) - Method in class com.google.common.collect.ImmutableSortedSet
tailSet(E, boolean) - Method in class com.google.common.collect.ImmutableSortedSet
 
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() - Method in class com.google.common.graph.EndpointPair
If this EndpointPair EndpointPair.isOrdered(), returns the node which is the target.
TE - Static variable in class com.google.common.net.HttpHeaders
The HTTP TE header field name.
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.
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(T) - Method in interface com.google.common.base.Predicate
 
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.
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.
THREE_GPP2_VIDEO - Static variable in class com.google.common.net.MediaType
Media type for the 3G2 multimedia container format.
THREE_GPP_VIDEO - Static variable in class com.google.common.net.MediaType
Media type for the 3GP multimedia container format.
Throwables - Class in com.google.common.base
Static utility methods pertaining to instances of Throwable.
throwIfInstanceOf(Throwable, Class<X>) - Static method in class com.google.common.base.Throwables
Throws throwable if it is an instance of declaredType.
throwIfUnchecked(Throwable) - Static method in class com.google.common.base.Throwables
Throws throwable if it is a RuntimeException or Error.
Ticker - Class in com.google.common.base
A time source; returns a time value representing the number of nanoseconds elapsed since some fixed but arbitrary point in time.
Ticker() - Constructor for class com.google.common.base.Ticker
Constructor for use by subclasses.
ticker(Ticker) - Method in class com.google.common.cache.CacheBuilder
Specifies a nanosecond-precision time source for this cache.
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.
times(UnsignedInteger) - Method in class com.google.common.primitives.UnsignedInteger
Returns the result of multiplying this and val.
times(UnsignedLong) - Method in class com.google.common.primitives.UnsignedLong
Returns the result of multiplying this and val.
TIMING_ALLOW_ORIGIN - Static variable in class com.google.common.net.HttpHeaders
The HTTP Timing-Allow-Origin header field name.
to(CaseFormat, String) - Method in enum com.google.common.base.CaseFormat
Converts the specified String str from this format to the specified format.
toAddrString(InetAddress) - Static method in class com.google.common.net.InetAddresses
Returns the string representation of an InetAddress.
toArray(Class<V>) - Method in class com.google.common.collect.ArrayTable
Returns a two-dimensional array with the table contents.
toArray() - Method in class com.google.common.collect.ConcurrentHashMultiset
 
toArray(T[]) - Method in class com.google.common.collect.ConcurrentHashMultiset
 
toArray(Class<E>) - Method in class com.google.common.collect.FluentIterable
Returns an array containing all of the elements from this fluent iterable in iteration order.
toArray() - Method in class com.google.common.collect.ForwardingCollection
 
toArray(T[]) - Method in class com.google.common.collect.ForwardingCollection
 
toArray() - Method in class com.google.common.collect.ImmutableCollection
 
toArray(T[]) - Method in class com.google.common.collect.ImmutableCollection
 
toArray(Iterable<? extends T>, Class<T>) - Static method in class com.google.common.collect.Iterables
Copies an iterable's elements into an array.
toArray(Iterator<? extends T>, Class<T>) - Static method in class com.google.common.collect.Iterators
Copies an iterator's elements into an array.
toArray() - Method in class com.google.common.collect.MinMaxPriorityQueue
 
toArray() - Method in class com.google.common.escape.CharEscaperBuilder
Convert this builder into an array of char[]s where the maximum index is the value of the highest character that has been seen.
toArray(Collection<Boolean>) - Static method in class com.google.common.primitives.Booleans
Copies a collection of Boolean instances into a new array of primitive boolean values.
toArray(Collection<? extends Number>) - Static method in class com.google.common.primitives.Bytes
Returns an array containing each value of collection, converted to a byte value in the manner of Number.byteValue().
toArray(Collection<Character>) - Static method in class com.google.common.primitives.Chars
Copies a collection of Character instances into a new array of primitive char values.
toArray(Collection<? extends Number>) - Static method in class com.google.common.primitives.Doubles
Returns an array containing each value of collection, converted to a double value in the manner of Number.doubleValue().
toArray(Collection<? extends Number>) - Static method in class com.google.common.primitives.Floats
Returns an array containing each value of collection, converted to a float value in the manner of Number.floatValue().
toArray() - 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(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().
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.
toByteArray() - Method in interface com.google.common.io.ByteArrayDataOutput
Returns the contents that have been written to this instance, as 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(File) - Static method in class com.google.common.io.Files
Reads all bytes from a file into a byte array.
toByteArray(URL) - Static method in class com.google.common.io.Resources
Reads all bytes from a URL into a byte array.
toByteArray() - Method in class com.google.common.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(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().
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.
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.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.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.Sets
Returns a Collector that accumulates the input elements into a new ImmutableSet with an implementation specialized for enums.
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.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(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>, 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.
toImmutableMultiset() - Static method in class com.google.common.collect.ImmutableMultiset
Returns a Collector that accumulates the input elements into a new ImmutableMultiset.
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.
toImmutableSet() - Static method in class com.google.common.collect.ImmutableSet
Returns a Collector that accumulates the input elements into a new ImmutableSet.
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.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.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.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>, BinaryOperator<V>) - Static method in class com.google.common.collect.ImmutableTable
Returns a Collector that accumulates elements into an ImmutableTable.
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.
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.
toJavaUtil() - Method in class com.google.common.base.Optional
Returns the equivalent java.util.Optional value to this optional.
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.
toLowerCase(String) - Static method in class com.google.common.base.Ascii
Returns a copy of the input string in which all uppercase ASCII characters have been converted to lowercase.
toLowerCase(CharSequence) - Static method in class com.google.common.base.Ascii
Returns a copy of the input character sequence in which all uppercase ASCII characters have been converted to lowercase.
toLowerCase(char) - Static method in class com.google.common.base.Ascii
If the argument is an uppercase ASCII character returns the lowercase equivalent.
toMap(Function<? super E, V>) - Method in class com.google.common.collect.FluentIterable
Returns an immutable map 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.
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.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.
toOptional() - Static method in class com.google.common.collect.MoreCollectors
A collector that converts a stream of zero or one elements to an Optional.
toParsableString() - Method in class com.google.common.cache.CacheBuilderSpec
Returns a string that can be used to parse an equivalent CacheBuilderSpec.
topPrivateDomain() - Method in class com.google.common.net.InternetDomainName
Returns the portion of this domain name that is one level beneath the public suffix.
toSet() - Method in class com.google.common.collect.FluentIterable
Returns an ImmutableSet containing all of the elements from this fluent iterable with duplicates removed.
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.
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.Equivalence.Wrapper
Returns a string representation for this equivalence wrapper.
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 enum com.google.common.base.StandardSystemProperty
Returns a string representation of this system property.
toString() - Method in class com.google.common.base.Stopwatch
Returns a string representation of the current elapsed time.
toString() - Method in class com.google.common.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.collect.ContiguousSet
Returns a short-hand representation of the contents such as "[1..100]".
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.ImmutableMap
 
toString() - Method in class com.google.common.collect.ImmutableMultiset
 
toString() - Method in class com.google.common.collect.ImmutableRangeMap
 
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(Iterator<?>) - Static method in class com.google.common.collect.Iterators
Returns a string representation of iterator, with the format [e1, e2, ..., en].
toString() - Method in class com.google.common.collect.MapMaker
Returns a string representation for this MapMaker instance.
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.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.TreeRangeMap
 
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.hash.HashCode
Returns a string containing each byte of HashCode.asBytes(), in order, as a two-digit unsigned hexadecimal number in lower case.
toString(Readable) - Static method in class com.google.common.io.CharStreams
Reads all characters from a Readable object into a String.
toString(File, Charset) - Static method in class com.google.common.io.Files
Deprecated.
Prefer asCharSource(file, charset).read(). This method is scheduled to be removed in January 2019.
toString(URL, Charset) - Static method in class com.google.common.io.Resources
Reads all characters from a URL into a String, using the given character set.
toString() - Method in class com.google.common.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.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
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
Returns a string representation of this array in the same form as Arrays.toString(long[]), for example "[1, 2, 3]".
toString(byte) - Static method in class com.google.common.primitives.UnsignedBytes
Returns a string representation of x, where x is treated as unsigned.
toString(byte, int) - Static method in class com.google.common.primitives.UnsignedBytes
Returns a string representation of x for the given radix, where x is treated as unsigned.
toString() - Method in class com.google.common.primitives.UnsignedInteger
Returns a string representation of the UnsignedInteger value, in base 10.
toString(int) - Method in class com.google.common.primitives.UnsignedInteger
Returns a string representation of the UnsignedInteger value, in base radix.
toString(int) - Static method in class com.google.common.primitives.UnsignedInts
Returns a string representation of x, where x is treated as unsigned.
toString(int, int) - Static method in class com.google.common.primitives.UnsignedInts
Returns a string representation of x for the given radix, where x is treated as unsigned.
toString() - Method in class com.google.common.primitives.UnsignedLong
Returns a string representation of the UnsignedLong value, in base 10.
toString(int) - Method in class com.google.common.primitives.UnsignedLong
Returns a string representation of the UnsignedLong value, in base radix.
toString(long) - Static method in class com.google.common.primitives.UnsignedLongs
Returns a string representation of x, where x is treated as unsigned.
toString(long, int) - Static method in class com.google.common.primitives.UnsignedLongs
Returns a string representation of x for the given radix, where x is treated as unsigned.
toString() - Method in class com.google.common.reflect.AbstractInvocationHandler
By default delegates to Object.toString().
toString() - Method in class com.google.common.reflect.ClassPath.ClassInfo
 
toString() - Method in class com.google.common.reflect.ClassPath.ResourceInfo
 
toString() - Method in class com.google.common.reflect.Parameter
 
toString() - Method in class com.google.common.reflect.TypeParameter
 
toString() - Method in class com.google.common.reflect.TypeToken
 
toString() - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
 
toString() - Method in class com.google.common.util.concurrent.AbstractFuture
 
toString() - Method in class com.google.common.util.concurrent.AbstractIdleService
 
toString() - Method in class com.google.common.util.concurrent.AbstractScheduledService
 
toString() - Method in class com.google.common.util.concurrent.AbstractService
 
toString() - Method in class com.google.common.util.concurrent.AtomicDouble
Returns the String representation of the current value.
toString() - Method in class com.google.common.util.concurrent.AtomicDoubleArray
Returns the String representation of the current values of array.
toString() - Method in class com.google.common.util.concurrent.AtomicLongMap
 
toString() - Method in class com.google.common.util.concurrent.RateLimiter
 
toString() - Method in class com.google.common.util.concurrent.ServiceManager
 
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.
toStringHelper(Object) - Static method in class com.google.common.base.MoreObjects
Creates an instance of MoreObjects.ToStringHelper.
toStringHelper(Class<?>) - Static method in class com.google.common.base.MoreObjects
Creates an instance of MoreObjects.ToStringHelper in the same manner as MoreObjects.toStringHelper(Object), but using the simple name of clazz instead of using an instance's Object.getClass().
toStringHelper(String) - Static method in class com.google.common.base.MoreObjects
Creates an instance of MoreObjects.ToStringHelper in the same manner as MoreObjects.toStringHelper(Object), but using className instead of using an instance's Object.getClass().
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.
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.
totalLoadTime() - Method in class com.google.common.cache.CacheStats
Returns the total number of nanoseconds the cache has spent loading new values.
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(String) - Static method in class com.google.common.base.Ascii
Returns a copy of the input string in which all lowercase ASCII characters have been converted to uppercase.
toUpperCase(CharSequence) - Static method in class com.google.common.base.Ascii
Returns a copy of the input character sequence in which all lowercase ASCII characters have been converted to uppercase.
toUpperCase(char) - Static method in class com.google.common.base.Ascii
If the argument is a lowercase ASCII character returns the uppercase equivalent.
toUriString(InetAddress) - Static method in class com.google.common.net.InetAddresses
Returns the string representation of an InetAddress suitable for inclusion in a URI.
TRAILER - Static variable in class com.google.common.net.HttpHeaders
The HTTP Trailer header field name.
TRANSFER_ENCODING - Static variable in class com.google.common.net.HttpHeaders
The HTTP Transfer-Encoding header field name.
transform(Function<? super T, V>) - Method in class com.google.common.base.Optional
If the instance is present, it is transformed with the given Function; otherwise, Optional.absent() is returned.
transform(Collection<F>, Function<? super F, T>) - Static method in class com.google.common.collect.Collections2
Returns a collection that applies function to each element of fromCollection.
transform(Function<? super E, T>) - Method in class com.google.common.collect.FluentIterable
Returns a fluent iterable that applies function to each element of this fluent iterable.
transform(Iterable<F>, Function<? super F, ? extends T>) - Static method in class com.google.common.collect.Iterables
Returns a view containing the result of applying function to each element of fromIterable.
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(double) - Method in class com.google.common.math.LinearTransformation
Returns the y corresponding to the given x.
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(ListenableFuture<I>, Function<? super I, ? extends O>) - Static method in class com.google.common.util.concurrent.Futures
Deprecated.
Use the overload that requires an executor. For identical behavior, pass MoreExecutors.directExecutor(), but consider whether another executor would be safer, as discussed in the ListenableFuture.addListener documentation. This method is scheduled to be removed in April 2018.
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.
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(ListenableFuture<I>, AsyncFunction<? super I, ? extends O>) - Static method in class com.google.common.util.concurrent.Futures
Deprecated.
Use the overload that requires an executor. For identical behavior, pass MoreExecutors.directExecutor(), but consider whether another executor would be safer, as discussed in the ListenableFuture.addListener documentation. This method is scheduled to be removed in April 2018.
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.
transformEntries(Map<K, V1>, Maps.EntryTransformer<? super K, ? super V1, V2>) - Static method in class com.google.common.collect.Maps
Returns a view of a map whose values are derived from the original map's entries.
transformEntries(SortedMap<K, V1>, Maps.EntryTransformer<? super K, ? super V1, V2>) - Static method in class com.google.common.collect.Maps
Returns a view of a sorted map whose values are derived from the original sorted map's entries.
transformEntries(NavigableMap<K, V1>, Maps.EntryTransformer<? super K, ? super V1, V2>) - Static method in class com.google.common.collect.Maps
Returns a view of a navigable map whose values are derived from the original navigable map's entries.
transformEntries(Multimap<K, V1>, Maps.EntryTransformer<? super K, ? super V1, V2>) - Static method in class com.google.common.collect.Multimaps
Returns a view of a multimap whose values are derived from the original multimap's entries.
transformEntries(ListMultimap<K, V1>, Maps.EntryTransformer<? super K, ? super V1, V2>) - Static method in class com.google.common.collect.Multimaps
Returns a view of a ListMultimap whose values are derived from the original multimap's entries.
transformEntry(K, V1) - Method in interface com.google.common.collect.Maps.EntryTransformer
Determines an output value based on a key-value pair.
transformValues(Map<K, V1>, Function<? super V1, V2>) - Static method in class com.google.common.collect.Maps
Returns a view of a map where each value is transformed by a function.
transformValues(SortedMap<K, V1>, Function<? super V1, V2>) - Static method in class com.google.common.collect.Maps
Returns a view of a sorted map where each value is transformed by a function.
transformValues(NavigableMap<K, V1>, Function<? super V1, V2>) - Static method in class com.google.common.collect.Maps
Returns a view of a navigable map where each value is transformed by a function.
transformValues(Multimap<K, V1>, Function<? super V1, V2>) - Static method in class com.google.common.collect.Multimaps
Returns a view of a multimap where each value is transformed by a function.
transformValues(ListMultimap<K, V1>, Function<? super V1, V2>) - Static method in class com.google.common.collect.Multimaps
Returns a view of a ListMultimap where each value is transformed by a function.
transformValues(Table<R, C, V1>, Function<? super V1, V2>) - Static method in class com.google.common.collect.Tables
Returns a view of a table where each value is transformed by a function.
transitiveClosure(Graph<N>) - Static method in class com.google.common.graph.Graphs
Returns the transitive closure of graph.
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(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(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.
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.
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.
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.
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.
TreeRangeMap<K extends Comparable,V> - Class in com.google.common.collect
An implementation of RangeMap based on a TreeMap, supporting all optional operations.
TreeRangeSet<C extends Comparable<?>> - Class in com.google.common.collect
An implementation of RangeSet backed by a TreeMap.
treeSetValues() - Method in class com.google.common.collect.MultimapBuilder.MultimapBuilderWithKeys
Uses a naturally-ordered TreeSet to store value collections.
treeSetValues(Comparator<V0>) - Method in class com.google.common.collect.MultimapBuilder.MultimapBuilderWithKeys
Uses a TreeSet ordered by the specified comparator to store value collections.
TreeTraverser<T> - Class in com.google.common.collect
Views elements of a type T as nodes in a tree, and provides methods to traverse the trees induced by this traverser.
TreeTraverser() - Constructor for class com.google.common.collect.TreeTraverser
 
triggerShutdown() - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
Invoked to request the service to stop.
trimAndCollapseFrom(CharSequence, char) - Method in class com.google.common.base.CharMatcher
Collapses groups of matching characters exactly as CharMatcher.collapseFrom(java.lang.CharSequence, char) does, except that groups of matching characters at the start or end of the sequence are removed without replacement.
trimFrom(CharSequence) - Method in class com.google.common.base.CharMatcher
Returns a substring of the input character sequence that omits all characters this matcher matches from the beginning and from the end of the string.
trimLeadingFrom(CharSequence) - Method in class com.google.common.base.CharMatcher
Returns a substring of the input character sequence that omits all characters this matcher matches from the beginning of the string.
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.
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>>. This method is scheduled for removal in April 2019.
trimTrailingFrom(CharSequence) - Method in class com.google.common.base.CharMatcher
Returns a substring of the input character sequence that omits all characters this matcher matches from the end of the string.
trueFirst() - Static method in class com.google.common.primitives.Booleans
Returns a Comparator<Boolean> that sorts true before false.
truncate(CharSequence, int, String) - Static method in class com.google.common.base.Ascii
Truncates the given character sequence to the given maximum length.
tryAcquire(long, TimeUnit) - Method in class com.google.common.util.concurrent.RateLimiter
Acquires a permit from this RateLimiter if it can be obtained without exceeding the specified timeout, or returns false immediately (without waiting) if the permit would not have been granted before the timeout expired.
tryAcquire(int) - Method in class com.google.common.util.concurrent.RateLimiter
Acquires permits from this RateLimiter if it can be acquired immediately without delay.
tryAcquire() - Method in class com.google.common.util.concurrent.RateLimiter
Acquires a permit from this RateLimiter if it can be acquired immediately without delay.
tryAcquire(int, long, TimeUnit) - Method in class com.google.common.util.concurrent.RateLimiter
Acquires the given number of permits from this RateLimiter if it can be obtained without exceeding the specified timeout, or returns false immediately (without waiting) if the permits would not have been granted before the timeout expired.
tryAcquireUninterruptibly(Semaphore, long, TimeUnit) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes semaphore.tryAcquire(1, timeout, unit) uninterruptibly.
tryAcquireUninterruptibly(Semaphore, int, long, TimeUnit) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes semaphore.tryAcquire(permits, timeout, unit) uninterruptibly.
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.
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.
tryParse(String) - Static method in class com.google.common.primitives.Doubles
Parses the specified string as a double-precision floating point value.
tryParse(String) - Static method in class com.google.common.primitives.Floats
Parses the specified string as a single-precision floating point value.
tryParse(String) - Static method in class com.google.common.primitives.Ints
Parses the specified string as a signed decimal integer value.
tryParse(String, int) - Static method in class com.google.common.primitives.Ints
Parses the specified string as a signed integer value using the specified radix.
tryParse(String) - Static method in class com.google.common.primitives.Longs
Parses the specified string as a signed decimal long value.
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.
TSV_UTF_8 - Static variable in class com.google.common.net.MediaType
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.
TypeParameter<T> - Class in com.google.common.reflect
TypeParameter() - Constructor for class com.google.common.reflect.TypeParameter
 
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
 
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.TypeSet - Class in com.google.common.reflect
The set of interfaces and classes that T is or is a subtype of.

U

UncaughtExceptionHandlers - Class in com.google.common.util.concurrent
Factories for Thread.UncaughtExceptionHandler instances.
UncheckedExecutionException - Exception in com.google.common.util.concurrent
Unchecked variant of ExecutionException.
UncheckedExecutionException() - Constructor for exception com.google.common.util.concurrent.UncheckedExecutionException
Creates a new instance with null as its detail message.
UncheckedExecutionException(String) - Constructor for exception com.google.common.util.concurrent.UncheckedExecutionException
Creates a new instance with the given detail message.
UncheckedExecutionException(String, Throwable) - Constructor for exception com.google.common.util.concurrent.UncheckedExecutionException
Creates a new instance with the given detail message and cause.
UncheckedExecutionException(Throwable) - Constructor for exception com.google.common.util.concurrent.UncheckedExecutionException
Creates a new instance with the given cause.
UncheckedTimeoutException - Exception in com.google.common.util.concurrent
Unchecked version of TimeoutException.
UncheckedTimeoutException() - Constructor for exception com.google.common.util.concurrent.UncheckedTimeoutException
 
UncheckedTimeoutException(String) - Constructor for exception com.google.common.util.concurrent.UncheckedTimeoutException
 
UncheckedTimeoutException(Throwable) - Constructor for exception com.google.common.util.concurrent.UncheckedTimeoutException
 
UncheckedTimeoutException(String, Throwable) - Constructor for exception com.google.common.util.concurrent.UncheckedTimeoutException
 
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.
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.
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.
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(Multiset<? extends E>, Multiset<? extends E>) - Static method in class com.google.common.collect.Multisets
Returns an unmodifiable view of the union of two multisets.
union(Set<? extends E>, Set<? extends E>) - Static method in class com.google.common.collect.Sets
Returns an unmodifiable view of the union of two sets.
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.
unmodifiableBiMap(BiMap<? extends K, ? extends V>) - Static method in class com.google.common.collect.Maps
Returns an unmodifiable view of the specified bimap.
unmodifiableIterable(Iterable<? extends T>) - Static method in class com.google.common.collect.Iterables
Returns an unmodifiable view of iterable.
unmodifiableIterable(ImmutableCollection<E>) - Static method in class com.google.common.collect.Iterables
Deprecated.
no need to use this
unmodifiableIterator(Iterator<? extends T>) - Static method in class com.google.common.collect.Iterators
Returns an unmodifiable view of iterator.
unmodifiableIterator(UnmodifiableIterator<T>) - Static method in class com.google.common.collect.Iterators
Deprecated.
no need to use this
UnmodifiableIterator<E> - Class in com.google.common.collect
An iterator that does not support UnmodifiableIterator.remove().
UnmodifiableIterator() - Constructor for class com.google.common.collect.UnmodifiableIterator
Constructor for use by subclasses.
UnmodifiableListIterator<E> - Class in com.google.common.collect
UnmodifiableListIterator() - Constructor for class com.google.common.collect.UnmodifiableListIterator
Constructor for use by subclasses.
unmodifiableListMultimap(ListMultimap<K, V>) - Static method in class com.google.common.collect.Multimaps
Returns an unmodifiable view of the specified ListMultimap.
unmodifiableListMultimap(ImmutableListMultimap<K, V>) - Static method in class com.google.common.collect.Multimaps
Deprecated.
no need to use this
unmodifiableMultimap(Multimap<K, V>) - Static method in class com.google.common.collect.Multimaps
Returns an unmodifiable view of the specified multimap.
unmodifiableMultimap(ImmutableMultimap<K, V>) - Static method in class com.google.common.collect.Multimaps
Deprecated.
no need to use this
unmodifiableMultiset(Multiset<? extends E>) - Static method in class com.google.common.collect.Multisets
Returns an unmodifiable view of the specified multiset.
unmodifiableMultiset(ImmutableMultiset<E>) - Static method in class com.google.common.collect.Multisets
Deprecated.
no need to use this
unmodifiableNavigableMap(NavigableMap<K, ? extends V>) - Static method in class com.google.common.collect.Maps
Returns an unmodifiable view of the specified navigable map.
unmodifiableNavigableSet(NavigableSet<E>) - Static method in class com.google.common.collect.Sets
Returns an unmodifiable view of the specified navigable set.
unmodifiableRowSortedTable(RowSortedTable<R, ? extends C, ? extends V>) - Static method in class com.google.common.collect.Tables
Returns an unmodifiable view of the specified row-sorted table.
unmodifiableSetMultimap(SetMultimap<K, V>) - Static method in class com.google.common.collect.Multimaps
Returns an unmodifiable view of the specified SetMultimap.
unmodifiableSetMultimap(ImmutableSetMultimap<K, V>) - Static method in class com.google.common.collect.Multimaps
Deprecated.
no need to use this
unmodifiableSortedMultiset(SortedMultiset<E>) - Static method in class com.google.common.collect.Multisets
Returns an unmodifiable view of the specified sorted multiset.
unmodifiableSortedSetMultimap(SortedSetMultimap<K, V>) - Static method in class com.google.common.collect.Multimaps
Returns an unmodifiable view of the specified SortedSetMultimap.
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.
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.
unregister(Object) - Method in class com.google.common.eventbus.EventBus
Unregisters all subscriber methods on a registered object.
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).
UnsignedInteger - Class in com.google.common.primitives
A wrapper class for unsigned int values, supporting arithmetic operations.
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).
UnsignedLong - Class in com.google.common.primitives
A wrapper class for unsigned long values, supporting arithmetic operations.
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).
unwrap(Class<T>) - Static method in class com.google.common.primitives.Primitives
Returns the corresponding primitive type of type if it is a wrapper type; otherwise returns type itself.
unwrap() - Method in class com.google.common.reflect.TypeToken
Returns the corresponding primitive type if this is a wrapper type; otherwise returns this itself.
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.
UPGRADE - Static variable in class com.google.common.net.HttpHeaders
The HTTP Upgrade header field name.
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.
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() - 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).
url() - Method in class com.google.common.reflect.ClassPath.ResourceInfo
Returns the url identifying the resource.
UrlEscapers - Class in com.google.common.net
Escaper instances suitable for strings to be included in particular sections of URLs.
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).
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.
using(Function<T, ? extends Iterable<T>>) - Static method in class com.google.common.collect.TreeTraverser
Returns a tree traverser that uses the given function to navigate from a node to its children.
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().
Utf8 - Class in com.google.common.base
Low-level, high-performance utility methods related to the UTF-8 character encoding.
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.

V

value() - Method in enum com.google.common.base.StandardSystemProperty
Returns the current value for this system property by delegating to System.getProperty(String).
valueComparator() - Method in class com.google.common.collect.ForwardingSortedSetMultimap
 
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.TreeMultimap
 
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 with user-defined properties.
valueOf(String) - Static method in enum com.google.common.base.CaseFormat
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.base.StandardSystemProperty
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.cache.RemovalCause
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.collect.BoundType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.graph.ElementOrder.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.io.FileWriteMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.io.RecursiveDeleteOption
Returns the enum constant of this type with the specified name.
valueOf(long) - Static method in class com.google.common.primitives.UnsignedInteger
Returns an UnsignedInteger that is equal to value, if possible.
valueOf(BigInteger) - Static method in class com.google.common.primitives.UnsignedInteger
Returns a UnsignedInteger representing the same value as the specified BigInteger.
valueOf(String) - Static method in class com.google.common.primitives.UnsignedInteger
Returns an UnsignedInteger holding the value of the specified String, parsed as an unsigned int value.
valueOf(String, int) - Static method in class com.google.common.primitives.UnsignedInteger
Returns an UnsignedInteger holding the value of the specified String, parsed as an unsigned int value in the specified radix.
valueOf(long) - Static method in class com.google.common.primitives.UnsignedLong
Returns an UnsignedLong representing the same value as the specified long.
valueOf(BigInteger) - Static method in class com.google.common.primitives.UnsignedLong
Returns a UnsignedLong representing the same value as the specified BigInteger.
valueOf(String) - Static method in class com.google.common.primitives.UnsignedLong
Returns an UnsignedLong holding the value of the specified String, parsed as an unsigned long value.
valueOf(String, int) - Static method in class com.google.common.primitives.UnsignedLong
Returns an UnsignedLong holding the value of the specified String, parsed as an unsigned long value in the specified radix.
valueOf(String) - Static method in enum com.google.common.util.concurrent.CycleDetectingLockFactory.Policies
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.common.util.concurrent.Service.State
Returns the enum constant of this type with the specified name.
values() - Static method in enum com.google.common.base.CaseFormat
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.base.StandardSystemProperty
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.cache.RemovalCause
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class com.google.common.collect.ArrayTable
Returns an unmodifiable collection of all values, which may contain duplicates.
values() - Method in interface com.google.common.collect.BiMap
values() - Static method in enum com.google.common.collect.BoundType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - 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
 
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() - Method in class com.google.common.collect.LinkedHashMultimap
Returns a collection of all values in the multimap.
values() - Method in class com.google.common.collect.LinkedListMultimap
Returns a view collection containing the value from each key-value pair contained in this multimap, without collapsing duplicates (so values().size() == size()).
values() - Method in 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() - Method in interface com.google.common.collect.Table
Returns a collection of all values, which may contain duplicates.
values() - Static method in enum com.google.common.graph.ElementOrder.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.io.FileWriteMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.io.RecursiveDeleteOption
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.util.concurrent.CycleDetectingLockFactory.Policies
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.common.util.concurrent.Service.State
Returns an array containing the constants of this enum type, in the order they are declared.
valueType() - Method in class com.google.common.collect.EnumBiMap
Returns the associated value type.
VARY - Static variable in class com.google.common.net.HttpHeaders
The HTTP Vary header field name.
VCARD_UTF_8 - Static variable in class com.google.common.net.MediaType
 
Verify - Class in com.google.common.base
Static convenience methods that serve the same purpose as Java language assertions, except that they are always enabled.
verify(boolean) - Static method in class com.google.common.base.Verify
Ensures that expression is true, throwing a VerifyException with no message otherwise.
verify(boolean, String, Object...) - Static method in class com.google.common.base.Verify
Ensures that expression is true, throwing a VerifyException with a custom message otherwise.
VerifyException - Exception in com.google.common.base
Exception thrown upon the failure of a verification check, including those performed by the convenience methods of the Verify class.
VerifyException() - Constructor for exception com.google.common.base.VerifyException
Constructs a VerifyException with no message.
VerifyException(String) - Constructor for exception com.google.common.base.VerifyException
Constructs a VerifyException with the message message.
VerifyException(Throwable) - Constructor for exception 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.
VerifyException(String, Throwable) - Constructor for exception com.google.common.base.VerifyException
Constructs a VerifyException with the message message and the cause cause.
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.
VIA - Static variable in class com.google.common.net.HttpHeaders
The HTTP Via header field name.
VisibleForTesting - Annotation Type in com.google.common.annotations
Annotates a program element that exists, or is more widely visible than otherwise necessary, only for use in test code.
VND_REAL_AUDIO - Static variable in class com.google.common.net.MediaType
Media type for Real Audio.
VND_WAVE_AUDIO - Static variable in class com.google.common.net.MediaType
Media type for WAVE format, as defined by RFC 2361.
VORBIS_AUDIO - Static variable in class com.google.common.net.MediaType
Media type for 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

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.
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.
WARNING - Static variable in class com.google.common.net.HttpHeaders
The HTTP Warning header field name.
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() - Method in class com.google.common.util.concurrent.AbstractFuture
Returns true if this future was cancelled with mayInterruptIfRunning set to true.
WAX_AUDIO - Static variable in class com.google.common.net.MediaType
Media type for Windows Media metafiles.
weak() - Method in class com.google.common.collect.Interners.InternerBuilder
Instructs the Interners.InternerBuilder to build a weak interner.
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.
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).
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).
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(K, V) - Method in interface com.google.common.cache.Weigher
Returns the weight of a cache entry.
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.
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 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(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 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.
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(TypeParameter<X>, TypeToken<X>) - Method in class com.google.common.reflect.TypeToken
Returns a new TypeToken where type variables represented by typeParam are substituted by typeArg.
where(TypeParameter<X>, Class<X>) - Method in class com.google.common.reflect.TypeToken
Returns a new TypeToken where type variables represented by typeParam are substituted by typeArg.
WHITESPACE - Static variable in class com.google.common.base.CharMatcher
Deprecated.
Use CharMatcher.whitespace() instead. This constant is scheduled to be removed in June 2018.
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.
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.
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(String) - Method in class com.google.common.base.Joiner
Returns a MapJoiner using the given key-value separator, and the same configuration as this Joiner otherwise.
withKeyValueSeparator(String) - Method in class com.google.common.base.Splitter
Returns a MapSplitter which splits entries based on this splitter, and splits entries into keys and values using the specified separator.
withKeyValueSeparator(char) - Method in class com.google.common.base.Splitter
Returns a MapSplitter which splits entries based on this splitter, and splits entries into keys and values using the specified separator.
withKeyValueSeparator(Splitter) - Method in class com.google.common.base.Splitter
Returns a MapSplitter which splits entries based on this splitter, and splits entries into keys and values using the specified key-value splitter.
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
Returns an encoding that behaves equivalently to this encoding, but uses an alternate character for padding.
withParameter(String, String) - Method in class com.google.common.net.MediaType
Replaces all parameters with the given attribute with a single parameter with the given value.
withParameters(Multimap<String, String>) - Method in class com.google.common.net.MediaType
Replaces all parameters with the given parameters.
withSeparator(String, int) - Method in class com.google.common.io.BaseEncoding
Returns an encoding that behaves equivalently to this encoding, but adds a separator string after every n characters.
withSlope(double) - Method in class com.google.common.math.LinearTransformation.LinearTransformationBuilder
Finish building an instance with the given slope, i.e.
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.
WMA_AUDIO - Static variable in class com.google.common.net.MediaType
Media type for 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
Media type for the Web Open Font Format (WOFF) defined by the W3C.
WOFF2 - Static variable in class com.google.common.net.MediaType
Media type for the Web Open Font Format (WOFF) version 2 defined by the W3C.
wrap(S) - Method in class com.google.common.base.Equivalence
Returns a wrapper of reference that implements Object.equals() such that wrap(a).equals(wrap(b)) if and only if equivalent(a, b).
wrap(byte[]) - Static method in class com.google.common.io.ByteSource
Returns a view of the given byte array as a ByteSource.
wrap(CharSequence) - Static method in class com.google.common.io.CharSource
Returns a view of the given character sequence as a CharSource.
wrap(Class<T>) - Static method in class com.google.common.primitives.Primitives
Returns the corresponding wrapper type of type if it is a primitive type; otherwise returns type itself.
wrap() - Method in class com.google.common.reflect.TypeToken
Returns the corresponding wrapper type if this is a primitive type; otherwise returns this itself.
write(int) - Method in class com.google.common.hash.HashingOutputStream
 
write(byte[], int, int) - Method in class com.google.common.hash.HashingOutputStream
 
write(int) - Method in interface com.google.common.io.ByteArrayDataOutput
 
write(byte[]) - Method in interface com.google.common.io.ByteArrayDataOutput
 
write(byte[], int, int) - Method in interface com.google.common.io.ByteArrayDataOutput
 
write(byte[]) - Method in class com.google.common.io.ByteSink
Writes all the given bytes to this sink.
write(CharSequence) - Method in class com.google.common.io.CharSink
Writes the given character sequence to this sink.
write(byte[], int, int) - Method in class com.google.common.io.CountingOutputStream
 
write(int) - Method in class com.google.common.io.CountingOutputStream
 
write(int) - Method in class com.google.common.io.FileBackedOutputStream
 
write(byte[]) - Method in class com.google.common.io.FileBackedOutputStream
 
write(byte[], int, int) - Method in class com.google.common.io.FileBackedOutputStream
 
write(byte[], File) - Static method in class com.google.common.io.Files
Overwrites a file with the contents of a byte array.
write(CharSequence, File, Charset) - Static method in class com.google.common.io.Files
Deprecated.
Prefer asCharSink(to, charset).write(from). This method is scheduled to be removed in January 2019.
write(byte[], int, int) - Method in class com.google.common.io.LittleEndianDataOutputStream
 
writeBoolean(boolean) - Method in interface com.google.common.io.ByteArrayDataOutput
 
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.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.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.
writeChar(int) - Method in interface com.google.common.io.ByteArrayDataOutput
 
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.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.LittleEndianDataOutputStream
Writes a double as specified by DataOutputStream.writeDouble(double), except using little-endian byte order.
writeFloat(float) - Method in interface com.google.common.io.ByteArrayDataOutput
 
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.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(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.
writeLong(long) - Method in interface com.google.common.io.ByteArrayDataOutput
 
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.
writeReplace() - Method in class com.google.common.reflect.TypeToken
Implemented to support serialization of subclasses.
writeShort(int) - Method in interface com.google.common.io.ByteArrayDataOutput
 
writeShort(int) - Method in class com.google.common.io.LittleEndianDataOutputStream
Writes a short as specified by DataOutputStream.writeShort(int), except using little-endian byte order.
writeTo(OutputStream) - Method in class com.google.common.hash.BloomFilter
Writes this BloomFilter to an output stream, with a custom format (not Java serialization).
writeUTF(String) - Method in interface com.google.common.io.ByteArrayDataOutput
 
writeUTF(String) - Method in class com.google.common.io.LittleEndianDataOutputStream
 
WWW_AUTHENTICATE - Static variable in class com.google.common.net.HttpHeaders
The HTTP WWW-Authenticate header field name.

X

X_CONTENT_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_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_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_POWERED_BY - Static variable in class com.google.common.net.HttpHeaders
The HTTP X-Powered-By header field name.
X_REQUESTED_WITH - Static variable in class com.google.common.net.HttpHeaders
The HTTP X-Requested-With header field name.
X_USER_IP - Static variable in class com.google.common.net.HttpHeaders
The HTTP X-User-IP header field name.
X_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.
XHTML_UTF_8 - Static variable in class com.google.common.net.MediaType
 
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.
XOFF - Static variable in class com.google.common.base.Ascii
Transmission off.
XON - Static variable in class com.google.common.base.Ascii
Transmission On: Although originally defined as DC1, this ASCII control character is now better known as the XON code used for software flow control in serial communications.
XRD_UTF_8 - Static variable in class com.google.common.net.MediaType
Media type for Extensible Resource Descriptors.
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

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 - Static variable in class com.google.common.primitives.UnsignedInteger
 
ZERO - Static variable in class com.google.common.primitives.UnsignedLong
 
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 elementY 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 
Skip navigation links

Copyright © 2010–2017. All rights reserved.