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

A

AAC_AUDIO - Static variable in class com.google.common.net.MediaType
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().
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 extends @Nullable java.lang.Object> - 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
Abstract implementation of InvocationHandler that handles Object.equals(java.lang.Object), Object.hashCode() and Object.toString().
AbstractInvocationHandler() - Constructor for class com.google.common.reflect.AbstractInvocationHandler
 
AbstractIterator<T extends @Nullable java.lang.Object> - 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(ClosingFuture.ValueAndCloser<V>) - Method in interface com.google.common.util.concurrent.ClosingFuture.ValueAndCloserConsumer
Accepts a ClosingFuture.ValueAndCloser for the last step in a ClosingFuture pipeline.
accept(File, String) - Method in class com.google.common.io.PatternFilenameFilter
 
ACCEPT - Static variable in class com.google.common.net.HttpHeaders
The HTTP Accept header field name.
ACCEPT_CH - Static variable in class com.google.common.net.HttpHeaders
The HTTP Accept-CH header field name.
ACCEPT_CHARSET - Static variable in class com.google.common.net.HttpHeaders
The HTTP Accept-Charset header field name.
ACCEPT_ENCODING - Static variable in class com.google.common.net.HttpHeaders
The HTTP Accept-Encoding header field name.
ACCEPT_LANGUAGE - Static variable in class com.google.common.net.HttpHeaders
The HTTP Accept-Language header field name.
ACCEPT_RANGES - Static variable in class com.google.common.net.HttpHeaders
The HTTP Accept-Ranges header field name.
ACCESS_CONTROL_ALLOW_CREDENTIALS - Static variable in class com.google.common.net.HttpHeaders
The HTTP Access-Control-Allow-Credentials header field name.
ACCESS_CONTROL_ALLOW_HEADERS - Static variable in class com.google.common.net.HttpHeaders
The HTTP Access-Control-Allow-Headers header field name.
ACCESS_CONTROL_ALLOW_METHODS - Static variable in class com.google.common.net.HttpHeaders
The HTTP Access-Control-Allow-Methods header field name.
ACCESS_CONTROL_ALLOW_ORIGIN - Static variable in class com.google.common.net.HttpHeaders
The HTTP Access-Control-Allow-Origin header field name.
ACCESS_CONTROL_ALLOW_PRIVATE_NETWORK - Static variable in class com.google.common.net.HttpHeaders
The HTTP Access-Control-Allow-Private-Network header field name.
ACCESS_CONTROL_EXPOSE_HEADERS - Static variable in class com.google.common.net.HttpHeaders
The HTTP Access-Control-Expose-Headers header field name.
ACCESS_CONTROL_MAX_AGE - Static variable in class com.google.common.net.HttpHeaders
The HTTP Access-Control-Max-Age header field name.
ACCESS_CONTROL_REQUEST_HEADERS - Static variable in class com.google.common.net.HttpHeaders
The HTTP Access-Control-Request-Headers header field name.
ACCESS_CONTROL_REQUEST_METHOD - Static variable in class com.google.common.net.HttpHeaders
The HTTP Access-Control-Request-Method header field name.
accumulateAndGet(double, DoubleBinaryOperator) - Method in class com.google.common.util.concurrent.AtomicDouble
Atomically updates the current value with the results of applying the given function to the current and given values.
accumulateAndGet(int, double, DoubleBinaryOperator) - Method in class com.google.common.util.concurrent.AtomicDoubleArray
Atomically updates the element at index i with the results of applying the given function to the current and given values.
accumulateAndGet(K, long, LongBinaryOperator) - Method in class com.google.common.util.concurrent.AtomicLongMap
Updates the value currently associated with key by combining it with x via the specified accumulator function, returning the new value.
ACK - Static variable in class com.google.common.base.Ascii
Acknowledge: A communication control character transmitted by a receiver as an affirmative response to a sender.
acquire() - Method in class com.google.common.util.concurrent.RateLimiter
Acquires a single permit from this RateLimiter, blocking until the request can be granted.
acquire(int) - Method in class com.google.common.util.concurrent.RateLimiter
Acquires the given number of permits from this RateLimiter, blocking until the request can be granted.
AD_AUCTION_ALLOWED - Static variable in class com.google.common.net.HttpHeaders
The HTTP Ad-Auction-Allowed header field name.
AD_AUCTION_SIGNALS - Static variable in class com.google.common.net.HttpHeaders
The HTTP Ad-Auction-Signals header field name.
add(double) - Method in class com.google.common.math.StatsAccumulator
Adds the given value to the dataset.
add(double) - Method in class com.google.common.primitives.ImmutableDoubleArray.Builder
Appends value to the end of the values the built ImmutableDoubleArray will contain.
add(double, double) - Method in class com.google.common.math.PairedStatsAccumulator
Adds the given pair of values to the dataset.
add(int) - Method in class com.google.common.primitives.ImmutableIntArray.Builder
Appends value to the end of the values the built ImmutableIntArray will contain.
add(int, E) - Method in class com.google.common.collect.ForwardingList
 
add(int, E) - Method in class com.google.common.collect.ImmutableList
Deprecated.
Unsupported operation.
add(long) - Method in class com.google.common.primitives.ImmutableLongArray.Builder
Appends value to the end of the values the built ImmutableLongArray will contain.
add(Range<C>) - Method in class com.google.common.collect.ImmutableRangeSet
Deprecated.
Unsupported operation.
add(Range<C>) - Method in class com.google.common.collect.ImmutableRangeSet.Builder
Add the specified range to this builder.
add(Range<C>) - Method in interface com.google.common.collect.RangeSet
Adds the specified range to this RangeSet (optional operation).
add(Range<C>) - Method in class com.google.common.collect.TreeRangeSet
 
add(E) - Method in class com.google.common.collect.EvictingQueue
Adds the given element to this queue.
add(E) - Method in class com.google.common.collect.ForwardingCollection
 
add(E) - Method in class com.google.common.collect.ForwardingListIterator
 
add(E) - Method in class com.google.common.collect.ImmutableCollection
Deprecated.
Unsupported operation.
add(E) - Method in class com.google.common.collect.ImmutableCollection.Builder
Adds element to the ImmutableCollection being built.
add(E) - Method in class com.google.common.collect.ImmutableList.Builder
Adds element to the ImmutableList.
add(E) - Method in class com.google.common.collect.ImmutableMultiset.Builder
Adds element to the ImmutableMultiset.
add(E) - Method in class com.google.common.collect.ImmutableSet.Builder
 
add(E) - Method in class com.google.common.collect.ImmutableSortedMultiset.Builder
Adds element to the ImmutableSortedMultiset.
add(E) - Method in class com.google.common.collect.ImmutableSortedSet.Builder
Adds element to the ImmutableSortedSet.
add(E) - Method in class com.google.common.collect.MinMaxPriorityQueue
Adds the given element to this queue.
add(E) - Method in interface com.google.common.collect.Multiset
Adds a single occurrence of the specified element to this multiset.
add(E) - Method in class com.google.common.collect.Sets.SetView
Deprecated.
Unsupported operation.
add(E) - Method in class com.google.common.collect.UnmodifiableListIterator
Deprecated.
Unsupported operation.
add(E...) - Method in class com.google.common.collect.ImmutableCollection.Builder
Adds each element of elements to the ImmutableCollection being built.
add(E...) - Method in class com.google.common.collect.ImmutableList.Builder
Adds each element of elements to the ImmutableList.
add(E...) - Method in class com.google.common.collect.ImmutableMultiset.Builder
Adds each element of elements to the ImmutableMultiset.
add(E...) - Method in class com.google.common.collect.ImmutableSet.Builder
 
add(E...) - Method in class com.google.common.collect.ImmutableSortedMultiset.Builder
Adds each element of elements to the ImmutableSortedMultiset.
add(E...) - Method in class com.google.common.collect.ImmutableSortedSet.Builder
Adds each element of elements to the ImmutableSortedSet, ignoring duplicate elements (only the first duplicate element is added).
add(E, int) - Method in class com.google.common.collect.ConcurrentHashMultiset
Adds a number of occurrences of the specified element to this multiset.
add(E, int) - Method in class com.google.common.collect.EnumMultiset
 
add(E, int) - Method in class com.google.common.collect.ForwardingMultiset
 
add(E, int) - Method in class com.google.common.collect.ImmutableMultiset
Deprecated.
Unsupported operation.
add(E, int) - Method in interface com.google.common.collect.Multiset
Adds a number of occurrences of an element to this multiset.
add(E, int) - Method in class com.google.common.collect.TreeMultiset
 
add(Runnable, Executor) - Method in class com.google.common.util.concurrent.ExecutionList
Adds the Runnable and accompanying Executor to the list of listeners to execute.
add(String, boolean) - Method in class com.google.common.base.MoreObjects.ToStringHelper
Adds a name/value pair to the formatted output in name=value format.
add(String, char) - Method in class com.google.common.base.MoreObjects.ToStringHelper
Adds a name/value pair to the formatted output in name=value format.
add(String, double) - Method in class com.google.common.base.MoreObjects.ToStringHelper
Adds a name/value pair to the formatted output in name=value format.
add(String, float) - Method in class com.google.common.base.MoreObjects.ToStringHelper
Adds a name/value pair to the formatted output in name=value format.
add(String, int) - Method in class com.google.common.base.MoreObjects.ToStringHelper
Adds a name/value pair to the formatted output in name=value format.
add(String, long) - Method in class com.google.common.base.MoreObjects.ToStringHelper
Adds a name/value pair to the formatted output in name=value format.
add(String, Object) - Method in class com.google.common.base.MoreObjects.ToStringHelper
Adds a name/value pair to the formatted output in name=value format.
addAll(double...) - Method in class com.google.common.math.StatsAccumulator
Adds the given values to the dataset.
addAll(double[]) - Method in class com.google.common.primitives.ImmutableDoubleArray.Builder
Appends values, in order, to the end of the values the built ImmutableDoubleArray will contain.
addAll(int...) - Method in class com.google.common.math.StatsAccumulator
Adds the given values to the dataset.
addAll(int[]) - Method in class com.google.common.primitives.ImmutableIntArray.Builder
Appends values, in order, to the end of the values the built ImmutableIntArray will contain.
addAll(int, Collection<? extends E>) - Method in class com.google.common.collect.ForwardingList
 
addAll(int, Collection<? extends E>) - Method in class com.google.common.collect.ImmutableList
Deprecated.
Unsupported operation.
addAll(long...) - Method in class com.google.common.math.StatsAccumulator
Adds the given values to the dataset.
addAll(long[]) - Method in class com.google.common.primitives.ImmutableLongArray.Builder
Appends values, in order, to the end of the values the built ImmutableLongArray will contain.
addAll(RangeSet<C>) - Method in class com.google.common.collect.ImmutableRangeSet
Deprecated.
Unsupported operation.
addAll(RangeSet<C>) - Method in class com.google.common.collect.ImmutableRangeSet.Builder
Add all ranges from the specified range set to this builder.
addAll(RangeSet<C>) - Method in interface com.google.common.collect.RangeSet
Adds all of the ranges from the specified range set to this range set (optional operation).
addAll(PairedStats) - Method in class com.google.common.math.PairedStatsAccumulator
Adds the given statistics to the dataset, as if the individual values used to compute the statistics had been added directly.
addAll(Stats) - Method in class com.google.common.math.StatsAccumulator
Adds the given statistics to the dataset, as if the individual values used to compute the statistics had been added directly.
addAll(StatsAccumulator) - Method in class com.google.common.math.StatsAccumulator
Adds the given statistics to the dataset, as if the individual values used to compute the statistics had been added directly.
addAll(ImmutableDoubleArray) - Method in class com.google.common.primitives.ImmutableDoubleArray.Builder
Appends values, in order, to the end of the values the built ImmutableDoubleArray will contain.
addAll(ImmutableIntArray) - Method in class com.google.common.primitives.ImmutableIntArray.Builder
Appends values, in order, to the end of the values the built ImmutableIntArray will contain.
addAll(ImmutableLongArray) - Method in class com.google.common.primitives.ImmutableLongArray.Builder
Appends values, in order, to the end of the values the built ImmutableLongArray will contain.
addAll(Iterable<? extends E>) - Method in class com.google.common.collect.ImmutableCollection.Builder
Adds each element of elements to the ImmutableCollection being built.
addAll(Iterable<? extends E>) - Method in class com.google.common.collect.ImmutableList.Builder
Adds each element of elements to the ImmutableList.
addAll(Iterable<? extends E>) - Method in class com.google.common.collect.ImmutableMultiset.Builder
Adds each element of elements to the ImmutableMultiset.
addAll(Iterable<? extends E>) - Method in class com.google.common.collect.ImmutableSet.Builder
Adds each element of elements to the ImmutableSet, ignoring duplicate elements (only the first duplicate element is added).
addAll(Iterable<? extends E>) - Method in class com.google.common.collect.ImmutableSortedMultiset.Builder
Adds each element of elements to the ImmutableSortedMultiset.
addAll(Iterable<? extends E>) - Method in class com.google.common.collect.ImmutableSortedSet.Builder
Adds each element of elements to the ImmutableSortedSet, ignoring duplicate elements (only the first duplicate element is added).
addAll(Iterable<? extends Number>) - Method in class com.google.common.math.StatsAccumulator
Adds the given values to the dataset.
addAll(Iterable<Range<C>>) - Method in class com.google.common.collect.ImmutableRangeSet
Deprecated.
Unsupported operation.
addAll(Iterable<Range<C>>) - Method in class com.google.common.collect.ImmutableRangeSet.Builder
Add all of the specified ranges to this builder.
addAll(Iterable<Range<C>>) - Method in interface com.google.common.collect.RangeSet
Adds all of the specified ranges to this range set (optional operation).
addAll(Iterable<Double>) - Method in class com.google.common.primitives.ImmutableDoubleArray.Builder
Appends values, in order, to the end of the values the built ImmutableDoubleArray will contain.
addAll(Iterable<Integer>) - Method in class com.google.common.primitives.ImmutableIntArray.Builder
Appends values, in order, to the end of the values the built ImmutableIntArray will contain.
addAll(Iterable<Long>) - Method in class com.google.common.primitives.ImmutableLongArray.Builder
Appends values, in order, to the end of the values the built ImmutableLongArray will contain.
addAll(Collection<? extends E>) - Method in class com.google.common.collect.EvictingQueue
 
addAll(Collection<? extends E>) - Method in class com.google.common.collect.ForwardingCollection
 
addAll(Collection<? extends E>) - Method in class com.google.common.collect.ImmutableCollection
Deprecated.
Unsupported operation.
addAll(Collection<? extends E>) - Method in class com.google.common.collect.MinMaxPriorityQueue
 
addAll(Collection<? extends E>) - Method in class com.google.common.collect.Sets.SetView
Deprecated.
Unsupported operation.
addAll(Collection<Double>) - Method in class com.google.common.primitives.ImmutableDoubleArray.Builder
Appends values, in order, to the end of the values the built ImmutableDoubleArray will contain.
addAll(Collection<Integer>) - Method in class com.google.common.primitives.ImmutableIntArray.Builder
Appends values, in order, to the end of the values the built ImmutableIntArray will contain.
addAll(Collection<Long>) - Method in class com.google.common.primitives.ImmutableLongArray.Builder
Appends values, in order, to the end of the values the built ImmutableLongArray will contain.
addAll(Collection<T>, Iterable<? extends T>) - Static method in class com.google.common.collect.Iterables
Adds all elements in iterable to collection.
addAll(Collection<T>, Iterator<? extends T>) - Static method in class com.google.common.collect.Iterators
Adds all elements in iterator to collection.
addAll(Iterator<? extends E>) - Method in class com.google.common.collect.ImmutableCollection.Builder
Adds each element of elements to the ImmutableCollection being built.
addAll(Iterator<? extends E>) - Method in class com.google.common.collect.ImmutableList.Builder
Adds each element of elements to the ImmutableList.
addAll(Iterator<? extends E>) - Method in class com.google.common.collect.ImmutableMultiset.Builder
Adds each element of elements to the ImmutableMultiset.
addAll(Iterator<? extends E>) - Method in class com.google.common.collect.ImmutableSet.Builder
 
addAll(Iterator<? extends E>) - Method in class com.google.common.collect.ImmutableSortedMultiset.Builder
Adds each element of elements to the ImmutableSortedMultiset.
addAll(Iterator<? extends E>) - Method in class com.google.common.collect.ImmutableSortedSet.Builder
Adds each element of elements to the ImmutableSortedSet, ignoring duplicate elements (only the first duplicate element is added).
addAll(Iterator<? extends Number>) - Method in class com.google.common.math.StatsAccumulator
Adds the given values to the dataset.
addAll(DoubleStream) - Method in class com.google.common.math.StatsAccumulator
Adds the given values to the dataset.
addAll(DoubleStream) - Method in class com.google.common.primitives.ImmutableDoubleArray.Builder
Appends all values from stream, in order, to the end of the values the built ImmutableDoubleArray will contain.
addAll(IntStream) - Method in class com.google.common.math.StatsAccumulator
Adds the given values to the dataset.
addAll(IntStream) - Method in class com.google.common.primitives.ImmutableIntArray.Builder
Appends all values from stream, in order, to the end of the values the built ImmutableIntArray will contain.
addAll(LongStream) - Method in class com.google.common.math.StatsAccumulator
Adds the given values to the dataset.
addAll(LongStream) - Method in class com.google.common.primitives.ImmutableLongArray.Builder
Appends all values from stream, in order, to the end of the values the built ImmutableLongArray will contain.
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>, Executor) - Static method in class com.google.common.util.concurrent.Futures
Registers separate success and failure callbacks to be run when the Future's computation is complete or, if the computation is already complete, immediately.
addCopies(E, int) - Method in class com.google.common.collect.ImmutableMultiset.Builder
Adds a number of occurrences of an element to this ImmutableMultiset.
addCopies(E, int) - Method in class com.google.common.collect.ImmutableSortedMultiset.Builder
Adds a number of occurrences of an element to this ImmutableSortedMultiset.
addDelayedShutdownHook(ExecutorService, long, TimeUnit) - Static method in class com.google.common.util.concurrent.MoreExecutors
Add a shutdown hook to wait for thread completion in the given service.
addDelayedShutdownHook(ExecutorService, Duration) - Static method in class com.google.common.util.concurrent.MoreExecutors
Add a shutdown hook to wait for thread completion in the given service.
addEdge(EndpointPair<N>, E) - Method in class com.google.common.graph.ImmutableNetwork.Builder
Adds edge connecting endpoints.
addEdge(EndpointPair<N>, E) - Method in interface com.google.common.graph.MutableNetwork
Adds edge connecting endpoints.
addEdge(N, N, E) - Method in class com.google.common.graph.ImmutableNetwork.Builder
Adds edge connecting nodeU to nodeV.
addEdge(N, N, E) - Method in interface com.google.common.graph.MutableNetwork
Adds edge connecting nodeU to nodeV.
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(Service.Listener, Executor) - Method in class com.google.common.util.concurrent.AbstractIdleService
 
addListener(Service.Listener, Executor) - Method in class com.google.common.util.concurrent.AbstractScheduledService
 
addListener(Service.Listener, Executor) - Method in class com.google.common.util.concurrent.AbstractService
 
addListener(Service.Listener, Executor) - Method in interface com.google.common.util.concurrent.Service
Registers a Service.Listener to be executed on the given executor.
addListener(ServiceManager.Listener, Executor) - Method in class com.google.common.util.concurrent.ServiceManager
Registers a ServiceManager.Listener to be executed on the given executor.
addListener(Runnable, Executor) - Method in class com.google.common.util.concurrent.AbstractFuture
Registers a listener to be run on the given executor.
addListener(Runnable, Executor) - Method in class com.google.common.util.concurrent.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
 
addNode(N) - Method in class com.google.common.graph.ImmutableGraph.Builder
Adds node if it is not already present.
addNode(N) - Method in class com.google.common.graph.ImmutableNetwork.Builder
Adds node if it is not already present.
addNode(N) - Method in class com.google.common.graph.ImmutableValueGraph.Builder
Adds node if it is not already present.
addNode(N) - Method in interface com.google.common.graph.MutableGraph
Adds node if it is not already present.
addNode(N) - Method in interface com.google.common.graph.MutableNetwork
Adds node if it is not already present.
addNode(N) - Method in interface com.google.common.graph.MutableValueGraph
Adds node if it is not already present.
addValue(boolean) - Method in class com.google.common.base.MoreObjects.ToStringHelper
Adds an unnamed value to the formatted output.
addValue(char) - Method in class com.google.common.base.MoreObjects.ToStringHelper
Adds an unnamed value to the formatted output.
addValue(double) - Method in class com.google.common.base.MoreObjects.ToStringHelper
Adds an unnamed value to the formatted output.
addValue(float) - Method in class com.google.common.base.MoreObjects.ToStringHelper
Adds an unnamed value to the formatted output.
addValue(int) - Method in class com.google.common.base.MoreObjects.ToStringHelper
Adds an unnamed value to the formatted output.
addValue(long) - Method in class com.google.common.base.MoreObjects.ToStringHelper
Adds an unnamed value to the formatted output.
addValue(Object) - Method in class com.google.common.base.MoreObjects.ToStringHelper
Adds an unnamed value to the formatted output.
adjacentEdges(E) - Method in class com.google.common.graph.AbstractNetwork
 
adjacentEdges(E) - Method in interface com.google.common.graph.Network
Returns a live view of the edges which have an incident node in common with edge.
adjacentNode(N) - 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 a live view of the nodes which have an incident edge in common with node in this graph.
adjacentNodes(N) - Method in interface com.google.common.graph.Network
Returns a live view of the nodes which have an incident edge in common with node in this graph.
adjacentNodes(N) - Method in interface com.google.common.graph.ValueGraph
Returns a live view of the nodes which have an incident edge in common with node in this graph.
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() - Static method in class com.google.common.collect.Range
Returns a range that contains every value of type C.
all(Iterable<T>, Predicate<? super T>) - Static method in class com.google.common.collect.Iterables
Returns true if every element in iterable satisfies the predicate.
all(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.
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.
ALLOW_INSECURE - com.google.common.io.RecursiveDeleteOption
Specifies that the recursive delete should not throw an exception when it can't be guaranteed that it can be done securely, without vulnerability to race conditions (i.e.
AllowConcurrentEvents - Annotation 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() - Method in interface com.google.common.graph.Network
Returns true if this network allows self-loops (edges that connect a node to itself).
allowsSelfLoops() - Method in interface com.google.common.graph.ValueGraph
Returns true if this graph allows self-loops (edges that connect a node to itself).
allowsSelfLoops(boolean) - Method in class com.google.common.graph.GraphBuilder
Specifies whether the graph will allow self-loops (edges that connect a node to itself).
allowsSelfLoops(boolean) - Method in class com.google.common.graph.NetworkBuilder
Specifies whether the network will allow self-loops (edges that connect a node to itself).
allowsSelfLoops(boolean) - Method in class com.google.common.graph.ValueGraphBuilder
Specifies whether the graph will allow self-loops (edges that connect a node to itself).
allPrimitiveTypes() - Static method in class com.google.common.primitives.Primitives
Returns an immutable set of all nine primitive types (including void).
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(double, double) - Method in class com.google.common.math.LinearTransformation.LinearTransformationBuilder
Finish building an instance which also maps x = x2 to y = y2.
and(CharMatcher) - Method in class com.google.common.base.CharMatcher
Returns a matcher that matches any character matched by both this matcher and other.
and(Predicate<? super T>...) - Static method in class com.google.common.base.Predicates
Returns a predicate that evaluates to true if each of its components evaluates to true.
and(Predicate<? super T>, Predicate<? super T>) - Static method in class com.google.common.base.Predicates
Returns a predicate that evaluates to true if both of its components evaluate to true.
and(Iterable<? extends Predicate<? super T>>) - Static method in class com.google.common.base.Predicates
Returns a predicate that evaluates to true if each of its components evaluates to true.
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 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_FONT_TYPE - Static variable in class com.google.common.net.MediaType
Wildcard matching any "font" top-level media type.
ANY_IMAGE_TYPE - Static variable in class com.google.common.net.MediaType
 
ANY_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 BMP character present in the given character sequence.
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 October 2019.
append(Iterable<? extends E>) - Method in class com.google.common.collect.FluentIterable
Returns a fluent iterable whose iterators traverse first the elements of this fluent iterable, followed by those of other.
APPEND - com.google.common.io.FileWriteMode
Specifies that writes to the opened file should append to the end of the file.
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, Iterable<? extends Object>) - Method in class com.google.common.base.Joiner
Appends the string representation of each of parts, using the previously configured separator between each, to appendable.
appendTo(A, Iterable<? extends Map.Entry<?, ?>>) - Method in class com.google.common.base.Joiner.MapJoiner
Appends the string representation of each entry in entries, using the previously configured separator and key-value separator, to appendable.
appendTo(A, Object, Object, Object...) - Method in class com.google.common.base.Joiner
Appends to appendable the string representation of each of the remaining arguments.
appendTo(A, Iterator<? extends Object>) - Method in class com.google.common.base.Joiner
Appends the string representation of each of parts, using the previously configured separator between each, to appendable.
appendTo(A, Iterator<? extends Map.Entry<?, ?>>) - Method in class com.google.common.base.Joiner.MapJoiner
Appends the string representation of each entry in entries, using the previously configured separator and key-value separator, to appendable.
appendTo(A, Map<?, ?>) - Method in class com.google.common.base.Joiner.MapJoiner
Appends the string representation of each entry of map, using the previously configured separator and key-value separator, to appendable.
appendTo(StringBuilder, Object[]) - Method in class com.google.common.base.Joiner
Appends the string representation of each of parts, using the previously configured separator between each, to builder.
appendTo(StringBuilder, Iterable<? extends Object>) - Method in class com.google.common.base.Joiner
Appends the string representation of each of parts, using the previously configured separator between each, to builder.
appendTo(StringBuilder, Iterable<? extends Map.Entry<?, ?>>) - Method in class com.google.common.base.Joiner.MapJoiner
Appends the string representation of each entry in entries, using the previously configured separator and key-value separator, to builder.
appendTo(StringBuilder, Object, Object, Object...) - Method in class com.google.common.base.Joiner
Appends to builder the string representation of each of the remaining arguments.
appendTo(StringBuilder, Iterator<? extends Object>) - Method in class com.google.common.base.Joiner
Appends the string representation of each of parts, using the previously configured separator between each, to builder.
appendTo(StringBuilder, Iterator<? extends Map.Entry<?, ?>>) - Method in class com.google.common.base.Joiner.MapJoiner
Appends the string representation of each entry in entries, using the previously configured separator and key-value separator, to builder.
appendTo(StringBuilder, Map<?, ?>) - Method in class com.google.common.base.Joiner.MapJoiner
Appends the string representation of each entry of map, using the previously configured separator and key-value separator, to builder.
APPLE_MOBILE_CONFIG - Static variable in class com.google.common.net.MediaType
APPLE_PASSBOOK - Static variable in class com.google.common.net.MediaType
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(double, long) - Method in interface com.google.common.collect.Streams.DoubleFunctionWithIndex
Applies this function to the given argument and its index within a stream.
apply(int, long) - Method in interface com.google.common.collect.Streams.IntFunctionWithIndex
Applies this function to the given argument and its index within a stream.
apply(long, long) - Method in interface com.google.common.collect.Streams.LongFunctionWithIndex
Applies this function to the given argument and its index within a stream.
apply(A) - Method in class com.google.common.base.Converter
Deprecated.
Provided to satisfy the Function interface; use Converter.convert(A) instead.
apply(C) - Method in class com.google.common.collect.Range
Deprecated.
Provided only to satisfy the Predicate interface; use Range.contains(C) instead.
apply(ClosingFuture.DeferredCloser, T) - Method in interface com.google.common.util.concurrent.ClosingFuture.AsyncClosingFunction
Applies this function to an input, or throws an exception if unable to do so.
apply(ClosingFuture.DeferredCloser, T) - Method in interface com.google.common.util.concurrent.ClosingFuture.ClosingFunction
Applies this function to an input, or throws an exception if unable to do so.
apply(ClosingFuture.DeferredCloser, V1, V2) - Method in interface com.google.common.util.concurrent.ClosingFuture.Combiner2.AsyncClosingFunction2
Applies this function to two inputs, or throws an exception if unable to do so.
apply(ClosingFuture.DeferredCloser, V1, V2) - Method in interface com.google.common.util.concurrent.ClosingFuture.Combiner2.ClosingFunction2
Applies this function to two inputs, or throws an exception if unable to do so.
apply(ClosingFuture.DeferredCloser, V1, V2, V3) - Method in interface com.google.common.util.concurrent.ClosingFuture.Combiner3.AsyncClosingFunction3
Applies this function to three inputs, or throws an exception if unable to do so.
apply(ClosingFuture.DeferredCloser, V1, V2, V3) - Method in interface com.google.common.util.concurrent.ClosingFuture.Combiner3.ClosingFunction3
Applies this function to three inputs, or throws an exception if unable to do so.
apply(ClosingFuture.DeferredCloser, V1, V2, V3, V4) - Method in interface com.google.common.util.concurrent.ClosingFuture.Combiner4.AsyncClosingFunction4
Applies this function to four inputs, or throws an exception if unable to do so.
apply(ClosingFuture.DeferredCloser, V1, V2, V3, V4) - Method in interface com.google.common.util.concurrent.ClosingFuture.Combiner4.ClosingFunction4
Applies this function to four inputs, or throws an exception if unable to do so.
apply(ClosingFuture.DeferredCloser, V1, V2, V3, V4, V5) - Method in interface com.google.common.util.concurrent.ClosingFuture.Combiner5.AsyncClosingFunction5
Applies this function to five inputs, or throws an exception if unable to do so.
apply(ClosingFuture.DeferredCloser, V1, V2, V3, V4, V5) - Method in interface com.google.common.util.concurrent.ClosingFuture.Combiner5.ClosingFunction5
Applies this function to five inputs, or throws an exception if unable to do so.
apply(F) - Method in interface com.google.common.base.Function
 
apply(I) - Method in interface com.google.common.util.concurrent.AsyncFunction
Returns an output Future to use in place of the given input.
apply(Character) - Method in class com.google.common.base.CharMatcher
Deprecated.
Provided only to satisfy the Predicate interface; use CharMatcher.matches(char) instead.
apply(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(T) - Method in interface com.google.common.base.Predicate
Returns the result of applying this predicate to input (Java 8+ users, see notes in the class documentation above).
apply(T) - Method in class com.google.common.hash.BloomFilter
Deprecated.
Provided only to satisfy the Predicate interface; use BloomFilter.mightContain(T) instead.
apply(T, long) - Method in interface com.google.common.collect.Streams.FunctionWithIndex
Applies this function to the given argument and its index within a stream.
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(ArrayBasedEscaperMap, char, char) - Constructor for class com.google.common.escape.ArrayBasedCharEscaper
Creates a new ArrayBasedCharEscaper instance with the given replacement map and specified safe range.
ArrayBasedCharEscaper(Map<Character, String>, char, char) - Constructor for class com.google.common.escape.ArrayBasedCharEscaper
Creates a new ArrayBasedCharEscaper instance with the given replacement map and specified safe range.
ArrayBasedEscaperMap - Class in com.google.common.escape
An implementation-specific parameter class suitable for initializing ArrayBasedCharEscaper or ArrayBasedUnicodeEscaper instances.
ArrayBasedUnicodeEscaper - Class in com.google.common.escape
A UnicodeEscaper that uses an array to quickly look up replacement characters for a given code point.
ArrayBasedUnicodeEscaper(ArrayBasedEscaperMap, int, int, String) - Constructor for class com.google.common.escape.ArrayBasedUnicodeEscaper
Creates a new ArrayBasedUnicodeEscaper instance with the given replacement map and specified safe range.
ArrayBasedUnicodeEscaper(Map<Character, String>, int, int, String) - Constructor for class com.google.common.escape.ArrayBasedUnicodeEscaper
Creates a new ArrayBasedUnicodeEscaper instance with the given replacement map and specified safe range.
ArrayListMultimap<K extends @Nullable java.lang.Object,​V extends @Nullable java.lang.Object> - 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() - Method in class com.google.common.io.FileBackedOutputStream
Returns a readable ByteSource view of the data that has been written to this stream.
asByteSource() - Method in class com.google.common.reflect.ClassPath.ResourceInfo
Returns a ByteSource view of the resource from which its bytes can be read.
asByteSource(File) - Static method in class com.google.common.io.Files
Returns a new ByteSource for reading bytes from the given file.
asByteSource(URL) - Static method in class com.google.common.io.Resources
Returns a ByteSource that reads from the given URL.
asByteSource(Charset) - Method in class com.google.common.io.CharSource
Returns a ByteSource view of this char source that encodes chars read from this source as bytes using the given Charset.
asByteSource(Path, OpenOption...) - Static method in class com.google.common.io.MoreFiles
Returns a view of the given path as a ByteSource.
asCharSink(File, Charset, FileWriteMode...) - Static method in class com.google.common.io.Files
Returns a new CharSink for writing character data to the given file using the given character set.
asCharSink(Charset) - Method in class com.google.common.io.ByteSink
Returns a CharSink view of this ByteSink that writes characters to this sink as bytes encoded with the given charset.
asCharSink(Path, Charset, OpenOption...) - Static method in class com.google.common.io.MoreFiles
Returns a view of the given path as a CharSink using the given charset.
asCharSource(File, Charset) - Static method in class com.google.common.io.Files
Returns a new CharSource for reading character data from the given file using the given character set.
asCharSource(URL, Charset) - Static method in class com.google.common.io.Resources
Returns a CharSource that reads from the given URL using the given character set.
asCharSource(Charset) - Method in class com.google.common.io.ByteSource
Returns a CharSource view of this byte source that decodes bytes read from this source as characters using the given Charset.
asCharSource(Charset) - Method in class com.google.common.reflect.ClassPath.ResourceInfo
Returns a CharSource view of the resource from which its bytes can be read as characters decoded with the given charset.
asCharSource(Path, Charset, OpenOption...) - Static method in class com.google.common.io.MoreFiles
Returns a view of the given path as a CharSource using the given charset.
ascii() - Static method in class com.google.common.base.CharMatcher
Determines whether a character is ASCII, meaning that its code point is less than 128.
Ascii - Class in com.google.common.base
Static methods pertaining to ASCII characters (those in the range of values 0x00 through 0x7F), and to strings containing such characters.
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() - Method in class com.google.common.escape.Escaper
Returns a Function that invokes Escaper.escape(String) on this escaper.
asFunction(Interner<E>) - Static method in class com.google.common.collect.Interners
Returns a function that delegates to the Interner.intern(E) method of the given interner.
asGraph() - Method in class com.google.common.graph.AbstractNetwork
 
asGraph() - Method in class com.google.common.graph.AbstractValueGraph
 
asGraph() - Method in class com.google.common.graph.ImmutableNetwork
 
asGraph() - Method in class com.google.common.graph.ImmutableValueGraph
 
asGraph() - Method in interface com.google.common.graph.Network
Returns a live view of this network as a Graph.
asGraph() - Method in interface com.google.common.graph.ValueGraph
Returns a live view of this graph as a Graph.
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
Deprecated.
There is no reason to use this; it always returns this.
asList() - Method in class com.google.common.collect.ImmutableMultiset
 
asList() - Method in class com.google.common.primitives.ImmutableDoubleArray
Returns an immutable view of this array's values as a List; note that double values are boxed into Double instances on demand, which can be very expensive.
asList() - Method in class com.google.common.primitives.ImmutableIntArray
Returns an immutable view of this array's values as a List; note that int values are boxed into Integer instances on demand, which can be very expensive.
asList() - Method in class com.google.common.primitives.ImmutableLongArray
Returns an immutable view of this array's values as a List; note that long values are boxed into Long instances on demand, which can be very expensive.
asList(boolean...) - Static method in class com.google.common.primitives.Booleans
Returns a fixed-size list backed by the specified array, similar to Arrays.asList(Object[]).
asList(byte...) - Static method in class com.google.common.primitives.Bytes
Returns a fixed-size list backed by the specified array, similar to Arrays.asList(Object[]).
asList(char...) - Static method in class com.google.common.primitives.Chars
Returns a fixed-size list backed by the specified array, similar to Arrays.asList(Object[]).
asList(double...) - Static method in class com.google.common.primitives.Doubles
Returns a fixed-size list backed by the specified array, similar to Arrays.asList(Object[]).
asList(float...) - Static method in class com.google.common.primitives.Floats
Returns a fixed-size list backed by the specified array, similar to Arrays.asList(Object[]).
asList(int...) - Static method in class com.google.common.primitives.Ints
Returns a fixed-size list backed by the specified array, similar to Arrays.asList(Object[]).
asList(long...) - Static method in class com.google.common.primitives.Longs
Returns a fixed-size list backed by the specified array, similar to Arrays.asList(Object[]).
asList(short...) - Static method in class com.google.common.primitives.Shorts
Returns a fixed-size list backed by the specified array, similar to Arrays.asList(Object[]).
asList(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.
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() - Method in interface com.google.common.collect.Multimap
Returns a view of this multimap as a Map from each distinct key to the nonempty collection of that key's associated values.
asMap() - Method in 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.
asMap(ListMultimap<K, V>) - Static method in class com.google.common.collect.Multimaps
Returns multimap.asMap(), with its type corrected from Map<K, Collection<V>> to Map<K, List<V>>.
asMap(Multimap<K, V>) - Static method in class com.google.common.collect.Multimaps
asMap(SetMultimap<K, V>) - Static method in class com.google.common.collect.Multimaps
Returns multimap.asMap(), with its type corrected from Map<K, Collection<V>> to Map<K, Set<V>>.
asMap(SortedSetMultimap<K, V>) - Static method in class com.google.common.collect.Multimaps
Returns multimap.asMap(), with its type corrected from Map<K, Collection<V>> to Map<K, SortedSet<V>>.
asMap(NavigableSet<K>, Function<? super K, V>) - Static method in class com.google.common.collect.Maps
Returns a view of the navigable set as a map, mapping keys from the set according to the specified function.
asMap(Set<K>, Function<? super K, V>) - Static method in class com.google.common.collect.Maps
Returns a live Map view whose keys are the contents of set and whose values are computed on demand using function.
asMap(SortedSet<K>, Function<? super K, V>) - Static method in class com.google.common.collect.Maps
Returns a view of the sorted set as a map, mapping keys from the set according to the specified function.
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.
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 extends @Nullable java.lang.Object> - 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) - Constructor for class com.google.common.eventbus.AsyncEventBus
Creates a new AsyncEventBus that will use executor to dispatch events.
AsyncEventBus(Executor, SubscriberExceptionHandler) - Constructor for class com.google.common.eventbus.AsyncEventBus
Creates a new AsyncEventBus that will use executor to dispatch events.
AsyncFunction<I extends @Nullable java.lang.Object,​O extends @Nullable java.lang.Object> - 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() - Constructor for class com.google.common.util.concurrent.AtomicDouble
Creates a new AtomicDouble with initial value 0.0.
AtomicDouble(double) - Constructor for class com.google.common.util.concurrent.AtomicDouble
Creates a new AtomicDouble with the given initial value.
AtomicDoubleArray - Class in com.google.common.util.concurrent
A double array in which elements may be updated atomically.
AtomicDoubleArray(double[]) - Constructor for class com.google.common.util.concurrent.AtomicDoubleArray
Creates a new AtomicDoubleArray with the same length as, and all elements copied from, the given array.
AtomicDoubleArray(int) - Constructor for class com.google.common.util.concurrent.AtomicDoubleArray
Creates a new AtomicDoubleArray of the given length, with all elements initially zero.
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.
awaitHealthy(Duration) - Method in class com.google.common.util.concurrent.ServiceManager
Waits for the ServiceManager to become healthy for no more than the given time.
awaitRunning() - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
 
awaitRunning() - Method in class com.google.common.util.concurrent.AbstractIdleService
 
awaitRunning() - Method in class com.google.common.util.concurrent.AbstractScheduledService
 
awaitRunning() - Method in class com.google.common.util.concurrent.AbstractService
 
awaitRunning() - Method in interface com.google.common.util.concurrent.Service
Waits for the Service to reach the running state.
awaitRunning(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
 
awaitRunning(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractIdleService
 
awaitRunning(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractScheduledService
 
awaitRunning(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractService
 
awaitRunning(long, TimeUnit) - Method in interface com.google.common.util.concurrent.Service
Waits for the Service to reach the running state for no more than the given time.
awaitRunning(Duration) - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
 
awaitRunning(Duration) - Method in class com.google.common.util.concurrent.AbstractIdleService
 
awaitRunning(Duration) - Method in class com.google.common.util.concurrent.AbstractScheduledService
 
awaitRunning(Duration) - Method in class com.google.common.util.concurrent.AbstractService
 
awaitRunning(Duration) - Method in interface com.google.common.util.concurrent.Service
Waits for the Service to reach the running state for no more than the given time.
awaitStopped() - Method in class com.google.common.util.concurrent.ServiceManager
Waits for the all the services to reach a terminal state.
awaitStopped(long, TimeUnit) - Method in class com.google.common.util.concurrent.ServiceManager
Waits for the all the services to reach a terminal state for no more than the given time.
awaitStopped(Duration) - Method in class com.google.common.util.concurrent.ServiceManager
Waits for the all the services to reach a terminal state for no more than the given time.
awaitTerminated() - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
 
awaitTerminated() - Method in class com.google.common.util.concurrent.AbstractIdleService
 
awaitTerminated() - Method in class com.google.common.util.concurrent.AbstractScheduledService
 
awaitTerminated() - Method in class com.google.common.util.concurrent.AbstractService
 
awaitTerminated() - Method in interface com.google.common.util.concurrent.Service
Waits for the Service to reach the terminated state.
awaitTerminated(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
 
awaitTerminated(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractIdleService
 
awaitTerminated(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractScheduledService
 
awaitTerminated(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractService
 
awaitTerminated(long, TimeUnit) - Method in interface com.google.common.util.concurrent.Service
Waits for the Service to reach a terminal state (either terminated or failed) for no more than the given time.
awaitTerminated(Duration) - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
 
awaitTerminated(Duration) - Method in class com.google.common.util.concurrent.AbstractIdleService
 
awaitTerminated(Duration) - Method in class com.google.common.util.concurrent.AbstractScheduledService
 
awaitTerminated(Duration) - Method in class com.google.common.util.concurrent.AbstractService
 
awaitTerminated(Duration) - Method in interface com.google.common.util.concurrent.Service
Waits for the Service to reach a terminal state (either terminated or failed) for no more than the given time.
awaitTermination(long, TimeUnit) - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
awaitTermination(Duration) - Method in interface com.google.common.util.concurrent.ListeningExecutorService
Duration-based overload of ExecutorService.awaitTermination(long, TimeUnit).
awaitTerminationUninterruptibly(ExecutorService) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes executor.awaitTermination(long, TimeUnit) uninterruptibly with no timeout.
awaitTerminationUninterruptibly(ExecutorService, long, TimeUnit) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes executor.awaitTermination(long, TimeUnit) uninterruptibly.
awaitTerminationUninterruptibly(ExecutorService, Duration) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes executor.awaitTermination(long, TimeUnit) uninterruptibly.
awaitUninterruptibly(CountDownLatch) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes latch.await() uninterruptibly.
awaitUninterruptibly(CountDownLatch, long, TimeUnit) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes latch.await(timeout, unit) uninterruptibly.
awaitUninterruptibly(CountDownLatch, Duration) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes latch.await(timeout, unit) uninterruptibly.
awaitUninterruptibly(Condition, long, TimeUnit) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes condition.await(timeout, unit) uninterruptibly.
awaitUninterruptibly(Condition, Duration) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes condition.await(timeout, unit) uninterruptibly.

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
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.
BigDecimalMath - Class in com.google.common.math
A class for arithmetic on BigDecimal that is not covered by its built-in methods.
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 extends @Nullable java.lang.Object,​V extends @Nullable java.lang.Object> - 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.
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 extends @Nullable java.lang.Object> - Class in com.google.common.hash
A Bloom filter for instances of T.
BMP - Static variable in class com.google.common.net.MediaType
Bitmap file format (bmp files).
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").
breadthFirst(Iterable<? extends N>) - Method in class com.google.common.graph.Traverser
Returns an unmodifiable Iterable over the nodes reachable from any of the startNodes, in the order of a breadth-first traversal.
breadthFirst(N) - Method in class com.google.common.graph.Traverser
Returns an unmodifiable Iterable over the nodes reachable from startNode, in the order of a breadth-first traversal.
breadthFirstTraversal(T) - Method in class com.google.common.collect.TreeTraverser
Deprecated.
Use Traverser.breadthFirst(N) instead, which has the same behavior.
breakingWhitespace() - Static method in class com.google.common.base.CharMatcher
Determines whether a character is a breaking whitespace (that is, a whitespace which can be interpreted as a break between words for formatting purposes).
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() - Method in class com.google.common.cache.CacheBuilder
Builds a cache which does not automatically load values when keys are requested.
build() - Method in class com.google.common.collect.ImmutableBiMap.Builder
Returns a newly-created immutable bimap.
build() - Method in class com.google.common.collect.ImmutableClassToInstanceMap.Builder
Returns a new immutable class-to-instance map containing the entries provided to this builder.
build() - Method in class com.google.common.collect.ImmutableCollection.Builder
Returns a newly-created ImmutableCollection of the appropriate type, containing the elements provided to this builder.
build() - Method in class com.google.common.collect.ImmutableList.Builder
Returns a newly-created ImmutableList based on the contents of the Builder.
build() - Method in class com.google.common.collect.ImmutableListMultimap.Builder
Returns a newly-created immutable list multimap.
build() - Method in class com.google.common.collect.ImmutableMap.Builder
Returns a newly-created immutable map.
build() - Method in class com.google.common.collect.ImmutableMultimap.Builder
Returns a newly-created immutable multimap.
build() - Method in class com.google.common.collect.ImmutableMultiset.Builder
Returns a newly-created ImmutableMultiset based on the contents of the Builder.
build() - Method in class com.google.common.collect.ImmutableRangeMap.Builder
Returns an ImmutableRangeMap containing the associations previously added to this builder.
build() - Method in class com.google.common.collect.ImmutableRangeSet.Builder
Returns an ImmutableRangeSet containing the ranges added to this builder.
build() - Method in class com.google.common.collect.ImmutableSet.Builder
 
build() - Method in class com.google.common.collect.ImmutableSetMultimap.Builder
Returns a newly-created immutable set multimap.
build() - Method in class com.google.common.collect.ImmutableSortedMap.Builder
Returns a newly-created immutable sorted map.
build() - Method in class com.google.common.collect.ImmutableSortedMultiset.Builder
Returns a newly-created ImmutableSortedMultiset based on the contents of the Builder.
build() - Method in class com.google.common.collect.ImmutableSortedSet.Builder
Returns a newly-created ImmutableSortedSet based on the contents of the Builder and its comparator.
build() - Method in class com.google.common.collect.ImmutableTable.Builder
Returns a newly-created immutable table.
build() - Method in class com.google.common.collect.Interners.InternerBuilder
 
build() - Method in class com.google.common.collect.MultimapBuilder
Returns a new, empty Multimap with the specified implementation.
build() - Method in class com.google.common.collect.MultimapBuilder.ListMultimapBuilder
 
build() - Method in class com.google.common.collect.MultimapBuilder.SetMultimapBuilder
 
build() - Method in class com.google.common.collect.MultimapBuilder.SortedSetMultimapBuilder
 
build() - Method in class com.google.common.escape.Escapers.Builder
Returns a new escaper based on the current state of the builder.
build() - Method in class com.google.common.graph.GraphBuilder
Returns an empty MutableGraph with the properties of this GraphBuilder.
build() - Method in class com.google.common.graph.ImmutableGraph.Builder
Returns a newly-created ImmutableGraph based on the contents of this Builder.
build() - Method in class com.google.common.graph.ImmutableNetwork.Builder
Returns a newly-created ImmutableNetwork based on the contents of this Builder.
build() - Method in class com.google.common.graph.ImmutableValueGraph.Builder
Returns a newly-created ImmutableValueGraph based on the contents of this Builder.
build() - Method in class com.google.common.graph.NetworkBuilder
Returns an empty MutableNetwork with the properties of this NetworkBuilder.
build() - Method in class com.google.common.graph.ValueGraphBuilder
Returns an empty MutableValueGraph with the properties of this ValueGraphBuilder.
build() - Method in class com.google.common.primitives.ImmutableDoubleArray.Builder
Returns a new immutable array.
build() - Method in class com.google.common.primitives.ImmutableIntArray.Builder
Returns a new immutable array.
build() - Method in class com.google.common.primitives.ImmutableLongArray.Builder
Returns a new immutable array.
build() - Method in class com.google.common.reflect.ImmutableTypeToInstanceMap.Builder
Returns a new immutable type-to-instance map containing the entries provided to this builder.
build() - Method in class com.google.common.util.concurrent.ThreadFactoryBuilder
Returns a new thread factory using the options supplied during the building process.
build(CacheLoader<? super K1, V1>) - Method in class com.google.common.cache.CacheBuilder
Builds a cache, which either returns an already-loaded value for a given key or atomically computes or retrieves it using the supplied CacheLoader.
build(Multimap<? extends K, ? extends V>) - Method in class com.google.common.collect.MultimapBuilder
Returns a Multimap with the specified implementation, initialized with the entries of multimap.
build(Multimap<? extends K, ? extends V>) - Method in class com.google.common.collect.MultimapBuilder.ListMultimapBuilder
 
build(Multimap<? extends K, ? extends V>) - Method in class com.google.common.collect.MultimapBuilder.SetMultimapBuilder
 
build(Multimap<? extends K, ? extends V>) - Method in class com.google.common.collect.MultimapBuilder.SortedSetMultimapBuilder
 
builder() - Static method in class com.google.common.collect.ContiguousSet
builder() - Static method in class com.google.common.collect.ImmutableBiMap
Returns a new builder.
builder() - Static method in class com.google.common.collect.ImmutableClassToInstanceMap
Returns a new builder.
builder() - Static method in class com.google.common.collect.ImmutableList
Returns a new builder.
builder() - Static method in class com.google.common.collect.ImmutableListMultimap
Returns a new builder.
builder() - Static method in class com.google.common.collect.ImmutableMap
Returns a new builder.
builder() - Static method in class com.google.common.collect.ImmutableMultimap
Returns a new builder.
builder() - Static method in class com.google.common.collect.ImmutableMultiset
Returns a new builder.
builder() - Static method in class com.google.common.collect.ImmutableRangeMap
Returns a new builder for an immutable range map.
builder() - Static method in class com.google.common.collect.ImmutableRangeSet
Returns a new builder for an immutable range set.
builder() - Static method in class com.google.common.collect.ImmutableSet
Returns a new builder.
builder() - Static method in class com.google.common.collect.ImmutableSetMultimap
builder() - Static method in class com.google.common.collect.ImmutableSortedMap
Deprecated.
Use ImmutableSortedMap.naturalOrder(), which offers better type-safety.
builder() - Static method in class com.google.common.collect.ImmutableSortedMultiset
Deprecated.
Use ImmutableSortedMultiset.naturalOrder(), which offers better type-safety.
builder() - Static method in class com.google.common.collect.ImmutableSortedSet
Deprecated.
Use ImmutableSortedSet.naturalOrder(), which offers better type-safety.
builder() - Static method in class com.google.common.collect.ImmutableTable
Returns a new builder.
builder() - Static method in class com.google.common.escape.Escapers
Returns a builder for creating simple, fast escapers.
builder() - Static method in class com.google.common.primitives.ImmutableDoubleArray
Returns a new, empty builder for ImmutableDoubleArray instances, with a default initial capacity.
builder() - Static method in class com.google.common.primitives.ImmutableIntArray
Returns a new, empty builder for ImmutableIntArray instances, with a default initial capacity.
builder() - Static method in class com.google.common.primitives.ImmutableLongArray
Returns a new, empty builder for ImmutableLongArray instances, with a default initial capacity.
builder() - Static method in class com.google.common.reflect.ImmutableTypeToInstanceMap
Returns a new builder.
builder(int) - Static method in class com.google.common.primitives.ImmutableDoubleArray
Returns a new, empty builder for ImmutableDoubleArray instances, sized to hold up to initialCapacity values without resizing.
builder(int) - Static method in class com.google.common.primitives.ImmutableIntArray
Returns a new, empty builder for ImmutableIntArray instances, sized to hold up to initialCapacity values without resizing.
builder(int) - Static method in class com.google.common.primitives.ImmutableLongArray
Returns a new, empty builder for ImmutableLongArray instances, sized to hold up to initialCapacity values without resizing.
Builder() - Constructor for class com.google.common.collect.ImmutableBiMap.Builder
Creates a new builder.
Builder() - Constructor for class com.google.common.collect.ImmutableClassToInstanceMap.Builder
 
Builder() - Constructor for class com.google.common.collect.ImmutableList.Builder
Creates a new builder.
Builder() - Constructor for class com.google.common.collect.ImmutableListMultimap.Builder
Creates a new builder.
Builder() - Constructor for class com.google.common.collect.ImmutableMap.Builder
Creates a new builder.
Builder() - Constructor for class com.google.common.collect.ImmutableMultimap.Builder
Creates a new builder.
Builder() - Constructor for class com.google.common.collect.ImmutableMultiset.Builder
Creates a new builder.
Builder() - Constructor for class com.google.common.collect.ImmutableRangeMap.Builder
 
Builder() - Constructor for class com.google.common.collect.ImmutableRangeSet.Builder
 
Builder() - Constructor for class com.google.common.collect.ImmutableSet.Builder
 
Builder() - Constructor for class com.google.common.collect.ImmutableSetMultimap.Builder
Creates a new builder.
Builder() - Constructor for class com.google.common.collect.ImmutableTable.Builder
Creates a new builder.
Builder(Comparator<? super E>) - Constructor for class com.google.common.collect.ImmutableSortedMultiset.Builder
Creates a new builder.
Builder(Comparator<? super E>) - Constructor for class com.google.common.collect.ImmutableSortedSet.Builder
Creates a new builder.
Builder(Comparator<? super K>) - Constructor for class com.google.common.collect.ImmutableSortedMap.Builder
Creates a new builder.
builderWithExpectedSize(int) - Static method in class com.google.common.collect.ImmutableBiMap
Returns a new builder, expecting the specified number of entries to be added.
builderWithExpectedSize(int) - Static method in class com.google.common.collect.ImmutableList
Returns a new builder, expecting the specified number of elements to be added.
builderWithExpectedSize(int) - Static method in class com.google.common.collect.ImmutableMap
Returns a new builder, expecting the specified number of entries to be added.
builderWithExpectedSize(int) - Static method in class com.google.common.collect.ImmutableSet
Returns a new builder, expecting the specified number of distinct elements to be added.
builderWithExpectedSize(int) - Static method in class com.google.common.collect.ImmutableSortedMap
Deprecated.
Not supported for ImmutableSortedMap.
builderWithExpectedSize(int) - Static method in class com.google.common.collect.ImmutableSortedSet
Deprecated.
Not supported by ImmutableSortedSet.
buildKeepingLast() - Method in class com.google.common.collect.ImmutableBiMap.Builder
Deprecated.
This method does not make sense for bimaps and should not be called.
buildKeepingLast() - Method in class com.google.common.collect.ImmutableMap.Builder
Returns a newly-created immutable map, using the last value for any key that was added more than once.
buildKeepingLast() - Method in class com.google.common.collect.ImmutableSortedMap.Builder
Deprecated.
This method is not currently implemented, and may never be.
buildOrThrow() - Method in class com.google.common.collect.ImmutableBiMap.Builder
Returns a newly-created immutable bimap, or throws an exception if any key or value was added more than once.
buildOrThrow() - Method in class com.google.common.collect.ImmutableMap.Builder
Returns a newly-created immutable map, or throws an exception if any key was added more than once.
buildOrThrow() - Method in class com.google.common.collect.ImmutableSortedMap.Builder
Returns a newly-created immutable sorted map, or throws an exception if any two keys are equal.
buildOrThrow() - Method in class com.google.common.collect.ImmutableTable.Builder
Returns a newly-created immutable table, or throws an exception if duplicate key pairs were added.
bulkGet(Iterable<? extends Object>) - Method in class com.google.common.util.concurrent.Striped
Returns the stripes that correspond to the passed objects, in ascending (as per Striped.getAt(int)) order.
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 extends @Nullable java.lang.Object> - 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.
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(ClosingFuture.Combiner.CombiningCallable<V>, Executor) - Method in class com.google.common.util.concurrent.ClosingFuture.Combiner
Returns a new ClosingFuture pipeline step derived from the inputs by applying a combining function to their values.
call(ClosingFuture.Combiner2.ClosingFunction2<V1, V2, U>, Executor) - Method in class com.google.common.util.concurrent.ClosingFuture.Combiner2
Returns a new ClosingFuture pipeline step derived from the inputs by applying a combining function to their values.
call(ClosingFuture.Combiner3.ClosingFunction3<V1, V2, V3, U>, Executor) - Method in class com.google.common.util.concurrent.ClosingFuture.Combiner3
Returns a new ClosingFuture pipeline step derived from the inputs by applying a combining function to their values.
call(ClosingFuture.Combiner4.ClosingFunction4<V1, V2, V3, V4, U>, Executor) - Method in class com.google.common.util.concurrent.ClosingFuture.Combiner4
Returns a new ClosingFuture pipeline step derived from the inputs by applying a combining function to their values.
call(ClosingFuture.Combiner5.ClosingFunction5<V1, V2, V3, V4, V5, U>, Executor) - Method in class com.google.common.util.concurrent.ClosingFuture.Combiner5
Returns a new ClosingFuture pipeline step derived from the inputs by applying a combining function to their values.
call(ClosingFuture.DeferredCloser) - Method in interface com.google.common.util.concurrent.ClosingFuture.AsyncClosingCallable
Computes a result, or throws an exception if unable to do so.
call(ClosingFuture.DeferredCloser) - Method in interface com.google.common.util.concurrent.ClosingFuture.ClosingCallable
Computes a result, or throws an exception if unable to do so.
call(ClosingFuture.DeferredCloser, ClosingFuture.Peeker) - Method in interface com.google.common.util.concurrent.ClosingFuture.Combiner.AsyncCombiningCallable
Computes a ClosingFuture result, or throws an exception if unable to do so.
call(ClosingFuture.DeferredCloser, ClosingFuture.Peeker) - Method in interface com.google.common.util.concurrent.ClosingFuture.Combiner.CombiningCallable
Computes a result, or throws an exception if unable to do so.
call(Callable<C>, Executor) - Method in class com.google.common.util.concurrent.Futures.FutureCombiner
Creates the ListenableFuture which will return the result of calling Callable.call() in combiner when all futures complete, using the specified executor.
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(ClosingFuture.Combiner.AsyncCombiningCallable<V>, Executor) - Method in class com.google.common.util.concurrent.ClosingFuture.Combiner
Returns a new ClosingFuture pipeline step derived from the inputs by applying a ClosingFuture-returning function to their values.
callAsync(ClosingFuture.Combiner2.AsyncClosingFunction2<V1, V2, U>, Executor) - Method in class com.google.common.util.concurrent.ClosingFuture.Combiner2
Returns a new ClosingFuture pipeline step derived from the inputs by applying a ClosingFuture-returning function to their values.
callAsync(ClosingFuture.Combiner3.AsyncClosingFunction3<V1, V2, V3, U>, Executor) - Method in class com.google.common.util.concurrent.ClosingFuture.Combiner3
Returns a new ClosingFuture pipeline step derived from the inputs by applying a ClosingFuture-returning function to their values.
callAsync(ClosingFuture.Combiner4.AsyncClosingFunction4<V1, V2, V3, V4, U>, Executor) - Method in class com.google.common.util.concurrent.ClosingFuture.Combiner4
Returns a new ClosingFuture pipeline step derived from the inputs by applying a ClosingFuture-returning function to their values.
callAsync(ClosingFuture.Combiner5.AsyncClosingFunction5<V1, V2, V3, V4, V5, U>, Executor) - Method in class com.google.common.util.concurrent.ClosingFuture.Combiner5
Returns a new ClosingFuture pipeline step derived from the inputs by applying a ClosingFuture-returning function to their values.
callUninterruptiblyWithTimeout(Callable<T>, long, TimeUnit) - Method in class com.google.common.util.concurrent.FakeTimeLimiter
 
callUninterruptiblyWithTimeout(Callable<T>, long, TimeUnit) - Method in class com.google.common.util.concurrent.SimpleTimeLimiter
 
callUninterruptiblyWithTimeout(Callable<T>, long, TimeUnit) - Method in interface com.google.common.util.concurrent.TimeLimiter
Invokes a specified Callable, timing out after the specified time limit.
callUninterruptiblyWithTimeout(Callable<T>, Duration) - Method in interface com.google.common.util.concurrent.TimeLimiter
Invokes a specified Callable, timing out after the specified time limit.
callWithTimeout(Callable<T>, long, TimeUnit) - Method in class com.google.common.util.concurrent.FakeTimeLimiter
 
callWithTimeout(Callable<T>, long, TimeUnit) - Method in class com.google.common.util.concurrent.SimpleTimeLimiter
 
callWithTimeout(Callable<T>, long, TimeUnit) - Method in interface com.google.common.util.concurrent.TimeLimiter
Invokes a specified Callable, timing out after the specified time limit.
callWithTimeout(Callable<T>, Duration) - Method in interface com.google.common.util.concurrent.TimeLimiter
Invokes a specified Callable, timing out after the specified time limit.
CAN - Static variable in class com.google.common.base.Ascii
Cancel: A control character used to indicate that the data with which it is sent is in error or is to be disregarded.
cancel(boolean) - Method in class com.google.common.util.concurrent.AbstractFuture
cancel(boolean) - Method in class com.google.common.util.concurrent.ClosingFuture
Attempts to cancel execution of this step.
cancel(boolean) - Method in class com.google.common.util.concurrent.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 B>...) - Static method in class com.google.common.collect.Lists
Returns every possible list that can be formed by choosing one element from each of the given lists in order; the "n-ary Cartesian product" of the lists.
cartesianProduct(List<? extends List<? extends B>>) - Static method in class com.google.common.collect.Lists
Returns every possible list that can be formed by choosing one element from each of the given lists in order; the "n-ary Cartesian product" of the lists.
cartesianProduct(List<? extends Set<? extends B>>) - Static method in class com.google.common.collect.Sets
Returns every possible list that can be formed by choosing one element from each of the given sets in order; the "n-ary Cartesian product" of the sets.
cartesianProduct(Set<? extends B>...) - Static method in class com.google.common.collect.Sets
Returns every possible list that can be formed by choosing one element from each of the given sets in order; the "n-ary Cartesian product" of the sets.
CaseFormat - Enum in com.google.common.base
Utility class for converting between various ASCII case formats.
catching(ListenableFuture<? extends V>, Class<X>, Function<? super X, ? extends V>, Executor) - Static method in class com.google.common.util.concurrent.Futures
Returns a Future whose result is taken from the given primary input or, if the primary input fails with the given exceptionType, from the result provided by the fallback.
catching(Class<X>, Function<? super X, ? extends V>, Executor) - Method in class com.google.common.util.concurrent.FluentFuture
Returns a Future whose result is taken from this Future or, if this Future fails with the given exceptionType, from the result provided by the fallback.
catching(Class<X>, ClosingFuture.ClosingFunction<? super X, ? extends V>, Executor) - Method in class com.google.common.util.concurrent.ClosingFuture
Returns a new ClosingFuture pipeline step derived from this one by applying a function to its exception if it is an instance of a given exception type.
catchingAsync(ListenableFuture<? extends V>, Class<X>, AsyncFunction<? super X, ? extends V>, Executor) - Static method in class com.google.common.util.concurrent.Futures
Returns a Future whose result is taken from the given primary input or, if the primary input fails with the given exceptionType, from the result provided by the fallback.
catchingAsync(Class<X>, AsyncFunction<? super X, ? extends V>, Executor) - Method in class com.google.common.util.concurrent.FluentFuture
Returns a Future whose result is taken from this Future or, if this Future fails with the given exceptionType, from the result provided by the fallback.
catchingAsync(Class<X>, ClosingFuture.AsyncClosingFunction<? super X, ? extends V>, Executor) - Method in class com.google.common.util.concurrent.ClosingFuture
Returns a new ClosingFuture pipeline step derived from this one by applying a function that returns a ClosingFuture to its exception if it is an instance of a given exception type.
CDN_LOOP - Static variable in class com.google.common.net.HttpHeaders
The HTTP CDN-Loop header field name.
ceiling(E) - Method in class com.google.common.collect.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(int) - Static method in class com.google.common.math.IntMath
Returns the smallest power of two greater than or equal to x.
ceilingPowerOfTwo(long) - Static method in class com.google.common.math.LongMath
Returns the smallest power of two greater than or equal to x.
ceilingPowerOfTwo(BigInteger) - Static method in class com.google.common.math.BigIntegerMath
Returns the smallest power of two greater than or equal to x.
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(CharSequence) - Static method in class com.google.common.collect.Lists
Returns a view of the specified CharSequence as a List<Character>, viewing sequence as a sequence of Unicode code units.
charactersOf(String) - Static method in class com.google.common.collect.Lists
Returns a view of the specified string as an immutable list of Character values.
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, char) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, char, char) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, char, int) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, char, long) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, char, Object) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, int) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, int, char) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, int, int) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, int, long) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, int, Object) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, long) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, long, char) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, long, int) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, long, long) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, long, Object) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, Object...) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, Object) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, Object, char) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, Object, int) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, Object, long) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, Object, Object) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, Object, Object, Object) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, Object, Object, Object, Object) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
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.
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, char) - Static method in class com.google.common.base.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, char, char) - Static method in class com.google.common.base.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, char, int) - Static method in class com.google.common.base.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, char, long) - Static method in class com.google.common.base.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, char, Object) - Static method in class com.google.common.base.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, int) - Static method in class com.google.common.base.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, int, char) - Static method in class com.google.common.base.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, int, int) - Static method in class com.google.common.base.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, int, long) - Static method in class com.google.common.base.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, int, Object) - Static method in class com.google.common.base.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, long) - Static method in class com.google.common.base.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, long, char) - Static method in class com.google.common.base.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, long, int) - Static method in class com.google.common.base.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, long, long) - Static method in class com.google.common.base.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, long, Object) - Static method in class com.google.common.base.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, Object...) - Static method in class com.google.common.base.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, Object) - Static method in class com.google.common.base.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, Object, char) - Static method in class com.google.common.base.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, Object, int) - Static method in class com.google.common.base.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, Object, long) - Static method in class com.google.common.base.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, Object, Object) - Static method in class com.google.common.base.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, Object, Object, Object) - Static method in class com.google.common.base.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, Object, Object, Object, Object) - Static method in class com.google.common.base.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkPositionIndex(int, int) - Static method in class com.google.common.base.Preconditions
Ensures that index specifies a valid position in an array, list or string of size size.
checkPositionIndex(int, int, String) - Static method in class com.google.common.base.Preconditions
Ensures that index specifies a valid position in an array, list or string of size size.
checkPositionIndexes(int, int, int) - Static method in class com.google.common.base.Preconditions
Ensures that start and end specify valid positions in an array, list or string of size size, and are in order.
checkState(boolean) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, Object) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, char) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, char, char) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, char, int) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, char, long) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, char, Object) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, int) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, int, char) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, int, int) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, int, long) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, int, Object) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, long) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, long, char) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, long, int) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, long, long) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, long, Object) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, Object...) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, Object) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, Object, char) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, Object, int) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, Object, long) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, Object, Object) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, Object, Object, Object) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, Object, Object, Object, Object) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
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.TreeTraverser
Deprecated.
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 extends @Nullable java.lang.Object> - 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.EnumMultiset
 
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.TreeMultiset
 
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() - Method in class com.google.common.io.Closer
Closes all Closeable instances that have been added to this Closer.
close() - Method in class com.google.common.io.CountingOutputStream
 
close() - Method in class com.google.common.io.FileBackedOutputStream
 
close() - Method in class com.google.common.io.LittleEndianDataOutputStream
 
close(Closeable, boolean) - Static method in class com.google.common.io.Closeables
Closes a Closeable, with control over whether an IOException may be thrown.
Closeables - Class in com.google.common.io
Utility methods for working with Closeable objects.
closeAsync() - Method in class com.google.common.util.concurrent.ClosingFuture.ValueAndCloser
Starts closing all closeable objects captured during the ClosingFuture's asynchronous operation on the Executors specified by calls to ClosingFuture.DeferredCloser.eventuallyClose(Object, Executor).
closed(int, int) - Static method in class com.google.common.collect.ContiguousSet
Returns a nonempty contiguous set containing all int values from lower (inclusive) to upper (inclusive).
closed(long, long) - Static method in class com.google.common.collect.ContiguousSet
Returns a nonempty contiguous set containing all long values from lower (inclusive) to upper (inclusive).
closed(C, C) - Static method in class com.google.common.collect.Range
Returns a range that contains all values greater than or equal to lower and less than or equal to upper.
CLOSED - com.google.common.collect.BoundType
 
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.
ClosingFuture<V extends @Nullable java.lang.Object> - Class in com.google.common.util.concurrent
A step in a pipeline of an asynchronous computation.
ClosingFuture.AsyncClosingCallable<V extends @Nullable java.lang.Object> - Interface in com.google.common.util.concurrent
An operation that computes a ClosingFuture of a result.
ClosingFuture.AsyncClosingFunction<T extends @Nullable java.lang.Object,​U extends @Nullable java.lang.Object> - Interface in com.google.common.util.concurrent
A function from an input to a ClosingFuture of a result.
ClosingFuture.ClosingCallable<V extends @Nullable java.lang.Object> - Interface in com.google.common.util.concurrent
An operation that computes a result.
ClosingFuture.ClosingFunction<T extends @Nullable java.lang.Object,​U extends @Nullable java.lang.Object> - Interface in com.google.common.util.concurrent
A function from an input to a result.
ClosingFuture.Combiner - Class in com.google.common.util.concurrent
A builder of a ClosingFuture step that is derived from more than one input step.
ClosingFuture.Combiner.AsyncCombiningCallable<V extends @Nullable java.lang.Object> - Interface in com.google.common.util.concurrent
An operation that returns a ClosingFuture result and may throw an exception.
ClosingFuture.Combiner.CombiningCallable<V extends @Nullable java.lang.Object> - Interface in com.google.common.util.concurrent
An operation that returns a result and may throw an exception.
ClosingFuture.Combiner2<V1 extends @Nullable java.lang.Object,​V2 extends @Nullable java.lang.Object> - Class in com.google.common.util.concurrent
A generic ClosingFuture.Combiner that lets you use a lambda or method reference to combine two ClosingFutures.
ClosingFuture.Combiner2.AsyncClosingFunction2<V1 extends @Nullable java.lang.Object,​V2 extends @Nullable java.lang.Object,​U extends @Nullable java.lang.Object> - Interface in com.google.common.util.concurrent
A function that returns a ClosingFuture when applied to the values of the two futures passed to ClosingFuture.whenAllSucceed(ClosingFuture, ClosingFuture).
ClosingFuture.Combiner2.ClosingFunction2<V1 extends @Nullable java.lang.Object,​V2 extends @Nullable java.lang.Object,​U extends @Nullable java.lang.Object> - Interface in com.google.common.util.concurrent
A function that returns a value when applied to the values of the two futures passed to ClosingFuture.whenAllSucceed(ClosingFuture, ClosingFuture).
ClosingFuture.Combiner3<V1 extends @Nullable java.lang.Object,​V2 extends @Nullable java.lang.Object,​V3 extends @Nullable java.lang.Object> - Class in com.google.common.util.concurrent
A generic ClosingFuture.Combiner that lets you use a lambda or method reference to combine three ClosingFutures.
ClosingFuture.Combiner3.AsyncClosingFunction3<V1 extends @Nullable java.lang.Object,​V2 extends @Nullable java.lang.Object,​V3 extends @Nullable java.lang.Object,​U extends @Nullable java.lang.Object> - Interface in com.google.common.util.concurrent
A function that returns a ClosingFuture when applied to the values of the three futures passed to ClosingFuture.whenAllSucceed(ClosingFuture, ClosingFuture, ClosingFuture).
ClosingFuture.Combiner3.ClosingFunction3<V1 extends @Nullable java.lang.Object,​V2 extends @Nullable java.lang.Object,​V3 extends @Nullable java.lang.Object,​U extends @Nullable java.lang.Object> - Interface in com.google.common.util.concurrent
A function that returns a value when applied to the values of the three futures passed to ClosingFuture.whenAllSucceed(ClosingFuture, ClosingFuture, ClosingFuture).
ClosingFuture.Combiner4<V1 extends @Nullable java.lang.Object,​V2 extends @Nullable java.lang.Object,​V3 extends @Nullable java.lang.Object,​V4 extends @Nullable java.lang.Object> - Class in com.google.common.util.concurrent
A generic ClosingFuture.Combiner that lets you use a lambda or method reference to combine four ClosingFutures.
ClosingFuture.Combiner4.AsyncClosingFunction4<V1 extends @Nullable java.lang.Object,​V2 extends @Nullable java.lang.Object,​V3 extends @Nullable java.lang.Object,​V4 extends @Nullable java.lang.Object,​U extends @Nullable java.lang.Object> - Interface in com.google.common.util.concurrent
A function that returns a ClosingFuture when applied to the values of the four futures passed to ClosingFuture.whenAllSucceed(ClosingFuture, ClosingFuture, ClosingFuture, ClosingFuture).
ClosingFuture.Combiner4.ClosingFunction4<V1 extends @Nullable java.lang.Object,​V2 extends @Nullable java.lang.Object,​V3 extends @Nullable java.lang.Object,​V4 extends @Nullable java.lang.Object,​U extends @Nullable java.lang.Object> - Interface in com.google.common.util.concurrent
A function that returns a value when applied to the values of the four futures passed to ClosingFuture.whenAllSucceed(ClosingFuture, ClosingFuture, ClosingFuture, ClosingFuture).
ClosingFuture.Combiner5<V1 extends @Nullable java.lang.Object,​V2 extends @Nullable java.lang.Object,​V3 extends @Nullable java.lang.Object,​V4 extends @Nullable java.lang.Object,​V5 extends @Nullable java.lang.Object> - Class in com.google.common.util.concurrent
A generic ClosingFuture.Combiner that lets you use a lambda or method reference to combine five ClosingFutures.
ClosingFuture.Combiner5.AsyncClosingFunction5<V1 extends @Nullable java.lang.Object,​V2 extends @Nullable java.lang.Object,​V3 extends @Nullable java.lang.Object,​V4 extends @Nullable java.lang.Object,​V5 extends @Nullable java.lang.Object,​U extends @Nullable java.lang.Object> - Interface in com.google.common.util.concurrent
A function that returns a ClosingFuture when applied to the values of the five futures passed to ClosingFuture.whenAllSucceed(ClosingFuture, ClosingFuture, ClosingFuture, ClosingFuture, ClosingFuture).
ClosingFuture.Combiner5.ClosingFunction5<V1 extends @Nullable java.lang.Object,​V2 extends @Nullable java.lang.Object,​V3 extends @Nullable java.lang.Object,​V4 extends @Nullable java.lang.Object,​V5 extends @Nullable java.lang.Object,​U extends @Nullable java.lang.Object> - Interface in com.google.common.util.concurrent
A function that returns a value when applied to the values of the five futures passed to ClosingFuture.whenAllSucceed(ClosingFuture, ClosingFuture, ClosingFuture, ClosingFuture, ClosingFuture).
ClosingFuture.DeferredCloser - Class in com.google.common.util.concurrent
An object that can capture objects to be closed later, when a ClosingFuture pipeline is done.
ClosingFuture.Peeker - Class in com.google.common.util.concurrent
An object that can return the value of the ClosingFutures that are passed to ClosingFuture.whenAllComplete(Iterable) or ClosingFuture.whenAllSucceed(Iterable).
ClosingFuture.ValueAndCloser<V extends @Nullable java.lang.Object> - Class in com.google.common.util.concurrent
An object that holds the final result of an asynchronous ClosingFuture operation and allows the user to close all the closeable objects that were captured during it for later closing.
ClosingFuture.ValueAndCloserConsumer<V extends @Nullable java.lang.Object> - Interface in com.google.common.util.concurrent
Represents an operation that accepts a ClosingFuture.ValueAndCloser for the last step in a ClosingFuture pipeline.
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 matching BMP characters replaced by a single replacement character.
COLLECTED - com.google.common.cache.RemovalCause
The entry was removed automatically because its key or value was garbage-collected.
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();.
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
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
Discouraged (in favor of Caffeine) caching utilities.
com.google.common.collect - package com.google.common.collect
Collection interfaces and implementations, and other utilities for collections.
com.google.common.escape - package com.google.common.escape
Interfaces, utilities, and simple implementations of escapers and encoders.
com.google.common.eventbus - package com.google.common.eventbus
Discouraged in favor of dependency injection and concurrency frameworks, EventBus allows publish-subscribe-style communication.
com.google.common.graph - package com.google.common.graph
An API for representing graph (node and edge) data.
com.google.common.hash - package com.google.common.hash
Hash functions and related structures.
com.google.common.html - package com.google.common.html
Escapers for HTML.
com.google.common.io - package com.google.common.io
Utility methods and classes for I/O; for example input streams, output streams, readers, writers, and files.
com.google.common.math - package com.google.common.math
Arithmetic functions operating on primitive values and on BigInteger and BigDecimal instances.
com.google.common.net - package com.google.common.net
Utility methods and classes for networking (such as IP addresses and domain names).
com.google.common.primitives - package com.google.common.primitives
Static utilities for the eight primitive types and void, and value types for treating them as unsigned or storing them in immutable arrays.
com.google.common.reflect - package com.google.common.reflect
Utilities for reflection.
com.google.common.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(boolean, boolean) - Static method in class com.google.common.primitives.Booleans
Compares the two specified boolean values in the standard way (false is considered less than true).
compare(byte, byte) - Static method in class com.google.common.primitives.SignedBytes
Compares the two specified byte values.
compare(byte, byte) - Static method in class com.google.common.primitives.UnsignedBytes
Compares the two specified byte values, treating them as unsigned values between 0 and 255 inclusive.
compare(char, char) - Static method in class com.google.common.primitives.Chars
Compares the two specified char values.
compare(double, double) - Method in class com.google.common.collect.ComparisonChain
Compares two double values as specified by Double.compare(double, double), if the result of this comparison chain has not already been determined.
compare(double, double) - Static method in class com.google.common.primitives.Doubles
Compares the two specified double values.
compare(float, float) - Method in class com.google.common.collect.ComparisonChain
Compares two float values as specified by Float.compare(float, float), if the result of this comparison chain has not already been determined.
compare(float, float) - Static method in class com.google.common.primitives.Floats
Compares the two specified float values using Float.compare(float, float).
compare(int, int) - Method in 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(int, int) - Static method in class com.google.common.primitives.Ints
Compares the two specified int values.
compare(int, int) - Static method in class com.google.common.primitives.UnsignedInts
Compares the two specified int values, treating them as unsigned values between 0 and 2^32 - 1 inclusive.
compare(long, long) - Method in 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(long, long) - Static method in class com.google.common.primitives.Longs
Compares the two specified long values.
compare(long, long) - Static method in class com.google.common.primitives.UnsignedLongs
Compares the two specified long values, treating them as unsigned values between 0 and 2^64 - 1 inclusive.
compare(short, short) - Static method in class com.google.common.primitives.Shorts
Compares the two specified short values.
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(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) - Method in class com.google.common.collect.Ordering
 
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.
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<? super F, T>, Supplier<F>) - Static method in class com.google.common.base.Suppliers
Returns a new supplier which is the composition of the provided function and supplier.
compose(Function<B, C>, Function<A, ? extends B>) - Static method in class com.google.common.base.Functions
Returns the composition of two functions.
compose(Predicate<B>, Function<A, ? extends B>) - Static method in class com.google.common.base.Predicates
Returns the composition of a function and a predicate.
compound(Iterable<? extends Comparator<? super T>>) - Static method in class com.google.common.collect.Ordering
Returns an ordering which tries each given comparator in order until a non-zero result is found, returning that result, and returning zero only if all comparators return zero.
compound(Comparator<? super U>) - Method in class com.google.common.collect.Ordering
Returns an ordering which first uses the ordering this, but which in the event of a "tie", then delegates to secondaryComparator.
ComputationException - Exception in com.google.common.collect
Deprecated.
This exception is no longer thrown by com.google.common. Previously, it was thrown by MapMaker computing maps. When support for computing maps was removed from MapMaker, it was added to CacheBuilder, which throws ExecutionException, UncheckedExecutionException, and ExecutionError. Any code that is still catching ComputationException may need to be updated to catch some of those types instead. (Note that this type, though deprecated, is not planned to be removed from Guava.)
ComputationException(Throwable) - Constructor for exception com.google.common.collect.ComputationException
Deprecated.
Creates a new instance with the given cause.
compute(double...) - Method in class com.google.common.math.Quantiles.ScaleAndIndex
Computes the quantile value of the given dataset.
compute(double...) - Method in class com.google.common.math.Quantiles.ScaleAndIndexes
Computes the quantile values of the given dataset.
compute(int...) - Method in class com.google.common.math.Quantiles.ScaleAndIndex
Computes the quantile value of the given dataset.
compute(int...) - Method in class com.google.common.math.Quantiles.ScaleAndIndexes
Computes the quantile values of the given dataset.
compute(long...) - Method in class com.google.common.math.Quantiles.ScaleAndIndex
Computes the quantile value of the given dataset.
compute(long...) - Method in class com.google.common.math.Quantiles.ScaleAndIndexes
Computes the quantile values of the given dataset.
compute(Collection<? extends Number>) - Method in class com.google.common.math.Quantiles.ScaleAndIndex
Computes the quantile value of the given dataset.
compute(Collection<? extends Number>) - Method in class com.google.common.math.Quantiles.ScaleAndIndexes
Computes the quantile values of the given dataset.
compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class com.google.common.collect.ImmutableMap
Deprecated.
Unsupported operation.
computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class com.google.common.collect.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(boolean[]...) - Static method in class com.google.common.primitives.Booleans
Returns the values from each provided array combined into a single array.
concat(byte[]...) - Static method in class com.google.common.primitives.Bytes
Returns the values from each provided array combined into a single array.
concat(char[]...) - Static method in class com.google.common.primitives.Chars
Returns the values from each provided array combined into a single array.
concat(double[]...) - Static method in class com.google.common.primitives.Doubles
Returns the values from each provided array combined into a single array.
concat(float[]...) - Static method in class com.google.common.primitives.Floats
Returns the values from each provided array combined into a single array.
concat(int[]...) - Static method in class com.google.common.primitives.Ints
Returns the values from each provided array combined into a single array.
concat(long[]...) - Static method in class com.google.common.primitives.Longs
Returns the values from each provided array combined into a single array.
concat(short[]...) - Static method in class com.google.common.primitives.Shorts
Returns the values from each provided array combined into a single array.
concat(ByteSource...) - Static method in class com.google.common.io.ByteSource
Concatenates multiple ByteSource instances into a single source.
concat(CharSource...) - Static method in class com.google.common.io.CharSource
Concatenates multiple CharSource instances into a single source.
concat(Iterable<? extends ByteSource>) - Static method in class com.google.common.io.ByteSource
Concatenates multiple ByteSource instances into a single source.
concat(Iterable<? extends CharSource>) - Static method in class com.google.common.io.CharSource
Concatenates multiple CharSource instances into a single source.
concat(Iterable<? extends Iterable<? extends T>>) - Static method in class com.google.common.collect.FluentIterable
Returns a fluent iterable that combines several iterables.
concat(Iterable<? extends Iterable<? extends T>>) - Static method in class com.google.common.collect.Iterables
Combines multiple iterables into a single iterable.
concat(Iterable<? extends T>...) - Static method in class com.google.common.collect.FluentIterable
Returns a fluent iterable that combines several iterables.
concat(Iterable<? extends T>...) - Static method in class com.google.common.collect.Iterables
Combines multiple iterables into a single iterable.
concat(Iterable<? extends T>, Iterable<? extends T>) - Static method in class com.google.common.collect.FluentIterable
Returns a fluent iterable that combines two iterables.
concat(Iterable<? extends T>, Iterable<? extends T>) - Static method in class com.google.common.collect.Iterables
Combines two iterables into a single iterable.
concat(Iterable<? extends T>, Iterable<? extends T>, Iterable<? extends T>) - Static method in class com.google.common.collect.FluentIterable
Returns a fluent iterable that combines three iterables.
concat(Iterable<? extends T>, Iterable<? extends T>, Iterable<? extends T>) - Static method in class com.google.common.collect.Iterables
Combines three iterables into a single iterable.
concat(Iterable<? extends T>, Iterable<? extends T>, Iterable<? extends T>, Iterable<? extends T>) - Static method in class com.google.common.collect.FluentIterable
Returns a fluent iterable that combines four iterables.
concat(Iterable<? extends T>, Iterable<? extends T>, Iterable<? extends T>, Iterable<? extends T>) - Static method in class com.google.common.collect.Iterables
Combines four iterables into a single iterable.
concat(Iterator<? extends ByteSource>) - Static method in class com.google.common.io.ByteSource
Concatenates multiple ByteSource instances into a single source.
concat(Iterator<? extends CharSource>) - Static method in class com.google.common.io.CharSource
Concatenates multiple CharSource instances into a single source.
concat(Iterator<? extends Iterator<? extends T>>) - Static method in class com.google.common.collect.Iterators
Combines multiple iterators into a single iterator.
concat(Iterator<? extends T>...) - Static method in class com.google.common.collect.Iterators
Combines multiple iterators into a single iterator.
concat(Iterator<? extends T>, Iterator<? extends T>) - Static method in class com.google.common.collect.Iterators
Combines two iterators into a single iterator.
concat(Iterator<? extends T>, Iterator<? extends T>, Iterator<? extends T>) - Static method in class com.google.common.collect.Iterators
Combines three iterators into a single iterator.
concat(Iterator<? extends T>, Iterator<? extends T>, Iterator<? extends T>, Iterator<? extends T>) - Static method in class com.google.common.collect.Iterators
Combines four iterators into a single iterator.
concat(DoubleStream...) - Static method in class com.google.common.collect.Streams
Returns a DoubleStream containing the elements of the first stream, followed by the elements of the second stream, and so on.
concat(IntStream...) - Static method in class com.google.common.collect.Streams
Returns an IntStream containing the elements of the first stream, followed by the elements of the second stream, and so on.
concat(LongStream...) - Static method in class com.google.common.collect.Streams
Returns a LongStream containing the elements of the first stream, followed by the elements of the second stream, and so on.
concat(Stream<? extends T>...) - Static method in class com.google.common.collect.Streams
Returns a Stream containing the elements of the first stream, followed by the elements of the second stream, and so on.
concat(T[], T) - Static method in class com.google.common.collect.ObjectArrays
Returns a new array that appends element to array.
concat(T[], T[], Class<T>) - Static method in class com.google.common.collect.ObjectArrays
Returns a new array that contains the concatenated contents of two arrays.
concat(T, T[]) - Static method in class com.google.common.collect.ObjectArrays
Returns a new array that prepends element to array.
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(long, int) - Static method in class com.google.common.hash.Hashing
Assigns to input a "bucket" in the range [0, buckets), in a uniform manner that minimizes the need for remapping as buckets grows.
consistentHash(HashCode, int) - Static method in class com.google.common.hash.Hashing
Assigns to hashCode a "bucket" in the range [0, buckets), in a uniform manner that minimizes the need for remapping as buckets grows.
constant(E) - Static method in class com.google.common.base.Functions
Returns a function that ignores its input and always returns value.
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(boolean[], boolean) - Static method in class com.google.common.primitives.Booleans
Returns true if target is present as an element anywhere in array.
contains(byte[], byte) - Static method in class com.google.common.primitives.Bytes
Returns true if target is present as an element anywhere in array.
contains(char[], char) - Static method in class com.google.common.primitives.Chars
Returns true if target is present as an element anywhere in array.
contains(double) - Method in class com.google.common.primitives.ImmutableDoubleArray
Returns true if target is present at any index in this array.
contains(double[], double) - Static method in class com.google.common.primitives.Doubles
Returns true if target is present as an element anywhere in array.
contains(float[], float) - Static method in class com.google.common.primitives.Floats
Returns true if target is present as an element anywhere in array.
contains(int) - Method in class com.google.common.primitives.ImmutableIntArray
Returns true if target is present at any index in this array.
contains(int[], int) - Static method in class com.google.common.primitives.Ints
Returns true if target is present as an element anywhere in array.
contains(long) - Method in class com.google.common.primitives.ImmutableLongArray
Returns true if target is present at any index in this array.
contains(long[], long) - Static method in class com.google.common.primitives.Longs
Returns true if target is present as an element anywhere in array.
contains(short[], short) - Static method in class com.google.common.primitives.Shorts
Returns true if target is present as an element anywhere in array.
contains(C) - Method in class com.google.common.collect.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(Iterable<? extends Object>, Object) - Static method in class com.google.common.collect.Iterables
Returns true if iterable contains any element o for which Objects.equals(o, element) would return true.
contains(Object) - Method in class com.google.common.collect.FluentIterable
Returns true if this fluent iterable contains any object for which equals(target) is true.
contains(Object) - Method in class com.google.common.collect.ForwardingCollection
 
contains(Object) - Method in class com.google.common.collect.ImmutableCollection
 
contains(Object) - Method in class com.google.common.collect.ImmutableList
 
contains(Object) - Method in class com.google.common.collect.ImmutableMultiset
 
contains(Object) - Method in interface com.google.common.collect.Multiset
Determines whether this multiset contains the specified element.
contains(Object, Object) - Method in class com.google.common.collect.ArrayTable
Returns true if the provided keys are among the keys provided when the table was constructed.
contains(Object, Object) - Method in class com.google.common.collect.ForwardingTable
 
contains(Object, Object) - Method in class com.google.common.collect.ImmutableTable
 
contains(Object, Object) - Method in interface com.google.common.collect.Table
Returns true if the table contains a mapping with the specified row and column keys.
contains(Iterator<?>, Object) - Static method in class com.google.common.collect.Iterators
Returns true if iterator contains element.
contains(Pattern) - Static method in class com.google.common.base.Predicates
Returns a predicate that evaluates to true if the CharSequence being tested contains any match for the given regular expression pattern.
containsAll(Iterable<? extends C>) - Method in class com.google.common.collect.Range
Returns true if every element in values is contained in this range.
containsAll(Collection<?>) - Method in class com.google.common.collect.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.
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 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 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.HashBiMap
Returns true if this BiMap contains an entry whose value is equal to value (or, equivalently, if this inverse view contains a key that is equal to value).
containsValue(Object) - Method in class com.google.common.collect.ImmutableMap
 
containsValue(Object) - Method in class com.google.common.collect.ImmutableMultimap
 
containsValue(Object) - Method in class com.google.common.collect.ImmutableTable
 
containsValue(Object) - Method in class com.google.common.collect.LinkedListMultimap
 
containsValue(Object) - Method in 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 java.lang.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 serializable 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(File, File) - Static method in class com.google.common.io.Files
Copies all the bytes from one file to another.
copy(File, OutputStream) - Static method in class com.google.common.io.Files
Copies all bytes from a file to an output stream.
copy(File, Charset, Appendable) - Static method in class com.google.common.io.Files
Deprecated.
Prefer asCharSource(from, charset).copyTo(to).
copy(InputStream, OutputStream) - Static method in class com.google.common.io.ByteStreams
Copies all bytes from the input stream to the output stream.
copy(Readable, Appendable) - Static method in class com.google.common.io.CharStreams
Copies all characters between the Readable and Appendable objects.
copy(URL, OutputStream) - Static method in class com.google.common.io.Resources
Copies all bytes from a URL to an output stream.
copy(ReadableByteChannel, WritableByteChannel) - Static method in class com.google.common.io.ByteStreams
Copies all bytes from the readable channel to the writable channel.
copyHighestCountFirst(Multiset<E>) - Static method in class com.google.common.collect.Multisets
Returns a copy of multiset as an ImmutableMultiset whose iteration order puts the highest count first, with ties broken by the iteration order of the original multiset.
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(double[]) - Static method in class com.google.common.primitives.ImmutableDoubleArray
Returns an immutable array containing the given values, in order.
copyOf(int[]) - Static method in class com.google.common.primitives.ImmutableIntArray
Returns an immutable array containing the given values, in order.
copyOf(long[]) - Static method in class com.google.common.primitives.ImmutableLongArray
Returns an immutable array containing the given values, in order.
copyOf(Multimap<? extends K, ? extends V>) - Static method in class com.google.common.collect.ImmutableListMultimap
Returns an immutable multimap containing the same mappings as multimap.
copyOf(Multimap<? extends K, ? extends V>) - Static method in class com.google.common.collect.ImmutableMultimap
Returns an immutable multimap containing the same mappings as multimap, in the "key-grouped" iteration order described in the class documentation.
copyOf(Multimap<? extends K, ? extends V>) - Static method in class com.google.common.collect.ImmutableSetMultimap
Returns an immutable set multimap containing the same mappings as multimap.
copyOf(RangeMap<K, ? extends V>) - Static method in class com.google.common.collect.ImmutableRangeMap
 
copyOf(RangeSet<C>) - Static method in class com.google.common.collect.ImmutableRangeSet
Returns an immutable copy of the specified RangeSet.
copyOf(Table<? extends R, ? extends C, ? extends V>) - Static method in class com.google.common.collect.ImmutableTable
Returns an immutable copy of the provided table.
copyOf(Graph<N>) - Static method in class com.google.common.graph.Graphs
Creates a mutable copy of graph with the same nodes and edges.
copyOf(Graph<N>) - Static method in class com.google.common.graph.ImmutableGraph
Returns an immutable copy of graph.
copyOf(ImmutableGraph<N>) - Static method in class com.google.common.graph.ImmutableGraph
Deprecated.
no need to use this
copyOf(ImmutableNetwork<N, E>) - Static method in class com.google.common.graph.ImmutableNetwork
Deprecated.
no need to use this
copyOf(ImmutableValueGraph<N, V>) - Static method in class com.google.common.graph.ImmutableValueGraph
Deprecated.
no need to use this
copyOf(Network<N, E>) - Static method in class com.google.common.graph.Graphs
Creates a mutable copy of network with the same nodes and edges.
copyOf(Network<N, E>) - Static method in class com.google.common.graph.ImmutableNetwork
Returns an immutable copy of network.
copyOf(ValueGraph<N, V>) - Static method in class com.google.common.graph.Graphs
Creates a mutable copy of graph with the same nodes, edges, and edge values.
copyOf(ValueGraph<N, V>) - Static method in class com.google.common.graph.ImmutableValueGraph
Returns an immutable copy of graph.
copyOf(E[]) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing the given elements, in order.
copyOf(E[]) - Static method in class com.google.common.collect.ImmutableMultiset
Returns an immutable multiset containing the given elements, in the "grouped iteration order" described in the class documentation.
copyOf(E[]) - Static method in class com.google.common.collect.ImmutableSet
Returns an immutable set containing each of elements, minus duplicates, in the order each appears first in the source array.
copyOf(E[]) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns an immutable sorted multiset containing the given elements sorted by their natural ordering.
copyOf(E[]) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by their natural ordering.
copyOf(Iterable<? extends E>) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing the given elements, in order.
copyOf(Iterable<? extends E>) - Static method in class com.google.common.collect.ImmutableMultiset
Returns an immutable multiset containing the given elements, in the "grouped iteration order" described in the class documentation.
copyOf(Iterable<? extends E>) - Static method in class com.google.common.collect.ImmutableSet
Returns an immutable set containing each of elements, minus duplicates, in the order each appears first in the source iterable.
copyOf(Iterable<? extends E>) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns an immutable sorted multiset containing the given elements sorted by their natural ordering.
copyOf(Iterable<? extends E>) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by their natural ordering.
copyOf(Iterable<? extends Map.Entry<? extends K, ? extends V>>) - Static method in class com.google.common.collect.ImmutableBiMap
Returns an immutable bimap containing the given entries.
copyOf(Iterable<? extends Map.Entry<? extends K, ? extends V>>) - Static method in class com.google.common.collect.ImmutableListMultimap
Returns an immutable multimap containing the specified entries.
copyOf(Iterable<? extends Map.Entry<? extends K, ? extends V>>) - Static method in class com.google.common.collect.ImmutableMap
Returns an immutable map containing the specified entries.
copyOf(Iterable<? extends Map.Entry<? extends K, ? extends V>>) - Static method in class com.google.common.collect.ImmutableMultimap
Returns an immutable multimap containing the specified entries.
copyOf(Iterable<? extends Map.Entry<? extends K, ? extends V>>) - Static method in class com.google.common.collect.ImmutableSetMultimap
Returns an immutable multimap containing the specified entries.
copyOf(Iterable<? extends Map.Entry<? extends K, ? extends V>>) - Static method in class com.google.common.collect.ImmutableSortedMap
Returns an immutable map containing the given entries, with keys sorted by their natural ordering.
copyOf(Iterable<? extends Map.Entry<? extends K, ? extends V>>, Comparator<? super K>) - Static method in class com.google.common.collect.ImmutableSortedMap
Returns an immutable map containing the given entries, with keys sorted by the provided comparator.
copyOf(Iterable<Range<C>>) - Static method in class com.google.common.collect.ImmutableRangeSet
Returns an ImmutableRangeSet containing each of the specified disjoint ranges.
copyOf(Iterable<Double>) - Static method in class com.google.common.primitives.ImmutableDoubleArray
Returns an immutable array containing the given values, in order.
copyOf(Iterable<Integer>) - Static method in class com.google.common.primitives.ImmutableIntArray
Returns an immutable array containing the given values, in order.
copyOf(Iterable<Long>) - Static method in class com.google.common.primitives.ImmutableLongArray
Returns an immutable array containing the given values, in order.
copyOf(Collection<? extends E>) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing the given elements, in order.
copyOf(Collection<? extends E>) - Static method in class com.google.common.collect.ImmutableSet
Returns an immutable set containing each of elements, minus duplicates, in the order each appears first in the source collection.
copyOf(Collection<? extends E>) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by their natural ordering.
copyOf(Collection<Double>) - Static method in class com.google.common.primitives.ImmutableDoubleArray
Returns an immutable array containing the given values, in order.
copyOf(Collection<Integer>) - Static method in class com.google.common.primitives.ImmutableIntArray
Returns an immutable array containing the given values, in order.
copyOf(Collection<Long>) - Static method in class com.google.common.primitives.ImmutableLongArray
Returns an immutable array containing the given values, in order.
copyOf(Comparator<? super E>, Iterable<? extends E>) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns an immutable sorted multiset containing the given elements sorted by the given Comparator.
copyOf(Comparator<? super E>, Iterable<? extends E>) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by the given Comparator.
copyOf(Comparator<? super E>, Collection<? extends E>) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by the given Comparator.
copyOf(Comparator<? super E>, Iterator<? extends E>) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns an immutable sorted multiset containing the given elements sorted by the given Comparator.
copyOf(Comparator<? super E>, Iterator<? extends E>) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by the given Comparator.
copyOf(Iterator<? extends E>) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing the given elements, in order.
copyOf(Iterator<? extends E>) - Static method in class com.google.common.collect.ImmutableMultiset
Returns an immutable multiset containing the given elements, in the "grouped iteration order" described in the class documentation.
copyOf(Iterator<? extends E>) - Static method in class com.google.common.collect.ImmutableSet
Returns an immutable set containing each of elements, minus duplicates, in the order each appears first in the source iterator.
copyOf(Iterator<? extends E>) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns an immutable sorted multiset containing the given elements sorted by their natural ordering.
copyOf(Iterator<? extends E>) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by their natural ordering.
copyOf(Map<? extends Class<? extends S>, ? extends S>) - Static method in class com.google.common.collect.ImmutableClassToInstanceMap
Returns an immutable map containing the same entries as map.
copyOf(Map<? extends K, ? extends V>) - Static method in class com.google.common.collect.ImmutableBiMap
Returns an immutable bimap containing the same entries as map.
copyOf(Map<? extends K, ? extends V>) - Static method in class com.google.common.collect.ImmutableMap
Returns an immutable map containing the same entries as map.
copyOf(Map<? extends K, ? extends V>) - Static method in class com.google.common.collect.ImmutableSortedMap
Returns an immutable map containing the same entries as map, sorted by the natural ordering of the keys.
copyOf(Map<? extends K, ? extends V>, Comparator<? super K>) - Static method in class com.google.common.collect.ImmutableSortedMap
Returns an immutable map containing the same entries as map, with keys sorted by the provided comparator.
copyOf(DoubleStream) - Static method in class com.google.common.primitives.ImmutableDoubleArray
Returns an immutable array containing all the values from stream, in order.
copyOf(IntStream) - Static method in class com.google.common.primitives.ImmutableIntArray
Returns an immutable array containing all the values from stream, in order.
copyOf(LongStream) - Static method in class com.google.common.primitives.ImmutableLongArray
Returns an immutable array containing all the values from stream, in order.
copyOf(Z[]) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Deprecated.
Pass parameters of type Comparable to use ImmutableSortedMultiset.copyOf(Comparable[]).
copyOf(Z[]) - Static method in class com.google.common.collect.ImmutableSortedSet
Deprecated.
Pass parameters of type Comparable to use ImmutableSortedSet.copyOf(Comparable[]).
copyOfSorted(SortedMultiset<E>) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns an immutable sorted multiset containing the elements of a sorted multiset, sorted by the same Comparator.
copyOfSorted(SortedMap<K, ? extends V>) - Static method in class com.google.common.collect.ImmutableSortedMap
Returns an immutable map containing the same entries as the provided sorted map, with the same ordering.
copyOfSorted(SortedSet<E>) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing the elements of a sorted set, sorted by the same Comparator.
copyTo(ByteSink) - Method in class com.google.common.io.ByteSource
Copies the contents of this byte source to the given ByteSink.
copyTo(CharSink) - Method in class com.google.common.io.CharSource
Copies the contents of this source to the given sink.
copyTo(OutputStream) - Method in class com.google.common.io.ByteSource
Copies the contents of this byte source to the given OutputStream.
copyTo(Appendable) - Method in class com.google.common.io.CharSource
Appends the contents of this source to the given Appendable (such as a Writer).
count() - Method in class com.google.common.math.PairedStats
Returns the number of pairs in the dataset.
count() - Method in class com.google.common.math.PairedStatsAccumulator
Returns the number of pairs in the dataset.
count() - Method in class com.google.common.math.Stats
Returns the number of values.
count() - Method in class com.google.common.math.StatsAccumulator
Returns the number of values.
count(Object) - Method in class com.google.common.collect.ConcurrentHashMultiset
Returns the number of occurrences of element in this multiset.
count(Object) - Method in class com.google.common.collect.EnumMultiset
 
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
 
countIn(CharSequence) - Method in class com.google.common.base.CharMatcher
Returns the number of matching chars 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() - Static method in class com.google.common.collect.ArrayListMultimap
Creates a new, empty ArrayListMultimap with the default initial capacities.
create() - Static method in class com.google.common.collect.ConcurrentHashMultiset
Creates a new, empty ConcurrentHashMultiset using the default initial capacity, load factor, and concurrency settings.
create() - Static method in class com.google.common.collect.HashBasedTable
Creates an empty HashBasedTable.
create() - Static method in class com.google.common.collect.HashBiMap
Returns a new, empty HashBiMap with the default initial capacity (16).
create() - Static method in class com.google.common.collect.HashMultimap
Creates a new, empty HashMultimap with the default initial capacities.
create() - Static method in class com.google.common.collect.HashMultiset
Creates a new, empty HashMultiset using the default initial capacity.
create() - Static method in class com.google.common.collect.LinkedHashMultimap
Creates a new, empty LinkedHashMultimap with the default initial capacities.
create() - Static method in class com.google.common.collect.LinkedHashMultiset
Creates a new, empty LinkedHashMultiset using the default initial capacity.
create() - Static method in class com.google.common.collect.LinkedListMultimap
Creates a new, empty LinkedListMultimap with the default initial capacity.
create() - Method in class com.google.common.collect.MinMaxPriorityQueue.Builder
Builds a new min-max priority queue using the previously specified options, and having no initial contents.
create() - Static method in class com.google.common.collect.MinMaxPriorityQueue
Creates a new min-max priority queue with default settings: natural order, no maximum size, no initial contents, and an initial expected size of 11.
create() - Static method in class com.google.common.collect.MutableClassToInstanceMap
Returns a new MutableClassToInstanceMap instance backed by a HashMap using the default initial capacity and load factor.
create() - Static method in class com.google.common.collect.TreeBasedTable
Creates an empty TreeBasedTable that uses the natural orderings of both row and column keys.
create() - Static method in class com.google.common.collect.TreeMultimap
Creates an empty TreeMultimap ordered by the natural ordering of its keys and values.
create() - Static method in class com.google.common.collect.TreeMultiset
Creates a new, empty multiset, sorted according to the elements' natural order.
create() - Static method in class com.google.common.collect.TreeRangeMap
 
create() - Static method in class com.google.common.collect.TreeRangeSet
Creates an empty TreeRangeSet instance.
create() - Static method in class com.google.common.io.Closer
Creates a new Closer.
create() - Static method in class com.google.common.util.concurrent.AtomicLongMap
Creates an AtomicLongMap.
create() - Static method in class com.google.common.util.concurrent.ExecutionSequencer
Creates a new instance.
create() - Static method in class com.google.common.util.concurrent.SettableFuture
Creates a new SettableFuture that can be completed or cancelled by a later method call.
create(double) - Static method in class com.google.common.util.concurrent.RateLimiter
Creates a RateLimiter with the specified stable throughput, given as "permits per second" (commonly referred to as QPS, queries per second).
create(double, long, TimeUnit) - Static method in class com.google.common.util.concurrent.RateLimiter
Creates a RateLimiter with the specified stable throughput, given as "permits per second" (commonly referred to as QPS, queries per second), and a warmup period, during which the RateLimiter smoothly ramps up its rate, until it reaches its maximum rate at the end of the period (as long as there are enough requests to saturate it).
create(double, Duration) - Static method in class com.google.common.util.concurrent.RateLimiter
Creates a RateLimiter with the specified stable throughput, given as "permits per second" (commonly referred to as QPS, queries per second), and a warmup period, during which the RateLimiter smoothly ramps up its rate, until it reaches its maximum rate at the end of the period (as long as there are enough requests to saturate it).
create(int) - Static method in class com.google.common.collect.EvictingQueue
Creates and returns a new evicting queue that will hold up to maxSize elements.
create(int) - Static method in class com.google.common.collect.HashBiMap
Constructs a new, empty bimap with the specified expected size.
create(int) - Static method in class com.google.common.collect.HashMultiset
Creates a new, empty HashMultiset with the specified expected number of distinct elements.
create(int) - Static method in class com.google.common.collect.LinkedHashMultiset
Creates a new, empty LinkedHashMultiset with the specified expected number of distinct elements.
create(int) - Static method in class com.google.common.collect.LinkedListMultimap
Constructs an empty LinkedListMultimap with enough capacity to hold the specified number of keys without rehashing.
create(int, int) - Static method in class com.google.common.collect.ArrayListMultimap
Constructs an empty ArrayListMultimap with enough capacity to hold the specified numbers of keys and values without resizing.
create(int, int) - Static method in class com.google.common.collect.HashBasedTable
Creates an empty HashBasedTable with the specified map sizes.
create(int, int) - Static method in class com.google.common.collect.HashMultimap
Constructs an empty HashMultimap with enough capacity to hold the specified numbers of keys and values without rehashing.
create(int, int) - Static method in class com.google.common.collect.LinkedHashMultimap
Constructs an empty LinkedHashMultimap with enough capacity to hold the specified numbers of keys and values without rehashing.
create(Multimap<? extends K, ? extends V>) - Static method in class com.google.common.collect.ArrayListMultimap
Constructs an ArrayListMultimap with the same mappings as the specified multimap.
create(Multimap<? extends K, ? extends V>) - Static method in class com.google.common.collect.HashMultimap
Constructs a HashMultimap with the same mappings as the specified multimap.
create(Multimap<? extends K, ? extends V>) - Static method in class com.google.common.collect.LinkedHashMultimap
Constructs a LinkedHashMultimap with the same mappings as the specified multimap.
create(Multimap<? extends K, ? extends V>) - Static method in class com.google.common.collect.LinkedListMultimap
Constructs a LinkedListMultimap with the same mappings as the specified Multimap.
create(Multimap<? extends K, ? extends V>) - Static method in class com.google.common.collect.TreeMultimap
Constructs a TreeMultimap, ordered by the natural ordering of its keys and values, with the same mappings as the specified multimap.
create(Range<C>, DiscreteDomain<C>) - Static method in class com.google.common.collect.ContiguousSet
Returns a ContiguousSet containing the same values in the given domain contained by the range.
create(RangeSet<C>) - Static method in class com.google.common.collect.TreeRangeSet
Returns a TreeRangeSet initialized with the ranges in the specified range set.
create(Table<? extends R, ? extends C, ? extends V>) - Static method in class com.google.common.collect.HashBasedTable
Creates a HashBasedTable with the same mappings as the specified table.
create(Table<R, C, ? extends V>) - Static method in class com.google.common.collect.ArrayTable
Creates an ArrayTable with the mappings in the provided table.
create(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(Funnel<? super T>, int) - Static method in class com.google.common.hash.BloomFilter
Creates a BloomFilter with the expected number of insertions and a default expected false positive probability of 3%.
create(Funnel<? super T>, int, double) - Static method in class com.google.common.hash.BloomFilter
Creates a BloomFilter with the expected number of insertions and expected false positive probability.
create(Funnel<? super T>, long) - Static method in class com.google.common.hash.BloomFilter
Creates a BloomFilter with the expected number of insertions and a default expected false positive probability of 3%.
create(Funnel<? super T>, long, double) - Static method in class com.google.common.hash.BloomFilter
Creates a BloomFilter with the expected number of insertions and expected false positive probability.
create(Class<E>) - Static method in class com.google.common.collect.EnumMultiset
Creates an empty EnumMultiset.
create(Class<K>) - Static method in class com.google.common.collect.EnumHashBiMap
Returns a new, empty EnumHashBiMap using the specified key type.
create(Class<K>, Class<V>) - Static method in class com.google.common.collect.EnumBiMap
Returns a new, empty EnumBiMap using the specified key and value types.
create(Iterable<? extends E>) - Static method in class com.google.common.collect.ConcurrentHashMultiset
Creates a new ConcurrentHashMultiset containing the specified elements, using the default initial capacity, load factor, and concurrency settings.
create(Iterable<? extends E>) - Static method in class com.google.common.collect.HashMultiset
Creates a new HashMultiset containing the specified elements.
create(Iterable<? extends E>) - Static method in class com.google.common.collect.LinkedHashMultiset
Creates a new LinkedHashMultiset containing the specified elements.
create(Iterable<? extends E>) - Static method in class com.google.common.collect.MinMaxPriorityQueue
Creates a new min-max priority queue using natural order, no maximum size, and initially containing the given elements.
create(Iterable<? extends E>) - Static method in class com.google.common.collect.TreeMultiset
Creates an empty multiset containing the given initial elements, sorted according to the elements' natural order.
create(Iterable<? extends R>, Iterable<? extends C>) - Static method in class com.google.common.collect.ArrayTable
Creates an ArrayTable filled with null.
create(Iterable<? extends T>) - Method in class com.google.common.collect.MinMaxPriorityQueue.Builder
Builds a new min-max priority queue using the previously specified options, and having the given initial elements.
create(Iterable<Range<C>>) - Static method in class com.google.common.collect.TreeRangeSet
Returns a TreeRangeSet representing the union of the specified ranges.
create(Iterable<E>) - Static method in class com.google.common.collect.EnumMultiset
Creates a new EnumMultiset containing the specified elements.
create(Iterable<E>, Class<E>) - Static method in class com.google.common.collect.EnumMultiset
Returns a new EnumMultiset instance containing the given elements.
create(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(String, String) - Static method in class com.google.common.net.MediaType
Creates a new media type with the given type and subtype.
create(Comparator<? super E>) - Static method in class com.google.common.collect.TreeMultiset
Creates a new, empty multiset, sorted according to the specified comparator.
create(Comparator<? super K>, Comparator<? super V>) - Static method in class com.google.common.collect.TreeMultimap
Creates an empty TreeMultimap instance using explicit comparators.
create(Comparator<? super R>, Comparator<? super C>) - Static method in class com.google.common.collect.TreeBasedTable
Creates an empty TreeBasedTable that is ordered by the specified comparators.
create(Callable<V>) - Static method in class com.google.common.util.concurrent.ListenableFutureTask
Creates a ListenableFutureTask that will upon running, execute the given Callable.
create(ConcurrentMap<E, AtomicInteger>) - Static method in class com.google.common.collect.ConcurrentHashMultiset
Creates a new, empty ConcurrentHashMultiset using countMap as the internal backing map.
create(ExecutorService) - Static method in class com.google.common.util.concurrent.SimpleTimeLimiter
Creates a TimeLimiter instance using the given executor service to execute method calls.
create(Map<? extends K, ? extends Long>) - Static method in class com.google.common.util.concurrent.AtomicLongMap
Creates an AtomicLongMap with the same mappings as the specified Map.
create(Map<? extends K, ? extends V>) - Static method in class com.google.common.collect.HashBiMap
Constructs a new bimap containing initial values from map.
create(Map<Character, String>) - Static method in class com.google.common.escape.ArrayBasedEscaperMap
Returns a new ArrayBasedEscaperMap for creating ArrayBasedCharEscaper or ArrayBasedUnicodeEscaper instances.
create(Map<Class<? extends B>, B>) - Static method in class com.google.common.collect.MutableClassToInstanceMap
Returns a new MutableClassToInstanceMap instance backed by a given empty backingMap.
create(Map<K, ? extends V>) - Static method in class com.google.common.collect.EnumHashBiMap
Constructs a new bimap with the same mappings as the specified map.
create(Map<K, V>) - Static method in class com.google.common.collect.EnumBiMap
Returns a new bimap with the same mappings as the specified map.
create(K, V, RemovalCause) - Static method in class com.google.common.cache.RemovalNotification
Creates a new RemovalNotification for the given key/value pair, with the given cause for the removal.
createEntrySet() - Method in class com.google.common.collect.ConcurrentHashMultiset
Deprecated.
Internal method, use Multiset.entrySet().
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
Deprecated.
For Android users, see the Data and File Storage overview to select an appropriate temporary directory (perhaps context.getCacheDir()), and create your own directory under that. (For example, you might use new File(context.getCacheDir(), "directoryname").mkdir(), or, if you need an arbitrary number of temporary directories, you might have to generate multiple directory names in a loop until mkdir() returns true.) For Java 7+ users, prefer Files.createTempDirectory(java.nio.file.Path, java.lang.String, java.nio.file.attribute.FileAttribute<?>...), transforming it to a File using toFile() if needed. To restrict permissions as this method does, pass PosixFilePermissions.asFileAttribute(PosixFilePermissions.fromString("rwx------")) to your call to createTempDirectory.
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.
CRITICAL_CH - Static variable in class com.google.common.net.HttpHeaders
The HTTP Critical-CH header field name.
CROSS_ORIGIN_EMBEDDER_POLICY - Static variable in class com.google.common.net.HttpHeaders
The HTTP Cross-Origin-Embedder-Policy header field name.
CROSS_ORIGIN_EMBEDDER_POLICY_REPORT_ONLY - Static variable in class com.google.common.net.HttpHeaders
CROSS_ORIGIN_OPENER_POLICY - Static variable in class com.google.common.net.HttpHeaders
The HTTP Cross-Origin-Opener-Policy header field name.
CROSS_ORIGIN_RESOURCE_POLICY - Static variable in class com.google.common.net.HttpHeaders
The HTTP Cross-Origin-Resource-Policy header field name.
CRW - Static variable in class com.google.common.net.MediaType
The Canon Image File Format (crw files), a widely-used "raw image" format for cameras.
CSS_UTF_8 - Static variable in class com.google.common.net.MediaType
 
CSV_UTF_8 - Static variable in class com.google.common.net.MediaType
 
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(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.Iterables
Returns an iterable whose iterators cycle indefinitely over the provided elements.
cycle(T...) - Static method in class com.google.common.collect.Iterators
Returns an iterator that cycles indefinitely over the provided elements.
CycleDetectingLockFactory - Class in com.google.common.util.concurrent
The CycleDetectingLockFactory creates ReentrantLock instances and ReentrantReadWriteLock instances that detect potential deadlock by checking for cycles in lock acquisition order.
CycleDetectingLockFactory.Policies - Enum in com.google.common.util.concurrent
Pre-defined CycleDetectingLockFactory.Policy implementations.
CycleDetectingLockFactory.Policy - Interface in com.google.common.util.concurrent
Encapsulates the action to be taken when a potential deadlock is encountered.
CycleDetectingLockFactory.PotentialDeadlockException - Exception in com.google.common.util.concurrent
Represents a detected cycle in lock acquisition ordering.
CycleDetectingLockFactory.WithExplicitOrdering<E extends java.lang.Enum<E>> - Class in com.google.common.util.concurrent
A CycleDetectingLockFactory.WithExplicitOrdering provides the additional enforcement of an application-specified ordering of lock acquisitions.

D

DART_UTF_8 - Static variable in class com.google.common.net.MediaType
Files in the dart programming language.
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.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.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.
depthFirstPostOrder(Iterable<? extends N>) - Method in class com.google.common.graph.Traverser
Returns an unmodifiable Iterable over the nodes reachable from any of the startNodes, in the order of a depth-first post-order traversal.
depthFirstPostOrder(N) - Method in class com.google.common.graph.Traverser
Returns an unmodifiable Iterable over the nodes reachable from startNode, in the order of a depth-first post-order traversal.
depthFirstPreOrder(Iterable<? extends N>) - Method in class com.google.common.graph.Traverser
Returns an unmodifiable Iterable over the nodes reachable from any of the startNodes, in the order of a depth-first pre-order traversal.
depthFirstPreOrder(N) - Method in class com.google.common.graph.Traverser
Returns an unmodifiable Iterable over the nodes reachable from startNode, in the order of a depth-first pre-order traversal.
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
 
DEVICE_MEMORY - Static variable in class com.google.common.net.HttpHeaders
The HTTP Device-Memory header field name.
difference(Multiset<E>, Multiset<?>) - Static method in class com.google.common.collect.Multisets
Returns an unmodifiable view of the difference of two multisets.
difference(RangeSet<C>) - Method in class com.google.common.collect.ImmutableRangeSet
Returns a new range set consisting of the difference of this range set and other.
difference(Map<? extends K, ? extends V>, Map<? extends K, ? extends V>) - Static method in class com.google.common.collect.Maps
Computes the difference between two maps.
difference(Map<? extends K, ? extends V>, Map<? extends K, ? extends V>, Equivalence<? super V>) - Static method in class com.google.common.collect.Maps
Computes the difference between two maps.
difference(Set<E>, Set<?>) - Static method in class com.google.common.collect.Sets
Returns an unmodifiable view of the difference of two sets.
difference(SortedMap<K, ? extends V>, Map<? extends K, ? extends V>) - Static method in class com.google.common.collect.Maps
Computes the difference between two sorted maps, using the comparator of the left map, or Ordering.natural() if the left map uses the natural ordering of its elements.
digit() - Static method in class com.google.common.base.CharMatcher
Deprecated.
Many digits are supplementary characters; see the class documentation.
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.
disableCaching() - Static method in class com.google.common.cache.CacheBuilderSpec
Returns a CacheBuilderSpec that will prevent caching.
DISABLED - com.google.common.util.concurrent.CycleDetectingLockFactory.Policies
Disables cycle detection.
DiscreteDomain<C extends java.lang.Comparable> - Class in com.google.common.collect
A descriptor for a discrete Comparable domain such as all Integer instances.
DiscreteDomain() - Constructor for class com.google.common.collect.DiscreteDomain
Constructor for use by subclasses.
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(int, int) - Static method in class com.google.common.primitives.UnsignedInts
Returns dividend / divisor, where the dividend and divisor are treated as unsigned 32-bit quantities.
divide(int, int, RoundingMode) - Static method in class com.google.common.math.IntMath
Returns the result of dividing p by q, rounding using the specified RoundingMode.
divide(long, long) - Static method in class com.google.common.primitives.UnsignedLongs
Returns dividend / divisor, where the dividend and divisor are treated as unsigned 64-bit quantities.
divide(long, long, RoundingMode) - Static method in class com.google.common.math.LongMath
Returns the result of dividing p by q, rounding using the specified RoundingMode.
divide(BigInteger, BigInteger, RoundingMode) - Static method in class com.google.common.math.BigIntegerMath
Returns the result of dividing p by q, rounding using the specified RoundingMode.
dividedBy(UnsignedInteger) - Method in class com.google.common.primitives.UnsignedInteger
Returns the result of dividing this by val.
dividedBy(UnsignedLong) - Method in class com.google.common.primitives.UnsignedLong
Returns the result of dividing this by val.
DLE - Static variable in class com.google.common.base.Ascii
Data Link Escape: A communication control character which will change the meaning of a limited number of contiguously following characters.
DNT - Static variable in class com.google.common.net.HttpHeaders
The HTTP DNT header field name.
doBackward(B) - Method in class com.google.common.base.Converter
Returns a representation of b as an instance of type A.
doCancelStart() - Method in class com.google.common.util.concurrent.AbstractService
This method is called by AbstractService.stopAsync() when the service is still starting (i.e.
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.
DOWNLINK - Static variable in class com.google.common.net.HttpHeaders
The HTTP Downlink header field name.
downTo(C, BoundType) - Static method in class com.google.common.collect.Range
Returns a range from the given endpoint, which may be either inclusive (closed) or exclusive (open), with no upper bound.
drain(BlockingQueue<E>, Collection<? super E>, int, long, TimeUnit) - Static method in class com.google.common.collect.Queues
Drains the queue as BlockingQueue.drainTo(Collection, int), but if the requested numElements elements are not available, it will wait for them up to the specified timeout.
drain(BlockingQueue<E>, Collection<? super E>, int, Duration) - Static method in class com.google.common.collect.Queues
Drains the queue as BlockingQueue.drainTo(Collection, int), but if the requested numElements elements are not available, it will wait for them up to the specified timeout.
drainTo(Collection<? super E>) - Method in class com.google.common.collect.ForwardingBlockingDeque
Deprecated.
 
drainTo(Collection<? super E>) - Method in class com.google.common.util.concurrent.ForwardingBlockingDeque
 
drainTo(Collection<? super E>) - Method in class com.google.common.util.concurrent.ForwardingBlockingQueue
 
drainTo(Collection<? super E>, int) - Method in class com.google.common.collect.ForwardingBlockingDeque
Deprecated.
 
drainTo(Collection<? super E>, int) - Method in class com.google.common.util.concurrent.ForwardingBlockingDeque
 
drainTo(Collection<? super E>, int) - Method in class com.google.common.util.concurrent.ForwardingBlockingQueue
 
drainUninterruptibly(BlockingQueue<E>, Collection<? super E>, int, long, TimeUnit) - Static method in class com.google.common.collect.Queues
Drains the queue as Queues.drain(BlockingQueue, Collection, int, long, TimeUnit), but with a different behavior in case it is interrupted while waiting.
drainUninterruptibly(BlockingQueue<E>, Collection<? super E>, int, Duration) - Static method in class com.google.common.collect.Queues
Drains the queue as Queues.drain(BlockingQueue, Collection, int, Duration), but with a different behavior in case it is interrupted while waiting.

E

EARLY_DATA - Static variable in class com.google.common.net.HttpHeaders
The HTTP Early-Data header field name.
ECT - Static variable in class com.google.common.net.HttpHeaders
The HTTP ECT header field name.
edgeConnecting(EndpointPair<N>) - Method in class com.google.common.graph.AbstractNetwork
 
edgeConnecting(EndpointPair<N>) - Method in interface com.google.common.graph.Network
Returns the single edge that directly connects endpoints (in the order, if any, specified by endpoints), if one is present, or Optional.empty() if no such edge exists.
edgeConnecting(N, N) - Method in class com.google.common.graph.AbstractNetwork
 
edgeConnecting(N, N) - Method in interface com.google.common.graph.Network
Returns the single edge that directly connects nodeU to nodeV, if one is present, or Optional.empty() if no such edge exists.
edgeConnectingOrNull(EndpointPair<N>) - Method in class com.google.common.graph.AbstractNetwork
 
edgeConnectingOrNull(EndpointPair<N>) - Method in interface com.google.common.graph.Network
Returns the single edge that directly connects endpoints (in the order, if any, specified by endpoints), if one is present, or null if no such edge exists.
edgeConnectingOrNull(N, N) - Method in class com.google.common.graph.AbstractNetwork
 
edgeConnectingOrNull(N, N) - Method in interface com.google.common.graph.Network
Returns the single edge that directly connects nodeU to nodeV, if one is present, or null if no such edge exists.
edgeInvalidatableSet(Set<T>, E) - Method in class com.google.common.graph.AbstractNetwork
Returns a Set whose methods throw IllegalStateException when the given edge is not present in this network.
edgeOrder() - 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(EndpointPair<N>) - Method in class com.google.common.graph.AbstractNetwork
 
edgesConnecting(EndpointPair<N>) - Method in interface com.google.common.graph.Network
Returns a live view of the set of edges that each directly connect endpoints (in the order, if any, specified by endpoints).
edgesConnecting(N, N) - Method in class com.google.common.graph.AbstractNetwork
 
edgesConnecting(N, N) - Method in interface com.google.common.graph.Network
Returns a live view of the set of edges that each directly connect nodeU to nodeV.
edgeValue(EndpointPair<N>) - Method in class com.google.common.graph.AbstractValueGraph
 
edgeValue(EndpointPair<N>) - Method in interface com.google.common.graph.ValueGraph
Returns the value of the edge that connects endpoints (in the order, if any, specified by endpoints), if one is present; otherwise, returns Optional.empty().
edgeValue(N, N) - Method in class com.google.common.graph.AbstractValueGraph
 
edgeValue(N, N) - Method in interface com.google.common.graph.ValueGraph
Returns the value of the edge that connects nodeU to nodeV (in the order, if any, specified by endpoints), if one is present; otherwise, returns Optional.empty().
edgeValueOrDefault(EndpointPair<N>, V) - Method in interface com.google.common.graph.ValueGraph
Returns the value of the edge that connects endpoints (in the order, if any, specified by endpoints), if one is present; otherwise, returns defaultValue.
edgeValueOrDefault(N, N, V) - Method in interface com.google.common.graph.ValueGraph
Returns the value of the edge that connects nodeU to nodeV, if one is present; otherwise, returns defaultValue.
elapsed() - Method in class com.google.common.base.Stopwatch
Returns the current elapsed time shown on this stopwatch as a Duration.
elapsed(TimeUnit) - Method in class com.google.common.base.Stopwatch
Returns the current elapsed time shown on this stopwatch, expressed in the desired time unit, with any fraction rounded down.
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<? super T>) - Static method in class com.google.common.collect.Comparators
Returns a comparator of Optional values which treats Optional.empty() as less than all other values, and orders the rest using valueComparator on the contained value.
emptiesLast(Comparator<? super T>) - Static method in class com.google.common.collect.Comparators
Returns a comparator of Optional values which treats Optional.empty() as greater than all other values, and orders the rest using valueComparator on the contained value.
empty() - 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.
emulated() - Method in annotation type com.google.common.annotations.GwtCompatible
When true, the annotated type is emulated in GWT.
encloseAll(Iterable<C>) - Static method in class com.google.common.collect.Range
Returns the minimal range that contains all of the given values.
encloses(Range<C>) - Method in class com.google.common.collect.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.
enter(Duration) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor.
enterIf(Monitor.Guard) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor if the guard is satisfied.
enterIf(Monitor.Guard, long, TimeUnit) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor if the guard is satisfied.
enterIf(Monitor.Guard, Duration) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor if the guard is satisfied.
enterIfInterruptibly(Monitor.Guard) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor if the guard is satisfied.
enterIfInterruptibly(Monitor.Guard, long, TimeUnit) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor if the guard is satisfied.
enterIfInterruptibly(Monitor.Guard, Duration) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor if the guard is satisfied.
enterInterruptibly() - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor.
enterInterruptibly(long, TimeUnit) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor.
enterInterruptibly(Duration) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor.
enterWhen(Monitor.Guard) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor when the guard is satisfied.
enterWhen(Monitor.Guard, long, TimeUnit) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor when the guard is satisfied.
enterWhen(Monitor.Guard, Duration) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor when the guard is satisfied.
enterWhenUninterruptibly(Monitor.Guard) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor when the guard is satisfied.
enterWhenUninterruptibly(Monitor.Guard, long, TimeUnit) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor when the guard is satisfied.
enterWhenUninterruptibly(Monitor.Guard, Duration) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor when the guard is satisfied.
entries() - 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 java.lang.Enum<K>,​V extends java.lang.Enum<V>> - Class in com.google.common.collect
A BiMap backed by two EnumMap instances.
EnumHashBiMap<K extends java.lang.Enum<K>,​V extends @Nullable java.lang.Object> - 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 java.lang.Enum<E>> - Class in com.google.common.collect
Multiset implementation specialized for enum elements, supporting all single-element operations in O(1).
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
EPUB - Static variable in class com.google.common.net.MediaType
As described in the International Digital Publishing Forum EPUB is the distribution and interchange format standard for digital publications and documents.
equal(File, File) - Static method in class com.google.common.io.Files
Returns true if the given files exist, are not directories, and contain the same bytes.
equal(Object, Object) - Static method in class com.google.common.base.Objects
Determines whether two possibly-null objects are equal.
equal(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() - 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.Converter
Indicates whether another object is equal to this converter.
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.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
Returns true if object is an ImmutableDoubleArray containing the same values as this one, in the same order.
equals(Object) - Method in class com.google.common.primitives.ImmutableIntArray
Returns true if object is an ImmutableIntArray containing the same values as this one, in the same order.
equals(Object) - Method in class com.google.common.primitives.ImmutableLongArray
Returns true if object is an ImmutableLongArray containing the same values as this one, in the same order.
equals(Object) - Method in class com.google.common.primitives.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.Invokable
 
equals(Object) - Method in class com.google.common.reflect.Parameter
 
equals(Object) - Method in class com.google.common.reflect.TypeParameter
 
equals(Object) - Method in class com.google.common.reflect.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 extends @Nullable java.lang.Object> - Class in com.google.common.base
equivalent(T, T) - Method in class com.google.common.base.Equivalence
Returns true if the given objects are considered equivalent.
equivalentTo(T) - Method in class com.google.common.base.Equivalence
Returns a predicate that evaluates to true if and only if the input is equivalent to target according to this equivalence relation.
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(char) - Method in class com.google.common.escape.ArrayBasedCharEscaper
Escapes a single character using the replacement array and safe range values.
escape(char) - Method in class com.google.common.escape.CharEscaper
Returns the escaped form of the given character, or null if this character does not need to be escaped.
escape(int) - Method in class com.google.common.escape.ArrayBasedUnicodeEscaper
Escapes a single Unicode code point using the replacement array and safe range values.
escape(int) - Method in class com.google.common.escape.UnicodeEscaper
Returns the escaped form of the given Unicode code point, or null if this code point does not need to be escaped.
escape(int) - Method in class com.google.common.net.PercentEscaper
Escapes the given Unicode code point in UTF-8.
escape(String) - Method in class com.google.common.escape.ArrayBasedCharEscaper
 
escape(String) - Method in class com.google.common.escape.ArrayBasedUnicodeEscaper
 
escape(String) - Method in class com.google.common.escape.CharEscaper
Returns the escaped form of a given literal string.
escape(String) - Method in class com.google.common.escape.Escaper
Returns the escaped form of a given literal string.
escape(String) - Method in class com.google.common.escape.UnicodeEscaper
Returns the escaped form of a given literal string.
escape(String) - Method in class com.google.common.net.PercentEscaper
 
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(SubscriberExceptionHandler) - Constructor for class com.google.common.eventbus.EventBus
Creates a new EventBus with the given SubscriberExceptionHandler.
EventBus(String) - Constructor for class com.google.common.eventbus.EventBus
Creates a new EventBus with the given identifier.
eventuallyClose(C, Executor) - Method in class com.google.common.util.concurrent.ClosingFuture.DeferredCloser
Captures an object to be closed when a ClosingFuture pipeline is done.
eventuallyClosing(ListenableFuture<C>, Executor) - Static method in class com.google.common.util.concurrent.ClosingFuture
Deprecated.
Creating Futures of closeable types is dangerous in general because the underlying value may never be closed if the Future is canceled after its operation begins. Consider replacing code that creates ListenableFutures of closeable types, including those that pass them to this method, with ClosingFuture.submit(ClosingCallable, Executor) in order to ensure that resources do not leak. Or, to start a pipeline with a ListenableFuture that doesn't create values that should be closed, use ClosingFuture.from(com.google.common.util.concurrent.ListenableFuture<V>).
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
Error variant of ExecutionException.
ExecutionError() - Constructor for error com.google.common.util.concurrent.ExecutionError
Deprecated.
Prefer ExecutionError(java.lang.Error) a constructor that accepts a cause: Users of this class typically expect for instances to have a non-null cause. At the moment, you can usually still preserve behavior by passing an explicit null cause. Note, however, that passing an explicit null cause prevents anyone from calling Throwable.initCause(java.lang.Throwable) later, so it is not quite equivalent to using a constructor that omits the cause.
ExecutionError(Error) - Constructor for error com.google.common.util.concurrent.ExecutionError
Creates a new instance with null as its detail message and the given cause.
ExecutionError(String) - Constructor for error com.google.common.util.concurrent.ExecutionError
Deprecated.
Prefer ExecutionError(java.lang.String,java.lang.Error) a constructor that accepts a cause: Users of this class typically expect for instances to have a non-null cause. At the moment, you can usually still preserve behavior by passing an explicit null cause. Note, however, that passing an explicit null cause prevents anyone from calling Throwable.initCause(java.lang.Throwable) later, so it is not quite equivalent to using a constructor that omits the cause.
ExecutionError(String, Error) - Constructor for error com.google.common.util.concurrent.ExecutionError
Creates a new instance with the given detail message and 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.
ExecutionSequencer - Class in com.google.common.util.concurrent
Serializes execution of tasks, somewhat like an "asynchronous synchronized block." Each enqueued callable will not be submitted to its associated executor until the previous callable has returned -- and, if the previous callable was an AsyncCallable, not until the Future it returned is done (successful, failed, or cancelled).
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
Returns the ScheduledExecutorService that will be used to execute the AbstractScheduledService.startUp(), AbstractScheduledService.runOneIteration() and AbstractScheduledService.shutDown() methods.
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.
expireAfterAccess(Duration) - Method in class com.google.common.cache.CacheBuilder
Specifies that each entry should be automatically removed from the cache once a fixed duration has elapsed after the entry's creation, the most recent replacement of its value, or its last access.
expireAfterWrite(long, TimeUnit) - Method in class com.google.common.cache.CacheBuilder
Specifies that each entry should be automatically removed from the cache once a fixed duration has elapsed after the entry's creation, or the most recent replacement of its value.
expireAfterWrite(Duration) - Method in class com.google.common.cache.CacheBuilder
Specifies that each entry should be automatically removed from the cache once a fixed duration has elapsed after the entry's creation, or the most recent replacement of its value.
EXPIRED - com.google.common.cache.RemovalCause
The entry's expiration timestamp has passed.
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.
EXPLICIT - com.google.common.cache.RemovalCause
The entry was manually removed by the user.

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.
FAILED - com.google.common.util.concurrent.Service.State
A service in this state has encountered a problem and may not be operational.
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.
FILE_SEPARATOR - com.google.common.base.StandardSystemProperty
File separator ("/" on UNIX).
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.
fileTraverser() - Static method in class com.google.common.io.Files
Returns a Traverser instance for the file and directory tree.
fileTraverser() - Static method in class com.google.common.io.MoreFiles
Returns a Traverser instance for the file and directory tree.
FileWriteMode - Enum in com.google.common.io
Modes for opening a file for writing.
filter(Predicate<? super E>) - Method in class com.google.common.collect.FluentIterable
Returns the elements from this fluent iterable that satisfy a predicate.
filter(Multiset<E>, Predicate<? super E>) - Static method in class com.google.common.collect.Multisets
Returns a view of the elements of unfiltered that satisfy a predicate.
filter(Class<T>) - Method in class com.google.common.collect.FluentIterable
Returns the elements from this fluent iterable that are instances of class type.
filter(Iterable<?>, Class<T>) - Static method in class com.google.common.collect.Iterables
Returns a view of unfiltered containing all elements that are of the type desiredType.
filter(Iterable<T>, Predicate<? super T>) - Static method in class com.google.common.collect.Iterables
Returns a view of unfiltered containing all elements that satisfy the input predicate retainIfTrue.
filter(Collection<E>, Predicate<? super E>) - Static method in class com.google.common.collect.Collections2
Returns the elements of unfiltered that satisfy a predicate.
filter(Iterator<?>, Class<T>) - Static method in class com.google.common.collect.Iterators
Returns a view of unfiltered containing all elements that are of the type desiredType.
filter(Iterator<T>, Predicate<? super T>) - Static method in class com.google.common.collect.Iterators
Returns a view of unfiltered containing all elements that satisfy the input predicate retainIfTrue.
filter(NavigableSet<E>, Predicate<? super E>) - Static method in class com.google.common.collect.Sets
Returns the elements of a NavigableSet, unfiltered, that satisfy a predicate.
filter(Set<E>, Predicate<? super E>) - Static method in class com.google.common.collect.Sets
Returns the elements of unfiltered that satisfy a predicate.
filter(SortedSet<E>, Predicate<? super E>) - Static method in class com.google.common.collect.Sets
Returns the elements of a SortedSet, unfiltered, that satisfy a predicate.
filterEntries(BiMap<K, V>, Predicate<? super Map.Entry<K, V>>) - Static method in class com.google.common.collect.Maps
Returns a bimap containing the mappings in unfiltered that satisfy a predicate.
filterEntries(Multimap<K, V>, Predicate<? super Map.Entry<K, V>>) - Static method in class com.google.common.collect.Multimaps
Returns a multimap containing the mappings in unfiltered that satisfy a predicate.
filterEntries(SetMultimap<K, V>, Predicate<? super Map.Entry<K, V>>) - Static method in class com.google.common.collect.Multimaps
Returns a multimap containing the mappings in unfiltered that satisfy a predicate.
filterEntries(Map<K, V>, Predicate<? super Map.Entry<K, V>>) - Static method in class com.google.common.collect.Maps
Returns a map containing the mappings in unfiltered that satisfy a predicate.
filterEntries(NavigableMap<K, V>, Predicate<? super Map.Entry<K, V>>) - Static method in class com.google.common.collect.Maps
Returns a sorted map containing the mappings in unfiltered that satisfy a predicate.
filterEntries(SortedMap<K, V>, Predicate<? super Map.Entry<K, V>>) - Static method in class com.google.common.collect.Maps
Returns a sorted map containing the mappings in unfiltered that satisfy a predicate.
filterKeys(BiMap<K, V>, Predicate<? super K>) - Static method in class com.google.common.collect.Maps
Returns a bimap containing the mappings in unfiltered whose keys satisfy a predicate.
filterKeys(ListMultimap<K, V>, Predicate<? super K>) - Static method in class com.google.common.collect.Multimaps
Returns a multimap containing the mappings in unfiltered whose keys satisfy a predicate.
filterKeys(Multimap<K, V>, Predicate<? super K>) - Static method in class com.google.common.collect.Multimaps
Returns a multimap containing the mappings in unfiltered whose keys satisfy a predicate.
filterKeys(SetMultimap<K, V>, Predicate<? super K>) - Static method in class com.google.common.collect.Multimaps
Returns a multimap containing the mappings in unfiltered whose keys satisfy a predicate.
filterKeys(Map<K, V>, Predicate<? super K>) - Static method in class com.google.common.collect.Maps
Returns a map containing the mappings in unfiltered whose keys satisfy a predicate.
filterKeys(NavigableMap<K, V>, Predicate<? super K>) - Static method in class com.google.common.collect.Maps
Returns a navigable map containing the mappings in unfiltered whose keys satisfy a predicate.
filterKeys(SortedMap<K, V>, Predicate<? super K>) - Static method in class com.google.common.collect.Maps
Returns a sorted map containing the mappings in unfiltered whose keys satisfy a predicate.
filterValues(BiMap<K, V>, Predicate<? super V>) - Static method in class com.google.common.collect.Maps
Returns a bimap containing the mappings in unfiltered whose values satisfy a predicate.
filterValues(Multimap<K, V>, Predicate<? super V>) - Static method in class com.google.common.collect.Multimaps
Returns a multimap containing the mappings in unfiltered whose values satisfy a predicate.
filterValues(SetMultimap<K, V>, Predicate<? super V>) - Static method in class com.google.common.collect.Multimaps
Returns a multimap containing the mappings in unfiltered whose values satisfy a predicate.
filterValues(Map<K, V>, Predicate<? super V>) - Static method in class com.google.common.collect.Maps
Returns a map containing the mappings in unfiltered whose values satisfy a predicate.
filterValues(NavigableMap<K, V>, Predicate<? super V>) - Static method in class com.google.common.collect.Maps
Returns a navigable map containing the mappings in unfiltered whose values satisfy a predicate.
filterValues(SortedMap<K, V>, Predicate<? super V>) - Static method in class com.google.common.collect.Maps
Returns a sorted map containing the mappings in unfiltered whose values satisfy a predicate.
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.
finalize() - Method in class com.google.common.util.concurrent.ClosingFuture
 
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<? extends T>, Predicate<? super T>, T) - Static method in class com.google.common.collect.Iterables
Returns the first element in iterable that satisfies the given predicate, or defaultValue if none found.
find(Iterable<T>, Predicate<? super T>) - Static method in class com.google.common.collect.Iterables
Returns the first element in iterable that satisfies the given predicate; use this method only when such an element is known to exist.
find(Iterator<? extends T>, Predicate<? super T>, T) - Static method in class com.google.common.collect.Iterators
Returns the first element in iterator that satisfies the given predicate.
find(Iterator<T>, Predicate<? super T>) - Static method in class com.google.common.collect.Iterators
Returns the first element in iterator that satisfies the given predicate; use this method only when such an element is known to exist.
findLast(DoubleStream) - Static method in class com.google.common.collect.Streams
Returns the last element of the specified stream, or OptionalDouble.empty() if the stream is empty.
findLast(IntStream) - Static method in class com.google.common.collect.Streams
Returns the last element of the specified stream, or OptionalInt.empty() if the stream is empty.
findLast(LongStream) - Static method in class com.google.common.collect.Streams
Returns the last element of the specified stream, or OptionalLong.empty() if the stream is empty.
findLast(Stream<T>) - Static method in class com.google.common.collect.Streams
Returns the last element of the specified stream, or Optional.empty() if the stream is empty.
fingerprint2011() - Static method in class com.google.common.hash.Hashing
Returns a hash function implementing the Fingerprint2011 hashing function (64 hash bits).
finishToFuture() - Method in class com.google.common.util.concurrent.ClosingFuture
Marks this step as the last step in the ClosingFuture pipeline.
finishToValueAndCloser(ClosingFuture.ValueAndCloserConsumer<? super V>, Executor) - Method in class com.google.common.util.concurrent.ClosingFuture
Marks this step as the last step in the ClosingFuture pipeline.
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(int) - Static method in class com.google.common.math.IntMath
Returns the largest power of two less than or equal to x.
floorPowerOfTwo(long) - Static method in class com.google.common.math.LongMath
Returns the largest power of two less than or equal to x.
floorPowerOfTwo(BigInteger) - Static method in class com.google.common.math.BigIntegerMath
Returns the largest power of two less than or equal to x.
FluentFuture<V extends @Nullable java.lang.Object> - Class in com.google.common.util.concurrent
A ListenableFuture that supports fluent chains of operations.
FluentIterable<E extends @Nullable java.lang.Object> - 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
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.
FONT_COLLECTION - Static variable in class com.google.common.net.MediaType
A collection of font outlines as defined by RFC 8081.
FONT_OTF - Static variable in class com.google.common.net.MediaType
Open Type Font Format (OTF) as defined by RFC 8081.
FONT_SFNT - Static variable in class com.google.common.net.MediaType
FONT_TTF - Static variable in class com.google.common.net.MediaType
True Type Font Format (TTF) as defined by RFC 8081.
FONT_WOFF - Static variable in class com.google.common.net.MediaType
FONT_WOFF2 - Static variable in class com.google.common.net.MediaType
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(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 class com.google.common.collect.ImmutableList
 
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 class com.google.common.collect.EnumMultiset
 
forEachEntry(ObjIntConsumer<? super E>) - Method in interface com.google.common.collect.Multiset
Runs the specified action for each distinct element in this multiset, and the number of occurrences of that element.
forEachEntry(ObjIntConsumer<? super E>) - Method in class com.google.common.collect.TreeMultiset
 
forEachLine(Consumer<? super String>) - Method in class com.google.common.io.CharSource
Reads all lines of text from this source, running the given action for each line as it is read.
forEachPair(Stream<A>, Stream<B>, BiConsumer<? super A, ? super B>) - Static method in class com.google.common.collect.Streams
Invokes consumer once for each pair of corresponding elements in streamA and streamB.
forEnumeration(Enumeration<T>) - Static method in class com.google.common.collect.Iterators
Adapts an Enumeration to the Iterator interface.
forGraph(SuccessorsFunction<N>) - Static method in class com.google.common.graph.Traverser
Creates a new traverser for the given general graph.
FORM_DATA - Static variable in class com.google.common.net.MediaType
 
forMap(Map<K, ? extends V>, V) - Static method in class com.google.common.base.Functions
Returns a function which performs a map lookup with a default value.
forMap(Map<K, V>) - Static method in class com.google.common.base.Functions
Returns a function which performs a map lookup.
forMap(Map<K, V>) - Static method in class com.google.common.collect.Multimaps
Returns a multimap view of the specified map.
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().
forTree(SuccessorsFunction<N>) - Static method in class com.google.common.graph.Traverser
Creates a new traverser for a directed acyclic graph that has at most one path from the start node(s) to any node reachable from the start node(s), and has no paths from any start node to any other start node, such as a tree or forest.
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.
ForwardingBlockingDeque<E> - Class in com.google.common.util.concurrent
A BlockingDeque which forwards all its method calls to another BlockingDeque.
ForwardingBlockingDeque() - Constructor for class com.google.common.collect.ForwardingBlockingDeque
Deprecated.
Constructor for use by subclasses.
ForwardingBlockingDeque() - Constructor for class com.google.common.util.concurrent.ForwardingBlockingDeque
Constructor for use by subclasses.
ForwardingBlockingQueue<E> - Class in com.google.common.util.concurrent
A BlockingQueue which forwards all its method calls to another BlockingQueue.
ForwardingBlockingQueue() - Constructor for class com.google.common.util.concurrent.ForwardingBlockingQueue
Constructor for use by subclasses.
ForwardingCache<K,​V> - Class in com.google.common.cache
A cache which forwards all its method calls to another cache.
ForwardingCache() - Constructor for class com.google.common.cache.ForwardingCache
Constructor for use by subclasses.
ForwardingCache.SimpleForwardingCache<K,​V> - Class in com.google.common.cache
A simplified version of ForwardingCache where subclasses can pass in an already constructed Cache as the delegate.
ForwardingCollection<E extends @Nullable java.lang.Object> - 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 extends @Nullable java.lang.Object> - 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 extends @Nullable java.lang.Object> - 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 extends @Nullable java.lang.Object> - 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 extends @Nullable java.lang.Object> - 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 extends @Nullable java.lang.Object> - 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 extends @Nullable java.lang.Object> - 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 extends @Nullable java.lang.Object> - 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 extends @Nullable java.lang.Object> - 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 extends @Nullable java.lang.Object,​V extends @Nullable java.lang.Object> - 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 extends @Nullable java.lang.Object,​V extends @Nullable java.lang.Object> - Class in com.google.common.collect
A map which forwards all its method calls to another map.
ForwardingMap() - Constructor for class com.google.common.collect.ForwardingMap
Constructor for use by subclasses.
ForwardingMap.StandardEntrySet - Class in com.google.common.collect
ForwardingMap.StandardKeySet - Class in com.google.common.collect
A sensible implementation of Map.keySet() in terms of the following methods: ForwardingMap.clear(), ForwardingMap.containsKey(java.lang.Object), ForwardingMap.isEmpty(), ForwardingMap.remove(java.lang.Object), ForwardingMap.size(), and the Set.iterator() method of ForwardingMap.entrySet().
ForwardingMap.StandardValues - Class in com.google.common.collect
A sensible implementation of Map.values() in terms of the following methods: ForwardingMap.clear(), ForwardingMap.containsValue(java.lang.Object), ForwardingMap.isEmpty(), ForwardingMap.size(), and the Set.iterator() method of ForwardingMap.entrySet().
ForwardingMapEntry<K extends @Nullable java.lang.Object,​V extends @Nullable java.lang.Object> - 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 extends @Nullable java.lang.Object,​V extends @Nullable java.lang.Object> - 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 extends @Nullable java.lang.Object> - 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 extends @Nullable java.lang.Object,​V extends @Nullable java.lang.Object> - 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 extends @Nullable java.lang.Object> - 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 extends @Nullable java.lang.Object> - 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 extends @Nullable java.lang.Object> - 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 extends @Nullable java.lang.Object,​V extends @Nullable java.lang.Object> - 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 extends @Nullable java.lang.Object,​V extends @Nullable java.lang.Object> - 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 extends @Nullable java.lang.Object> - 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 extends @Nullable java.lang.Object> - 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 extends @Nullable java.lang.Object,​V extends @Nullable java.lang.Object> - 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 extends @Nullable java.lang.Object,​C extends @Nullable java.lang.Object,​V extends @Nullable java.lang.Object> - 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(Function<K, V>) - Static method in class com.google.common.cache.CacheLoader
Returns a cache loader that uses function to load keys, without supporting either reloading or bulk loading.
from(Supplier<V>) - Static method in class com.google.common.cache.CacheLoader
Returns a cache loader based on an existing supplier instance.
from(CacheBuilderSpec) - Static method in class com.google.common.cache.CacheBuilder
Constructs a new CacheBuilder instance with the settings specified in spec.
from(FluentIterable<E>) - Static method in class com.google.common.collect.FluentIterable
Deprecated.
instances of FluentIterable don't need to be converted to FluentIterable
from(Ordering<T>) - Static method in class com.google.common.collect.Ordering
Deprecated.
no need to use this
from(Graph<N>) - Static method in class com.google.common.graph.GraphBuilder
Returns a GraphBuilder initialized with all properties queryable from graph.
from(Network<N, E>) - Static method in class com.google.common.graph.NetworkBuilder
Returns a NetworkBuilder initialized with all properties queryable from network.
from(ValueGraph<N, V>) - Static method in class com.google.common.graph.ValueGraphBuilder
Returns a ValueGraphBuilder initialized with all properties queryable from graph.
from(FluentFuture<V>) - Static method in class com.google.common.util.concurrent.FluentFuture
Deprecated.
no need to use this
from(ListenableFuture<V>) - Static method in class com.google.common.util.concurrent.ClosingFuture
Starts a ClosingFuture pipeline with a ListenableFuture.
from(ListenableFuture<V>) - Static method in class com.google.common.util.concurrent.FluentFuture
Converts the given ListenableFuture to an equivalent FluentFuture.
from(E[]) - Static method in class com.google.common.collect.FluentIterable
Returns a fluent iterable containing elements in the specified order.
from(ClassLoader) - Static method in class com.google.common.reflect.ClassPath
Returns a ClassPath representing all classes and resources loadable from classloader and its ancestor class loaders.
from(Iterable<E>) - Static method in class com.google.common.collect.FluentIterable
Returns a fluent iterable that wraps iterable, or iterable itself if it is already a FluentIterable.
from(Constructor<T>) - Static method in class com.google.common.reflect.Invokable
Returns Invokable of constructor.
from(Method) - Static method in class com.google.common.reflect.Invokable
Returns Invokable of method.
from(String) - Static method in class com.google.common.cache.CacheBuilder
Constructs a new CacheBuilder instance with the settings specified in spec.
from(String) - Static method in class com.google.common.net.HostSpecifier
Attempts to return a HostSpecifier for the given string, throwing an exception if parsing fails.
from(String) - Static method in class com.google.common.net.InternetDomainName
Returns an instance of InternetDomainName after lenient validation.
from(Comparator<T>) - Static method in class com.google.common.collect.Ordering
Returns an ordering based on an existing comparator instance.
FROM - Static variable in class com.google.common.net.HttpHeaders
The HTTP From header field name.
fromByteArray(byte[]) - Static method in class com.google.common.math.PairedStats
Creates a PairedStats instance from the given byte representation which was obtained by PairedStats.toByteArray().
fromByteArray(byte[]) - Static method in class com.google.common.math.Stats
Creates a Stats instance from the given byte representation which was obtained by Stats.toByteArray().
fromByteArray(byte[]) - Static method in class com.google.common.primitives.Chars
Returns the char value whose big-endian representation is stored in the first 2 bytes of bytes; equivalent to ByteBuffer.wrap(bytes).getChar().
fromByteArray(byte[]) - Static method in class com.google.common.primitives.Ints
Returns the int value whose big-endian representation is stored in the first 4 bytes of bytes; equivalent to ByteBuffer.wrap(bytes).getInt().
fromByteArray(byte[]) - Static method in class com.google.common.primitives.Longs
Returns the long value whose big-endian representation is stored in the first 8 bytes of bytes; equivalent to ByteBuffer.wrap(bytes).getLong().
fromByteArray(byte[]) - Static method in class com.google.common.primitives.Shorts
Returns the short value whose big-endian representation is stored in the first 2 bytes of bytes; equivalent to ByteBuffer.wrap(bytes).getShort().
fromBytes(byte[]) - Static method in class com.google.common.hash.HashCode
Creates a HashCode from a byte array.
fromBytes(byte, byte) - Static method in class com.google.common.primitives.Chars
Returns the char value whose byte representation is the given 2 bytes, in big-endian order; equivalent to Chars.fromByteArray(new byte[] {b1, b2}).
fromBytes(byte, byte) - Static method in class com.google.common.primitives.Shorts
Returns the short value whose byte representation is the given 2 bytes, in big-endian order; equivalent to Shorts.fromByteArray(new byte[] {b1, b2}).
fromBytes(byte, byte, byte, byte) - Static method in class com.google.common.primitives.Ints
Returns the int value whose byte representation is the given 4 bytes, in big-endian order; equivalent to Ints.fromByteArray(new byte[] {b1, b2, b3, b4}).
fromBytes(byte, byte, byte, byte, byte, byte, byte, byte) - Static method in class com.google.common.primitives.Longs
Returns the long value whose byte representation is the given 8 bytes, in big-endian order; equivalent to Longs.fromByteArray(new byte[] {b1, b2, b3, b4, b5, b6, b7, b8}).
fromHost(String) - Static method in class com.google.common.net.HostAndPort
Build a HostAndPort instance from a host only.
fromInt(int) - Static method in class com.google.common.hash.HashCode
Creates a 32-bit HashCode representation of the given int value.
fromIntBits(int) - Static method in class com.google.common.primitives.UnsignedInteger
Returns an UnsignedInteger corresponding to a given bit representation.
fromInteger(int) - Static method in class com.google.common.net.InetAddresses
Returns an Inet4Address having the integer value specified by the argument.
fromIPv4BigInteger(BigInteger) - Static method in class com.google.common.net.InetAddresses
Returns the Inet4Address corresponding to a given BigInteger.
fromIPv6BigInteger(BigInteger) - Static method in class com.google.common.net.InetAddresses
Returns the Inet6Address corresponding to a given BigInteger.
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 extends @Nullable java.lang.Object,​T extends @Nullable java.lang.Object> - Interface in com.google.common.base
Legacy version of java.util.function.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, PrimitiveSink) - Method in interface com.google.common.hash.Funnel
Sends a stream of data from the from object into the sink into.
Funnel<T extends @Nullable java.lang.Object> - Interface in com.google.common.hash
An object which can send data from an object of type T into a PrimitiveSink.
Funnels - Class in com.google.common.hash
Funnels for common types.
FutureCallback<V extends @Nullable java.lang.Object> - 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 extends @Nullable java.lang.Object> - 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

gap(Range<C>) - Method in class com.google.common.collect.Range
Returns the maximal range lying between this range and otherRange, if such a range exists.
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.
GEO_JSON - Static variable in class com.google.common.net.MediaType
Media type for the GeoJSON Format, a geospatial data interchange format based on JSON.
get() - Method in class com.google.common.base.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() - Method in class com.google.common.util.concurrent.AbstractFuture
get() - Method in class com.google.common.util.concurrent.AtomicDouble
Gets the current value.
get() - Method in class com.google.common.util.concurrent.ClosingFuture.ValueAndCloser
Returns the final value of the associated ClosingFuture, or throws an exception as Future.get() would.
get() - Method in class com.google.common.util.concurrent.ForwardingFuture
 
get(int) - Method in class com.google.common.collect.FluentIterable
Returns the element at the specified position in this fluent iterable.
get(int) - Method in class com.google.common.collect.ForwardingList
 
get(int) - Method in class com.google.common.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(int) - Method in class com.google.common.util.concurrent.AtomicDoubleArray
Gets the current value at position i.
get(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractFuture
get(long, TimeUnit) - Method in class com.google.common.util.concurrent.ForwardingFuture
 
get(long, TimeUnit) - Method in class com.google.common.util.concurrent.ListenableFutureTask
 
get(Iterable<? extends T>, int, T) - Static method in class com.google.common.collect.Iterables
Returns the element at the specified position in an iterable or a default value otherwise.
get(Iterable<T>, int) - Static method in class com.google.common.collect.Iterables
Returns the element at the specified position in an iterable.
get(Object) - Method in class com.google.common.collect.ForwardingMap
 
get(Object) - Method in class com.google.common.collect.HashBiMap
 
get(Object) - Method in class com.google.common.collect.ImmutableMap
 
get(Object) - Method in class com.google.common.collect.ImmutableSortedMap
 
get(Object) - Method in class com.google.common.util.concurrent.Striped
Returns the stripe that corresponds to the passed key.
get(Object, Object) - Method in class com.google.common.collect.ArrayTable
 
get(Object, Object) - Method in class com.google.common.collect.ForwardingTable
 
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(Iterator<? extends T>, int, T) - Static method in class com.google.common.collect.Iterators
Advances iterator position + 1 times, returning the element at the positionth position or defaultValue otherwise.
get(Iterator<T>, int) - Static method in class com.google.common.collect.Iterators
Advances iterator position + 1 times, returning the element at the positionth position.
get(K) - Method in class com.google.common.cache.ForwardingLoadingCache
 
get(K) - Method in interface com.google.common.cache.LoadingCache
Returns the value associated with key in this cache, first loading that value if necessary.
get(K) - Method in class com.google.common.collect.ForwardingListMultimap
 
get(K) - Method in class com.google.common.collect.ForwardingMultimap
 
get(K) - Method in class com.google.common.collect.ForwardingSetMultimap
 
get(K) - Method in class com.google.common.collect.ForwardingSortedSetMultimap
 
get(K) - Method in class com.google.common.collect.ImmutableListMultimap
Returns an immutable list of the values for the given key.
get(K) - Method in class com.google.common.collect.ImmutableMultimap
Returns an immutable collection of the values for the given key.
get(K) - Method in class com.google.common.collect.ImmutableRangeMap
 
get(K) - Method in class com.google.common.collect.ImmutableSetMultimap
Returns an immutable set of the values for the given key.
get(K) - Method in class com.google.common.collect.LinkedListMultimap
Returns a view collection of the values associated with key in this multimap, if any.
get(K) - Method in interface com.google.common.collect.ListMultimap
Returns a view collection of the values associated with key in this multimap, if any.
get(K) - Method in interface com.google.common.collect.Multimap
Returns a view collection of the values associated with key in this multimap, if any.
get(K) - Method in interface com.google.common.collect.RangeMap
Returns the value associated with the specified key, or null if there is no such value.
get(K) - Method in interface com.google.common.collect.SetMultimap
Returns a view collection of the values associated with key in this multimap, if any.
get(K) - Method in interface com.google.common.collect.SortedSetMultimap
Returns a collection view of all values associated with a key.
get(K) - Method in class com.google.common.collect.TreeMultimap
 
get(K) - Method in class com.google.common.collect.TreeRangeMap
 
get(K) - Method in class com.google.common.util.concurrent.AtomicLongMap
Returns the value associated with key, or zero if there is no value associated with key.
get(K, 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
 
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<? extends Object>) - Method in class com.google.common.cache.AbstractCache
Returns a map of the values associated with keys in this cache.
getAllPresent(Iterable<? extends Object>) - Method in interface com.google.common.cache.Cache
Returns a map of the values associated with keys in this cache.
getAllPresent(Iterable<? extends Object>) - Method in class com.google.common.cache.ForwardingCache
 
getAndAccumulate(double, DoubleBinaryOperator) - Method in class com.google.common.util.concurrent.AtomicDouble
Atomically updates the current value with the results of applying the given function to the current and given values.
getAndAccumulate(int, double, DoubleBinaryOperator) - Method in class com.google.common.util.concurrent.AtomicDoubleArray
Atomically updates the element at index i with the results of applying the given function to the current and given values.
getAndAccumulate(K, long, LongBinaryOperator) - Method in class com.google.common.util.concurrent.AtomicLongMap
Updates the value currently associated with key by combining it with x via the specified accumulator function, returning the old value.
getAndAdd(double) - Method in class com.google.common.util.concurrent.AtomicDouble
Atomically adds the given value to the current value.
getAndAdd(int, double) - Method in class com.google.common.util.concurrent.AtomicDoubleArray
Atomically adds the given value to the element at index i.
getAndAdd(K, long) - Method in class com.google.common.util.concurrent.AtomicLongMap
Adds delta to the value currently associated with key, and returns the old value.
getAndDecrement(K) - Method in class com.google.common.util.concurrent.AtomicLongMap
Decrements by one the value currently associated with key, and returns the old value.
getAndIncrement(K) - Method in class com.google.common.util.concurrent.AtomicLongMap
Increments by one the value currently associated with key, and returns the old value.
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(int, DoubleUnaryOperator) - Method in class com.google.common.util.concurrent.AtomicDoubleArray
Atomically updates the element at index i with the results of applying the given function to the current value.
getAndUpdate(DoubleUnaryOperator) - Method in class com.google.common.util.concurrent.AtomicDouble
Atomically updates the current value with the results of applying the given function.
getAndUpdate(K, LongUnaryOperator) - Method in class com.google.common.util.concurrent.AtomicLongMap
Updates the value currently associated with key with the specified function, and returns the old value.
getAnnotatedReturnType() - Method in class com.google.common.reflect.Invokable
Returns the AnnotatedType for the return type.
getAnnotatedType() - Method in class com.google.common.reflect.Parameter
Returns the AnnotatedType of the parameter.
getAnnotation(Class<A>) - Method in class com.google.common.reflect.Invokable
 
getAnnotation(Class<A>) - Method in class com.google.common.reflect.Parameter
 
getAnnotations() - Method in class com.google.common.reflect.Invokable
 
getAnnotations() - Method in class com.google.common.reflect.Parameter
 
getAnnotationsByType(Class<A>) - Method in class com.google.common.reflect.Parameter
 
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.
getChecked(Future<V>, Class<X>, Duration) - Static method in class com.google.common.util.concurrent.Futures
Returns the result of Future.get(long, TimeUnit), converting most exceptions to a new instance of the given checked exception type.
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.Invokable
 
getDeclaredAnnotations() - Method in class com.google.common.reflect.Parameter
 
getDeclaredAnnotationsByType(Class<A>) - Method in class com.google.common.reflect.Parameter
 
getDeclaringClass() - Method in class com.google.common.reflect.Invokable
 
getDeclaringInvokable() - Method in class com.google.common.reflect.Parameter
Returns the Invokable that declares this parameter.
getDone(ClosingFuture<D>) - Method in class com.google.common.util.concurrent.ClosingFuture.Peeker
Returns the value of closingFuture.
getDone(Future<V>) - Static method in class com.google.common.util.concurrent.Futures
Returns the result of the input Future, which must have already completed.
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) - Static method in class com.google.common.util.concurrent.MoreExecutors
Converts the given ThreadPoolExecutor into an ExecutorService that exits when the application is complete.
getExitingExecutorService(ThreadPoolExecutor, long, TimeUnit) - Static method in class com.google.common.util.concurrent.MoreExecutors
Converts the given ThreadPoolExecutor into an ExecutorService that exits when the application is complete.
getExitingExecutorService(ThreadPoolExecutor, Duration) - Static method in class com.google.common.util.concurrent.MoreExecutors
Converts the given ThreadPoolExecutor into an ExecutorService that exits when the application is complete.
getExitingScheduledExecutorService(ScheduledThreadPoolExecutor) - Static method in class com.google.common.util.concurrent.MoreExecutors
Converts the given ScheduledThreadPoolExecutor into a ScheduledExecutorService that exits when the application is complete.
getExitingScheduledExecutorService(ScheduledThreadPoolExecutor, long, TimeUnit) - Static method in class com.google.common.util.concurrent.MoreExecutors
Converts the given ScheduledThreadPoolExecutor into a ScheduledExecutorService that exits when the application is complete.
getExitingScheduledExecutorService(ScheduledThreadPoolExecutor, Duration) - Static method in class com.google.common.util.concurrent.MoreExecutors
Converts the given ScheduledThreadPoolExecutor into a ScheduledExecutorService that exits when the application is complete.
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(TypeToken<T>) - Method in class com.google.common.reflect.ImmutableTypeToInstanceMap
 
getInstance(TypeToken<T>) - Method in class com.google.common.reflect.MutableTypeToInstanceMap
 
getInstance(TypeToken<T>) - Method in interface com.google.common.reflect.TypeToInstanceMap
Returns the value the specified type is mapped to, or null if no entry for this type is present.
getInstance(Class<T>) - Method in interface com.google.common.collect.ClassToInstanceMap
Returns the value the specified class is mapped to, or null if no entry for this class is present.
getInstance(Class<T>) - Method in class com.google.common.collect.ImmutableClassToInstanceMap
 
getInstance(Class<T>) - Method in class com.google.common.collect.MutableClassToInstanceMap
 
getInstance(Class<T>) - Method in class com.google.common.reflect.ImmutableTypeToInstanceMap
 
getInstance(Class<T>) - Method in class com.google.common.reflect.MutableTypeToInstanceMap
 
getInstance(Class<T>) - Method in interface com.google.common.reflect.TypeToInstanceMap
Returns the value the specified class is mapped to, or null if no entry for this class is present.
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<? extends T>, T) - Static method in class com.google.common.collect.Iterables
Returns the last element of iterable or defaultValue if the iterable is empty.
getLast(Iterable<T>) - Static method in class com.google.common.collect.Iterables
Returns the last element of iterable.
getLast(Iterator<? extends T>, T) - Static method in class com.google.common.collect.Iterators
Advances iterator to the end, returning the last element or defaultValue if the iterator is empty.
getLast(Iterator<T>) - Static method in class com.google.common.collect.Iterators
Advances iterator to the end, returning the last element.
getMessage() - Method in exception com.google.common.util.concurrent.CycleDetectingLockFactory.PotentialDeadlockException
Appends the chain of messages from the conflictingStackTrace to the original message.
getModifiers() - Method in class com.google.common.reflect.Invokable
 
getName() - Method in class com.google.common.reflect.ClassPath.ClassInfo
Returns the fully qualified name of the class.
getName() - Method in class com.google.common.reflect.Invokable
 
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<? extends T>, T) - Static method in class com.google.common.collect.Iterables
Returns the single element contained in iterable, or defaultValue if the iterable is empty.
getOnlyElement(Iterable<T>) - Static method in class com.google.common.collect.Iterables
Returns the single element contained in iterable.
getOnlyElement(Iterator<? extends T>, T) - Static method in class com.google.common.collect.Iterators
Returns the single element contained in iterator, or defaultValue if the iterator is empty.
getOnlyElement(Iterator<T>) - Static method in class com.google.common.collect.Iterators
Returns the single element contained in iterator.
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(Class<?>, String) - Static method in class com.google.common.io.Resources
Given a resourceName that is relative to contextClass, returns a URL pointing to the named resource.
getResource(String) - Static method in class com.google.common.io.Resources
Returns a URL pointing to resourceName if the resource is found using the context class loader.
getResourceName() - Method in class com.google.common.reflect.ClassPath.ResourceInfo
Returns the fully qualified name of the resource.
getResources() - Method in class com.google.common.reflect.ClassPath
Returns all resources loadable from the current class path, including the class files of all loadable classes but excluding the "META-INF/MANIFEST.MF" file.
getResult() - Method in interface com.google.common.io.ByteProcessor
Return the result of processing all the bytes.
getResult() - Method in interface com.google.common.io.LineProcessor
Return the result of processing all the lines.
getReturnType() - Method in class com.google.common.reflect.Invokable
Returns the return type of this Invokable.
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.
getTypeParameters() - Method in class com.google.common.reflect.Invokable
See GenericDeclaration.getTypeParameters().
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(Future<V>) - Static method in class com.google.common.util.concurrent.Futures
Returns the result of calling Future.get() uninterruptibly on a task known not to throw a checked exception.
getUnchecked(K) - Method in class com.google.common.cache.AbstractLoadingCache
 
getUnchecked(K) - Method in class com.google.common.cache.ForwardingLoadingCache
 
getUnchecked(K) - Method in interface com.google.common.cache.LoadingCache
Returns the value associated with key in this cache, first loading that value if necessary.
getUninterruptibly(Future<V>) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes future.get() uninterruptibly.
getUninterruptibly(Future<V>, long, TimeUnit) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes future.get(timeout, unit) uninterruptibly.
getUninterruptibly(Future<V>, Duration) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes future.get(timeout, unit) uninterruptibly.
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