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

A

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.SimpleStatsCounter() - Constructor for class com.google.common.cache.AbstractCache.SimpleStatsCounter
Constructs an instance with all counts initialized to zero.
AbstractCache.StatsCounter - Interface in com.google.common.cache
Accumulates statistics during the operation of a Cache for presentation by Cache.stats().
AbstractCheckedFuture<V,X extends Exception> - Class in com.google.common.util.concurrent
A delegating wrapper around a ListenableFuture that adds support for the AbstractCheckedFuture.checkedGet() and AbstractCheckedFuture.checkedGet(long, TimeUnit) methods.
AbstractCheckedFuture(ListenableFuture<V>) - Constructor for class com.google.common.util.concurrent.AbstractCheckedFuture
Constructs an AbstractCheckedFuture that wraps a delegate.
AbstractExecutionThreadService - Class in com.google.common.util.concurrent
AbstractExecutionThreadService() - Constructor for class com.google.common.util.concurrent.AbstractExecutionThreadService
Constructor for use by subclasses.
AbstractFuture<V> - Class in com.google.common.util.concurrent
An abstract implementation of the ListenableFuture interface.
AbstractFuture() - Constructor for class com.google.common.util.concurrent.AbstractFuture
Constructor for use by subclasses.
AbstractIdleService - Class in com.google.common.util.concurrent
Base class for services that do not need a thread while "running" but may need one during startup and shutdown.
AbstractIdleService() - Constructor for class com.google.common.util.concurrent.AbstractIdleService
Constructor for use by subclasses.
AbstractInvocationHandler - Class in com.google.common.reflect
AbstractInvocationHandler() - Constructor for class com.google.common.reflect.AbstractInvocationHandler
 
AbstractIterator<T> - Class in com.google.common.collect
This class provides a skeletal implementation of the Iterator interface, to make this interface easier to implement for certain types of data sources.
AbstractIterator() - Constructor for class com.google.common.collect.AbstractIterator
Constructor for use by subclasses.
AbstractListeningExecutorService - Class in com.google.common.util.concurrent
Abstract ListeningExecutorService implementation that creates ListenableFutureTask 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.
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() - Constructor for class com.google.common.util.concurrent.AbstractScheduledService.CustomScheduler
 
AbstractScheduledService.CustomScheduler.Schedule - Class in com.google.common.util.concurrent
A value object that represents an absolute delay until a task should be invoked.
AbstractScheduledService.CustomScheduler.Schedule(long, TimeUnit) - Constructor for class com.google.common.util.concurrent.AbstractScheduledService.CustomScheduler.Schedule
 
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.
accept(File, String) - Method in class com.google.common.io.PatternFilenameFilter
 
ACCEPT - Static variable in class com.google.common.net.HttpHeaders
The HTTP Accept header field name.
ACCEPT_CHARSET - Static variable in class com.google.common.net.HttpHeaders
The HTTP Accept-Charset header field name.
ACCEPT_ENCODING - Static variable in class com.google.common.net.HttpHeaders
The HTTP Accept-Encoding header field name.
ACCEPT_LANGUAGE - Static variable in class com.google.common.net.HttpHeaders
The HTTP Accept-Language header field name.
ACCEPT_RANGES - Static variable in class com.google.common.net.HttpHeaders
The HTTP Accept-Ranges header field name.
ACCESS_CONTROL_ALLOW_CREDENTIALS - Static variable in class com.google.common.net.HttpHeaders
The HTTP Access-Control-Allow-Credentials header field name.
ACCESS_CONTROL_ALLOW_HEADERS - Static variable in class com.google.common.net.HttpHeaders
The HTTP Access-Control-Allow-Headers header field name.
ACCESS_CONTROL_ALLOW_METHODS - Static variable in class com.google.common.net.HttpHeaders
The HTTP Access-Control-Allow-Methods header field name.
ACCESS_CONTROL_ALLOW_ORIGIN - Static variable in class com.google.common.net.HttpHeaders
The HTTP Access-Control-Allow-Origin header field name.
ACCESS_CONTROL_EXPOSE_HEADERS - Static variable in class com.google.common.net.HttpHeaders
The HTTP Access-Control-Expose-Headers header field name.
ACCESS_CONTROL_MAX_AGE - Static variable in class com.google.common.net.HttpHeaders
The HTTP Access-Control-Max-Age header field name.
ACCESS_CONTROL_REQUEST_HEADERS - Static variable in class com.google.common.net.HttpHeaders
The HTTP Access-Control-Request-Headers header field name.
ACCESS_CONTROL_REQUEST_METHOD - Static variable in class com.google.common.net.HttpHeaders
The HTTP Access-Control-Request-Method header field name.
ACK - Static variable in class com.google.common.base.Ascii
Acknowledge: A communication control character transmitted by a receiver as an affirmative response to a sender.
acquire() - Method in class com.google.common.util.concurrent.RateLimiter
Acquires a single permit from this RateLimiter, blocking until the request can be granted.
acquire(int) - Method in class com.google.common.util.concurrent.RateLimiter
Acquires the given number of permits from this RateLimiter, blocking until the request can be granted.
add(String, Object) - Method in class com.google.common.base.Objects.ToStringHelper
Adds a name/value pair to the formatted output in name=value format.
add(String, boolean) - Method in class com.google.common.base.Objects.ToStringHelper
Adds a name/value pair to the formatted output in name=value format.
add(String, char) - Method in class com.google.common.base.Objects.ToStringHelper
Adds a name/value pair to the formatted output in name=value format.
add(String, double) - Method in class com.google.common.base.Objects.ToStringHelper
Adds a name/value pair to the formatted output in name=value format.
add(String, float) - Method in class com.google.common.base.Objects.ToStringHelper
Adds a name/value pair to the formatted output in name=value format.
add(String, int) - Method in class com.google.common.base.Objects.ToStringHelper
Adds a name/value pair to the formatted output in name=value format.
add(String, long) - Method in class com.google.common.base.Objects.ToStringHelper
Adds a name/value pair to the formatted output in name=value format.
add(E, int) - Method in class com.google.common.collect.ConcurrentHashMultiset
Adds a number of occurrences of the specified element to this multiset.
add(E) - Method in class com.google.common.collect.EvictingQueue
Adds the given element to this queue.
add(E) - Method in class com.google.common.collect.ForwardingCollection
 
add(int, E) - Method in class com.google.common.collect.ForwardingList
 
add(E) - Method in class com.google.common.collect.ForwardingListIterator
 
add(E, int) - Method in class com.google.common.collect.ForwardingMultiset
 
add(E) - Method in class com.google.common.collect.ImmutableCollection
Deprecated.
Unsupported operation.
add(E) - Method in class com.google.common.collect.ImmutableCollection.Builder
Adds element to the ImmutableCollection being built.
add(E...) - Method in class com.google.common.collect.ImmutableCollection.Builder
Adds each element of elements to the ImmutableCollection being built.
add(int, E) - Method in class com.google.common.collect.ImmutableList
Deprecated.
Unsupported operation.
add(E) - Method in class com.google.common.collect.ImmutableList.Builder
Adds element to the ImmutableList.
add(E...) - Method in class com.google.common.collect.ImmutableList.Builder
Adds each element of elements to the ImmutableList.
add(E, int) - Method in class com.google.common.collect.ImmutableMultiset
Deprecated.
Unsupported operation.
add(E) - Method in class com.google.common.collect.ImmutableMultiset.Builder
Adds element to the ImmutableMultiset.
add(E...) - Method in class com.google.common.collect.ImmutableMultiset.Builder
Adds each element of elements to the ImmutableMultiset.
add(Range<C>) - Method in class com.google.common.collect.ImmutableRangeSet
 
add(Range<C>) - Method in class com.google.common.collect.ImmutableRangeSet.Builder
Add the specified range to this builder.
add(E) - Method in class com.google.common.collect.ImmutableSet.Builder
Adds element to the ImmutableSet.
add(E...) - Method in class com.google.common.collect.ImmutableSet.Builder
Adds each element of elements to the ImmutableSet, ignoring duplicate elements (only the first duplicate element is added).
add(E) - Method in class com.google.common.collect.ImmutableSortedMultiset.Builder
Adds element to the ImmutableSortedMultiset.
add(E...) - Method in class com.google.common.collect.ImmutableSortedMultiset.Builder
Adds each element of elements to the ImmutableSortedMultiset.
add(E) - Method in class com.google.common.collect.ImmutableSortedSet.Builder
Adds element to the ImmutableSortedSet.
add(E...) - Method in class com.google.common.collect.ImmutableSortedSet.Builder
Adds each element of elements to the ImmutableSortedSet, ignoring duplicate elements (only the first duplicate element is added).
add(E) - Method in class com.google.common.collect.MinMaxPriorityQueue
Adds the given element to this queue.
add(E, int) - Method in interface com.google.common.collect.Multiset
Adds a number of occurrences of an element to this multiset.
add(E) - Method in interface com.google.common.collect.Multiset
Adds a single occurrence of the specified element to this multiset.
add(Range<C>) - Method in interface com.google.common.collect.RangeSet
Adds the specified range to this RangeSet (optional operation).
add(E, int) - Method in class com.google.common.collect.TreeMultiset
 
add(Range<C>) - Method in class com.google.common.collect.TreeRangeSet
 
add(E) - Method in class com.google.common.collect.UnmodifiableListIterator
Deprecated.
Unsupported operation.
add(Runnable, Executor) - Method in class com.google.common.util.concurrent.ExecutionList
Adds the Runnable and accompanying Executor to the list of listeners to execute.
addAll(Collection<? extends E>) - Method in class com.google.common.collect.EvictingQueue
 
addAll(Collection<? extends E>) - Method in class com.google.common.collect.ForwardingCollection
 
addAll(int, Collection<? extends E>) - Method in class com.google.common.collect.ForwardingList
 
addAll(Collection<? extends E>) - Method in class com.google.common.collect.ImmutableCollection
Deprecated.
Unsupported operation.
addAll(Iterable<? extends E>) - Method in class com.google.common.collect.ImmutableCollection.Builder
Adds each element of elements to the ImmutableCollection being built.
addAll(Iterator<? extends E>) - Method in class com.google.common.collect.ImmutableCollection.Builder
Adds each element of elements to the ImmutableCollection being built.
addAll(int, Collection<? extends E>) - Method in class com.google.common.collect.ImmutableList
Deprecated.
Unsupported operation.
addAll(Iterable<? extends E>) - Method in class com.google.common.collect.ImmutableList.Builder
Adds each element of elements to the ImmutableList.
addAll(Iterator<? extends E>) - Method in class com.google.common.collect.ImmutableList.Builder
Adds each element of elements to the ImmutableList.
addAll(Iterable<? extends E>) - Method in class com.google.common.collect.ImmutableMultiset.Builder
Adds each element of elements to the ImmutableMultiset.
addAll(Iterator<? extends E>) - Method in class com.google.common.collect.ImmutableMultiset.Builder
Adds each element of elements to the ImmutableMultiset.
addAll(RangeSet<C>) - Method in class com.google.common.collect.ImmutableRangeSet
 
addAll(RangeSet<C>) - Method in class com.google.common.collect.ImmutableRangeSet.Builder
Add all ranges from the specified range set to this builder.
addAll(Iterable<? extends E>) - Method in class com.google.common.collect.ImmutableSet.Builder
Adds each element of elements to the ImmutableSet, ignoring duplicate elements (only the first duplicate element is added).
addAll(Iterator<? extends E>) - Method in class com.google.common.collect.ImmutableSet.Builder
Adds each element of elements to the ImmutableSet, ignoring duplicate elements (only the first duplicate element is added).
addAll(Iterable<? extends E>) - Method in class com.google.common.collect.ImmutableSortedMultiset.Builder
Adds each element of elements to the ImmutableSortedMultiset.
addAll(Iterator<? extends E>) - Method in class com.google.common.collect.ImmutableSortedMultiset.Builder
Adds each element of elements to the ImmutableSortedMultiset.
addAll(Iterable<? extends E>) - Method in class com.google.common.collect.ImmutableSortedSet.Builder
Adds each element of elements to the ImmutableSortedSet, ignoring duplicate elements (only the first duplicate element is added).
addAll(Iterator<? extends E>) - Method in class com.google.common.collect.ImmutableSortedSet.Builder
Adds each element of elements to the ImmutableSortedSet, ignoring duplicate elements (only the first duplicate element is added).
addAll(Collection<T>, Iterable<? extends T>) - Static method in class com.google.common.collect.Iterables
Adds all elements in iterable to collection.
addAll(Collection<T>, Iterator<? extends T>) - Static method in class com.google.common.collect.Iterators
Adds all elements in iterator to collection.
addAll(Collection<? extends E>) - Method in class com.google.common.collect.MinMaxPriorityQueue
 
addAll(RangeSet<C>) - Method in interface com.google.common.collect.RangeSet
Adds all of the ranges from the specified range set to this range set (optional operation).
addAndGet(double) - Method in class com.google.common.util.concurrent.AtomicDouble
Atomically adds the given value to the current value.
addAndGet(int, double) - Method in class com.google.common.util.concurrent.AtomicDoubleArray
Atomically adds the given value to the element at index i.
addAndGet(K, long) - Method in class com.google.common.util.concurrent.AtomicLongMap
Adds delta to the value currently associated with key, and returns the new value.
addCallback(ListenableFuture<V>, FutureCallback<? super V>) - Static method in class com.google.common.util.concurrent.Futures
Registers separate success and failure callbacks to be run when the Future's computation is complete or, if the computation is already complete, immediately.
addCallback(ListenableFuture<V>, FutureCallback<? super V>, Executor) - Static method in class com.google.common.util.concurrent.Futures
Registers separate success and failure callbacks to be run when the Future's computation is complete or, if the computation is already complete, immediately.
addCopies(E, int) - Method in class com.google.common.collect.ImmutableMultiset.Builder
Adds a number of occurrences of an element to this ImmutableMultiset.
addCopies(E, int) - Method in class com.google.common.collect.ImmutableSortedMultiset.Builder
Adds a number of occurrences of an element to this ImmutableSortedMultiset.
addDelayedShutdownHook(ExecutorService, long, TimeUnit) - Static method in class com.google.common.util.concurrent.MoreExecutors
Add a shutdown hook to wait for thread completion in the given service.
addEscape(char, String) - Method in class com.google.common.escape.CharEscaperBuilder
Add a new mapping from an index to an object to the escaping.
addEscape(char, String) - Method in class com.google.common.escape.Escapers.Builder
Adds a replacement string for the given input character.
addEscapes(char[], String) - Method in class com.google.common.escape.CharEscaperBuilder
Add multiple mappings at once for a particular index.
addFirst(E) - Method in class com.google.common.collect.ForwardingDeque
 
addLast(E) - Method in class com.google.common.collect.ForwardingDeque
 
addListener(Service.Listener, Executor) - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
 
addListener(Runnable, Executor) - Method in class com.google.common.util.concurrent.AbstractFuture
Registers a listener to be run on the given executor.
addListener(Service.Listener, Executor) - Method in class com.google.common.util.concurrent.AbstractIdleService
 
addListener(Service.Listener, Executor) - Method in class com.google.common.util.concurrent.AbstractScheduledService
 
addListener(Service.Listener, Executor) - Method in class com.google.common.util.concurrent.AbstractService
 
addListener(Runnable, Executor) - Method in class com.google.common.util.concurrent.ForwardingListenableFuture
 
addListener(Runnable, Executor) - Method in interface com.google.common.util.concurrent.ListenableFuture
Registers a listener to be run on the given executor.
addListener(Runnable, Executor) - Method in class com.google.common.util.concurrent.ListenableFutureTask
 
addListener(Service.Listener, Executor) - Method in interface com.google.common.util.concurrent.Service
Registers a Service.Listener to be executed on the given executor.
addListener(ServiceManager.Listener, Executor) - Method in class com.google.common.util.concurrent.ServiceManager
Registers a ServiceManager.Listener to be executed on the given executor.
addListener(ServiceManager.Listener) - Method in class com.google.common.util.concurrent.ServiceManager
Registers a ServiceManager.Listener to be run when this ServiceManager changes state.
addValue(Object) - Method in class com.google.common.base.Objects.ToStringHelper
Adds an unnamed value to the formatted output.
addValue(boolean) - Method in class com.google.common.base.Objects.ToStringHelper
Adds an unnamed value to the formatted output.
addValue(char) - Method in class com.google.common.base.Objects.ToStringHelper
Adds an unnamed value to the formatted output.
addValue(double) - Method in class com.google.common.base.Objects.ToStringHelper
Adds an unnamed value to the formatted output.
addValue(float) - Method in class com.google.common.base.Objects.ToStringHelper
Adds an unnamed value to the formatted output.
addValue(int) - Method in class com.google.common.base.Objects.ToStringHelper
Adds an unnamed value to the formatted output.
addValue(long) - Method in class com.google.common.base.Objects.ToStringHelper
Adds an unnamed value to the formatted output.
adler32() - Static method in class com.google.common.hash.Hashing
Returns a hash function implementing the Adler-32 checksum algorithm (32 hash bits) by delegating to the Adler32 Checksum.
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.
AGE - Static variable in class com.google.common.net.HttpHeaders
The HTTP Age header field name.
all(Iterable<T>, Predicate<? super T>) - Static method in class com.google.common.collect.Iterables
Returns true if every element in iterable satisfies the predicate.
all(Iterator<T>, Predicate<? super T>) - Static method in class com.google.common.collect.Iterators
Returns true if every element returned by iterator satisfies the given predicate.
all() - Static method in class com.google.common.collect.Range
Returns a range that contains every value of type C.
allAsList(ListenableFuture<? extends V>...) - Static method in class com.google.common.util.concurrent.Futures
Creates a new ListenableFuture whose value is a list containing the values of all its input futures, if all succeed.
allAsList(Iterable<? extends ListenableFuture<? extends V>>) - Static method in class com.google.common.util.concurrent.Futures
Creates a new ListenableFuture whose value is a list containing the values of all its input futures, if all succeed.
allEqual() - Static method in class com.google.common.collect.Ordering
Returns an ordering which treats all values as equal, indicating "no ordering." Passing this ordering to any stable sort algorithm results in no change to the order of elements.
allMatch(Predicate<? super E>) - Method in class com.google.common.collect.FluentIterable
Returns true if every element in this fluent iterable satisfies the predicate.
ALLOW - Static variable in class com.google.common.net.HttpHeaders
The HTTP Allow header field name.
AllowConcurrentEvents - Annotation Type in com.google.common.eventbus
Marks an event subscriber method as being thread-safe.
allPrimitiveTypes() - Static method in class com.google.common.primitives.Primitives
Returns an immutable set of all nine primitive types (including void).
allWrapperTypes() - Static method in class com.google.common.primitives.Primitives
Returns an immutable set of all nine primitive-wrapper types (including Void).
alwaysFalse() - Static method in class com.google.common.base.Predicates
Returns a predicate that always evaluates to false.
alwaysTrue() - Static method in class com.google.common.base.Predicates
Returns a predicate that always evaluates to true.
and(CharMatcher) - Method in class com.google.common.base.CharMatcher
Returns a matcher that matches any character matched by both this matcher and other.
and(Iterable<? extends Predicate<? super T>>) - Static method in class com.google.common.base.Predicates
Returns a predicate that evaluates to true if each of its components evaluates to true.
and(Predicate<? super T>...) - Static method in class com.google.common.base.Predicates
Returns a predicate that evaluates to true if each of its components evaluates to true.
and(Predicate<? super T>, Predicate<? super T>) - Static method in class com.google.common.base.Predicates
Returns a predicate that evaluates to true if both of its components evaluate to true.
andThen(Converter<B, C>) - Method in class com.google.common.base.Converter
Returns a converter whose convert method applies secondConverter to the result of this converter.
ANY - Static variable in class com.google.common.base.CharMatcher
Matches any character.
any(Iterable<T>, Predicate<? super T>) - Static method in class com.google.common.collect.Iterables
Returns true if any element in iterable satisfies the predicate.
any(Iterator<T>, Predicate<? super T>) - Static method in class com.google.common.collect.Iterators
Returns true if one or more elements returned by iterator satisfy the given predicate.
ANY_APPLICATION_TYPE - Static variable in class com.google.common.net.MediaType
 
ANY_AUDIO_TYPE - Static variable in class com.google.common.net.MediaType
 
ANY_IMAGE_TYPE - Static variable in class com.google.common.net.MediaType
 
ANY_TEXT_TYPE - Static variable in class com.google.common.net.MediaType
 
ANY_TYPE - Static variable in class com.google.common.net.MediaType
 
ANY_VIDEO_TYPE - Static variable in class com.google.common.net.MediaType
 
anyMatch(Predicate<? super E>) - Method in class com.google.common.collect.FluentIterable
Returns true if any element in this fluent iterable satisfies the predicate.
anyOf(CharSequence) - Static method in class com.google.common.base.CharMatcher
Returns a char matcher that matches any character present in the given character sequence.
append(CharSequence, File, Charset) - Static method in class com.google.common.io.Files
Appends a character sequence (such as a string) to a file using the given character set.
appendTo(A, Iterable<?>) - Method in class com.google.common.base.Joiner
Appends the string representation of each of parts, using the previously configured separator between each, to appendable.
appendTo(A, Iterator<?>) - Method in class com.google.common.base.Joiner
Appends the string representation of each of parts, using the previously configured separator between each, to appendable.
appendTo(A, Object[]) - Method in class com.google.common.base.Joiner
Appends the string representation of each of parts, using the previously configured separator between each, to appendable.
appendTo(A, Object, Object, Object...) - Method in class com.google.common.base.Joiner
Appends to appendable the string representation of each of the remaining arguments.
appendTo(StringBuilder, Iterable<?>) - Method in class com.google.common.base.Joiner
Appends the string representation of each of parts, using the previously configured separator between each, to builder.
appendTo(StringBuilder, Iterator<?>) - Method in class com.google.common.base.Joiner
Appends the string representation of each of parts, using the previously configured separator between each, to builder.
appendTo(StringBuilder, Object[]) - Method in class com.google.common.base.Joiner
Appends the string representation of each of parts, using the previously configured separator between each, to builder.
appendTo(StringBuilder, Object, Object, Object...) - Method in class com.google.common.base.Joiner
Appends to builder the string representation of each of the remaining arguments.
appendTo(A, Map<?, ?>) - Method in class com.google.common.base.Joiner.MapJoiner
Appends the string representation of each entry of map, using the previously configured separator and key-value separator, to appendable.
appendTo(StringBuilder, Map<?, ?>) - Method in class com.google.common.base.Joiner.MapJoiner
Appends the string representation of each entry of map, using the previously configured separator and key-value separator, to builder.
appendTo(A, Iterable<? extends Map.Entry<?, ?>>) - Method in class com.google.common.base.Joiner.MapJoiner
Appends the string representation of each entry in entries, using the previously configured separator and key-value separator, to appendable.
appendTo(A, Iterator<? extends Map.Entry<?, ?>>) - Method in class com.google.common.base.Joiner.MapJoiner
Appends the string representation of each entry in entries, using the previously configured separator and key-value separator, to appendable.
appendTo(StringBuilder, Iterable<? extends Map.Entry<?, ?>>) - Method in class com.google.common.base.Joiner.MapJoiner
Appends the string representation of each entry in entries, using the previously configured separator and key-value separator, to builder.
appendTo(StringBuilder, Iterator<? extends Map.Entry<?, ?>>) - Method in class com.google.common.base.Joiner.MapJoiner
Appends the string representation of each entry in entries, using the previously configured separator and key-value separator, to builder.
APPLICATION_BINARY - Static variable in class com.google.common.net.MediaType
This is a non-standard media type, but is commonly used in serving hosted binary files as it is known not to trigger content sniffing in current browsers.
APPLICATION_XML_UTF_8 - Static variable in class com.google.common.net.MediaType
As described in RFC 3023, this constant (application/xml) is used for XML documents that are "unreadable by casual users." MediaType.XML_UTF_8 is provided for documents that may be read by users.
apply(Character) - Method in class com.google.common.base.CharMatcher
Deprecated.
Provided only to satisfy the Predicate interface; use CharMatcher.matches(char) instead.
apply(A) - Method in class com.google.common.base.Converter
Deprecated.
Provided to satisfy the Function interface; use Converter.convert(A) instead.
apply(F) - Method in interface com.google.common.base.Function
Returns the result of applying this function to input.
apply(T) - Method in interface com.google.common.base.Predicate
Returns the result of applying this predicate to input.
apply(K) - Method in class com.google.common.cache.AbstractLoadingCache
 
apply(K) - Method in class com.google.common.cache.ForwardingLoadingCache
 
apply(K) - Method in interface com.google.common.cache.LoadingCache
Deprecated.
Provided to satisfy the Function interface; use LoadingCache.get(K) or LoadingCache.getUnchecked(K) instead.
apply(C) - Method in class com.google.common.collect.Range
Deprecated.
Provided only to satisfy the Predicate interface; use Range.contains(C) instead.
apply(T) - Method in class com.google.common.hash.BloomFilter
Deprecated.
Provided only to satisfy the Predicate interface; use BloomFilter.mightContain(T) instead.
apply(I) - Method in interface com.google.common.util.concurrent.AsyncFunction
Returns an output Future to use in place of the given input.
arbitrary() - Static method in class com.google.common.collect.Ordering
Returns an arbitrary ordering over all objects, for which compare(a, b) == 0 implies a == b (identity equality).
areEqual() - Method in interface com.google.common.collect.MapDifference
Returns true if there are no differences between the two maps; that is, if the maps are equal.
ArrayBasedCharEscaper - Class in com.google.common.escape
A CharEscaper that uses an array to quickly look up replacement characters for a given char value.
ArrayBasedCharEscaper(Map<Character, String>, char, char) - Constructor for class com.google.common.escape.ArrayBasedCharEscaper
Creates a new ArrayBasedCharEscaper instance with the given replacement map and specified safe range.
ArrayBasedCharEscaper(ArrayBasedEscaperMap, char, char) - Constructor for class com.google.common.escape.ArrayBasedCharEscaper
Creates a new ArrayBasedCharEscaper instance with the given replacement map and specified safe range.
ArrayBasedEscaperMap - Class in com.google.common.escape
An implementation-specific parameter class suitable for initializing ArrayBasedCharEscaper or ArrayBasedUnicodeEscaper instances.
ArrayBasedUnicodeEscaper - Class in com.google.common.escape
A UnicodeEscaper that uses an array to quickly look up replacement characters for a given code point.
ArrayBasedUnicodeEscaper(Map<Character, String>, int, int, String) - Constructor for class com.google.common.escape.ArrayBasedUnicodeEscaper
Creates a new ArrayBasedUnicodeEscaper instance with the given replacement map and specified safe range.
ArrayBasedUnicodeEscaper(ArrayBasedEscaperMap, int, int, String) - Constructor for class com.google.common.escape.ArrayBasedUnicodeEscaper
Creates a new ArrayBasedUnicodeEscaper instance with the given replacement map and specified safe range.
ArrayListMultimap<K,V> - Class in com.google.common.collect
Implementation of Multimap that uses an ArrayList to store the values for a given key.
arrayListValues() - Method in class com.google.common.collect.MultimapBuilder.MultimapBuilderWithKeys
Uses an ArrayList to store value collections.
arrayListValues(int) - Method in class com.google.common.collect.MultimapBuilder.MultimapBuilderWithKeys
Uses an ArrayList to store value collections, initialized to expect the specified number of values per key.
ArrayTable<R,C,V> - Class in com.google.common.collect
Fixed-size Table implementation backed by a two-dimensional array.
asBytes() - Method in class com.google.common.hash.HashCode
Returns the value of this hash code as a byte array.
asByteSink(OutputSupplier<? extends OutputStream>) - Static method in class com.google.common.io.ByteStreams
Deprecated.
Convert all OutputSupplier<? extends OutputStream> implementations to extend ByteSink or provide a method for viewing the object as a ByteSink. This method is scheduled for removal in Guava 18.0.
asByteSink(File, FileWriteMode...) - Static method in class com.google.common.io.Files
Returns a new ByteSink for writing bytes to the given file.
asByteSource(InputSupplier<? extends InputStream>) - Static method in class com.google.common.io.ByteStreams
Deprecated.
Convert all InputSupplier<? extends InputStream> implementations to extend ByteSource or provide a method for viewing the object as a ByteSource. This method is scheduled for removal in Guava 18.0.
asByteSource() - Method in class com.google.common.io.FileBackedOutputStream
Returns a readable ByteSource view of the data that has been written to this stream.
asByteSource(File) - Static method in class com.google.common.io.Files
Returns a new ByteSource for reading bytes from the given file.
asByteSource(URL) - Static method in class com.google.common.io.Resources
Returns a ByteSource that reads from the given URL.
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(OutputSupplier<? extends Appendable>) - Static method in class com.google.common.io.CharStreams
Deprecated.
Convert all OutputSupplier<? extends Appendable> implementations to extend CharSink or provide a method for viewing the object as a CharSink. This method is scheduled for removal in Guava 18.0.
asCharSink(File, Charset, FileWriteMode...) - Static method in class com.google.common.io.Files
Returns a new CharSink for writing character data to the given file using the given character set.
asCharSource(Charset) - Method in class com.google.common.io.ByteSource
Returns a CharSource view of this byte source that decodes bytes read from this source as characters using the given Charset.
asCharSource(InputSupplier<? extends Readable>) - Static method in class com.google.common.io.CharStreams
Deprecated.
Convert all InputSupplier<? extends Readable> implementations to extend CharSource or provide a method for viewing the object as a CharSource. This method is scheduled for removal in Guava 18.0.
asCharSource(File, Charset) - Static method in class com.google.common.io.Files
Returns a new CharSource for reading character data from the given file using the given character set.
asCharSource(URL, Charset) - Static method in class com.google.common.io.Resources
Returns a CharSource that reads from the given URL using the given character set.
Ascii - Class in com.google.common.base
Static methods pertaining to ASCII characters (those in the range of values 0x00 through 0x7F), and to strings containing such characters.
ASCII - Static variable in class com.google.common.base.CharMatcher
Determines whether a character is ASCII, meaning that its code point is less than 128.
asConverter(BiMap<A, B>) - Static method in class com.google.common.collect.Maps
Returns a Converter that converts values using bimap.get(), and whose inverse view converts values using bimap.inverse().get().
asEnumeration(Iterator<T>) - Static method in class com.google.common.collect.Iterators
Adapts an Iterator to the Enumeration interface.
asFunction(Interner<E>) - Static method in class com.google.common.collect.Interners
Returns a function that delegates to the Interner.intern(E) method of the given interner.
asFunction() - Method in class com.google.common.escape.Escaper
Returns a Function that invokes Escaper.escape(String) on this escaper.
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 a list view of the collection.
asList() - Method in class com.google.common.collect.ImmutableList
Returns this list instance.
asList(E, E[]) - Static method in class com.google.common.collect.Lists
Returns an unmodifiable list containing the specified first element and backed by the specified array of additional elements.
asList(E, E, E[]) - Static method in class com.google.common.collect.Lists
Returns an unmodifiable list containing the specified first and second element, and backed by the specified array of additional elements.
asList(boolean...) - Static method in class com.google.common.primitives.Booleans
Returns a fixed-size list backed by the specified array, similar to Arrays.asList(Object[]).
asList(byte...) - Static method in class com.google.common.primitives.Bytes
Returns a fixed-size list backed by the specified array, similar to Arrays.asList(Object[]).
asList(char...) - Static method in class com.google.common.primitives.Chars
Returns a fixed-size list backed by the specified array, similar to Arrays.asList(Object[]).
asList(double...) - Static method in class com.google.common.primitives.Doubles
Returns a fixed-size list backed by the specified array, similar to Arrays.asList(Object[]).
asList(float...) - Static method in class com.google.common.primitives.Floats
Returns a fixed-size list backed by the specified array, similar to Arrays.asList(Object[]).
asList(int...) - Static method in class com.google.common.primitives.Ints
Returns a fixed-size list backed by the specified array, similar to Arrays.asList(Object[]).
asList(long...) - Static method in class com.google.common.primitives.Longs
Returns a fixed-size list backed by the specified array, similar to Arrays.asList(Object[]).
asList(short...) - Static method in class com.google.common.primitives.Shorts
Returns a fixed-size list backed by the specified array, similar to Arrays.asList(Object[]).
asLong() - Method in class com.google.common.hash.HashCode
Returns the first eight bytes of this hashcode's bytes, converted to a long value in little-endian order.
asMap() - Method in class com.google.common.cache.AbstractCache
 
asMap() - Method in interface com.google.common.cache.Cache
Returns a view of the entries stored in this cache as a thread-safe map.
asMap() - Method in class com.google.common.cache.ForwardingCache
 
asMap() - Method in interface com.google.common.cache.LoadingCache
Returns a view of the entries stored in this cache as a thread-safe map.
asMap() - Method in class com.google.common.collect.ForwardingMultimap
 
asMap() - Method in class com.google.common.collect.ImmutableMultimap
Returns an immutable map that associates each key with its corresponding values in the multimap.
asMap() - Method in interface com.google.common.collect.ListMultimap
Returns a view of this multimap as a Map from each distinct key to the nonempty collection of that key's associated values.
asMap(Set<K>, Function<? super K, V>) - Static method in class com.google.common.collect.Maps
Returns a live Map view whose keys are the contents of set and whose values are computed on demand using function.
asMap(SortedSet<K>, Function<? super K, V>) - Static method in class com.google.common.collect.Maps
Returns a view of the sorted set as a map, mapping keys from the set according to the specified function.
asMap(NavigableSet<K>, Function<? super K, V>) - Static method in class com.google.common.collect.Maps
Returns a view of the navigable set as a map, mapping keys from the set according to the specified function.
asMap() - Method in interface com.google.common.collect.Multimap
Returns a view of this multimap as a Map from each distinct key to the nonempty collection of that key's associated values.
asMap(ListMultimap<K, V>) - Static method in class com.google.common.collect.Multimaps
Returns multimap.asMap(), with its type corrected from Map<K, Collection<V>> to Map<K, List<V>>.
asMap(SetMultimap<K, V>) - Static method in class com.google.common.collect.Multimaps
Returns multimap.asMap(), with its type corrected from Map<K, Collection<V>> to Map<K, Set<V>>.
asMap(SortedSetMultimap<K, V>) - Static method in class com.google.common.collect.Multimaps
Returns multimap.asMap(), with its type corrected from Map<K, Collection<V>> to Map<K, SortedSet<V>>.
asMap(Multimap<K, V>) - Static method in class com.google.common.collect.Multimaps
asMap() - Method in interface com.google.common.collect.SetMultimap
Returns a view of this multimap as a Map from each distinct key to the nonempty collection of that key's associated values.
asMap() - Method in interface com.google.common.collect.SortedSetMultimap
Returns a map view that associates each key with the corresponding values in the multimap.
asMap() - Method in class com.google.common.collect.TreeMultimap
Returns a map view that associates each key with the corresponding values in the multimap.
asMap() - Method in class com.google.common.util.concurrent.AtomicLongMap
Returns a live, read-only view of the map backing this AtomicLongMap.
asMapOfRanges() - Method in class com.google.common.collect.ImmutableRangeMap
 
asMapOfRanges() - Method in interface com.google.common.collect.RangeMap
Returns a view of this range map as an unmodifiable Map<Range<K>, V>.
asMapOfRanges() - Method in class com.google.common.collect.TreeRangeMap
 
asMultimap() - Method in class com.google.common.collect.ImmutableMap
Returns a multimap view of the map.
asOutputStream(PrimitiveSink) - Static method in class com.google.common.hash.Funnels
Wraps a PrimitiveSink as an OutputStream, so it is easy to funnel an object to a PrimitiveSink if there is already a way to write the contents of the object to an OutputStream.
asRanges() - Method in class com.google.common.collect.ImmutableRangeSet
 
asRanges() - Method in interface com.google.common.collect.RangeSet
Returns a view of the disconnected ranges that make up this range set.
asRanges() - Method in class com.google.common.collect.TreeRangeSet
 
asSet() - Method in class com.google.common.base.Optional
Returns an immutable singleton Set whose only element is the contained instance if it is present; an empty immutable Set otherwise.
asSet(DiscreteDomain<C>) - Method in class com.google.common.collect.ImmutableRangeSet
Returns an ImmutableSortedSet containing the same values in the given domain contained by this range set.
assignableFrom(Class<?>) - Static method in class com.google.common.base.Predicates
Returns a predicate that evaluates to true if the class being tested is assignable from the given class.
asWriter(Appendable) - Static method in class com.google.common.io.CharStreams
Returns a Writer that sends all output to the given Appendable target.
AsyncEventBus - Class in com.google.common.eventbus
An EventBus that takes the Executor of your choice and uses it to dispatch events, allowing dispatch to occur asynchronously.
AsyncEventBus(String, Executor) - Constructor for class com.google.common.eventbus.AsyncEventBus
Creates a new AsyncEventBus that will use executor to dispatch events.
AsyncEventBus(Executor, SubscriberExceptionHandler) - Constructor for class com.google.common.eventbus.AsyncEventBus
Creates a new AsyncEventBus that will use executor to dispatch events.
AsyncEventBus(Executor) - Constructor for class com.google.common.eventbus.AsyncEventBus
Creates a new AsyncEventBus that will use executor to dispatch events.
AsyncFunction<I,O> - Interface in com.google.common.util.concurrent
Transforms a value, possibly asynchronously.
asynchronous(RemovalListener<K, V>, Executor) - Static method in class com.google.common.cache.RemovalListeners
Returns a RemovalListener which processes all eviction notifications using executor.
asyncReloading(CacheLoader<K, V>, Executor) - Static method in class com.google.common.cache.CacheLoader
Returns a CacheLoader which wraps loader, executing calls to CacheLoader.reload(K, V) using executor.
at(int, int) - Method in class com.google.common.collect.ArrayTable
Returns the value corresponding to the specified row and column indices.
atLeast(C) - Static method in class com.google.common.collect.Range
Returns a range that contains all values greater than or equal to endpoint.
atMost(C) - Static method in class com.google.common.collect.Range
Returns a range that contains all values less than or equal to endpoint.
ATOM_UTF_8 - Static variable in class com.google.common.net.MediaType
 
AtomicDouble - Class in com.google.common.util.concurrent
A double value that may be updated atomically.
AtomicDouble(double) - Constructor for class com.google.common.util.concurrent.AtomicDouble
Creates a new AtomicDouble with the given initial value.
AtomicDouble() - Constructor for class com.google.common.util.concurrent.AtomicDouble
Creates a new AtomicDouble with initial value 0.0.
AtomicDoubleArray - Class in com.google.common.util.concurrent
A double array in which elements may be updated atomically.
AtomicDoubleArray(int) - Constructor for class com.google.common.util.concurrent.AtomicDoubleArray
Creates a new AtomicDoubleArray of the given length, with all elements initially zero.
AtomicDoubleArray(double[]) - Constructor for class com.google.common.util.concurrent.AtomicDoubleArray
Creates a new AtomicDoubleArray with the same length as, and all elements copied from, the given array.
AtomicLongMap<K> - Class in com.google.common.util.concurrent
A map containing long values that can be atomically updated.
Atomics - Class in com.google.common.util.concurrent
Static utility methods pertaining to classes in the java.util.concurrent.atomic package.
AUTHORIZATION - Static variable in class com.google.common.net.HttpHeaders
The HTTP Authorization header field name.
averageLoadPenalty() - Method in class com.google.common.cache.CacheStats
Returns the average time spent loading new values.
awaitHealthy() - Method in class com.google.common.util.concurrent.ServiceManager
Waits for the ServiceManager to become healthy.
awaitHealthy(long, TimeUnit) - Method in class com.google.common.util.concurrent.ServiceManager
Waits for the ServiceManager to become healthy for no more than the given time.
awaitRunning() - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
 
awaitRunning(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
 
awaitRunning() - Method in class com.google.common.util.concurrent.AbstractIdleService
 
awaitRunning(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractIdleService
 
awaitRunning() - Method in class com.google.common.util.concurrent.AbstractScheduledService
 
awaitRunning(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractScheduledService
 
awaitRunning() - Method in class com.google.common.util.concurrent.AbstractService
 
awaitRunning(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractService
 
awaitRunning() - Method in interface com.google.common.util.concurrent.Service
Waits for the Service to reach the running state.
awaitRunning(long, TimeUnit) - Method in interface com.google.common.util.concurrent.Service
Waits for the Service to reach the running state for no more than the given time.
awaitStopped() - Method in class com.google.common.util.concurrent.ServiceManager
Waits for the all the services to reach a terminal state.
awaitStopped(long, TimeUnit) - Method in class com.google.common.util.concurrent.ServiceManager
Waits for the all the services to reach a terminal state for no more than the given time.
awaitTerminated() - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
 
awaitTerminated(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
 
awaitTerminated() - Method in class com.google.common.util.concurrent.AbstractIdleService
 
awaitTerminated(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractIdleService
 
awaitTerminated() - Method in class com.google.common.util.concurrent.AbstractScheduledService
 
awaitTerminated(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractScheduledService
 
awaitTerminated() - Method in class com.google.common.util.concurrent.AbstractService
 
awaitTerminated(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractService
 
awaitTerminated() - Method in interface com.google.common.util.concurrent.Service
Waits for the Service to reach the terminated state.
awaitTerminated(long, TimeUnit) - Method in interface com.google.common.util.concurrent.Service
Waits for the Service to reach a terminal state (either terminated or failed) for no more than the given time.
awaitTermination(long, TimeUnit) - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
awaitUninterruptibly(CountDownLatch) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes latch.await() uninterruptibly.
awaitUninterruptibly(CountDownLatch, long, TimeUnit) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes latch.await(timeout, unit) uninterruptibly.

B

base16() - Static method in class com.google.common.io.BaseEncoding
The "base16" encoding specified by RFC 4648 section 8, Base 16 Encoding.
base32() - Static method in class com.google.common.io.BaseEncoding
The "base32" encoding specified by RFC 4648 section 6, Base 32 Encoding.
base32Hex() - Static method in class com.google.common.io.BaseEncoding
The "base32hex" encoding specified by RFC 4648 section 7, Base 32 Encoding with Extended Hex Alphabet.
base64() - Static method in class com.google.common.io.BaseEncoding
The "base64" base encoding specified by RFC 4648 section 4, Base 64 Encoding.
base64Url() - Static method in class com.google.common.io.BaseEncoding
The "base64url" encoding specified by RFC 4648 section 5, Base 64 Encoding with URL and Filename Safe Alphabet, also sometimes referred to as the "web safe Base64." (This is the same as the base 64 encoding with URL and filename safe alphabet from RFC 3548.)
BaseEncoding - Class in com.google.common.io
A binary encoding scheme for reversibly translating between byte sequences and printable ASCII strings.
BaseEncoding.DecodingException - Exception in com.google.common.io
Exception indicating invalid base-encoded input encountered while decoding.
BEL - Static variable in class com.google.common.base.Ascii
Bell ('\a'): A character for use when there is a need to call for human attention.
Beta - Annotation Type in com.google.common.annotations
Signifies that a public API (public class, method or field) is subject to incompatible changes, or even removal, in a future release.
BigIntegerMath - Class in com.google.common.math
A class for arithmetic on values of type BigInteger.
bigIntegers() - Static method in class com.google.common.collect.DiscreteDomain
Returns the discrete domain for values of type BigInteger.
bigIntegerValue() - Method in class com.google.common.primitives.UnsignedInteger
Returns the value of this UnsignedInteger as a BigInteger.
bigIntegerValue() - Method in class com.google.common.primitives.UnsignedLong
Returns the value of this UnsignedLong as a BigInteger.
BiMap<K,V> - Interface in com.google.common.collect
A bimap (or "bidirectional map") is a map that preserves the uniqueness of its values as well as that of its keys.
binarySearch(List<? extends T>, T) - Method in class com.google.common.collect.Ordering
Searches sortedList for key using the binary search algorithm.
BinaryTreeTraverser<T> - Class in com.google.common.collect
A variant of TreeTraverser for binary trees, providing additional traversals specific to binary trees.
BinaryTreeTraverser() - Constructor for class com.google.common.collect.BinaryTreeTraverser
 
binomial(int, int) - Static method in class com.google.common.math.BigIntegerMath
Returns n choose k, also known as the binomial coefficient of n and k, that is, n! / (k! (n - k)!).
binomial(int, int) - Static method in class com.google.common.math.IntMath
Returns n choose k, also known as the binomial coefficient of n and k, or Integer.MAX_VALUE if the result does not fit in an int.
binomial(int, int) - Static method in class com.google.common.math.LongMath
Returns n choose k, also known as the binomial coefficient of n and k, or Long.MAX_VALUE if the result does not fit in a long.
bits() - Method in class com.google.common.hash.HashCode
Returns the number of bits in this hash code; a positive multiple of 8.
bits() - Method in interface com.google.common.hash.HashFunction
Returns the number of bits (a multiple of 32) that each hash code produced by this hash function has.
BloomFilter<T> - Class in com.google.common.hash
A Bloom filter for instances of T.
BMP - Static variable in class com.google.common.net.MediaType
 
Booleans - Class in com.google.common.primitives
Static utility methods pertaining to boolean primitives, that are not already found in either Boolean or Arrays.
BoundType - Enum in com.google.common.collect
Indicates whether an endpoint of some range is contained in the range itself ("closed") or not ("open").
breadthFirstTraversal(T) - Method in class com.google.common.collect.TreeTraverser
Returns an unmodifiable iterable over the nodes in a tree structure, using breadth-first traversal.
BREAKING_WHITESPACE - Static variable in class com.google.common.base.CharMatcher
Determines whether a character is a breaking whitespace (that is, a whitespace which can be interpreted as a break between words for formatting purposes).
BS - Static variable in class com.google.common.base.Ascii
Backspace ('\b'): A format effector which controls the movement of the printing position one printing space backward on the same printing line.
build(CacheLoader<? super K1, V1>) - Method in class com.google.common.cache.CacheBuilder
Builds a cache, which either returns an already-loaded value for a given key or atomically computes or retrieves it using the supplied CacheLoader.
build() - Method in class com.google.common.cache.CacheBuilder
Builds a cache which does not automatically load values when keys are requested.
build() - Method in class com.google.common.collect.ImmutableBiMap.Builder
Returns a newly-created immutable bimap.
build() - Method in class com.google.common.collect.ImmutableClassToInstanceMap.Builder
Returns a new immutable class-to-instance map containing the entries provided to this builder.
build() - Method in class com.google.common.collect.ImmutableCollection.Builder
Returns a newly-created ImmutableCollection of the appropriate type, containing the elements provided to this builder.
build() - Method in class com.google.common.collect.ImmutableList.Builder
Returns a newly-created ImmutableList based on the contents of the Builder.
build() - Method in class com.google.common.collect.ImmutableListMultimap.Builder
Returns a newly-created immutable list multimap.
build() - Method in class com.google.common.collect.ImmutableMap.Builder
Returns a newly-created immutable map.
build() - Method in class com.google.common.collect.ImmutableMultimap.Builder
Returns a newly-created immutable multimap.
build() - Method in class com.google.common.collect.ImmutableMultiset.Builder
Returns a newly-created ImmutableMultiset based on the contents of the Builder.
build() - Method in class com.google.common.collect.ImmutableRangeMap.Builder
Returns an ImmutableRangeMap containing the associations previously added to this builder.
build() - Method in class com.google.common.collect.ImmutableRangeSet.Builder
Returns an ImmutableRangeSet containing the ranges added to this builder.
build() - Method in class com.google.common.collect.ImmutableSet.Builder
Returns a newly-created ImmutableSet based on the contents of the Builder.
build() - Method in class com.google.common.collect.ImmutableSetMultimap.Builder
Returns a newly-created immutable set multimap.
build() - Method in class com.google.common.collect.ImmutableSortedMap.Builder
Returns a newly-created immutable sorted map.
build() - Method in class com.google.common.collect.ImmutableSortedMultiset.Builder
Returns a newly-created ImmutableSortedMultiset based on the contents of the Builder.
build() - Method in class com.google.common.collect.ImmutableSortedSet.Builder
Returns a newly-created ImmutableSortedSet based on the contents of the Builder and its comparator.
build() - Method in class com.google.common.collect.ImmutableTable.Builder
Returns a newly-created immutable table.
build() - Method in class com.google.common.collect.MultimapBuilder
Returns a new, empty Multimap with the specified implementation.
build(Multimap<? extends K, ? extends V>) - Method in class com.google.common.collect.MultimapBuilder
Returns a Multimap with the specified implementation, initialized with the entries of multimap.
build() - Method in class com.google.common.collect.MultimapBuilder.ListMultimapBuilder
 
build(Multimap<? extends K, ? extends V>) - Method in class com.google.common.collect.MultimapBuilder.ListMultimapBuilder
 
build() - Method in class com.google.common.collect.MultimapBuilder.SetMultimapBuilder
 
build(Multimap<? extends K, ? extends V>) - Method in class com.google.common.collect.MultimapBuilder.SetMultimapBuilder
 
build() - Method in class com.google.common.collect.MultimapBuilder.SortedSetMultimapBuilder
 
build(Multimap<? extends K, ? extends V>) - Method in class com.google.common.collect.MultimapBuilder.SortedSetMultimapBuilder
 
build() - Method in class com.google.common.escape.Escapers.Builder
Returns a new escaper based on the current state of the builder.
build() - Method in class com.google.common.reflect.ImmutableTypeToInstanceMap.Builder
Returns a new immutable type-to-instance map containing the entries provided to this builder.
build() - Method in class com.google.common.util.concurrent.ThreadFactoryBuilder
Returns a new thread factory using the options supplied during the building process.
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.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.reflect.ImmutableTypeToInstanceMap
Returns a new builder.
bulkGet(Iterable<?>) - Method in class com.google.common.util.concurrent.Striped
Returns the stripes that correspond to the passed objects, in ascending (as per Striped.getAt(int)) order.
ByteArrayDataInput - Interface in com.google.common.io
An extension of DataInput for reading from in-memory byte arrays; its methods offer identical functionality but do not throw IOException.
ByteArrayDataOutput - Interface in com.google.common.io
An extension of DataOutput for writing to in-memory byte arrays; its methods offer identical functionality but do not throw IOException.
byteArrayFunnel() - Static method in class com.google.common.hash.Funnels
Returns a funnel that extracts the bytes from a byte array.
ByteProcessor<T> - Interface in com.google.common.io
A callback interface to process bytes from a stream.
Bytes - Class in com.google.common.primitives
Static utility methods pertaining to byte primitives, that are not already found in either Byte or Arrays, and interpret bytes as neither signed nor unsigned.
BYTES - Static variable in class com.google.common.primitives.Chars
The number of bytes required to represent a primitive char value.
BYTES - Static variable in class com.google.common.primitives.Doubles
The number of bytes required to represent a primitive double value.
BYTES - Static variable in class com.google.common.primitives.Floats
The number of bytes required to represent a primitive float value.
BYTES - Static variable in class com.google.common.primitives.Ints
The number of bytes required to represent a primitive int value.
BYTES - Static variable in class com.google.common.primitives.Longs
The number of bytes required to represent a primitive long value.
BYTES - Static variable in class com.google.common.primitives.Shorts
The number of bytes required to represent a primitive short value.
ByteSink - Class in com.google.common.io
A destination to which bytes can be written, such as a file.
ByteSink() - Constructor for class com.google.common.io.ByteSink
Constructor for use by subclasses.
ByteSource - Class in com.google.common.io
A readable source of bytes, such as a file.
ByteSource() - Constructor for class com.google.common.io.ByteSource
Constructor for use by subclasses.
ByteStreams - Class in com.google.common.io
Provides utility methods for working with byte arrays and I/O streams.
BZIP2 - Static variable in class com.google.common.net.MediaType
 

C

Cache<K,V> - Interface in com.google.common.cache
A semi-persistent mapping from keys to values.
CACHE_CONTROL - Static variable in class com.google.common.net.HttpHeaders
The HTTP Cache-Control header field name.
CACHE_MANIFEST_UTF_8 - Static variable in class com.google.common.net.MediaType
 
CacheBuilder<K,V> - Class in com.google.common.cache
A builder of LoadingCache and Cache instances having any combination of the following features: automatic loading of entries into the cache least-recently-used eviction when a maximum size is exceeded time-based expiration of entries, measured since last access or last write keys automatically wrapped in weak references values automatically wrapped in weak or soft references notification of evicted (or otherwise removed) entries accumulation of cache access statistics
CacheBuilderSpec - Class in com.google.common.cache
A specification of a CacheBuilder configuration.
CacheLoader<K,V> - Class in com.google.common.cache
Computes or retrieves values, based on a key, for use in populating a LoadingCache.
CacheLoader() - Constructor for class com.google.common.cache.CacheLoader
Constructor for use by subclasses.
CacheLoader.InvalidCacheLoadException - Exception in com.google.common.cache
Thrown to indicate that an invalid response was returned from a call to CacheLoader.
CacheLoader.InvalidCacheLoadException(String) - Constructor for exception com.google.common.cache.CacheLoader.InvalidCacheLoadException
 
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.
Callables - Class in com.google.common.util.concurrent
Static utility methods pertaining to the Callable interface.
callWithTimeout(Callable<T>, long, TimeUnit, boolean) - Method in class com.google.common.util.concurrent.FakeTimeLimiter
 
callWithTimeout(Callable<T>, long, TimeUnit, boolean) - Method in class com.google.common.util.concurrent.SimpleTimeLimiter
 
callWithTimeout(Callable<T>, long, TimeUnit, boolean) - Method in interface com.google.common.util.concurrent.TimeLimiter
Invokes a specified Callable, timing out after the specified time limit.
CAN - Static variable in class com.google.common.base.Ascii
Cancel: A control character used to indicate that the data with which it is sent is in error or is to be disregarded.
cancel(boolean) - Method in class com.google.common.util.concurrent.AbstractFuture
 
cancel(boolean) - Method in class com.google.common.util.concurrent.ForwardingFuture
 
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 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.
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
 
cellSet() - Method in class com.google.common.collect.ArrayTable
Returns an unmodifiable set of all row key / column key / value triplets.
cellSet() - Method in class com.google.common.collect.ForwardingTable
 
cellSet() - Method in class com.google.common.collect.ImmutableTable
 
cellSet() - Method in interface com.google.common.collect.Table
Returns a set of all row key / column key / value triplets.
charactersOf(String) - Static method in class com.google.common.collect.Lists
Returns a view of the specified string as an immutable list of Character values.
charactersOf(CharSequence) - Static method in class com.google.common.collect.Lists
Returns a view of the specified CharSequence as a List<Character>, viewing sequence as a sequence of Unicode code units.
CharEscaper - Class in com.google.common.escape
An object that converts literal text into a format safe for inclusion in a particular context (such as an XML document).
CharEscaper() - Constructor for class com.google.common.escape.CharEscaper
Constructor for use by subclasses.
CharEscaperBuilder - Class in com.google.common.escape
Simple helper class to build a "sparse" array of objects based on the indexes that were added to it.
CharEscaperBuilder() - Constructor for class com.google.common.escape.CharEscaperBuilder
Construct a new sparse array builder.
CharMatcher - Class in com.google.common.base
Determines a true or false value for any Java char value, just as Predicate does for any Object.
CharMatcher() - Constructor for class com.google.common.base.CharMatcher
Constructor for use by subclasses.
Chars - Class in com.google.common.primitives
Static utility methods pertaining to char primitives, that are not already found in either Character or Arrays.
charset() - Method in class com.google.common.net.MediaType
Returns an optional charset for the value of the charset parameter if it is specified.
Charsets - Class in com.google.common.base
Contains constant definitions for the six standard Charset instances, which are guaranteed to be supported by all Java platform implementations.
CharSink - Class in com.google.common.io
A destination to which characters can be written, such as a text file.
CharSink() - Constructor for class com.google.common.io.CharSink
Constructor for use by subclasses.
CharSource - Class in com.google.common.io
A readable source of characters, such as a text file.
CharSource() - Constructor for class com.google.common.io.CharSource
Constructor for use by subclasses.
CharStreams - Class in com.google.common.io
Provides utility methods for working with character streams.
checkArgument(boolean) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, Object) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, Object...) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkedAdd(int, int) - Static method in class com.google.common.math.IntMath
Returns the sum of a and b, provided it does not overflow.
checkedAdd(long, long) - Static method in class com.google.common.math.LongMath
Returns the sum of a and b, provided it does not overflow.
checkedCast(long) - Static method in class com.google.common.primitives.Chars
Returns the char value that is equal to value, if possible.
checkedCast(long) - Static method in class com.google.common.primitives.Ints
Returns the int value that is equal to value, if possible.
checkedCast(long) - Static method in class com.google.common.primitives.Shorts
Returns the short value that is equal to value, if possible.
checkedCast(long) - Static method in class com.google.common.primitives.SignedBytes
Returns the byte value that is equal to value, if possible.
checkedCast(long) - Static method in class com.google.common.primitives.UnsignedBytes
Returns the byte value that, when treated as unsigned, is equal to value, if possible.
CheckedFuture<V,X extends Exception> - Interface in com.google.common.util.concurrent
A CheckedFuture is a ListenableFuture that includes versions of the get methods that can throw a checked exception.
checkedGet() - Method in class com.google.common.util.concurrent.AbstractCheckedFuture
Exception checking version of Future.get() that will translate InterruptedException, CancellationException and ExecutionException into application-specific exceptions.
checkedGet(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractCheckedFuture
Exception checking version of Future.get(long, TimeUnit) that will translate InterruptedException, CancellationException and ExecutionException into application-specific exceptions.
checkedGet() - Method in interface com.google.common.util.concurrent.CheckedFuture
Exception checking version of Future.get() that will translate InterruptedException, CancellationException and ExecutionException into application-specific exceptions.
checkedGet(long, TimeUnit) - Method in interface com.google.common.util.concurrent.CheckedFuture
Exception checking version of Future.get(long, TimeUnit) that will translate InterruptedException, CancellationException and ExecutionException into application-specific exceptions.
checkedGet() - Method in class com.google.common.util.concurrent.ForwardingCheckedFuture
 
checkedGet(long, TimeUnit) - Method in class com.google.common.util.concurrent.ForwardingCheckedFuture
 
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.
checkKeyValue(K, V) - Method in interface com.google.common.collect.MapConstraint
Throws a suitable RuntimeException if the specified key or value is illegal.
checkNotNull(T) - Static method in class com.google.common.base.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, Object) - Static method in class com.google.common.base.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T, String, Object...) - Static method in class com.google.common.base.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkPositionIndex(int, int) - Static method in class com.google.common.base.Preconditions
Ensures that index specifies a valid position in an array, list or string of size size.
checkPositionIndex(int, int, String) - Static method in class com.google.common.base.Preconditions
Ensures that index specifies a valid position in an array, list or string of size size.
checkPositionIndexes(int, int, int) - Static method in class com.google.common.base.Preconditions
Ensures that start and end specify a valid positions in an array, list or string of size size, and are in order.
checkState(boolean) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, Object) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkState(boolean, String, Object...) - Static method in class com.google.common.base.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
child(String) - Method in class com.google.common.net.InternetDomainName
Creates and returns a new InternetDomainName by prepending the argument and a dot to the current name.
children(T) - Method in class com.google.common.collect.BinaryTreeTraverser
Returns the children of this node, in left-to-right order.
children(T) - Method in class com.google.common.collect.TreeTraverser
Returns the children of the specified node.
classes() - Method in class com.google.common.reflect.TypeToken.TypeSet
Returns the types that are classes.
ClassPath - Class in com.google.common.reflect
Scans the source of a ClassLoader and finds all loadable classes and resources.
ClassPath.ClassInfo - Class in com.google.common.reflect
Represents a class that can be loaded through ClassPath.ClassInfo.load().
ClassPath.ResourceInfo - Class in com.google.common.reflect
Represents a class path resource that can be either a class file or any other resource file loadable from the class path.
ClassToInstanceMap<B> - Interface in com.google.common.collect
A map, each entry of which maps a Java raw type to an instance of that type.
cleanUp() - Method in class com.google.common.cache.AbstractCache
 
cleanUp() - Method in interface com.google.common.cache.Cache
Performs any pending maintenance operations needed by the cache.
cleanUp() - Method in class com.google.common.cache.ForwardingCache
 
clear() - Method in class com.google.common.collect.ArrayTable
Deprecated.
clear() - Method in class com.google.common.collect.ConcurrentHashMultiset
 
clear() - Method in class com.google.common.collect.ForwardingCollection
 
clear() - Method in class com.google.common.collect.ForwardingMap
 
clear() - Method in class com.google.common.collect.ForwardingMultimap
 
clear() - Method in class com.google.common.collect.ForwardingTable
 
clear() - Method in class com.google.common.collect.HashBiMap
 
clear() - Method in class com.google.common.collect.ImmutableCollection
Deprecated.
Unsupported operation.
clear() - Method in class com.google.common.collect.ImmutableMap
Deprecated.
Unsupported operation.
clear() - Method in class com.google.common.collect.ImmutableMultimap
Deprecated.
Unsupported operation.
clear() - Method in class com.google.common.collect.ImmutableRangeMap
 
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 interface com.google.common.collect.Table
Removes all mappings from the table.
clear() - Method in class com.google.common.collect.TreeRangeMap
 
clear() - Method in class com.google.common.util.concurrent.AtomicLongMap
Removes all of the mappings from this map.
close() - Method in class com.google.common.base.FinalizableReferenceQueue
 
close() - Method in class com.google.common.hash.HashingOutputStream
 
close(Closeable, boolean) - Static method in class com.google.common.io.Closeables
Closes a Closeable, with control over whether an IOException may be thrown.
close() - Method in class com.google.common.io.Closer
Closes all Closeable instances that have been added to this Closer.
close() - Method in class com.google.common.io.CountingOutputStream
 
close() - Method in class com.google.common.io.FileBackedOutputStream
 
close() - Method in class com.google.common.io.LittleEndianDataOutputStream
 
Closeables - Class in com.google.common.io
Utility methods for working with Closeable objects.
closed(C, C) - Static method in class com.google.common.collect.Range
Returns a range that contains all values greater than or equal to lower and less than or equal to upper.
closedOpen(C, C) - Static method in class com.google.common.collect.Range
Returns a range that contains all values greater than or equal to lower and strictly less than upper.
closeQuietly(InputStream) - Static method in class com.google.common.io.Closeables
Closes the given InputStream, logging any IOException that's thrown rather than propagating it.
closeQuietly(Reader) - Static method in class com.google.common.io.Closeables
Closes the given Reader, logging any IOException that's thrown rather than propagating it.
Closer - Class in com.google.common.io
A Closeable that collects Closeable resources and closes them all when it is closed.
codePointAt(CharSequence, int, int) - Static method in class com.google.common.escape.UnicodeEscaper
Returns the Unicode code point of the character at the given index.
coerceToInteger(InetAddress) - Static method in class com.google.common.net.InetAddresses
Returns an integer representing an IPv4 address regardless of whether the supplied argument is an IPv4 address or not.
collapseFrom(CharSequence, char) - Method in class com.google.common.base.CharMatcher
Returns a string copy of the input character sequence, with each group of consecutive characters that match this matcher replaced by a single replacement character.
Collections2 - Class in com.google.common.collect
Provides static methods for working with Collection instances.
column(C) - Method in class com.google.common.collect.ArrayTable
Returns a view of all mappings that have the given column key.
column(C) - Method in class com.google.common.collect.ForwardingTable
 
column(C) - Method in class com.google.common.collect.ImmutableTable
Returns a view of all mappings that have the given column key.
column(C) - Method in interface com.google.common.collect.Table
Returns a view of all mappings that have the given column key.
columnComparator() - Method in class com.google.common.collect.TreeBasedTable
Returns the comparator that orders the columns.
columnKeyList() - Method in class com.google.common.collect.ArrayTable
Returns, as an immutable list, the column keys provided when the table was constructed, including those that are mapped to null values only.
columnKeySet() - Method in class com.google.common.collect.ArrayTable
Returns an immutable set of the valid column keys, including those that are associated with null values only.
columnKeySet() - Method in class com.google.common.collect.ForwardingTable
 
columnKeySet() - Method in class com.google.common.collect.ImmutableTable
 
columnKeySet() - Method in interface com.google.common.collect.Table
Returns a set of column keys that have one or more values in the table.
columnMap() - Method in class com.google.common.collect.ArrayTable
 
columnMap() - Method in class com.google.common.collect.ForwardingTable
 
columnMap() - Method in class com.google.common.collect.ImmutableTable
Returns a view that associates each column key with the corresponding map from row keys to values.
columnMap() - Method in interface com.google.common.collect.Table
Returns a view that associates each column key with the corresponding map from row keys to values.
com.google.common.annotations - package com.google.common.annotations
Common annotation types.
com.google.common.base - package com.google.common.base
Basic utility libraries and interfaces.
com.google.common.cache - package com.google.common.cache
This package contains caching utilities.
com.google.common.collect - package com.google.common.collect
This package contains generic collection interfaces and implementations, and other utilities for working with collections.
com.google.common.escape - package com.google.common.escape
Interfaces, utilities, and simple implementations of escapers and encoders.
com.google.common.eventbus - package com.google.common.eventbus
The EventBus allows publish-subscribe-style communication between components without requiring the components to explicitly register with one another (and thus be aware of each other).
com.google.common.hash - package com.google.common.hash
Hash functions and related structures.
com.google.common.html - package com.google.common.html
Escapers for HTML.
com.google.common.io - package com.google.common.io
This package contains utility methods and classes for working with Java I/O; for example input streams, output streams, readers, writers, and files.
com.google.common.math - package com.google.common.math
Arithmetic functions operating on primitive values and BigInteger instances.
com.google.common.net - package com.google.common.net
This package contains utility methods and classes for working with net addresses (numeric IP and domain names).
com.google.common.primitives - package com.google.common.primitives
Static utilities for working with the eight primitive types and void, and value types for treating them as unsigned.
com.google.common.reflect - package com.google.common.reflect
This package contains utilities to work with Java reflection.
com.google.common.util.concurrent - package com.google.common.util.concurrent
Concurrency utilities.
com.google.common.xml - package com.google.common.xml
Escapers for XML.
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.
compare(Comparable<?>, Comparable<?>) - Method in class com.google.common.collect.ComparisonChain
Compares two comparable objects as specified by Comparable.compareTo(T), if the result of this comparison chain has not already been determined.
compare(T, T, Comparator<T>) - Method in class com.google.common.collect.ComparisonChain
Compares two objects using a comparator, if the result of this comparison chain has not already been determined.
compare(int, int) - Method in class com.google.common.collect.ComparisonChain
Compares two int values as specified by Ints.compare(int, int), if the result of this comparison chain has not already been determined.
compare(long, long) - Method in class com.google.common.collect.ComparisonChain
Compares two long values as specified by Longs.compare(long, long), if the result of this comparison chain has not already been determined.
compare(float, float) - Method in class com.google.common.collect.ComparisonChain
Compares two float values as specified by Float.compare(float, float), if the result of this comparison chain has not already been determined.
compare(double, double) - Method in class com.google.common.collect.ComparisonChain
Compares two double values as specified by Double.compare(double, double), if the result of this comparison chain has not already been determined.
compare(T, T) - Method in class com.google.common.collect.Ordering
 
compare(boolean, boolean) - Static method in class com.google.common.primitives.Booleans
Compares the two specified boolean values in the standard way (false is considered less than true).
compare(char, char) - Static method in class com.google.common.primitives.Chars
Compares the two specified char values.
compare(double, double) - Static method in class com.google.common.primitives.Doubles
Compares the two specified double values.
compare(float, float) - Static method in class com.google.common.primitives.Floats
Compares the two specified float values using Float.compare(float, float).
compare(int, int) - Static method in class com.google.common.primitives.Ints
Compares the two specified int values.
compare(long, long) - Static method in class com.google.common.primitives.Longs
Compares the two specified long values.
compare(short, short) - Static method in class com.google.common.primitives.Shorts
Compares the two specified short values.
compare(byte, byte) - Static method in class com.google.common.primitives.SignedBytes
Compares the two specified byte values.
compare(byte, byte) - Static method in class com.google.common.primitives.UnsignedBytes
Compares the two specified byte values, treating them as unsigned values between 0 and 255 inclusive.
compare(int, int) - Static method in class com.google.common.primitives.UnsignedInts
Compares the two specified int values, treating them as unsigned values between 0 and 2^32 - 1 inclusive.
compare(long, long) - Static method in class com.google.common.primitives.UnsignedLongs
Compares the two specified long values, treating them as unsigned values between 0 and 2^64 - 1 inclusive.
compareAndSet(double, double) - Method in class com.google.common.util.concurrent.AtomicDouble
Atomically sets the value to the given updated value if the current value is bitwise equal to the expected value.
compareAndSet(int, double, double) - Method in class com.google.common.util.concurrent.AtomicDoubleArray
Atomically sets the element at position i to the given updated value if the current value is bitwise equal to the expected value.
compareFalseFirst(boolean, boolean) - Method in class com.google.common.collect.ComparisonChain
Compares two boolean values, considering false to be less than true, if the result of this comparison chain has not already been determined.
compareTo(UnsignedInteger) - Method in class com.google.common.primitives.UnsignedInteger
Compares this unsigned integer to another unsigned integer.
compareTo(UnsignedLong) - Method in class com.google.common.primitives.UnsignedLong
 
compareTrueFirst(boolean, boolean) - Method in class com.google.common.collect.ComparisonChain
Compares two boolean values, considering true to be less than false, if the result of this comparison chain has not already been determined.
ComparisonChain - Class in com.google.common.collect
A utility for performing a chained comparison statement.
complement() - Method in class com.google.common.collect.ImmutableRangeSet
 
complement() - Method in interface com.google.common.collect.RangeSet
Returns a view of the complement of this RangeSet.
complement() - Method in class com.google.common.collect.TreeRangeSet
 
complementOf(Collection<E>) - Static method in class com.google.common.collect.Sets
Creates an EnumSet consisting of all enum values that are not in the specified collection.
complementOf(Collection<E>, Class<E>) - Static method in class com.google.common.collect.Sets
Creates an EnumSet consisting of all enum values that are not in the specified collection.
compose(Function<B, C>, Function<A, ? extends B>) - Static method in class com.google.common.base.Functions
Returns the composition of two functions.
compose(Predicate<B>, Function<A, ? extends B>) - Static method in class com.google.common.base.Predicates
Returns the composition of a function and a predicate.
compose(Function<? super F, T>, Supplier<F>) - Static method in class com.google.common.base.Suppliers
Returns a new supplier which is the composition of the provided function and supplier.
compound(Comparator<? super U>) - Method in class com.google.common.collect.Ordering
Returns an ordering which first uses the ordering this, but which in the event of a "tie", then delegates to secondaryComparator.
compound(Iterable<? extends Comparator<? super T>>) - Static method in class com.google.common.collect.Ordering
Returns an ordering which tries each given comparator in order until a non-zero result is found, returning that result, and returning zero only if all comparators return zero.
ComputationException - Exception in com.google.common.collect
Wraps an exception that occurred during a computation.
ComputationException(Throwable) - Constructor for exception com.google.common.collect.ComputationException
Creates a new instance with the given cause.
computeNext() - Method in class com.google.common.collect.AbstractIterator
Returns the next element.
computeNext(T) - Method in class com.google.common.collect.AbstractSequentialIterator
Returns the element that follows previous, or returns null if no elements remain.
computeReplacement(CharEscaper, char) - Static method in class com.google.common.escape.Escapers
Returns a string that would replace the given character in the specified escaper, or null if no replacement should be made.
computeReplacement(UnicodeEscaper, int) - Static method in class com.google.common.escape.Escapers
Returns a string that would replace the given character in the specified escaper, or null if no replacement should be made.
concat(Iterable<? extends T>, Iterable<? extends T>) - Static method in class com.google.common.collect.Iterables
Combines two iterables into a single iterable.
concat(Iterable<? extends T>, Iterable<? extends T>, Iterable<? extends T>) - Static method in class com.google.common.collect.Iterables
Combines three iterables into a single iterable.
concat(Iterable<? extends T>, Iterable<? extends T>, Iterable<? extends T>, Iterable<? extends T>) - Static method in class com.google.common.collect.Iterables
Combines four iterables into a single iterable.
concat(Iterable<? extends T>...) - Static method in class com.google.common.collect.Iterables
Combines multiple iterables into a single iterable.
concat(Iterable<? extends Iterable<? extends T>>) - Static method in class com.google.common.collect.Iterables
Combines multiple iterables into a single iterable.
concat(Iterator<? extends T>, Iterator<? extends T>) - Static method in class com.google.common.collect.Iterators
Combines two iterators into a single iterator.
concat(Iterator<? extends T>, Iterator<? extends T>, Iterator<? extends T>) - Static method in class com.google.common.collect.Iterators
Combines three iterators into a single iterator.
concat(Iterator<? extends T>, Iterator<? extends T>, Iterator<? extends T>, Iterator<? extends T>) - Static method in class com.google.common.collect.Iterators
Combines four iterators into a single iterator.
concat(Iterator<? extends T>...) - Static method in class com.google.common.collect.Iterators
Combines multiple iterators into a single iterator.
concat(Iterator<? extends Iterator<? extends T>>) - Static method in class com.google.common.collect.Iterators
Combines multiple iterators into a single iterator.
concat(T[], T[], Class<T>) - Static method in class com.google.common.collect.ObjectArrays
Returns a new array that contains the concatenated contents of two arrays.
concat(T, T[]) - Static method in class com.google.common.collect.ObjectArrays
Returns a new array that prepends element to array.
concat(T[], T) - Static method in class com.google.common.collect.ObjectArrays
Returns a new array that appends element to array.
concat(Iterable<? extends ByteSource>) - Static method in class com.google.common.io.ByteSource
Concatenates multiple ByteSource instances into a single source.
concat(Iterator<? extends ByteSource>) - Static method in class com.google.common.io.ByteSource
Concatenates multiple ByteSource instances into a single source.
concat(ByteSource...) - Static method in class com.google.common.io.ByteSource
Concatenates multiple ByteSource instances into a single source.
concat(Iterable<? extends CharSource>) - Static method in class com.google.common.io.CharSource
Concatenates multiple CharSource instances into a single source.
concat(Iterator<? extends CharSource>) - Static method in class com.google.common.io.CharSource
Concatenates multiple CharSource instances into a single source.
concat(CharSource...) - Static method in class com.google.common.io.CharSource
Concatenates multiple CharSource instances into a single source.
concat(boolean[]...) - Static method in class com.google.common.primitives.Booleans
Returns the values from each provided array combined into a single array.
concat(byte[]...) - Static method in class com.google.common.primitives.Bytes
Returns the values from each provided array combined into a single array.
concat(char[]...) - Static method in class com.google.common.primitives.Chars
Returns the values from each provided array combined into a single array.
concat(double[]...) - Static method in class com.google.common.primitives.Doubles
Returns the values from each provided array combined into a single array.
concat(float[]...) - Static method in class com.google.common.primitives.Floats
Returns the values from each provided array combined into a single array.
concat(int[]...) - Static method in class com.google.common.primitives.Ints
Returns the values from each provided array combined into a single array.
concat(long[]...) - Static method in class com.google.common.primitives.Longs
Returns the values from each provided array combined into a single array.
concat(short[]...) - Static method in class com.google.common.primitives.Shorts
Returns the values from each provided array combined into a single array.
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.MapMaker
Guides the allowed concurrency among update operations.
ConcurrentHashMultiset<E> - Class in com.google.common.collect
A multiset that supports concurrent modifications and that provides atomic versions of most Multiset operations (exceptions where noted).
CONNECTION - Static variable in class com.google.common.net.HttpHeaders
The HTTP Connection header field name.
consistentHash(HashCode, int) - Static method in class com.google.common.hash.Hashing
Assigns to hashCode a "bucket" in the range [0, buckets), in a uniform manner that minimizes the need for remapping as buckets grows.
consistentHash(long, int) - Static method in class com.google.common.hash.Hashing
Assigns to input a "bucket" in the range [0, buckets), in a uniform manner that minimizes the need for remapping as buckets grows.
constant(E) - Static method in class com.google.common.base.Functions
Creates a function that returns value for any input.
constrainedBiMap(BiMap<K, V>, MapConstraint<? super K, ? super V>) - Static method in class com.google.common.collect.MapConstraints
Returns a constrained view of the specified bimap, using the specified constraint.
constrainedListMultimap(ListMultimap<K, V>, MapConstraint<? super K, ? super V>) - Static method in class com.google.common.collect.MapConstraints
Returns a constrained view of the specified list multimap, using the specified constraint.
constrainedMap(Map<K, V>, MapConstraint<? super K, ? super V>) - Static method in class com.google.common.collect.MapConstraints
Returns a constrained view of the specified map, using the specified constraint.
constrainedMultimap(Multimap<K, V>, MapConstraint<? super K, ? super V>) - Static method in class com.google.common.collect.MapConstraints
Returns a constrained view of the specified multimap, using the specified constraint.
constrainedSetMultimap(SetMultimap<K, V>, MapConstraint<? super K, ? super V>) - Static method in class com.google.common.collect.MapConstraints
Returns a constrained view of the specified set multimap, using the specified constraint.
constrainedSortedSetMultimap(SortedSetMultimap<K, V>, MapConstraint<? super K, ? super V>) - Static method in class com.google.common.collect.MapConstraints
Returns a constrained view of the specified sorted-set multimap, using the specified constraint.
constructor(Constructor<?>) - Method in class com.google.common.reflect.TypeToken
Returns the Invokable for constructor, which must be a member of T.
consumingIterable(Iterable<T>) - Static method in class com.google.common.collect.Iterables
Returns a view of the supplied iterable that wraps each generated Iterator through Iterators.consumingIterator(Iterator).
consumingIterator(Iterator<T>) - Static method in class com.google.common.collect.Iterators
Returns a view of the supplied iterator that removes each element from the supplied iterator as it is returned.
contains(Pattern) - Static method in class com.google.common.base.Predicates
Returns a predicate that evaluates to true if the CharSequence being tested contains any match for the given regular expression pattern.
contains(Object, Object) - Method in class com.google.common.collect.ArrayTable
Returns true if the provided keys are among the keys provided when the table was constructed.
contains(Object) - Method in class com.google.common.collect.EvictingQueue
 
contains(Object) - Method in class com.google.common.collect.FluentIterable
Returns true if this fluent iterable contains any object for which equals(element) is true.
contains(Object) - Method in class com.google.common.collect.ForwardingCollection
 
contains(Object, Object) - Method in class com.google.common.collect.ForwardingTable
 
contains(Object, Object) - Method in class com.google.common.collect.HashBasedTable
 
contains(Object) - Method in class com.google.common.collect.ImmutableCollection
 
contains(Object) - Method in class com.google.common.collect.ImmutableList
 
contains(Object) - Method in class com.google.common.collect.ImmutableMultiset
 
contains(Object, Object) - Method in class com.google.common.collect.ImmutableTable
 
contains(Iterable<?>, Object) - Static method in class com.google.common.collect.Iterables
Returns true if iterable contains any object for which equals(element) is true.
contains(Iterator<?>, Object) - Static method in class com.google.common.collect.Iterators
Returns true if iterator contains element.
contains(Object) - Method in interface com.google.common.collect.Multiset
Determines whether this multiset contains the specified element.
contains(C) - Method in class com.google.common.collect.Range
Returns true if value is within the bounds of this range.
contains(C) - Method in interface com.google.common.collect.RangeSet
Determines whether any of this range set's member ranges contains value.
contains(Object, Object) - Method in interface com.google.common.collect.Table
Returns true if the table contains a mapping with the specified row and column keys.
contains(boolean[], boolean) - Static method in class com.google.common.primitives.Booleans
Returns true if target is present as an element anywhere in array.
contains(byte[], byte) - Static method in class com.google.common.primitives.Bytes
Returns true if target is present as an element anywhere in array.
contains(char[], char) - Static method in class com.google.common.primitives.Chars
Returns true if target is present as an element anywhere in array.
contains(double[], double) - Static method in class com.google.common.primitives.Doubles
Returns true if target is present as an element anywhere in array.
contains(float[], float) - Static method in class com.google.common.primitives.Floats
Returns true if target is present as an element anywhere in array.
contains(int[], int) - Static method in class com.google.common.primitives.Ints
Returns true if target is present as an element anywhere in array.
contains(long[], long) - Static method in class com.google.common.primitives.Longs
Returns true if target is present as an element anywhere in array.
contains(short[], short) - Static method in class com.google.common.primitives.Shorts
Returns true if target is present as an element anywhere in array.
containsAll(Collection<?>) - Method in class com.google.common.collect.ForwardingCollection
 
containsAll(Collection<?>) - Method in class com.google.common.collect.ImmutableMultiset
 
containsAll(Collection<?>) - Method in interface com.google.common.collect.Multiset
Returns true if this multiset contains at least one occurrence of each element in the specified collection.
containsAll(Iterable<? extends C>) - Method in class com.google.common.collect.Range
Returns true if every element in values is contained in this range.
containsColumn(Object) - Method in class com.google.common.collect.ArrayTable
Returns true if the provided column key is among the column keys provided when the table was constructed.
containsColumn(Object) - Method in class com.google.common.collect.ForwardingTable
 
containsColumn(Object) - Method in class com.google.common.collect.HashBasedTable
 
containsColumn(Object) - Method in interface com.google.common.collect.Table
Returns true if the table contains a mapping with the specified column.
containsEntry(Object, Object) - Method in class com.google.common.collect.ForwardingMultimap
 
containsEntry(Object, Object) - Method in interface com.google.common.collect.Multimap
Returns true if this multimap contains at least one key-value pair with the key key and the value value.
containsKey(Object) - Method in class com.google.common.collect.ForwardingMap
 
containsKey(Object) - Method in class com.google.common.collect.ForwardingMultimap
 
containsKey(Object) - Method in class com.google.common.collect.HashBiMap
 
containsKey(Object) - Method in class com.google.common.collect.ImmutableMap
 
containsKey(Object) - Method in class com.google.common.collect.ImmutableMultimap
 
containsKey(Object) - Method in class com.google.common.collect.LinkedListMultimap
 
containsKey(Object) - Method in interface com.google.common.collect.Multimap
Returns true if this multimap contains at least one key-value pair with the key key.
containsKey(Object) - Method in class com.google.common.util.concurrent.AtomicLongMap
Returns true if this map contains a mapping for the specified key.
containsOccurrences(Multiset<?>, Multiset<?>) - Static method in class com.google.common.collect.Multisets
Returns true if subMultiset.count(o) <= superMultiset.count(o) for all o.
containsPattern(String) - Static method in class com.google.common.base.Predicates
Returns a predicate that evaluates to true if the CharSequence being tested contains any match for the given regular expression pattern.
containsRow(Object) - Method in class com.google.common.collect.ArrayTable
Returns true if the provided row key is among the row keys provided when the table was constructed.
containsRow(Object) - Method in class com.google.common.collect.ForwardingTable
 
containsRow(Object) - Method in class com.google.common.collect.HashBasedTable
 
containsRow(Object) - Method in interface com.google.common.collect.Table
Returns true if the table contains a mapping with the specified row key.
containsValue(Object) - Method in class com.google.common.collect.ArrayTable
 
containsValue(Object) - Method in class com.google.common.collect.ForwardingMap
 
containsValue(Object) - Method in class com.google.common.collect.ForwardingMultimap
 
containsValue(Object) - Method in class com.google.common.collect.ForwardingTable
 
containsValue(Object) - Method in class com.google.common.collect.HashBasedTable
 
containsValue(Object) - Method in class com.google.common.collect.HashBiMap
 
containsValue(Object) - Method in class com.google.common.collect.ImmutableMap
 
containsValue(Object) - Method in class com.google.common.collect.ImmutableMultimap
 
containsValue(Object) - Method in class com.google.common.collect.ImmutableSortedMap
 
containsValue(Object) - Method in class com.google.common.collect.ImmutableTable
 
containsValue(Object) - Method in class com.google.common.collect.LinkedListMultimap
 
containsValue(Object) - Method in interface com.google.common.collect.Multimap
Returns true if this multimap contains at least one key-value pair with the value value.
containsValue(Object) - Method in interface com.google.common.collect.Table
Returns true if the table contains a mapping with the specified value.
CONTENT_DISPOSITION - Static variable in class com.google.common.net.HttpHeaders
The HTTP Content-Disposition header field name.
CONTENT_ENCODING - Static variable in class com.google.common.net.HttpHeaders
The HTTP Content-Encoding header field name.
CONTENT_LANGUAGE - Static variable in class com.google.common.net.HttpHeaders
The HTTP Content-Language header field name.
CONTENT_LENGTH - Static variable in class com.google.common.net.HttpHeaders
The HTTP Content-Length header field name.
CONTENT_LOCATION - Static variable in class com.google.common.net.HttpHeaders
The HTTP Content-Location header field name.
CONTENT_MD5 - Static variable in class com.google.common.net.HttpHeaders
The HTTP Content-MD5 header field name.
CONTENT_RANGE - Static variable in class com.google.common.net.HttpHeaders
The HTTP Content-Range header field name.
CONTENT_SECURITY_POLICY - Static variable in class com.google.common.net.HttpHeaders
The HTTP Content-Security-Policy header field name.
CONTENT_SECURITY_POLICY_REPORT_ONLY - Static variable in class com.google.common.net.HttpHeaders
The HTTP Content-Security-Policy-Report-Only header field name.
CONTENT_TYPE - Static variable in class com.google.common.net.HttpHeaders
The HTTP Content-Type header field name.
contentEquals(ByteSource) - Method in class com.google.common.io.ByteSource
Checks that the contents of this byte source are equal to the contents of the given byte source.
ContiguousSet<C extends Comparable> - Class in com.google.common.collect
A sorted set of contiguous values in a given DiscreteDomain.
convert(A) - Method in class com.google.common.base.Converter
Returns a representation of a as an instance of type B.
convertAll(Iterable<? extends A>) - Method in class com.google.common.base.Converter
Returns an iterable that applies convert to each element of fromIterable.
Converter<A,B> - Class in com.google.common.base
A function from A to B with an associated reverse function from B to A; used for converting back and forth between different representations of the same information.
Converter() - Constructor for class com.google.common.base.Converter
Constructor for use by subclasses.
converterTo(CaseFormat) - Method in enum com.google.common.base.CaseFormat
Returns a Converter that converts strings from this format to targetFormat.
COOKIE - Static variable in class com.google.common.net.HttpHeaders
The HTTP Cookie header field name.
copy() - Method in class com.google.common.hash.BloomFilter
Creates a new BloomFilter that's a copy of this instance.
copy(InputSupplier<? extends InputStream>, OutputSupplier<? extends OutputStream>) - Static method in class com.google.common.io.ByteStreams
Deprecated.
Use ByteSource.copyTo(ByteSink) instead. This method is scheduled for removal in Guava 18.0.
copy(InputSupplier<? extends InputStream>, OutputStream) - Static method in class com.google.common.io.ByteStreams
Deprecated.
Use ByteSource.copyTo(OutputStream) instead. This method is scheduled for removal in Guava 18.0.
copy(InputStream, OutputSupplier<? extends OutputStream>) - Static method in class com.google.common.io.ByteStreams
Deprecated.
Use ByteSink.writeFrom(InputStream) instead. This method is scheduled for removal in Guava 18.0.
copy(InputStream, OutputStream) - Static method in class com.google.common.io.ByteStreams
Copies all bytes from the input stream to the output stream.
copy(ReadableByteChannel, WritableByteChannel) - Static method in class com.google.common.io.ByteStreams
Copies all bytes from the readable channel to the writable channel.
copy(InputSupplier<R>, OutputSupplier<W>) - Static method in class com.google.common.io.CharStreams
Deprecated.
Use CharSource.copyTo(CharSink) instead. This method is scheduled for removal in Guava 18.0.
copy(InputSupplier<R>, Appendable) - Static method in class com.google.common.io.CharStreams
Deprecated.
Use CharSource.copyTo(Appendable) instead. This method is scheduled for removal in Guava 18.0.
copy(Readable, Appendable) - Static method in class com.google.common.io.CharStreams
Copies all characters between the Readable and Appendable objects.
copy(InputSupplier<? extends InputStream>, File) - Static method in class com.google.common.io.Files
Deprecated.
Use from.copyTo(Files.asByteSink(to)) after changing from to a ByteSource if necessary. This method is scheduled to be removed in Guava 18.0.
copy(File, OutputSupplier<? extends OutputStream>) - Static method in class com.google.common.io.Files
Deprecated.
Use Files.asByteSource(from).copyTo(to) after changing to to a ByteSink if necessary. This method is scheduled to be removed in Guava 18.0.
copy(File, OutputStream) - Static method in class com.google.common.io.Files
Copies all bytes from a file to an output stream.
copy(File, File) - Static method in class com.google.common.io.Files
Copies all the bytes from one file to another.
copy(InputSupplier<R>, File, Charset) - Static method in class com.google.common.io.Files
Deprecated.
Use from.copyTo(Files.asCharSink(to, charset)) after changing from to a CharSource if necessary. This method is scheduled to be removed in Guava 18.0.
copy(File, Charset, OutputSupplier<W>) - Static method in class com.google.common.io.Files
Deprecated.
Use Files.asCharSource(from, charset).copyTo(to) after changing to to a CharSink if necessary. This method is scheduled to be removed in Guava 18.0.
copy(File, Charset, Appendable) - Static method in class com.google.common.io.Files
Copies all characters from a file to an appendable object, using the given character set.
copy(URL, OutputStream) - Static method in class com.google.common.io.Resources
Copies all bytes from a URL to an output stream.
copyHighestCountFirst(Multiset<E>) - Static method in class com.google.common.collect.Multisets
Returns a copy of multiset as an ImmutableMultiset whose iteration order is highest count first, with ties broken by the iteration order of the original multiset.
copyInto(C) - Method in class com.google.common.collect.FluentIterable
Copies all the elements from this fluent iterable to collection.
copyInto(S) - Method in class com.google.common.collect.Sets.SetView
Copies the current contents of this set view into an existing set.
copyOf(Map<? extends K, ? extends V>) - Static method in class com.google.common.collect.ImmutableBiMap
Returns an immutable bimap containing the same entries as map.
copyOf(Map<? extends Class<? extends S>, ? extends S>) - Static method in class com.google.common.collect.ImmutableClassToInstanceMap
Returns an immutable map containing the same entries as map.
copyOf(Iterable<? extends E>) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing the given elements, in order.
copyOf(Collection<? extends E>) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing the given elements, in order.
copyOf(Iterator<? extends E>) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing the given elements, in order.
copyOf(E[]) - Static method in class com.google.common.collect.ImmutableList
Returns an immutable list containing the given elements, in order.
copyOf(Multimap<? extends K, ? extends V>) - Static method in class com.google.common.collect.ImmutableListMultimap
Returns an immutable multimap containing the same mappings as multimap.
copyOf(Map<? extends K, ? extends V>) - Static method in class com.google.common.collect.ImmutableMap
Returns an immutable map containing the same entries as map.
copyOf(Multimap<? extends K, ? extends V>) - Static method in class com.google.common.collect.ImmutableMultimap
Returns an immutable multimap containing the same mappings as multimap.
copyOf(E[]) - Static method in class com.google.common.collect.ImmutableMultiset
Returns an immutable multiset containing the given elements.
copyOf(Iterable<? extends E>) - Static method in class com.google.common.collect.ImmutableMultiset
Returns an immutable multiset containing the given elements.
copyOf(Iterator<? extends E>) - Static method in class com.google.common.collect.ImmutableMultiset
Returns an immutable multiset containing the given elements.
copyOf(RangeMap<K, ? extends V>) - Static method in class com.google.common.collect.ImmutableRangeMap
 
copyOf(RangeSet<C>) - Static method in class com.google.common.collect.ImmutableRangeSet
Returns an immutable copy of the specified RangeSet.
copyOf(E[]) - Static method in class com.google.common.collect.ImmutableSet
Returns an immutable set containing the given elements, in order.
copyOf(Iterable<? extends E>) - Static method in class com.google.common.collect.ImmutableSet
Returns an immutable set containing the given elements, in order.
copyOf(Iterator<? extends E>) - Static method in class com.google.common.collect.ImmutableSet
Returns an immutable set containing the given elements, in order.
copyOf(Collection<? extends E>) - Static method in class com.google.common.collect.ImmutableSet
Returns an immutable set containing the given elements, in order.
copyOf(Multimap<? extends K, ? extends V>) - Static method in class com.google.common.collect.ImmutableSetMultimap
Returns an immutable set multimap containing the same mappings as multimap.
copyOf(Map<? extends K, ? extends V>) - Static method in class com.google.common.collect.ImmutableSortedMap
Returns an immutable map containing the same entries as map, sorted by the natural ordering of the keys.
copyOf(Map<? extends K, ? extends V>, Comparator<? super K>) - Static method in class com.google.common.collect.ImmutableSortedMap
Returns an immutable map containing the same entries as map, with keys sorted by the provided comparator.
copyOf(E[]) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns an immutable sorted multiset containing the given elements sorted by their natural ordering.
copyOf(Iterable<? extends E>) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns an immutable sorted multiset containing the given elements sorted by their natural ordering.
copyOf(Iterator<? extends E>) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns an immutable sorted multiset containing the given elements sorted by their natural ordering.
copyOf(Comparator<? super E>, Iterator<? extends E>) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns an immutable sorted multiset containing the given elements sorted by the given Comparator.
copyOf(Comparator<? super E>, Iterable<? extends E>) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns an immutable sorted multiset containing the given elements sorted by the given Comparator.
copyOf(E[]) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by their natural ordering.
copyOf(Iterable<? extends E>) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by their natural ordering.
copyOf(Collection<? extends E>) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by their natural ordering.
copyOf(Iterator<? extends E>) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by their natural ordering.
copyOf(Comparator<? super E>, Iterator<? extends E>) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by the given Comparator.
copyOf(Comparator<? super E>, Iterable<? extends E>) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by the given Comparator.
copyOf(Comparator<? super E>, Collection<? extends E>) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by the given Comparator.
copyOf(Table<? extends R, ? extends C, ? extends V>) - Static method in class com.google.common.collect.ImmutableTable
Returns an immutable copy of the provided table.
copyOfSorted(SortedMap<K, ? extends V>) - Static method in class com.google.common.collect.ImmutableSortedMap
Returns an immutable map containing the same entries as the provided sorted map, with the same ordering.
copyOfSorted(SortedMultiset<E>) - Static method in class com.google.common.collect.ImmutableSortedMultiset
Returns an immutable sorted multiset containing the elements of a sorted multiset, sorted by the same Comparator.
copyOfSorted(SortedSet<E>) - Static method in class com.google.common.collect.ImmutableSortedSet
Returns an immutable sorted set containing the elements of a sorted set, sorted by the same Comparator.
copyTo(OutputStream) - Method in class com.google.common.io.ByteSource
Copies the contents of this byte source to the given OutputStream.
copyTo(ByteSink) - Method in class com.google.common.io.ByteSource
Copies the contents of this byte source to the given ByteSink.
copyTo(Appendable) - Method in class com.google.common.io.CharSource
Appends the contents of this source to the given Appendable (such as a Writer).
copyTo(CharSink) - Method in class com.google.common.io.CharSource
Copies the contents of this source to the given sink.
count(Object) - Method in class com.google.common.collect.ConcurrentHashMultiset
Returns the number of occurrences of element in this multiset.
count(Object) - Method in class com.google.common.collect.ForwardingMultiset
 
count(Object) - Method in interface com.google.common.collect.Multiset
Returns the number of occurrences of an element in this multiset (the count of the element).
count(Object) - Method in class com.google.common.collect.TreeMultiset
 
countIn(CharSequence) - Method in class com.google.common.base.CharMatcher
Returns the number of matching characters found in a character sequence.
CountingInputStream - Class in com.google.common.io
An InputStream that counts the number of bytes read.
CountingInputStream(InputStream) - Constructor for class com.google.common.io.CountingInputStream
Wraps another input stream, counting the number of bytes read.
CountingOutputStream - Class in com.google.common.io
An OutputStream that counts the number of bytes written.
CountingOutputStream(OutputStream) - Constructor for class com.google.common.io.CountingOutputStream
Wraps another output stream, counting the number of bytes written.
countTrue(boolean...) - Static method in class com.google.common.primitives.Booleans
Returns the number of values that are true.
CR - Static variable in class com.google.common.base.Ascii
Carriage Return ('\r'): A format effector which controls the movement of the printing position to the first printing position on the same printing line.
crc32() - Static method in class com.google.common.hash.Hashing
Returns a hash function implementing the CRC-32 checksum algorithm (32 hash bits) by delegating to the CRC32 Checksum.
create() - Static method in class com.google.common.collect.ArrayListMultimap
Creates a new, empty ArrayListMultimap with the default initial capacities.
create(int, int) - Static method in class com.google.common.collect.ArrayListMultimap
Constructs an empty ArrayListMultimap with enough capacity to hold the specified numbers of keys and values without resizing.
create(Multimap<? extends K, ? extends V>) - Static method in class com.google.common.collect.ArrayListMultimap
Constructs an ArrayListMultimap with the same mappings as the specified multimap.
create(Iterable<? extends R>, Iterable<? extends C>) - Static method in class com.google.common.collect.ArrayTable
Creates an empty ArrayTable.
create(Table<R, C, V>) - Static method in class com.google.common.collect.ArrayTable
Creates an ArrayTable with the mappings in the provided table.
create() - Static method in class com.google.common.collect.ConcurrentHashMultiset
Creates a new, empty ConcurrentHashMultiset using the default initial capacity, load factor, and concurrency settings.
create(Iterable<? extends E>) - Static method in class com.google.common.collect.ConcurrentHashMultiset
Creates a new ConcurrentHashMultiset containing the specified elements, using the default initial capacity, load factor, and concurrency settings.
create(MapMaker) - Static method in class com.google.common.collect.ConcurrentHashMultiset
Creates a new, empty ConcurrentHashMultiset using mapMaker to construct the internal backing map.
create(Range<C>, DiscreteDomain<C>) - Static method in class com.google.common.collect.ContiguousSet
Returns a ContiguousSet containing the same values in the given domain contained by the range.
create(Class<K>, Class<V>) - Static method in class com.google.common.collect.EnumBiMap
Returns a new, empty EnumBiMap using the specified key and value types.
create(Map<K, V>) - Static method in class com.google.common.collect.EnumBiMap
Returns a new bimap with the same mappings as the specified map.
create(Class<K>) - Static method in class com.google.common.collect.EnumHashBiMap
Returns a new, empty EnumHashBiMap using the specified key type.
create(Map<K, ? extends V>) - Static method in class com.google.common.collect.EnumHashBiMap
Constructs a new bimap with the same mappings as the specified map.
create(Class<E>) - Static method in class com.google.common.collect.EnumMultiset
Creates an empty EnumMultiset.
create(Iterable<E>) - Static method in class com.google.common.collect.EnumMultiset
Creates a new EnumMultiset containing the specified elements.
create(Iterable<E>, Class<E>) - Static method in class com.google.common.collect.EnumMultiset
Returns a new EnumMultiset instance containing the given elements.
create(int) - Static method in class com.google.common.collect.EvictingQueue
Creates and returns a new evicting queue that will hold up to maxSize elements.
create() - Static method in class com.google.common.collect.HashBasedTable
Creates an empty HashBasedTable.
create(int, int) - Static method in class com.google.common.collect.HashBasedTable
Creates an empty HashBasedTable with the specified map sizes.
create(Table<? extends R, ? extends C, ? extends V>) - Static method in class com.google.common.collect.HashBasedTable
Creates a HashBasedTable with the same mappings as the specified table.
create() - Static method in class com.google.common.collect.HashBiMap
Returns a new, empty HashBiMap with the default initial capacity (16).
create(int) - Static method in class com.google.common.collect.HashBiMap
Constructs a new, empty bimap with the specified expected size.
create(Map<? extends K, ? extends V>) - Static method in class com.google.common.collect.HashBiMap
Constructs a new bimap containing initial values from map.
create() - Static method in class com.google.common.collect.HashMultimap
Creates a new, empty HashMultimap with the default initial capacities.
create(int, int) - Static method in class com.google.common.collect.HashMultimap
Constructs an empty HashMultimap with enough capacity to hold the specified numbers of keys and values without rehashing.
create(Multimap<? extends K, ? extends V>) - Static method in class com.google.common.collect.HashMultimap
Constructs a HashMultimap with the same mappings as the specified multimap.
create() - Static method in class com.google.common.collect.HashMultiset
Creates a new, empty HashMultiset using the default initial capacity.
create(int) - Static method in class com.google.common.collect.HashMultiset
Creates a new, empty HashMultiset with the specified expected number of distinct elements.
create(Iterable<? extends E>) - Static method in class com.google.common.collect.HashMultiset
Creates a new HashMultiset containing the specified elements.
create() - Static method in class com.google.common.collect.LinkedHashMultimap
Creates a new, empty LinkedHashMultimap with the default initial capacities.
create(int, int) - Static method in class com.google.common.collect.LinkedHashMultimap
Constructs an empty LinkedHashMultimap with enough capacity to hold the specified numbers of keys and values without rehashing.
create(Multimap<? extends K, ? extends V>) - Static method in class com.google.common.collect.LinkedHashMultimap
Constructs a LinkedHashMultimap with the same mappings as the specified multimap.
create() - Static method in class com.google.common.collect.LinkedHashMultiset
Creates a new, empty LinkedHashMultiset using the default initial capacity.
create(int) - Static method in class com.google.common.collect.LinkedHashMultiset
Creates a new, empty LinkedHashMultiset with the specified expected number of distinct elements.
create(Iterable<? extends E>) - Static method in class com.google.common.collect.LinkedHashMultiset
Creates a new LinkedHashMultiset containing the specified elements.
create() - Static method in class com.google.common.collect.LinkedListMultimap
Creates a new, empty LinkedListMultimap with the default initial capacity.
create(int) - Static method in class com.google.common.collect.LinkedListMultimap
Constructs an empty LinkedListMultimap with enough capacity to hold the specified number of keys without rehashing.
create(Multimap<? extends K, ? extends V>) - Static method in class com.google.common.collect.LinkedListMultimap
Constructs a LinkedListMultimap with the same mappings as the specified Multimap.
create() - Method in class com.google.common.collect.MinMaxPriorityQueue.Builder
Builds a new min-max priority queue using the previously specified options, and having no initial contents.
create(Iterable<? extends T>) - Method in class com.google.common.collect.MinMaxPriorityQueue.Builder
Builds a new min-max priority queue using the previously specified options, and having the given initial elements.
create() - Static method in class com.google.common.collect.MinMaxPriorityQueue
Creates a new min-max priority queue with default settings: natural order, no maximum size, no initial contents, and an initial expected size of 11.
create(Iterable<? extends E>) - Static method in class com.google.common.collect.MinMaxPriorityQueue
Creates a new min-max priority queue using natural order, no maximum size, and initially containing the given elements.
create() - Static method in class com.google.common.collect.MutableClassToInstanceMap
Returns a new MutableClassToInstanceMap instance backed by a HashMap using the default initial capacity and load factor.
create(Map<Class<? extends B>, B>) - Static method in class com.google.common.collect.MutableClassToInstanceMap
Returns a new MutableClassToInstanceMap instance backed by a given empty backingMap.
create() - Static method in class com.google.common.collect.TreeBasedTable
Creates an empty TreeBasedTable that uses the natural orderings of both row and column keys.
create(Comparator<? super R>, Comparator<? super C>) - Static method in class com.google.common.collect.TreeBasedTable
Creates an empty TreeBasedTable that is ordered by the specified comparators.
create(TreeBasedTable<R, C, ? extends V>) - Static method in class com.google.common.collect.TreeBasedTable
Creates a TreeBasedTable with the same mappings and sort order as the specified TreeBasedTable.
create() - Static method in class com.google.common.collect.TreeMultimap
Creates an empty TreeMultimap ordered by the natural ordering of its keys and values.
create(Comparator<? super K>, Comparator<? super V>) - Static method in class com.google.common.collect.TreeMultimap
Creates an empty TreeMultimap instance using explicit comparators.
create(Multimap<? extends K, ? extends V>) - Static method in class com.google.common.collect.TreeMultimap
Constructs a TreeMultimap, ordered by the natural ordering of its keys and values, with the same mappings as the specified multimap.
create() - Static method in class com.google.common.collect.TreeMultiset
Creates a new, empty multiset, sorted according to the elements' natural order.
create(Comparator<? super E>) - Static method in class com.google.common.collect.TreeMultiset
Creates a new, empty multiset, sorted according to the specified comparator.
create(Iterable<? extends E>) - Static method in class com.google.common.collect.TreeMultiset
Creates an empty multiset containing the given initial elements, sorted according to the elements' natural order.
create() - Static method in class com.google.common.collect.TreeRangeMap
 
create() - Static method in class com.google.common.collect.TreeRangeSet
Creates an empty TreeRangeSet instance.
create(RangeSet<C>) - Static method in class com.google.common.collect.TreeRangeSet
Returns a TreeRangeSet initialized with the ranges in the specified range set.
create(Map<Character, String>) - Static method in class com.google.common.escape.ArrayBasedEscaperMap
Returns a new ArrayBasedEscaperMap for creating ArrayBasedCharEscaper or ArrayBasedUnicodeEscaper instances.
create(Funnel<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<T>, int) - Static method in class com.google.common.hash.BloomFilter
Creates a BloomFilter with the expected number of insertions and a default expected false positive probability of 3%.
create() - Static method in class com.google.common.io.Closer
Creates a new Closer.
create(String, String) - Static method in class com.google.common.net.MediaType
Creates a new media type with the given type and subtype.
create() - Static method in class com.google.common.util.concurrent.AtomicLongMap
Creates an AtomicLongMap.
create(Map<? extends K, ? extends Long>) - Static method in class com.google.common.util.concurrent.AtomicLongMap
Creates an AtomicLongMap with the same mappings as the specified Map.
create(Throwable) - Method in interface com.google.common.util.concurrent.FutureFallback
Returns a Future to be used in place of the Future that failed with the given exception.
create(Callable<V>) - Static method in class com.google.common.util.concurrent.ListenableFutureTask
Creates a ListenableFutureTask that will upon running, execute the given Callable.
create(Runnable, V) - Static method in class com.google.common.util.concurrent.ListenableFutureTask
Creates a ListenableFutureTask that will upon running, execute the given Runnable, and arrange that get will return the given result on successful completion.
create(double) - Static method in class com.google.common.util.concurrent.RateLimiter
Creates a RateLimiter with the specified stable throughput, given as "permits per second" (commonly referred to as QPS, queries per second).
create(double, long, TimeUnit) - Static method in class com.google.common.util.concurrent.RateLimiter
Creates a RateLimiter with the specified stable throughput, given as "permits per second" (commonly referred to as QPS, queries per second), and a warmup period, during which the RateLimiter smoothly ramps up its rate, until it reaches its maximum rate at the end of the period (as long as there are enough requests to saturate it).
create() - Static method in class com.google.common.util.concurrent.SettableFuture
Creates a new SettableFuture in the default state.
createParentDirs(File) - Static method in class com.google.common.io.Files
Creates any necessary but nonexistent parent directories of the specified file.
createStarted() - Static method in class com.google.common.base.Stopwatch
Creates (and starts) a new stopwatch using System.nanoTime() as its time source.
createStarted(Ticker) - Static method in class com.google.common.base.Stopwatch
Creates (and starts) a new stopwatch, using the specified time source.
createTempDir() - Static method in class com.google.common.io.Files
Atomically creates a new directory somewhere beneath the system's temporary directory (as defined by the java.io.tmpdir system property), and returns its name.
createUnstarted() - Static method in class com.google.common.base.Stopwatch
Creates (but does not start) a new stopwatch using System.nanoTime() as its time source.
createUnstarted(Ticker) - Static method in class com.google.common.base.Stopwatch
Creates (but does not start) a new stopwatch, using the specified time source.
CRW - Static variable in class com.google.common.net.MediaType
The media type for the Canon Image File Format (crw files), a widely-used "raw image" format for cameras.
CSS_UTF_8 - Static variable in class com.google.common.net.MediaType
 
CSV_UTF_8 - Static variable in class com.google.common.net.MediaType
 
cycle() - Method in class com.google.common.collect.FluentIterable
Returns a fluent iterable whose Iterator cycles indefinitely over the elements of this fluent iterable.
cycle(Iterable<T>) - Static method in class com.google.common.collect.Iterables
Returns an iterable whose iterators cycle indefinitely over the elements of iterable.
cycle(T...) - Static method in class com.google.common.collect.Iterables
Returns an iterable whose iterators cycle indefinitely over the provided elements.
cycle(Iterable<T>) - Static method in class com.google.common.collect.Iterators
Returns an iterator that cycles indefinitely over the elements of iterable.
cycle(T...) - Static method in class com.google.common.collect.Iterators
Returns an iterator that cycles indefinitely over the provided elements.
CycleDetectingLockFactory - Class in com.google.common.util.concurrent
The CycleDetectingLockFactory creates ReentrantLock instances and ReentrantReadWriteLock instances that detect potential deadlock by checking for cycles in lock acquisition order.
CycleDetectingLockFactory.Policies - Enum in com.google.common.util.concurrent
Pre-defined CycleDetectingLockFactory.Policy implementations.
CycleDetectingLockFactory.Policy - Interface in com.google.common.util.concurrent
Encapsulates the action to be taken when a potential deadlock is encountered.
CycleDetectingLockFactory.PotentialDeadlockException - Exception in com.google.common.util.concurrent
Represents a detected cycle in lock acquisition ordering.
CycleDetectingLockFactory.WithExplicitOrdering<E extends Enum<E>> - Class in com.google.common.util.concurrent
A CycleDetectingLockFactory.WithExplicitOrdering provides the additional enforcement of an application-specified ordering of lock acquisitions.

D

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.
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.
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
 
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.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.ForwardingBlockingQueue
 
delegate() - Method in class com.google.common.util.concurrent.ForwardingCheckedFuture
 
delegate() - Method in class com.google.common.util.concurrent.ForwardingCheckedFuture.SimpleForwardingCheckedFuture
 
delegate() - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
delegate() - Method in class com.google.common.util.concurrent.ForwardingFuture
 
delegate() - 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
 
dereference(ListenableFuture<? extends ListenableFuture<? extends V>>) - Static method in class com.google.common.util.concurrent.Futures
Returns a new ListenableFuture whose result is the product of calling get() on the Future nested within the given Future, effectively chaining the futures one after the other.
descendingIterator() - Method in class com.google.common.collect.ForwardingDeque
 
descendingIterator() - Method in class com.google.common.collect.ForwardingNavigableSet
 
descendingIterator() - Method in class com.google.common.collect.ImmutableSortedSet
 
descendingKeySet() - Method in class com.google.common.collect.ForwardingNavigableMap
 
descendingKeySet() - Method in class com.google.common.collect.ImmutableSortedMap
 
descendingMap() - Method in class com.google.common.collect.ForwardingNavigableMap
 
descendingMap() - Method in class com.google.common.collect.ImmutableSortedMap
 
descendingMultiset() - Method in class com.google.common.collect.ForwardingSortedMultiset
 
descendingMultiset() - Method in class com.google.common.collect.ImmutableSortedMultiset
 
descendingMultiset() - Method in interface com.google.common.collect.SortedMultiset
Returns a descending view of this multiset.
descendingSet() - Method in class com.google.common.collect.ForwardingNavigableSet
 
descendingSet() - Method in class com.google.common.collect.ImmutableSortedSet
 
difference(Map<? extends K, ? extends V>, Map<? extends K, ? extends V>) - Static method in class com.google.common.collect.Maps
Computes the difference between two maps.
difference(Map<? extends K, ? extends V>, Map<? extends K, ? extends V>, Equivalence<? super V>) - Static method in class com.google.common.collect.Maps
Computes the difference between two maps.
difference(SortedMap<K, ? extends V>, Map<? extends K, ? extends V>) - Static method in class com.google.common.collect.Maps
Computes the difference between two sorted maps, using the comparator of the left map, or Ordering.natural() if the left map uses the natural ordering of its elements.
difference(Multiset<E>, Multiset<?>) - Static method in class com.google.common.collect.Multisets
Returns an unmodifiable view of the difference of two multisets.
difference(Set<E>, Set<?>) - Static method in class com.google.common.collect.Sets
Returns an unmodifiable view of the difference of two sets.
DIGIT - Static variable in class com.google.common.base.CharMatcher
Determines whether a character is a digit according to Unicode.
disableCaching() - Static method in class com.google.common.cache.CacheBuilderSpec
Returns a CacheBuilderSpec that will prevent caching.
DiscreteDomain<C extends Comparable> - Class in com.google.common.collect
A descriptor for a discrete Comparable domain such as all Integer instances.
DiscreteDomain() - Constructor for class com.google.common.collect.DiscreteDomain
Constructor for use by subclasses.
dispatchQueuedEvents() - Method in class com.google.common.eventbus.AsyncEventBus
Dispatch events in the order they were posted, regardless of the posting thread.
distance(C, C) - Method in class com.google.common.collect.DiscreteDomain
Returns a signed value indicating how many nested invocations of DiscreteDomain.next(C) (if positive) or DiscreteDomain.previous(C) (if negative) are needed to reach end starting from start.
divide(BigInteger, BigInteger, RoundingMode) - Static method in class com.google.common.math.BigIntegerMath
Returns the result of dividing p by q, rounding using the specified RoundingMode.
divide(int, int, RoundingMode) - Static method in class com.google.common.math.IntMath
Returns the result of dividing p by q, rounding using the specified RoundingMode.
divide(long, long, RoundingMode) - Static method in class com.google.common.math.LongMath
Returns the result of dividing p by q, rounding using the specified RoundingMode.
divide(int, int) - Static method in class com.google.common.primitives.UnsignedInts
Returns dividend / divisor, where the dividend and divisor are treated as unsigned 32-bit quantities.
divide(long, long) - Static method in class com.google.common.primitives.UnsignedLongs
Returns dividend / divisor, where the dividend and divisor are treated as unsigned 64-bit quantities.
dividedBy(UnsignedInteger) - Method in class com.google.common.primitives.UnsignedInteger
Returns the result of dividing this by val.
dividedBy(UnsignedLong) - Method in class com.google.common.primitives.UnsignedLong
Returns the result of dividing this by val.
DLE - Static variable in class com.google.common.base.Ascii
Data Link Escape: A communication control character which will change the meaning of a limited number of contiguously following characters.
DNT - Static variable in class com.google.common.net.HttpHeaders
The HTTP DNT header field name.
doBackward(B) - Method in class com.google.common.base.Converter
Returns a representation of b as an instance of type A.
doEquivalent(T, T) - Method in class com.google.common.base.Equivalence
Returns true if a and b are considered equivalent.
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
Returns a hash code for non-null object t.
done() - Method in class com.google.common.util.concurrent.ListenableFutureTask
Internal implementation detail used to invoke the listeners.
doNothing() - Static method in class com.google.common.util.concurrent.Runnables
Returns a Runnable instance that does nothing when run.
doStart() - Method in class com.google.common.util.concurrent.AbstractService
This method is called by AbstractService.startAsync() to initiate service startup.
doStop() - Method in class com.google.common.util.concurrent.AbstractService
This method should be used to initiate service shutdown.
DoubleMath - Class in com.google.common.math
A class for arithmetic on doubles that is not covered by Math.
Doubles - Class in com.google.common.primitives
Static utility methods pertaining to double primitives, that are not already found in either Double or Arrays.
doubleValue() - Method in class com.google.common.primitives.UnsignedInteger
Returns the value of this UnsignedInteger as a float, analogous to a widening primitive conversion from int to double, and correctly rounded.
doubleValue() - Method in class com.google.common.primitives.UnsignedLong
Returns the value of this UnsignedLong as a double, analogous to a widening primitive conversion from long to double, and correctly rounded.
doubleValue() - Method in class com.google.common.util.concurrent.AtomicDouble
Returns the value of this AtomicDouble as a double.
downTo(C, BoundType) - Static method in class com.google.common.collect.Range
Returns a range from the given endpoint, which may be either inclusive (closed) or exclusive (open), with no upper bound.
drain(BlockingQueue<E>, Collection<? super E>, int, long, TimeUnit) - Static method in class com.google.common.collect.Queues
Drains the queue as BlockingQueue.drainTo(Collection, int), but if the requested numElements elements are not available, it will wait for them up to the specified timeout.
drainTo(Collection<? super E>) - Method in class com.google.common.collect.ForwardingBlockingDeque
 
drainTo(Collection<? super E>, int) - Method in class com.google.common.collect.ForwardingBlockingDeque
 
drainTo(Collection<? super E>, int) - Method in class com.google.common.util.concurrent.ForwardingBlockingQueue
 
drainTo(Collection<? super E>) - Method in class com.google.common.util.concurrent.ForwardingBlockingQueue
 
drainUninterruptibly(BlockingQueue<E>, Collection<? super E>, int, long, TimeUnit) - Static method in class com.google.common.collect.Queues
Drains the queue as Queues.drain(BlockingQueue, Collection, int, long, TimeUnit), but with a different behavior in case it is interrupted while waiting.

E

elapsed(TimeUnit) - Method in class com.google.common.base.Stopwatch
Returns the current elapsed time shown on this stopwatch, expressed in the desired time unit, with any fraction rounded down.
element() - Method in class com.google.common.collect.ForwardingQueue
 
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.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.
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.
emptyIterator() - Static method in class com.google.common.collect.Iterators
Returns the empty iterator.
emptyToNull(String) - Static method in class com.google.common.base.Strings
Returns the given string if it is nonempty; null otherwise.
encloseAll(Iterable<C>) - Static method in class com.google.common.collect.Range
Returns the minimal range that contains all of the given values.
encloses(Range<C>) - Method in class com.google.common.collect.ImmutableRangeSet
 
encloses(Range<C>) - Method in class com.google.common.collect.Range
Returns true if the bounds of other do not extend outside the bounds of this range.
encloses(Range<C>) - Method in interface com.google.common.collect.RangeSet
Returns true if there exists a member range in this range set which encloses the specified range.
encloses(Range<C>) - Method in class com.google.common.collect.TreeRangeSet
 
enclosesAll(RangeSet<C>) - Method in interface com.google.common.collect.RangeSet
Returns true if for each member range in other there exists a member range in this range set which encloses it.
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.
ENQ - Static variable in class com.google.common.base.Ascii
Enquiry: A communication control character used in data communication systems as a request for a response from a remote station.
ensureCapacity(boolean[], int, int) - Static method in class com.google.common.primitives.Booleans
Returns an array containing the same values as array, but guaranteed to be of a specified minimum length.
ensureCapacity(byte[], int, int) - Static method in class com.google.common.primitives.Bytes
Returns an array containing the same values as array, but guaranteed to be of a specified minimum length.
ensureCapacity(char[], int, int) - Static method in class com.google.common.primitives.Chars
Returns an array containing the same values as array, but guaranteed to be of a specified minimum length.
ensureCapacity(double[], int, int) - Static method in class com.google.common.primitives.Doubles
Returns an array containing the same values as array, but guaranteed to be of a specified minimum length.
ensureCapacity(float[], int, int) - Static method in class com.google.common.primitives.Floats
Returns an array containing the same values as array, but guaranteed to be of a specified minimum length.
ensureCapacity(int[], int, int) - Static method in class com.google.common.primitives.Ints
Returns an array containing the same values as array, but guaranteed to be of a specified minimum length.
ensureCapacity(long[], int, int) - Static method in class com.google.common.primitives.Longs
Returns an array containing the same values as array, but guaranteed to be of a specified minimum length.
ensureCapacity(short[], int, int) - Static method in class com.google.common.primitives.Shorts
Returns an array containing the same values as array, but guaranteed to be of a specified minimum length.
enter() - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor.
enter(long, TimeUnit) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor.
enterIf(Monitor.Guard) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor if the guard is satisfied.
enterIf(Monitor.Guard, long, TimeUnit) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor if the guard is satisfied.
enterIfInterruptibly(Monitor.Guard) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor if the guard is satisfied.
enterIfInterruptibly(Monitor.Guard, long, TimeUnit) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor if the guard is satisfied.
enterInterruptibly() - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor.
enterInterruptibly(long, TimeUnit) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor.
enterWhen(Monitor.Guard) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor when the guard is satisfied.
enterWhen(Monitor.Guard, long, TimeUnit) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor when the guard is satisfied.
enterWhenUninterruptibly(Monitor.Guard) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor when the guard is satisfied.
enterWhenUninterruptibly(Monitor.Guard, long, TimeUnit) - Method in class com.google.common.util.concurrent.Monitor
Enters this monitor when the guard is satisfied.
entries() - Method in class com.google.common.collect.ForwardingMultimap
 
entries() - Method in class com.google.common.collect.ForwardingSetMultimap
 
entries() - Method in class com.google.common.collect.ImmutableMultimap
Returns an immutable collection of all key-value pairs in the multimap.
entries() - Method in class com.google.common.collect.ImmutableSetMultimap
Returns an immutable collection of all key-value pairs in the multimap.
entries() - Method in class com.google.common.collect.LinkedHashMultimap
Returns a set of all key-value pairs.
entries() - Method in class com.google.common.collect.LinkedListMultimap
Returns a view collection of all key-value pairs contained in this multimap, as Map.Entry instances.
entries() - Method in interface com.google.common.collect.Multimap
Returns a view collection of all key-value pairs contained in this multimap, as Map.Entry instances.
entries() - Method in interface com.google.common.collect.SetMultimap
Returns a view collection of all key-value pairs contained in this multimap, as Map.Entry instances.
entriesDiffering() - Method in interface com.google.common.collect.MapDifference
Returns an unmodifiable map describing keys that appear in both maps, but with different values.
entriesDiffering() - Method in interface com.google.common.collect.SortedMapDifference
 
entriesInCommon() - Method in interface com.google.common.collect.MapDifference
Returns an unmodifiable map containing the entries that appear in both maps; that is, the intersection of the two maps.
entriesInCommon() - Method in interface com.google.common.collect.SortedMapDifference
 
entriesOnlyOnLeft() - Method in interface com.google.common.collect.MapDifference
Returns an unmodifiable map containing the entries from the left map whose keys are not present in the right map.
entriesOnlyOnLeft() - Method in interface com.google.common.collect.SortedMapDifference
 
entriesOnlyOnRight() - Method in interface com.google.common.collect.MapDifference
Returns an unmodifiable map containing the entries from the right map whose keys are not present in the left map.
entriesOnlyOnRight() - Method in interface com.google.common.collect.SortedMapDifference
 
entryIterator() - Method in class com.google.common.collect.ForwardingNavigableMap.StandardDescendingMap
 
entrySet() - Method in class com.google.common.collect.ConcurrentHashMultiset
 
entrySet() - Method in class com.google.common.collect.ForwardingMap
 
entrySet() - Method in class com.google.common.collect.ForwardingMultiset
 
entrySet() - Method in class com.google.common.collect.HashBiMap
 
entrySet() - 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 interface com.google.common.collect.SortedMultiset
Returns a view of the contents of this multiset, grouped into Multiset.Entry instances, each providing an element of the multiset and the count of that element.
entrySet() - Method in class com.google.common.reflect.MutableTypeToInstanceMap
 
EnumBiMap<K extends Enum<K>,V extends Enum<V>> - Class in com.google.common.collect
A BiMap backed by two EnumMap instances.
EnumHashBiMap<K extends Enum<K>,V> - Class in com.google.common.collect
A BiMap backed by an EnumMap instance for keys-to-values, and a HashMap instance for values-to-keys.
enumKeys(Class<K0>) - Static method in class com.google.common.collect.MultimapBuilder
Uses an EnumMap to map keys to value collections.
EnumMultiset<E extends Enum<E>> - Class in com.google.common.collect
Multiset implementation backed by an EnumMap.
Enums - Class in com.google.common.base
Utility methods for working with Enum instances.
enumSetValues(Class<V0>) - Method in class com.google.common.collect.MultimapBuilder.MultimapBuilderWithKeys
Uses an EnumSet to store value collections.
EOT - Static variable in class com.google.common.base.Ascii
End of Transmission: A communication control character used to indicate the conclusion of a transmission, which may have contained one or more texts and any associated headings.
EOT - Static variable in class com.google.common.net.MediaType
Media type for Embedded OpenType fonts.
EPUB - Static variable in class com.google.common.net.MediaType
As described in the International Digital Publishing Forum EPUB is the distribution and interchange format standard for digital publications and documents.
equal(Object, Object) - Static method in class com.google.common.base.Objects
Determines whether two possibly-null objects are equal.
equal(InputSupplier<? extends InputStream>, InputSupplier<? extends InputStream>) - Static method in class com.google.common.io.ByteStreams
Deprecated.
Use ByteSource.contentEquals(ByteSource) instead. This method is scheduled for removal in Guava 18.0.
equal(File, File) - Static method in class com.google.common.io.Files
Returns true if the files contains the same bytes.
equals(Object) - Method in class com.google.common.base.Converter
Indicates whether another object is equal to this converter.
equals() - Static method in class com.google.common.base.Equivalence
Returns an equivalence that delegates to Object.equals(java.lang.Object) and Object.hashCode().
equals(Object) - Method in class com.google.common.base.Equivalence.Wrapper
Returns true if Equivalence.equivalent(Object, Object) applied to the wrapped references is true and both wrappers use the same equivalence.
equals(Object) - Method in interface com.google.common.base.Function
Indicates whether another object is equal 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.cache.RemovalNotification
 
equals(Object) - Method in class com.google.common.collect.ForwardingList
 
equals(Object) - Method in class com.google.common.collect.ForwardingMap
 
equals(Object) - Method in class com.google.common.collect.ForwardingMapEntry
 
equals(Object) - Method in class com.google.common.collect.ForwardingMultimap
 
equals(Object) - Method in class com.google.common.collect.ForwardingMultiset
 
equals(Object) - Method in class com.google.common.collect.ForwardingSet
 
equals(Object) - Method in class com.google.common.collect.ForwardingTable
 
equals(Object) - Method in class com.google.common.collect.HashBasedTable
 
equals(Object) - Method in class com.google.common.collect.ImmutableList
 
equals(Object) - Method in class com.google.common.collect.ImmutableMap
 
equals(Object) - Method in class com.google.common.collect.ImmutableMultiset
 
equals(Object) - Method in class com.google.common.collect.ImmutableRangeMap
 
equals(Object) - Method in class com.google.common.collect.ImmutableSet
 
equals(Object) - Method in interface com.google.common.collect.ListMultimap
Compares the specified object to this multimap for equality.
equals(Object) - Method in interface com.google.common.collect.MapDifference
Compares the specified object with this instance for equality.
equals(Object) - Method in interface com.google.common.collect.MapDifference.ValueDifference
Two instances are considered equal if their MapDifference.ValueDifference.leftValue() values are equal and their MapDifference.ValueDifference.rightValue() values are also equal.
equals(Object) - Method in interface com.google.common.collect.Multimap
Compares the specified object with this multimap for equality.
equals(Object) - Method in interface com.google.common.collect.Multiset.Entry
Indicates whether some other object is "equal to" this one.
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.hash.BloomFilter
 
equals(Object) - Method in class com.google.common.hash.HashCode
 
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.UnsignedInteger
 
equals(Object) - Method in class com.google.common.primitives.UnsignedLong
 
equals(Object) - Method in class com.google.common.reflect.AbstractInvocationHandler
By default delegates to Object.equals(java.lang.Object) so instances are only equal if they are identical.
equals(Object) - Method in class com.google.common.reflect.ClassPath.ResourceInfo
 
equals(Object) - Method in class com.google.common.reflect.Parameter
 
equals(Object) - Method in class com.google.common.reflect.TypeParameter
 
equals(Object) - Method in class com.google.common.reflect.TypeToken
Returns true if o is another TypeToken that represents the same Type.
equalsIgnoreCase(CharSequence, CharSequence) - Static method in class com.google.common.base.Ascii
Indicates whether the contents of the given character sequences s1 and s2 are equal, ignoring the case of any ASCII alphabetic characters between 'a' and 'z' or 'A' and 'Z' inclusive.
equalTo(T) - Static method in class com.google.common.base.Predicates
Returns a predicate that evaluates to true if the object being tested equals() the given target or both are null.
Equivalence<T> - Class in com.google.common.base
A strategy for determining whether two instances are considered equivalent.
Equivalence() - Constructor for class com.google.common.base.Equivalence
Constructor for use by subclasses.
Equivalence.Wrapper<T> - Class in com.google.common.base
equivalent(T, T) - Method in class com.google.common.base.Equivalence
Returns true if the given objects are considered equivalent.
equivalentTo(T) - Method in class com.google.common.base.Equivalence
Returns a predicate that evaluates to true if and only if the input is equivalent to target according to this equivalence relation.
erase(Object, Object) - Method in class com.google.common.collect.ArrayTable
Associates the value null with the specified keys, assuming both keys are valid.
eraseAll() - Method in class com.google.common.collect.ArrayTable
Associates the value null with every pair of allowed row and column keys.
ESC - Static variable in class com.google.common.base.Ascii
Escape: A control character intended to provide code extension (supplementary characters) in general information interchange.
escape(String) - Method in class com.google.common.escape.ArrayBasedCharEscaper
 
escape(char) - Method in class com.google.common.escape.ArrayBasedCharEscaper
Escapes a single character using the replacement array and safe range values.
escape(String) - Method in class com.google.common.escape.ArrayBasedUnicodeEscaper
 
escape(int) - Method in class com.google.common.escape.ArrayBasedUnicodeEscaper
Escapes a single Unicode code point using the replacement array and safe range values.
escape(String) - Method in class com.google.common.escape.CharEscaper
Returns the escaped form of a given literal string.
escape(char) - Method in class com.google.common.escape.CharEscaper
Returns the escaped form of the given character, or null if this character does not need to be escaped.
escape(String) - Method in class com.google.common.escape.Escaper
Returns the escaped form of a given literal string.
escape(int) - Method in class com.google.common.escape.UnicodeEscaper
Returns the escaped form of the given Unicode code point, or null if this code point does not need to be escaped.
escape(String) - Method in class com.google.common.escape.UnicodeEscaper
Returns the escaped form of a given literal string.
escape(String) - Method in class com.google.common.net.PercentEscaper
 
escape(int) - Method in class com.google.common.net.PercentEscaper
Escapes the given Unicode code point in UTF-8.
Escaper - Class in com.google.common.escape
An object that converts literal text into a format safe for inclusion in a particular context (such as an XML document).
Escaper() - Constructor for class com.google.common.escape.Escaper
Constructor for use by subclasses.
Escapers - Class in com.google.common.escape
Static utility methods pertaining to Escaper instances.
Escapers.Builder - Class in com.google.common.escape
A builder for simple, fast escapers.
escapeSlow(String, int) - Method in class com.google.common.escape.CharEscaper
Returns the escaped form of a given literal string, starting at the given index.
escapeSlow(String, int) - Method in class com.google.common.escape.UnicodeEscaper
Returns the escaped form of a given literal string, starting at the given index.
escapeUnsafe(char) - Method in class com.google.common.escape.ArrayBasedCharEscaper
Escapes a char value that has no direct explicit value in the replacement array and lies outside the stated safe range.
escapeUnsafe(int) - Method in class com.google.common.escape.ArrayBasedUnicodeEscaper
Escapes a code point that has no direct explicit value in the replacement array and lies outside the stated safe range.
ETAG - Static variable in class com.google.common.net.HttpHeaders
The HTTP ETag header field name.
ETB - Static variable in class com.google.common.base.Ascii
End of Transmission Block: A communication control character used to indicate the end of a block of data for communication purposes.
ETX - Static variable in class com.google.common.base.Ascii
End of Text: A communication control character used to terminate a sequence of characters started with STX and transmitted as an entity.
EventBus - Class in com.google.common.eventbus
Dispatches events to listeners, and provides ways for listeners to register themselves.
EventBus() - Constructor for class com.google.common.eventbus.EventBus
Creates a new EventBus named "default".
EventBus(String) - Constructor for class com.google.common.eventbus.EventBus
Creates a new EventBus with the given identifier.
EventBus(SubscriberExceptionHandler) - Constructor for class com.google.common.eventbus.EventBus
Creates a new EventBus with the given SubscriberExceptionHandler.
EvictingQueue<E> - Class in com.google.common.collect
A non-blocking queue which automatically evicts elements from the head of the queue when attempting to add new elements onto the queue and it is full.
evictionCount() - Method in class com.google.common.cache.CacheStats
Returns the number of times an entry has been evicted.
execute() - Method in class com.google.common.util.concurrent.ExecutionList
Runs this execution list, executing all existing pairs in the order they were added.
execute(Runnable) - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
ExecutionError - Error in com.google.common.util.concurrent
ExecutionError() - Constructor for error com.google.common.util.concurrent.ExecutionError
Creates a new instance with null as its detail message.
ExecutionError(String) - Constructor for error com.google.common.util.concurrent.ExecutionError
Creates a new instance with the given detail message.
ExecutionError(String, Error) - Constructor for error com.google.common.util.concurrent.ExecutionError
Creates a new instance with the given detail message and cause.
ExecutionError(Error) - Constructor for error com.google.common.util.concurrent.ExecutionError
Creates a new instance with the given cause.
ExecutionList - Class in com.google.common.util.concurrent
A list of listeners, each with an associated Executor, that guarantees that every Runnable that is added will be executed after ExecutionList.execute() is called.
ExecutionList() - Constructor for class com.google.common.util.concurrent.ExecutionList
Creates a new, empty ExecutionList.
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
EXPECT - Static variable in class com.google.common.net.HttpHeaders
The HTTP Expect header field name.
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.
expectedSize(int) - Method in class com.google.common.collect.MinMaxPriorityQueue.Builder
Configures this builder to build min-max priority queues with an initial expected size of expectedSize.
expectedSize(int) - Static method in class com.google.common.collect.MinMaxPriorityQueue
Creates and returns a new builder, configured to build MinMaxPriorityQueue instances sized appropriately to hold expectedSize elements.
expireAfterAccess(long, TimeUnit) - Method in class com.google.common.cache.CacheBuilder
Specifies that each entry should be automatically removed from the cache once a fixed duration has elapsed after the entry's creation, the most recent replacement of its value, or its last access.
expireAfterWrite(long, TimeUnit) - Method in class com.google.common.cache.CacheBuilder
Specifies that each entry should be automatically removed from the cache once a fixed duration has elapsed after the entry's creation, or the most recent replacement of its value.
EXPIRES - Static variable in class com.google.common.net.HttpHeaders
The HTTP Expires header field name.
explicit(List<T>) - Static method in class com.google.common.collect.Ordering
Returns an ordering that compares objects according to the order in which they appear in the given list.
explicit(T, T...) - Static method in class com.google.common.collect.Ordering
Returns an ordering that compares objects according to the order in which they are given to this method.

F

factorial(int) - Static method in class com.google.common.math.BigIntegerMath
Returns n!, that is, the product of the first n positive integers, or 1 if n == 0.
factorial(int) - Static method in class com.google.common.math.DoubleMath
Returns n!, that is, the product of the first n positive integers, 1 if n == 0, or e n!}, or Double.POSITIVE_INFINITY if n! > Double.MAX_VALUE.
factorial(int) - Static method in class com.google.common.math.IntMath
Returns n!, that is, the product of the first n positive integers, 1 if n == 0, or Integer.MAX_VALUE if the result does not fit in a int.
factorial(int) - Static method in class com.google.common.math.LongMath
Returns n!, that is, the product of the first n positive integers, 1 if n == 0, or Long.MAX_VALUE if the result does not fit in a long.
failed(Service.State, Throwable) - Method in class com.google.common.util.concurrent.Service.Listener
Called when the service transitions to the FAILED state.
failure(Service) - Method in class com.google.common.util.concurrent.ServiceManager.Listener
Called when a component service has failed.
failureCause() - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
 
failureCause() - Method in class com.google.common.util.concurrent.AbstractIdleService
 
failureCause() - Method in class com.google.common.util.concurrent.AbstractScheduledService
 
failureCause() - Method in class com.google.common.util.concurrent.AbstractService
 
failureCause() - Method in interface com.google.common.util.concurrent.Service
Returns the Throwable that caused this service to fail.
FakeTimeLimiter - Class in com.google.common.util.concurrent
A TimeLimiter implementation which actually does not attempt to limit time at all.
FakeTimeLimiter() - Constructor for class com.google.common.util.concurrent.FakeTimeLimiter
 
FF - Static variable in class com.google.common.base.Ascii
Form Feed ('\f'): A format effector which controls the movement of the printing position to the first pre-determined printing line on the next form or page.
FileBackedOutputStream - Class in com.google.common.io
An OutputStream that starts buffering to a byte array, but switches to file buffering once the data reaches a configurable size.
FileBackedOutputStream(int) - Constructor for class com.google.common.io.FileBackedOutputStream
Creates a new instance that uses the given file threshold, and does not reset the data when the ByteSource returned by FileBackedOutputStream.asByteSource() is finalized.
FileBackedOutputStream(int, boolean) - Constructor for class com.google.common.io.FileBackedOutputStream
Creates a new instance that uses the given file threshold, and optionally resets the data when the ByteSource returned by FileBackedOutputStream.asByteSource() is finalized.
Files - Class in com.google.common.io
Provides utility methods for working with files.
fileTreeTraverser() - Static method in class com.google.common.io.Files
Returns a TreeTraverser instance for File trees.
FileWriteMode - Enum in com.google.common.io
Modes for opening a file for writing.
filter(Collection<E>, Predicate<? super E>) - Static method in class com.google.common.collect.Collections2
Returns the elements of unfiltered that satisfy a predicate.
filter(Predicate<? super E>) - Method in class com.google.common.collect.FluentIterable
Returns the elements from this fluent iterable that satisfy a predicate.
filter(Class<T>) - Method in class com.google.common.collect.FluentIterable
Returns the elements from this fluent iterable that are instances of class type.
filter(Iterable<T>, Predicate<? super T>) - Static method in class com.google.common.collect.Iterables
Returns the elements of unfiltered that satisfy a predicate.
filter(Iterable<?>, Class<T>) - Static method in class com.google.common.collect.Iterables
Returns all instances of class type in unfiltered.
filter(Iterator<T>, Predicate<? super T>) - Static method in class com.google.common.collect.Iterators
Returns the elements of unfiltered that satisfy a predicate.
filter(Iterator<?>, Class<T>) - Static method in class com.google.common.collect.Iterators
Returns all instances of class type in unfiltered.
filter(Multiset<E>, Predicate<? super E>) - Static method in class com.google.common.collect.Multisets
Returns a view of the elements of unfiltered that satisfy a predicate.
filter(Set<E>, Predicate<? super E>) - Static method in class com.google.common.collect.Sets
Returns the elements of unfiltered that satisfy a predicate.
filter(SortedSet<E>, Predicate<? super E>) - Static method in class com.google.common.collect.Sets
Returns the elements of a SortedSet, unfiltered, that satisfy a predicate.
filter(NavigableSet<E>, Predicate<? super E>) - Static method in class com.google.common.collect.Sets
Returns the elements of a NavigableSet, unfiltered, that satisfy a predicate.
filterEntries(Map<K, V>, Predicate<? super Map.Entry<K, V>>) - Static method in class com.google.common.collect.Maps
Returns a map containing the mappings in unfiltered that satisfy a predicate.
filterEntries(SortedMap<K, V>, Predicate<? super Map.Entry<K, V>>) - Static method in class com.google.common.collect.Maps
Returns a sorted map containing the mappings in unfiltered that satisfy a predicate.
filterEntries(NavigableMap<K, V>, Predicate<? super Map.Entry<K, V>>) - Static method in class com.google.common.collect.Maps
Returns a sorted map containing the mappings in unfiltered that satisfy a predicate.
filterEntries(BiMap<K, V>, Predicate<? super Map.Entry<K, V>>) - Static method in class com.google.common.collect.Maps
Returns a bimap containing the mappings in unfiltered that satisfy a predicate.
filterEntries(Multimap<K, V>, Predicate<? super Map.Entry<K, V>>) - Static method in class com.google.common.collect.Multimaps
Returns a multimap containing the mappings in unfiltered that satisfy a predicate.
filterEntries(SetMultimap<K, V>, Predicate<? super Map.Entry<K, V>>) - Static method in class com.google.common.collect.Multimaps
Returns a multimap containing the mappings in unfiltered that satisfy a predicate.
filterKeys(Map<K, V>, Predicate<? super K>) - Static method in class com.google.common.collect.Maps
Returns a map containing the mappings in unfiltered whose keys satisfy a predicate.
filterKeys(SortedMap<K, V>, Predicate<? super K>) - Static method in class com.google.common.collect.Maps
Returns a sorted map containing the mappings in unfiltered whose keys satisfy a predicate.
filterKeys(NavigableMap<K, V>, Predicate<? super K>) - Static method in class com.google.common.collect.Maps
Returns a navigable map containing the mappings in unfiltered whose keys satisfy a predicate.
filterKeys(BiMap<K, V>, Predicate<? super K>) - Static method in class com.google.common.collect.Maps
Returns a bimap containing the mappings in unfiltered whose keys satisfy a predicate.
filterKeys(Multimap<K, V>, Predicate<? super K>) - Static method in class com.google.common.collect.Multimaps
Returns a multimap containing the mappings in unfiltered whose keys satisfy a predicate.
filterKeys(SetMultimap<K, V>, Predicate<? super K>) - Static method in class com.google.common.collect.Multimaps
Returns a multimap containing the mappings in unfiltered whose keys satisfy a predicate.
filterKeys(ListMultimap<K, V>, Predicate<? super K>) - Static method in class com.google.common.collect.Multimaps
Returns a multimap containing the mappings in unfiltered whose keys satisfy a predicate.
filterValues(Map<K, V>, Predicate<? super V>) - Static method in class com.google.common.collect.Maps
Returns a map containing the mappings in unfiltered whose values satisfy a predicate.
filterValues(SortedMap<K, V>, Predicate<? super V>) - Static method in class com.google.common.collect.Maps
Returns a sorted map containing the mappings in unfiltered whose values satisfy a predicate.
filterValues(NavigableMap<K, V>, Predicate<? super V>) - Static method in class com.google.common.collect.Maps
Returns a navigable map containing the mappings in unfiltered whose values satisfy a predicate.
filterValues(BiMap<K, V>, Predicate<? super V>) - Static method in class com.google.common.collect.Maps
Returns a bimap containing the mappings in unfiltered whose values satisfy a predicate.
filterValues(Multimap<K, V>, Predicate<? super V>) - Static method in class com.google.common.collect.Multimaps
Returns a multimap containing the mappings in unfiltered whose values satisfy a predicate.
filterValues(SetMultimap<K, V>, Predicate<? super V>) - Static method in class com.google.common.collect.Multimaps
Returns a multimap containing the mappings in unfiltered whose values satisfy a predicate.
FinalizablePhantomReference<T> - Class in com.google.common.base
Phantom reference with a finalizeReferent() method which a background thread invokes after the garbage collector reclaims the referent.
FinalizablePhantomReference(T, FinalizableReferenceQueue) - Constructor for class com.google.common.base.FinalizablePhantomReference
Constructs a new finalizable phantom reference.
FinalizableReference - Interface in com.google.common.base
Implemented by references that have code to run after garbage collection of their referents.
FinalizableReferenceQueue - Class in com.google.common.base
A reference queue with an associated background thread that dequeues references and invokes FinalizableReference.finalizeReferent() on them.
FinalizableReferenceQueue() - Constructor for class com.google.common.base.FinalizableReferenceQueue
Constructs a new queue.
FinalizableSoftReference<T> - Class in com.google.common.base
Soft reference with a finalizeReferent() method which a background thread invokes after the garbage collector reclaims the referent.
FinalizableSoftReference(T, FinalizableReferenceQueue) - Constructor for class com.google.common.base.FinalizableSoftReference
Constructs a new finalizable soft reference.
FinalizableWeakReference<T> - Class in com.google.common.base
Weak reference with a finalizeReferent() method which a background thread invokes after the garbage collector reclaims the referent.
FinalizableWeakReference(T, FinalizableReferenceQueue) - Constructor for class com.google.common.base.FinalizableWeakReference
Constructs a new finalizable weak reference.
finalizeReferent() - Method in interface com.google.common.base.FinalizableReference
Invoked on a background thread after the referent has been garbage collected unless security restrictions prevented starting a background thread, in which case this method is invoked when new references are created.
find(Iterable<T>, Predicate<? super T>) - Static method in class com.google.common.collect.Iterables
Returns the first element in iterable that satisfies the given predicate; use this method only when such an element is known to exist.
find(Iterable<? extends T>, Predicate<? super T>, T) - Static method in class com.google.common.collect.Iterables
Returns the first element in iterable that satisfies the given predicate, or defaultValue if none found.
find(Iterator<T>, Predicate<? super T>) - Static method in class com.google.common.collect.Iterators
Returns the first element in iterator that satisfies the given predicate; use this method only when such an element is known to exist.
find(Iterator<? extends T>, Predicate<? super T>, T) - Static method in class com.google.common.collect.Iterators
Returns the first element in iterator that satisfies the given predicate.
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.Objects
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.
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
 
FluentIterable<E> - Class in com.google.common.collect
FluentIterable provides a rich interface for manipulating Iterable instances in a chained fashion.
FluentIterable() - Constructor for class com.google.common.collect.FluentIterable
Constructor for use by subclasses.
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.
FOLLOW_ONLY_WHEN_PRERENDER_SHOWN - Static variable in class com.google.common.net.HttpHeaders
The HTTP Follow-Only-When-Prerender-Shown header field name.
forArray(T...) - Static method in class com.google.common.collect.Iterators
Returns an iterator containing the elements of array in order.
forcePut(K, V) - Method in interface com.google.common.collect.BiMap
An alternate form of put that silently removes any existing entry with the value value before proceeding with the BiMap.put(K, V) operation.
forcePut(K, V) - Method in class com.google.common.collect.EnumHashBiMap
 
forcePut(K, V) - Method in class com.google.common.collect.HashBiMap
 
forcePut(K, V) - Method in class com.google.common.collect.ImmutableBiMap
Deprecated.
Unsupported operation.
forEnumeration(Enumeration<T>) - Static method in class com.google.common.collect.Iterators
Adapts an Enumeration to the Iterator interface.
FORM_DATA - Static variable in class com.google.common.net.MediaType
 
forMap(Map<K, V>) - Static method in class com.google.common.base.Functions
Returns a function which performs a map lookup.
forMap(Map<K, ? extends V>, V) - Static method in class com.google.common.base.Functions
Returns a function which performs a map lookup with a default value.
forMap(Map<K, V>) - Static method in class com.google.common.collect.Multimaps
Returns a multimap view of the specified map.
forPredicate(Predicate<? super Character>) - Static method in class com.google.common.base.CharMatcher
Returns a matcher with identical behavior to the given Character-based predicate, but which operates on primitive char instances instead.
forPredicate(Predicate<T>) - Static method in class com.google.common.base.Functions
Creates a function that returns the same boolean output as the given predicate for all inputs.
forString(String) - Static method in class com.google.common.net.InetAddresses
Returns the InetAddress having the given string representation.
forSupplier(Supplier<T>) - Static method in class com.google.common.base.Functions
Returns a function that always returns the result of invoking Supplier.get() on supplier, regardless of its input.
forUriString(String) - Static method in class com.google.common.net.InetAddresses
Returns an InetAddress representing the literal IPv4 or IPv6 host portion of a URL, encoded in the format specified by RFC 3986 section 3.2.2.
ForwardingBlockingDeque<E> - Class in com.google.common.collect
A BlockingDeque which forwards all its method calls to another BlockingDeque.
ForwardingBlockingDeque() - Constructor for class com.google.common.collect.ForwardingBlockingDeque
Constructor for use by subclasses.
ForwardingBlockingQueue<E> - Class in com.google.common.util.concurrent
A BlockingQueue which forwards all its method calls to another BlockingQueue.
ForwardingBlockingQueue() - Constructor for class com.google.common.util.concurrent.ForwardingBlockingQueue
Constructor for use by subclasses.
ForwardingCache<K,V> - Class in com.google.common.cache
A cache which forwards all its method calls to another cache.
ForwardingCache() - Constructor for class com.google.common.cache.ForwardingCache
Constructor for use by subclasses.
ForwardingCache.SimpleForwardingCache<K,V> - Class in com.google.common.cache
A simplified version of ForwardingCache where subclasses can pass in an already constructed Cache as the delegete.
ForwardingCache.SimpleForwardingCache(Cache<K, V>) - Constructor for class com.google.common.cache.ForwardingCache.SimpleForwardingCache
 
ForwardingCheckedFuture<V,X extends Exception> - Class in com.google.common.util.concurrent
A future which forwards all its method calls to another future.
ForwardingCheckedFuture() - Constructor for class com.google.common.util.concurrent.ForwardingCheckedFuture
 
ForwardingCheckedFuture.SimpleForwardingCheckedFuture<V,X extends Exception> - Class in com.google.common.util.concurrent
A simplified version of ForwardingCheckedFuture where subclasses can pass in an already constructed CheckedFuture as the delegate.
ForwardingCheckedFuture.SimpleForwardingCheckedFuture(CheckedFuture<V, X>) - Constructor for class com.google.common.util.concurrent.ForwardingCheckedFuture.SimpleForwardingCheckedFuture
 
ForwardingCollection<E> - Class in com.google.common.collect
A collection which forwards all its method calls to another collection.
ForwardingCollection() - Constructor for class com.google.common.collect.ForwardingCollection
Constructor for use by subclasses.
ForwardingConcurrentMap<K,V> - Class in com.google.common.collect
A concurrent map which forwards all its method calls to another concurrent map.
ForwardingConcurrentMap() - Constructor for class com.google.common.collect.ForwardingConcurrentMap
Constructor for use by subclasses.
ForwardingDeque<E> - Class in com.google.common.collect
A deque which forwards all its method calls to another deque.
ForwardingDeque() - Constructor for class com.google.common.collect.ForwardingDeque
Constructor for use by subclasses.
ForwardingExecutorService - Class in com.google.common.util.concurrent
An executor service which forwards all its method calls to another executor service.
ForwardingExecutorService() - Constructor for class com.google.common.util.concurrent.ForwardingExecutorService
Constructor for use by subclasses.
ForwardingFuture<V> - Class in com.google.common.util.concurrent
A Future which forwards all its method calls to another future.
ForwardingFuture() - Constructor for class com.google.common.util.concurrent.ForwardingFuture
Constructor for use by subclasses.
ForwardingFuture.SimpleForwardingFuture<V> - Class in com.google.common.util.concurrent
A simplified version of ForwardingFuture where subclasses can pass in an already constructed Future as the delegate.
ForwardingFuture.SimpleForwardingFuture(Future<V>) - Constructor for class com.google.common.util.concurrent.ForwardingFuture.SimpleForwardingFuture
 
ForwardingIterator<T> - Class in com.google.common.collect
An iterator which forwards all its method calls to another iterator.
ForwardingIterator() - Constructor for class com.google.common.collect.ForwardingIterator
Constructor for use by subclasses.
ForwardingList<E> - Class in com.google.common.collect
A list which forwards all its method calls to another list.
ForwardingList() - Constructor for class com.google.common.collect.ForwardingList
Constructor for use by subclasses.
ForwardingListenableFuture<V> - Class in com.google.common.util.concurrent
A ListenableFuture which forwards all its method calls to another future.
ForwardingListenableFuture() - Constructor for class com.google.common.util.concurrent.ForwardingListenableFuture
Constructor for use by subclasses.
ForwardingListenableFuture.SimpleForwardingListenableFuture<V> - Class in com.google.common.util.concurrent
A simplified version of ForwardingListenableFuture where subclasses can pass in an already constructed ListenableFuture as the delegate.
ForwardingListenableFuture.SimpleForwardingListenableFuture(ListenableFuture<V>) - Constructor for class com.google.common.util.concurrent.ForwardingListenableFuture.SimpleForwardingListenableFuture
 
ForwardingListeningExecutorService - Class in com.google.common.util.concurrent
A listening executor service which forwards all its method calls to another listening executor service.
ForwardingListeningExecutorService() - Constructor for class com.google.common.util.concurrent.ForwardingListeningExecutorService
Constructor for use by subclasses.
ForwardingListIterator<E> - Class in com.google.common.collect
A list iterator which forwards all its method calls to another list iterator.
ForwardingListIterator() - Constructor for class com.google.common.collect.ForwardingListIterator
Constructor for use by subclasses.
ForwardingListMultimap<K,V> - Class in com.google.common.collect
A list multimap which forwards all its method calls to another list multimap.
ForwardingListMultimap() - Constructor for class com.google.common.collect.ForwardingListMultimap
Constructor for use by subclasses.
ForwardingLoadingCache<K,V> - Class in com.google.common.cache
A cache which forwards all its method calls to another cache.
ForwardingLoadingCache() - Constructor for class com.google.common.cache.ForwardingLoadingCache
Constructor for use by subclasses.
ForwardingLoadingCache.SimpleForwardingLoadingCache<K,V> - Class in com.google.common.cache
A simplified version of ForwardingLoadingCache where subclasses can pass in an already constructed LoadingCache as the delegete.
ForwardingLoadingCache.SimpleForwardingLoadingCache(LoadingCache<K, V>) - Constructor for class com.google.common.cache.ForwardingLoadingCache.SimpleForwardingLoadingCache
 
ForwardingMap<K,V> - Class in com.google.common.collect
A map which forwards all its method calls to another map.
ForwardingMap() - Constructor for class com.google.common.collect.ForwardingMap
Constructor for use by subclasses.
ForwardingMap.StandardEntrySet - Class in com.google.common.collect
ForwardingMap.StandardEntrySet() - Constructor for class com.google.common.collect.ForwardingMap.StandardEntrySet
Constructor for use by subclasses.
ForwardingMap.StandardKeySet - Class in com.google.common.collect
ForwardingMap.StandardKeySet() - Constructor for class com.google.common.collect.ForwardingMap.StandardKeySet
Constructor for use by subclasses.
ForwardingMap.StandardValues - Class in com.google.common.collect
ForwardingMap.StandardValues() - Constructor for class com.google.common.collect.ForwardingMap.StandardValues
Constructor for use by subclasses.
ForwardingMapEntry<K,V> - Class in com.google.common.collect
A map entry which forwards all its method calls to another map entry.
ForwardingMapEntry() - Constructor for class com.google.common.collect.ForwardingMapEntry
Constructor for use by subclasses.
ForwardingMultimap<K,V> - Class in com.google.common.collect
A multimap which forwards all its method calls to another multimap.
ForwardingMultimap() - Constructor for class com.google.common.collect.ForwardingMultimap
Constructor for use by subclasses.
ForwardingMultiset<E> - Class in com.google.common.collect
A multiset which forwards all its method calls to another multiset.
ForwardingMultiset() - Constructor for class com.google.common.collect.ForwardingMultiset
Constructor for use by subclasses.
ForwardingMultiset.StandardElementSet - Class in com.google.common.collect
ForwardingMultiset.StandardElementSet() - Constructor for class com.google.common.collect.ForwardingMultiset.StandardElementSet
Constructor for use by subclasses.
ForwardingNavigableMap<K,V> - Class in com.google.common.collect
A navigable map which forwards all its method calls to another navigable map.
ForwardingNavigableMap() - Constructor for class com.google.common.collect.ForwardingNavigableMap
Constructor for use by subclasses.
ForwardingNavigableMap.StandardDescendingMap - Class in com.google.common.collect
A sensible implementation of NavigableMap.descendingMap() in terms of the methods of this NavigableMap.
ForwardingNavigableMap.StandardDescendingMap() - Constructor for class com.google.common.collect.ForwardingNavigableMap.StandardDescendingMap
Constructor for use by subclasses.
ForwardingNavigableMap.StandardNavigableKeySet - Class in com.google.common.collect
A sensible implementation of NavigableMap.navigableKeySet() in terms of the methods of this NavigableMap.
ForwardingNavigableMap.StandardNavigableKeySet() - Constructor for class com.google.common.collect.ForwardingNavigableMap.StandardNavigableKeySet
Constructor for use by subclasses.
ForwardingNavigableSet<E> - Class in com.google.common.collect
A navigable set which forwards all its method calls to another navigable set.
ForwardingNavigableSet() - Constructor for class com.google.common.collect.ForwardingNavigableSet
Constructor for use by subclasses.
ForwardingNavigableSet.StandardDescendingSet - Class in com.google.common.collect
A sensible implementation of NavigableSet.descendingSet() in terms of the other methods of NavigableSet, notably including NavigableSet.descendingIterator().
ForwardingNavigableSet.StandardDescendingSet() - Constructor for class com.google.common.collect.ForwardingNavigableSet.StandardDescendingSet
Constructor for use by subclasses.
ForwardingObject - Class in com.google.common.collect
An abstract base class for implementing the decorator pattern.
ForwardingObject() - Constructor for class com.google.common.collect.ForwardingObject
Constructor for use by subclasses.
ForwardingQueue<E> - Class in com.google.common.collect
A queue which forwards all its method calls to another queue.
ForwardingQueue() - Constructor for class com.google.common.collect.ForwardingQueue
Constructor for use by subclasses.
ForwardingSet<E> - Class in com.google.common.collect
A set which forwards all its method calls to another set.
ForwardingSet() - Constructor for class com.google.common.collect.ForwardingSet
Constructor for use by subclasses.
ForwardingSetMultimap<K,V> - Class in com.google.common.collect
A set multimap which forwards all its method calls to another set multimap.
ForwardingSetMultimap() - Constructor for class com.google.common.collect.ForwardingSetMultimap
 
ForwardingSortedMap<K,V> - Class in com.google.common.collect
A sorted map which forwards all its method calls to another sorted map.
ForwardingSortedMap() - Constructor for class com.google.common.collect.ForwardingSortedMap
Constructor for use by subclasses.
ForwardingSortedMap.StandardKeySet - Class in com.google.common.collect
A sensible implementation of SortedMap.keySet() in terms of the methods of ForwardingSortedMap.
ForwardingSortedMap.StandardKeySet() - Constructor for class com.google.common.collect.ForwardingSortedMap.StandardKeySet
Constructor for use by subclasses.
ForwardingSortedMultiset<E> - Class in com.google.common.collect
A sorted multiset which forwards all its method calls to another sorted multiset.
ForwardingSortedMultiset() - Constructor for class com.google.common.collect.ForwardingSortedMultiset
Constructor for use by subclasses.
ForwardingSortedMultiset.StandardDescendingMultiset - Class in com.google.common.collect
A skeleton implementation of a descending multiset view.
ForwardingSortedMultiset.StandardDescendingMultiset() - Constructor for class com.google.common.collect.ForwardingSortedMultiset.StandardDescendingMultiset
Constructor for use by subclasses.
ForwardingSortedMultiset.StandardElementSet - Class in com.google.common.collect
ForwardingSortedMultiset.StandardElementSet() - Constructor for class com.google.common.collect.ForwardingSortedMultiset.StandardElementSet
Constructor for use by subclasses.
ForwardingSortedSet<E> - Class in com.google.common.collect
A sorted set which forwards all its method calls to another sorted set.
ForwardingSortedSet() - Constructor for class com.google.common.collect.ForwardingSortedSet
Constructor for use by subclasses.
ForwardingSortedSetMultimap<K,V> - Class in com.google.common.collect
A sorted set multimap which forwards all its method calls to another sorted set multimap.
ForwardingSortedSetMultimap() - Constructor for class com.google.common.collect.ForwardingSortedSetMultimap
Constructor for use by subclasses.
ForwardingTable<R,C,V> - Class in com.google.common.collect
A table which forwards all its method calls to another table.
ForwardingTable() - Constructor for class com.google.common.collect.ForwardingTable
Constructor for use by subclasses.
frequency(Iterable<?>, Object) - Static method in class com.google.common.collect.Iterables
Returns the number of elements in the specified iterable that equal the specified object.
frequency(Iterator<?>, Object) - Static method in class com.google.common.collect.Iterators
Returns the number of elements in the specified iterator that equal the specified object.
from(Function<? super A, ? extends B>, Function<? super B, ? extends A>) - Static method in class com.google.common.base.Converter
Returns a converter based on existing forward and backward functions.
from(CacheBuilderSpec) - Static method in class com.google.common.cache.CacheBuilder
Constructs a new CacheBuilder instance with the settings specified in spec.
from(String) - Static method in class com.google.common.cache.CacheBuilder
Constructs a new CacheBuilder instance with the settings specified in spec.
from(Function<K, V>) - Static method in class com.google.common.cache.CacheLoader
Returns a cache loader based on an existing function instance.
from(Supplier<V>) - Static method in class com.google.common.cache.CacheLoader
Returns a cache loader based on an existing supplier instance.
from(Iterable<E>) - Static method in class com.google.common.collect.FluentIterable
Returns a fluent iterable that wraps iterable, or iterable itself if it is already a FluentIterable.
from(FluentIterable<E>) - Static method in class com.google.common.collect.FluentIterable
Deprecated.
instances of FluentIterable don't need to be converted to FluentIterable
from(Comparator<T>) - Static method in class com.google.common.collect.Ordering
Returns an ordering based on an existing comparator instance.
from(Ordering<T>) - Static method in class com.google.common.collect.Ordering
Deprecated.
no need to use this
from(String) - Static method in class com.google.common.net.HostSpecifier
Attempts to return a HostSpecifier for the given string, throwing an exception if parsing fails.
FROM - Static variable in class com.google.common.net.HttpHeaders
The HTTP From header field name.
from(String) - Static method in class com.google.common.net.InternetDomainName
Returns an instance of InternetDomainName after lenient validation.
from(ClassLoader) - Static method in class com.google.common.reflect.ClassPath
Returns a ClassPath representing all classes and resources loadable from classloader and its parent class loaders.
from(Method) - Static method in class com.google.common.reflect.Invokable
Returns Invokable of method.
from(Constructor<T>) - Static method in class com.google.common.reflect.Invokable
Returns Invokable of constructor.
fromByteArray(byte[]) - Static method in class com.google.common.primitives.Chars
Returns the char value whose big-endian representation is stored in the first 2 bytes of bytes; equivalent to ByteBuffer.wrap(bytes).getChar().
fromByteArray(byte[]) - Static method in class com.google.common.primitives.Ints
Returns the int value whose big-endian representation is stored in the first 4 bytes of bytes; equivalent to ByteBuffer.wrap(bytes).getInt().
fromByteArray(byte[]) - Static method in class com.google.common.primitives.Longs
Returns the long value whose big-endian representation is stored in the first 8 bytes of bytes; equivalent to ByteBuffer.wrap(bytes).getLong().
fromByteArray(byte[]) - Static method in class com.google.common.primitives.Shorts
Returns the short value whose big-endian representation is stored in the first 2 bytes of bytes; equivalent to ByteBuffer.wrap(bytes).getShort().
fromBytes(byte[]) - Static method in class com.google.common.hash.HashCode
Creates a HashCode from a byte array.
fromBytes(byte, byte) - Static method in class com.google.common.primitives.Chars
Returns the char value whose byte representation is the given 2 bytes, in big-endian order; equivalent to Chars.fromByteArray(new byte[] {b1, b2}).
fromBytes(byte, byte, byte, byte) - Static method in class com.google.common.primitives.Ints
Returns the int value whose byte representation is the given 4 bytes, in big-endian order; equivalent to Ints.fromByteArray(new byte[] {b1, b2, b3, b4}).
fromBytes(byte, byte, byte, byte, byte, byte, byte, byte) - Static method in class com.google.common.primitives.Longs
Returns the long value whose byte representation is the given 8 bytes, in big-endian order; equivalent to Longs.fromByteArray(new byte[] {b1, b2, b3, b4, b5, b6, b7, b8}).
fromBytes(byte, byte) - Static method in class com.google.common.primitives.Shorts
Returns the short value whose byte representation is the given 2 bytes, in big-endian order; equivalent to Shorts.fromByteArray(new byte[] {b1, b2}).
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.
fromLittleEndianByteArray(byte[]) - Static method in class com.google.common.net.InetAddresses
Returns an address from a little-endian ordered byte array (the opposite of what InetAddress.getByAddress(java.lang.String, byte[]) expects).
fromLong(long) - Static method in class com.google.common.hash.HashCode
Creates a 64-bit HashCode representation of the given long value.
fromLongBits(long) - Static method in class com.google.common.primitives.UnsignedLong
Returns an UnsignedLong corresponding to a given bit representation.
fromNullable(T) - Static method in class com.google.common.base.Optional
If nullableReference is non-null, returns an Optional instance containing that reference; otherwise returns Optional.absent().
fromParts(String, int) - Static method in class com.google.common.net.HostAndPort
Build a HostAndPort instance from separate host and port values.
fromProperties(Properties) - Static method in class com.google.common.collect.Maps
Creates an ImmutableMap<String, String> from a Properties instance.
fromString(String) - Static method in class com.google.common.hash.HashCode
Creates a HashCode from a hexadecimal (base 16) encoded string.
fromString(String) - Static method in class com.google.common.net.HostAndPort
Split a freeform string into a host and port, without strict validation.
fromValid(String) - Static method in class com.google.common.net.HostSpecifier
Returns a HostSpecifier built from the provided specifier, which is already known to be valid.
FS - Static variable in class com.google.common.base.Ascii
File Separator: These four information separators may be used within data in optional fashion, except that their hierarchical relationship shall be: FS is the most inclusive, then GS, then RS, and US is least inclusive.
Function<F,T> - Interface in com.google.common.base
Determines an output value based on an input value.
Functions - Class in com.google.common.base
Static utility methods pertaining to Function instances.
Funnel<T> - Interface in com.google.common.hash
An object which can send data from an object of type T into a PrimitiveSink.
funnel(T, PrimitiveSink) - Method in interface com.google.common.hash.Funnel
Sends a stream of data from the from object into the sink into.
Funnels - Class in com.google.common.hash
Funnels for common types.
FutureCallback<V> - Interface in com.google.common.util.concurrent
A callback for accepting the results of a Future computation asynchronously.
FutureFallback<V> - Interface in com.google.common.util.concurrent
Provides a backup Future to replace an earlier failed Future.
Futures - Class in com.google.common.util.concurrent
Static utility methods pertaining to the Future interface.
fuzzyCompare(double, double, double) - Static method in class com.google.common.math.DoubleMath
Compares a and b "fuzzily," with a tolerance for nearly-equal values.
fuzzyEquals(double, double, double) - Static method in class com.google.common.math.DoubleMath
Returns true if a and b are within tolerance of each other.

G

gcd(int, int) - Static method in class com.google.common.math.IntMath
Returns the greatest common divisor of a, b.
gcd(long, long) - Static method in class com.google.common.math.LongMath
Returns the greatest common divisor of a, b.
get() - Method in class com.google.common.base.Equivalence.Wrapper
Returns the (possibly null) reference wrapped by this instance.
get() - Method in class com.google.common.base.Optional
Returns the contained instance, which must be present.
get() - Method in interface com.google.common.base.Supplier
Retrieves an instance of the appropriate type.
get(K, Callable<? extends V>) - Method in class com.google.common.cache.AbstractCache
 
get(K, Callable<? extends V>) - Method in interface com.google.common.cache.Cache
Returns the value associated with key in this cache, obtaining that value from valueLoader if necessary.
get(K, Callable<? extends V>) - Method in class com.google.common.cache.ForwardingCache
 
get(K) - Method in class com.google.common.cache.ForwardingLoadingCache
 
get(K) - Method in interface com.google.common.cache.LoadingCache
Returns the value associated with key in this cache, first loading that value if necessary.
get(Object, Object) - Method in class com.google.common.collect.ArrayTable
 
get(int) - Method in class com.google.common.collect.FluentIterable
Returns the element at the specified position in this fluent iterable.
get(int) - Method in class com.google.common.collect.ForwardingList
 
get(K) - Method in class com.google.common.collect.ForwardingListMultimap
 
get(Object) - Method in class com.google.common.collect.ForwardingMap
 
get(K) - Method in class com.google.common.collect.ForwardingMultimap
 
get(K) - Method in class com.google.common.collect.ForwardingSetMultimap
 
get(K) - Method in class com.google.common.collect.ForwardingSortedSetMultimap
 
get(Object, Object) - Method in class com.google.common.collect.ForwardingTable
 
get(Object, Object) - Method in class com.google.common.collect.HashBasedTable
 
get(Object) - Method in class com.google.common.collect.HashBiMap
 
get(K) - Method in class com.google.common.collect.ImmutableListMultimap
Returns an immutable list of the values for the given key.
get(Object) - Method in class com.google.common.collect.ImmutableMap
 
get(K) - Method in class com.google.common.collect.ImmutableMultimap
Returns an immutable collection of the values for the given key.
get(K) - Method in class com.google.common.collect.ImmutableRangeMap
 
get(K) - Method in class com.google.common.collect.ImmutableSetMultimap
Returns an immutable set of the values for the given key.
get(Iterable<T>, int) - Static method in class com.google.common.collect.Iterables
Returns the element at the specified position in an iterable.
get(Iterable<? extends T>, int, T) - Static method in class com.google.common.collect.Iterables
Returns the element at the specified position in an iterable or a default value otherwise.
get(Iterator<T>, int) - Static method in class com.google.common.collect.Iterators
Advances iterator position + 1 times, returning the element at the positionth position.
get(Iterator<? extends T>, int, T) - Static method in class com.google.common.collect.Iterators
Advances iterator position + 1 times, returning the element at the positionth position or defaultValue otherwise.
get(K) - Method in class com.google.common.collect.LinkedListMultimap
Returns a view collection of the values associated with key in this multimap, if any.
get(K) - Method in interface com.google.common.collect.ListMultimap
Returns a view collection of the values associated with key in this multimap, if any.
get(K) - Method in interface com.google.common.collect.Multimap
Returns a view collection of the values associated with key in this multimap, if any.
get(K) - Method in interface com.google.common.collect.RangeMap
Returns the value associated with the specified key, or null if there is no such value.
get(K) - Method in interface com.google.common.collect.SetMultimap
Returns a view collection of the values associated with key in this multimap, if any.
get(K) - Method in interface com.google.common.collect.SortedSetMultimap
Returns a collection view of all values associated with a key.
get(Object, Object) - Method in interface com.google.common.collect.Table
Returns the value corresponding to the given row and column keys, or null if no such mapping exists.
get(K) - Method in class com.google.common.collect.TreeMultimap
 
get(K) - Method in class com.google.common.collect.TreeRangeMap
 
get(long, TimeUnit) - Method in class com.google.common.util.concurrent.AbstractFuture
Waits if necessary for at most the given time for the computation to complete, and then retrieves its result, if available.
get() - Method in class com.google.common.util.concurrent.AbstractFuture
Waits if necessary for the computation to complete, and then retrieves its result.
get() - Method in class com.google.common.util.concurrent.AtomicDouble
Gets the current value.
get(int) - Method in class com.google.common.util.concurrent.AtomicDoubleArray
Gets the current value at position i.
get(K) - Method in class com.google.common.util.concurrent.AtomicLongMap
Returns the value associated with key, or zero if there is no value associated with key.
get() - Method in class com.google.common.util.concurrent.ForwardingFuture
 
get(long, TimeUnit) - Method in class com.google.common.util.concurrent.ForwardingFuture
 
get(Future<V>, Class<X>) - Static method in class com.google.common.util.concurrent.Futures
Returns the result of Future.get(), converting most exceptions to a new instance of the given checked exception type.
get(Future<V>, long, TimeUnit, Class<X>) - Static method in class com.google.common.util.concurrent.Futures
Returns the result of Future.get(long, TimeUnit), converting most exceptions to a new instance of the given checked exception type.
get(Object) - Method in class com.google.common.util.concurrent.Striped
Returns the stripe that corresponds to the passed key.
get6to4IPv4Address(Inet6Address) - Static method in class com.google.common.net.InetAddresses
Returns the IPv4 address embedded in a 6to4 address.
getAll(Iterable<? extends K>) - Method in class com.google.common.cache.AbstractLoadingCache
 
getAll(Iterable<? extends K>) - Method in class com.google.common.cache.ForwardingLoadingCache
 
getAll(Iterable<? extends K>) - Method in interface com.google.common.cache.LoadingCache
Returns a map of the values associated with keys, creating or retrieving those values if necessary.
getAllClasses() - Method in class com.google.common.reflect.ClassPath
Returns all classes loadable from the current class path.
getAllPresent(Iterable<?>) - Method in class com.google.common.cache.AbstractCache
This implementation of getAllPresent lacks any insight into the internal cache data structure, and is thus forced to return the query keys instead of the cached keys.
getAllPresent(Iterable<?>) - Method in interface com.google.common.cache.Cache
Returns a map of the values associated with keys in this cache.
getAllPresent(Iterable<?>) - Method in class com.google.common.cache.ForwardingCache
 
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.
getAnnotation(Class<A>) - Method in class com.google.common.reflect.Parameter
 
getAnnotations() - 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.
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.
getDeclaredAnnotations() - 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.
getElement() - Method in interface com.google.common.collect.Multiset.Entry
Returns the multiset element corresponding to this entry.
getEmbeddedIPv4ClientAddress(Inet6Address) - Static method in class com.google.common.net.InetAddresses
Examines the Inet6Address to extract the embedded IPv4 client address if the InetAddress is an IPv6 address of one of the specified address types that contain an embedded IPv4 address.
getEntry(K) - Method in class com.google.common.collect.ImmutableRangeMap
 
getEntry(K) - Method in interface com.google.common.collect.RangeMap
Returns the range containing this key and its associated value, if such a range is present in the range map, or null otherwise.
getEntry(K) - Method in class com.google.common.collect.TreeRangeMap
 
getEvent() - Method in class com.google.common.eventbus.DeadEvent
Returns the wrapped, 'dead' event, which the system was unable to deliver to any registered subscriber.
getEvent() - Method in class com.google.common.eventbus.SubscriberExceptionContext
 
getEventBus() - Method in class com.google.common.eventbus.SubscriberExceptionContext
 
getExceptionTypes() - Method in class com.google.common.reflect.Invokable
Returns all declared exception types of this Invokable.
getExitingExecutorService(ThreadPoolExecutor, long, TimeUnit) - Static method in class com.google.common.util.concurrent.MoreExecutors
Converts the given ThreadPoolExecutor into an ExecutorService that exits when the application is complete.
getExitingExecutorService(ThreadPoolExecutor) - Static method in class com.google.common.util.concurrent.MoreExecutors
Converts the given ThreadPoolExecutor into an ExecutorService that exits when the application is complete.
getExitingScheduledExecutorService(ScheduledThreadPoolExecutor, long, TimeUnit) - Static method in class com.google.common.util.concurrent.MoreExecutors
Converts the given ScheduledThreadPoolExecutor into a ScheduledExecutorService that exits when the application is complete.
getExitingScheduledExecutorService(ScheduledThreadPoolExecutor) - Static method in class com.google.common.util.concurrent.MoreExecutors
Converts the given ThreadPoolExecutor 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.
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
 
getHostText() - Method in class com.google.common.net.HostAndPort
Returns the portion of this HostAndPort instance that should represent the hostname or IPv4/IPv6 literal.
getIfPresent(Class<T>, String) - Static method in class com.google.common.base.Enums
Returns an optional enum constant for the given type, using Enum.valueOf(java.lang.Class<T>, java.lang.String).
getIfPresent(Object) - Method in interface com.google.common.cache.Cache
Returns the value associated with key in this cache, or null if there is no cached value for key.
getIfPresent(Object) - Method in class com.google.common.cache.ForwardingCache
 
getInput() - Method in class com.google.common.io.ByteSource
Deprecated.
This method is only provided for temporary compatibility with the InputSupplier interface and should not be called directly. Use ByteSource.openStream() instead. This method is scheduled for removal in Guava 18.0.
getInput() - Method in class com.google.common.io.CharSource
Deprecated.
This method is only provided for temporary compatibility with the InputSupplier interface and should not be called directly. Use CharSource.openStream() instead. This method is scheduled for removal in Guava 18.0.
getInput() - Method in interface com.google.common.io.InputSupplier
Deprecated.
Returns an object that encapsulates a readable resource.
getInstance(Class<T>) - Method in interface com.google.common.collect.ClassToInstanceMap
Returns the value the specified class is mapped to, or null if no entry for this class is present.
getInstance(Class<T>) - Method in class com.google.common.collect.ImmutableClassToInstanceMap
 
getInstance(Class<T>) - Method in class com.google.common.collect.MutableClassToInstanceMap
 
getInstance(TypeToken<T>) - Method in class com.google.common.reflect.ImmutableTypeToInstanceMap
 
getInstance(Class<T>) - Method in class com.google.common.reflect.ImmutableTypeToInstanceMap
 
getInstance(Class<T>) - Method in class com.google.common.reflect.MutableTypeToInstanceMap
 
getInstance(TypeToken<T>) - Method in class com.google.common.reflect.MutableTypeToInstanceMap
 
getInstance(Class<T>) - Method in interface com.google.common.reflect.TypeToInstanceMap
Returns the value the specified class is mapped to, or null if no entry for this class is present.
getInstance(TypeToken<T>) - Method in interface com.google.common.reflect.TypeToInstanceMap
Returns the value the specified type is mapped to, or null if no entry for this type is present.
getIsatapIPv4Address(Inet6Address) - Static method in class com.google.common.net.InetAddresses
Returns the IPv4 address embedded in an ISATAP address.
getKey() - Method in class com.google.common.cache.RemovalNotification
 
getKey() - Method in class com.google.common.collect.ForwardingMapEntry
 
getLast() - Method in class com.google.common.collect.ForwardingDeque
 
getLast(Iterable<T>) - Static method in class com.google.common.collect.Iterables
Returns the last element of iterable.
getLast(Iterable<? extends T>, T) - Static method in class com.google.common.collect.Iterables
Returns the last element of iterable or defaultValue if the iterable is empty.
getLast(Iterator<T>) - Static method in class com.google.common.collect.Iterators
Advances iterator to the end, returning the last element.
getLast(Iterator<? extends T>, T) - Static method in class com.google.common.collect.Iterators
Advances iterator to the end, returning the last element or defaultValue if the iterator is empty.
getMessage() - Method in exception com.google.common.util.concurrent.CycleDetectingLockFactory.PotentialDeadlockException
Appends the chain of messages from the conflictingStackTrace to the original message.
getName() - Method in class com.google.common.reflect.ClassPath.ClassInfo
Returns the fully qualified name of the class.
getNameWithoutExtension(String) - Static method in class com.google.common.io.Files
Returns the file name without its file extension or path.
getNext(Iterator<? extends T>, T) - Static method in class com.google.common.collect.Iterators
Returns the next element in iterator or defaultValue if the iterator is empty.
getNextSchedule() - Method in class com.google.common.util.concurrent.AbstractScheduledService.CustomScheduler
Calculates the time at which to next invoke the task.
getOccupiedDepth() - Method in class com.google.common.util.concurrent.Monitor
Returns the number of times the current thread has entered this monitor in excess of the number of times it has left.
getOnlyElement(Iterable<T>) - Static method in class com.google.common.collect.Iterables
Returns the single element contained in iterable.
getOnlyElement(Iterable<? extends T>, T) - Static method in class com.google.common.collect.Iterables
Returns the single element contained in iterable, or defaultValue if the iterable is empty.
getOnlyElement(Iterator<T>) - Static method in class com.google.common.collect.Iterators
Returns the single element contained in iterator.
getOnlyElement(Iterator<? extends T>, T) - Static method in class com.google.common.collect.Iterators
Returns the single element contained in iterator, or defaultValue if the iterator is empty.
getOutput() - Method in class com.google.common.io.ByteSink
Deprecated.
This method is only provided for temporary compatibility with the OutputSupplier interface and should not be called directly. Use ByteSink.openStream() instead. This method is scheduled for removal in Guava 18.0.
getOutput() - Method in class com.google.common.io.CharSink
Deprecated.
This method is only provided for temporary compatibility with the OutputSupplier interface and should not be called directly. Use CharSink.openStream() instead. This method is scheduled for removal in Guava 18.0.
getOutput() - Method in interface com.google.common.io.OutputSupplier
Deprecated.
Returns an object that encapsulates a writable resource.
getOwnerType() - Method in class com.google.common.reflect.Invokable
Returns the type of T.
getPackageName() - Method in class com.google.common.reflect.ClassPath.ClassInfo
Returns the package name of the class, without attempting to load the class.
getPackageName(Class<?>) - Static method in class com.google.common.reflect.Reflection
Returns the package name of clazz according to the Java Language Specification (section 6.7).
getPackageName(String) - Static method in class com.google.common.reflect.Reflection
Returns the package name of classFullName according to the Java Language Specification (section 6.7).
getParameters() - Method in class com.google.common.reflect.Invokable
Returns all declared parameters of this Invokable.
getPort() - Method in class com.google.common.net.HostAndPort
Get the current port number, failing if no port is defined.
getPort() - Method in class com.google.common.net.InetAddresses.TeredoInfo
 
getPortOrDefault(int) - Method in class com.google.common.net.HostAndPort
Returns the current port number, with a default if no port is defined.
getQueueLength() - Method in class com.google.common.util.concurrent.Monitor
Returns an estimate of the number of threads waiting to enter this monitor.
getRate() - Method in class com.google.common.util.concurrent.RateLimiter
Returns the stable rate (as permits per seconds) with which this RateLimiter is configured with.
getRawType() - Method in class com.google.common.reflect.TypeToken
Returns the raw type of T.
getResource(String) - Static method in class com.google.common.io.Resources
Returns a URL pointing to resourceName if the resource is found using the context class loader.
getResource(Class<?>, String) - Static method in class com.google.common.io.Resources
Given a resourceName that is relative to contextClass, returns a URL pointing to the named resource.
getResourceName() - Method in class com.google.common.reflect.ClassPath.ResourceInfo
Returns the fully qualified name of the resource.
getResources() - Method in class com.google.common.reflect.ClassPath
Returns all resources loadable from the current class path, including the class files of all loadable classes but excluding the "META-INF/MANIFEST.MF" file.
getResult() - Method in interface com.google.common.io.ByteProcessor
Return the result of processing all the bytes.
getResult() - Method in interface com.google.common.io.LineProcessor
Return the result of processing all the lines.
getReturnType() - Method in class com.google.common.reflect.Invokable
Returns the return type of this Invokable.
getRootCause(Throwable) - Static method in class com.google.common.base.Throwables
Returns the innermost cause of throwable.
getRowKey() - Method in interface com.google.common.collect.Table.Cell
Returns the row key of this cell.
getServer() - Method in class com.google.common.net.InetAddresses.TeredoInfo
 
getSimpleName() - Method in class com.google.common.reflect.ClassPath.ClassInfo
Returns the simple name of the underlying class as given in the source code.
getSource() - Method in class com.google.common.eventbus.DeadEvent
Returns the object that originated this event (not the object that originated the wrapped event).
getStackTraceAsString(Throwable) - Static method in class com.google.common.base.Throwables
Returns a string containing the result of toString(), followed by the full, recursive stack trace of throwable.
getSubscriber() - Method in class com.google.common.eventbus.SubscriberExceptionContext
 
getSubscriberMethod() - Method in class com.google.common.eventbus.SubscriberExceptionContext
 
getSubtype(Class<?>) - Method in class com.google.common.reflect.TypeToken
Returns subtype of this with subclass as the raw class.
getSupertype(Class<? super T>) - Method in class com.google.common.reflect.TypeToken
Returns the generic form of superclass.
getTeredoInfo(Inet6Address) - Static method in class com.google.common.net.InetAddresses
Returns the Teredo information embedded in a Teredo address.
getTopLevelClasses() - Method in class com.google.common.reflect.ClassPath
Returns all top level classes loadable from the current class path.
getTopLevelClasses(String) - Method in class com.google.common.reflect.ClassPath
Returns all top level classes whose package name is packageName.
getTopLevelClassesRecursive(String) - Method in class com.google.common.reflect.ClassPath
Returns all top level classes whose package name is packageName or starts with packageName followed by a '.'.
getType() - Method in class com.google.common.reflect.Parameter
Returns the type of the parameter.
getType() - Method in class com.google.common.reflect.TypeToken
Returns the represented type.
getTypes() - Method in class com.google.common.reflect.TypeToken
Returns the set of interfaces and classes that this type is or is a subtype of.
getUnchecked(K) - Method in class com.google.common.cache.AbstractLoadingCache
 
getUnchecked(K) - Method in class com.google.common.cache.ForwardingLoadingCache
 
getUnchecked(K) - Method in interface com.google.common.cache.LoadingCache
Returns the value associated with key in this cache, first loading that value if necessary.
getUnchecked(Future<V>) - Static method in class com.google.common.util.concurrent.Futures
Returns the result of calling Future.get() uninterruptibly on a task known not to throw a checked exception.
getUninterruptibly(Future<V>) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes future.get() uninterruptibly.
getUninterruptibly(Future<V>, long, TimeUnit) - Static method in class com.google.common.util.concurrent.Uninterruptibles
Invokes future.get(timeout, unit) uninterruptibly.
getValue() - Method in class com.google.common.cache.RemovalNotification
 
getValue() - Method in class com.google.common.collect.ForwardingMapEntry
 
getValue() - Method in interface com.google.common.collect.Table.Cell
Returns the value of this cell.
getWaitQueueLength(Monitor.Guard) - Method in class com.google.common.util.concurrent.Monitor
Returns an estimate of the number of threads waiting for the given guard to become satisfied.
GIF - Static variable in class com.google.common.net.MediaType
 
goodFastHash(int) - Static method in class com.google.common.hash.Hashing
Returns a general-purpose, temporary-use, non-cryptographic hash function.
greaterThan(C) - Static method in class com.google.common.collect.Range
Returns a range that contains all values strictly greater than endpoint.
greatestOf(Iterable<E>, int) - Method in class com.google.common.collect.Ordering
Returns the k greatest elements of the given iterable according to this ordering, in order from greatest to least.
greatestOf(Iterator<E>, int) - Method in class com.google.common.collect.Ordering
Returns the k greatest elements from the given iterator according to this ordering, in order from greatest to least.
GS - Static variable in class com.google.common.base.Ascii
Group Separator: These four information separators may be used within data in optional fashion, except that their hierarchical relationship shall be: FS is the most inclusive, then GS, then RS, and US is least inclusive.
GwtCompatible - Annotation Type in com.google.common.annotations
The presence of this annotation on a type indicates that the type may be used with the Google Web Toolkit (GWT).
GwtIncompatible - Annotation Type in com.google.common.annotations
The presence of this annotation on a method indicates that the method may not be used with the Google Web Toolkit (GWT), even though its type is annotated as GwtCompatible and accessible in GWT.
GZIP - Static variable in class com.google.common.net.MediaType
 

H

handleException(Throwable, SubscriberExceptionContext) - Method in interface com.google.common.eventbus.SubscriberExceptionHandler
Handles exceptions thrown by subscribers.
handleInvocation(Object, Method, Object[]) - Method in class com.google.common.reflect.AbstractInvocationHandler
handlePotentialDeadlock(CycleDetectingLockFactory.PotentialDeadlockException) - Method in interface com.google.common.util.concurrent.CycleDetectingLockFactory.Policy
Called when a potential deadlock is encountered.
hasEmbeddedIPv4ClientAddress(Inet6Address) - Static method in class com.google.common.net.InetAddresses
Examines the Inet6Address to determine if it is an IPv6 address of one of the specified address types that contain an embedded IPv4 address.
hash(T) - Method in class com.google.common.base.Equivalence
Returns a hash code for t.
hash() - Method in interface com.google.common.hash.Hasher
Computes a hash code based on the data that have been provided to this hasher.
hash() - Method in class com.google.common.hash.HashingInputStream
Returns the HashCode based on the data read from this stream.
hash() - Method in class com.google.common.hash.HashingOutputStream
Returns the HashCode based on the data written to this stream.
hash(HashFunction) - Method in class com.google.common.io.ByteSource
Hashes the contents of this byte source using the given hash function.
hash(InputSupplier<? extends InputStream>, HashFunction) - Static method in class com.google.common.io.ByteStreams
Deprecated.
Use ByteSource.hash(HashFunction) instead. This method is scheduled for removal in Guava 18.0.
hash(File, HashFunction) - Static method in class com.google.common.io.Files
Computes the hash code of the file using hashFunction.
HashBasedTable<R,C,V> - Class in com.google.common.collect
Implementation of Table using hash tables.
HashBiMap<K,V> - Class in com.google.common.collect
A BiMap backed by two hash tables.
hashBytes(byte[]) - Method in interface com.google.common.hash.HashFunction
Shortcut for newHasher().putBytes(input).hash().
hashBytes(byte[], int, int) - Method in interface com.google.common.hash.HashFunction
Shortcut for newHasher().putBytes(input, off, len).hash().
hashCode() - Method in class com.google.common.base.Equivalence.Wrapper
Returns the result of Equivalence.hash(Object) applied to the wrapped reference.
hashCode(Object...) - Static method in class com.google.common.base.Objects
Generates a hash code for multiple values.
hashCode() - Method in class com.google.common.base.Optional
Returns a hash code for this instance.
hashCode() - Method in class com.google.common.cache.CacheBuilderSpec
 
hashCode() - Method in class com.google.common.cache.CacheStats
 
hashCode() - Method in class com.google.common.cache.RemovalNotification
 
hashCode() - Method in class com.google.common.collect.ForwardingList
 
hashCode() - Method in class com.google.common.collect.ForwardingMap
 
hashCode() - Method in class com.google.common.collect.ForwardingMapEntry
 
hashCode() - Method in class com.google.common.collect.ForwardingMultimap
 
hashCode() - Method in class com.google.common.collect.ForwardingMultiset
 
hashCode() - Method in class com.google.common.collect.ForwardingSet
 
hashCode() - Method in class com.google.common.collect.ForwardingTable
 
hashCode() - Method in class com.google.common.collect.ImmutableList
 
hashCode() - Method in class com.google.common.collect.ImmutableMap
 
hashCode() - Method in class com.google.common.collect.ImmutableMultiset
 
hashCode() - Method in class com.google.common.collect.ImmutableRangeMap
 
hashCode() - Method in class com.google.common.collect.ImmutableSet
 
hashCode() - Method in interface com.google.common.collect.MapDifference
Returns the hash code for this instance.
hashCode() - Method in interface com.google.common.collect.MapDifference.ValueDifference
The hash code equals the value Arrays.asList(leftValue(), rightValue()).hashCode().
hashCode() - Method in interface com.google.common.collect.Multimap
Returns the hash code for this multimap.
hashCode() - Method in interface com.google.common.collect.Multiset.Entry
Returns a hash code value for the object.
hashCode() - Method in interface com.google.common.collect.Multiset
Returns the hash code for this multiset.
hashCode() - Method in class com.google.common.collect.Range
Returns a hash code for this range.
hashCode() - Method in interface com.google.common.collect.RangeMap
Returns asMapOfRanges().hashCode().
hashCode() - Method in interface com.google.common.collect.RangeSet
Returns asRanges().hashCode().
hashCode() - Method in interface com.google.common.collect.Table.Cell
Returns the hash code of this cell.
hashCode() - Method in interface com.google.common.collect.Table
Returns the hash code for this table.
hashCode() - Method in class com.google.common.collect.TreeRangeMap
 
hashCode() - Method in class com.google.common.hash.BloomFilter
 
HashCode - Class in com.google.common.hash
An immutable hash code of arbitrary bit length.
hashCode() - Method in class com.google.common.hash.HashCode
Returns a "Java hash code" for this HashCode instance; this is well-defined (so, for example, you can safely put HashCode instances into a HashSet) but is otherwise probably not what you want to use.
hashCode() - Method in class com.google.common.net.HostAndPort
 
hashCode() - Method in class com.google.common.net.HostSpecifier
 
hashCode() - Method in class com.google.common.net.InternetDomainName
 
hashCode() - Method in class com.google.common.net.MediaType
 
hashCode(boolean) - Static method in class com.google.common.primitives.Booleans
Returns a hash code for value; equal to the result of invoking ((Boolean) value).hashCode().
hashCode(byte) - Static method in class com.google.common.primitives.Bytes
Returns a hash code for value; equal to the result of invoking ((Byte) value).hashCode().
hashCode(char) - Static method in class com.google.common.primitives.Chars
Returns a hash code for value; equal to the result of invoking ((Character) value).hashCode().
hashCode(double) - Static method in class com.google.common.primitives.Doubles
Returns a hash code for value; equal to the result of invoking ((Double) value).hashCode().
hashCode(float) - Static method in class com.google.common.primitives.Floats
Returns a hash code for value; equal to the result of invoking ((Float) value).hashCode().
hashCode(int) - Static method in class com.google.common.primitives.Ints
Returns a hash code for value; equal to the result of invoking ((Integer) value).hashCode().
hashCode(long) - Static method in class com.google.common.primitives.Longs
Returns a hash code for value; equal to the result of invoking ((Long) value).hashCode().
hashCode(short) - Static method in class com.google.common.primitives.Shorts
Returns a hash code for value; equal to the result of invoking ((Short) value).hashCode().
hashCode() - Method in class com.google.common.primitives.UnsignedInteger
 
hashCode() - Method in class com.google.common.primitives.UnsignedLong
 
hashCode() - Method in class com.google.common.reflect.AbstractInvocationHandler
By default delegates to Object.hashCode().
hashCode() - Method in class com.google.common.reflect.ClassPath.ResourceInfo
 
hashCode() - Method in class com.google.common.reflect.Parameter
 
hashCode() - Method in class com.google.common.reflect.TypeParameter
 
hashCode() - Method in class com.google.common.reflect.TypeToken
 
Hasher - Interface in com.google.common.hash
A PrimitiveSink that can compute a hash code after reading the input.
HashFunction - Interface in com.google.common.hash
A hash function is a collision-averse pure function that maps an arbitrary block of data to a number called a hash code.
Hashing - Class in com.google.common.hash
Static methods to obtain HashFunction instances, and other static hashing-related utilities.
HashingInputStream - Class in com.google.common.hash
An InputStream that maintains a hash of the data read from it.
HashingInputStream(HashFunction, InputStream) - Constructor for class com.google.common.hash.HashingInputStream
Creates an input stream that hashes using the given HashFunction and delegates all data read from it to the underlying InputStream.
HashingOutputStream - Class in com.google.common.hash
An OutputStream that maintains a hash of the data written to it.
HashingOutputStream(HashFunction, OutputStream) - Constructor for class com.google.common.hash.HashingOutputStream
Creates an output stream that hashes using the given HashFunction, and forwards all data written to it to the underlying OutputStream.
hashInt(int) - Method in interface com.google.common.hash.HashFunction
Shortcut for newHasher().putInt(input).hash(); returns the hash code for the given int value, interpreted in little-endian byte order.
hashKeys() - Static method in class com.google.common.collect.MultimapBuilder
Uses a HashMap to map keys to value collections.
hashKeys(int) - Static method in class com.google.common.collect.MultimapBuilder
Uses a HashMap to map keys to value collections, initialized to expect the specified number of keys.
hashLong(long) - Method in interface com.google.common.hash.HashFunction
Shortcut for newHasher().putLong(input).hash(); returns the hash code for the given long value, interpreted in little-endian byte order.
HashMultimap<K,V> - Class in com.google.common.collect
Implementation of Multimap using hash tables.
HashMultiset<E> - Class in com.google.common.collect
Multiset implementation backed by a HashMap.
hashObject(T, Funnel<? super T>) - Method in interface com.google.common.hash.HashFunction
Shortcut for newHasher().putObject(instance, funnel).hash().
hashSetValues() - Method in class com.google.common.collect.MultimapBuilder.MultimapBuilderWithKeys
Uses a HashSet to store value collections.
hashSetValues(int) - Method in class com.google.common.collect.MultimapBuilder.MultimapBuilderWithKeys
Uses a HashSet to store value collections, initialized to expect the specified number of values per key.
hashString(CharSequence, Charset) - Method in interface com.google.common.hash.HashFunction
Shortcut for newHasher().putString(input, charset).hash().
hashUnencodedChars(CharSequence) - Method in interface com.google.common.hash.HashFunction
Shortcut for newHasher().putUnencodedChars(input).hash().
hasLowerBound() - Method in class com.google.common.collect.Range
Returns true if this range has a lower endpoint.
hasNext() - Method in class com.google.common.collect.AbstractIterator
 
hasNext() - Method in class com.google.common.collect.AbstractSequentialIterator
 
hasNext() - Method in class com.google.common.collect.ForwardingIterator
 
hasParent() - Method in class com.google.common.net.InternetDomainName
Indicates whether this domain is composed of two or more parts.
hasPort() - Method in class com.google.common.net.HostAndPort
Return true if this instance has a defined port.
hasPrevious() - Method in class com.google.common.collect.ForwardingListIterator
 
hasPublicSuffix() - Method in class com.google.common.net.InternetDomainName
Indicates whether this domain name ends in a public suffix, including if it is a public suffix itself.
hasQueuedThread(Thread) - Method in class com.google.common.util.concurrent.Monitor
Queries whether the given thread is waiting to enter this monitor.
hasQueuedThreads() - Method in class com.google.common.util.concurrent.Monitor
Returns whether any threads are waiting to enter this monitor.
hasUpperBound() - Method in class com.google.common.collect.Range
Returns true if this range has an upper endpoint.
hasWaiters(Monitor.Guard) - Method in class com.google.common.util.concurrent.Monitor
Queries whether any threads are waiting for the given guard to become satisfied.
hasWildcard() - Method in class com.google.common.net.MediaType
Returns true if either the type or subtype is the wildcard.
headMap(K, boolean) - Method in class com.google.common.collect.ForwardingNavigableMap
 
headMap(K) - Method in class com.google.common.collect.ForwardingSortedMap
 
headMap(K) - Method in class com.google.common.collect.ImmutableSortedMap
This method returns a ImmutableSortedMap, consisting of the entries whose keys are less than toKey.
headMap(K, boolean) - Method in class com.google.common.collect.ImmutableSortedMap
This method returns a ImmutableSortedMap, consisting of the entries whose keys are less than (or equal to, if inclusive) toKey.
headMultiset(E, BoundType) - Method in class com.google.common.collect.ForwardingSortedMultiset
 
headMultiset(E, BoundType) - Method in class com.google.common.collect.ImmutableSortedMultiset
 
headMultiset(E, BoundType) - Method in interface com.google.common.collect.SortedMultiset
Returns a view of this multiset restricted to the elements less than upperBound, optionally including upperBound itself.
headMultiset(E, BoundType) - Method in class com.google.common.collect.TreeMultiset
 
headSet(C) - Method in class com.google.common.collect.ContiguousSet
 
headSet(C, boolean) - Method in class com.google.common.collect.ContiguousSet
 
headSet(E, boolean) - Method in class com.google.common.collect.ForwardingNavigableSet
 
headSet(E) - Method in class com.google.common.collect.ForwardingSortedSet
 
headSet(E) - Method in class com.google.common.collect.ImmutableSortedSet
Returns a view of the portion of this set whose elements are strictly less than toElement.
headSet(E, boolean) - Method in class com.google.common.collect.ImmutableSortedSet
 
healthy() - Method in class com.google.common.util.concurrent.ServiceManager.Listener
Called when the service initially becomes healthy.
higher(E) - Method in class com.google.common.collect.ForwardingNavigableSet
 
higher(E) - Method in class com.google.common.collect.ImmutableSortedSet
 
higherEntry(K) - Method in class com.google.common.collect.ForwardingNavigableMap
 
higherEntry(K) - Method in class com.google.common.collect.ImmutableSortedMap
 
higherKey(K) - Method in class com.google.common.collect.ForwardingNavigableMap
 
higherKey(K) - Method in class com.google.common.collect.ImmutableSortedMap
 
hitCount() - Method in class com.google.common.cache.CacheStats
Returns the number of times Cache lookup methods have returned a cached value.
hitRate() - Method in class com.google.common.cache.CacheStats
Returns the ratio of cache requests which were hits.
HOST - Static variable in class com.google.common.net.HttpHeaders
The HTTP Host header field name.
HostAndPort - Class in com.google.common.net
An immutable representation of a host and port.
HostSpecifier - Class in com.google.common.net
A syntactically valid host specifier, suitable for use in a URI.
HT - Static variable in class com.google.common.base.Ascii
Horizontal Tabulation ('\t'): A format effector which controls the movement of the printing position to the next in a series of predetermined positions along the printing line.
HTML_UTF_8 - Static variable in class com.google.common.net.MediaType
 
htmlEscaper() - Static method in class com.google.common.html.HtmlEscapers
Returns an Escaper instance that escapes HTML metacharacters as specified by HTML 4.01.
HtmlEscapers - Class in com.google.common.html
Escaper instances suitable for strings to be included in HTML attribute values and most elements' text contents.
HttpHeaders - Class in com.google.common.net
Contains constant definitions for the HTTP header field names.

I

I_CALENDAR_UTF_8 - Static variable in class com.google.common.net.MediaType
 
ICO - Static variable in class com.google.common.net.MediaType
 
identity() - Static method in class com.google.common.base.Converter
Returns a serializable converter that always converts or reverses an object to itself.
identity() - Static method in class com.google.common.base.Equivalence
Returns an equivalence that uses == to compare values and System.identityHashCode(Object) to compute the hash code.
identity() - Static method in class com.google.common.base.Functions
Returns the identity function.
IF_MATCH - Static variable in class com.google.common.net.HttpHeaders
The HTTP If-Match header field name.
IF_MODIFIED_SINCE - Static variable in class com.google.common.net.HttpHeaders
The HTTP If-Modified-Since header field name.
IF_NONE_MATCH - Static variable in class com.google.common.net.HttpHeaders
The HTTP If-None-Match header field name.
IF_RANGE - Static variable in class com.google.common.net.HttpHeaders
The HTTP If-Range header field name.
IF_UNMODIFIED_SINCE - Static variable in class com.google.common.net.HttpHeaders
The HTTP If-Unmodified-Since header field name.
immediateCancelledFuture() - Static method in class com.google.common.util.concurrent.Futures
Creates a ListenableFuture which is cancelled immediately upon construction, so that isCancelled() always returns true.
immediateCheckedFuture(V) - Static method in class com.google.common.util.concurrent.Futures
Returns a CheckedFuture which has its value set immediately upon construction.
immediateFailedCheckedFuture(X) - Static method in class com.google.common.util.concurrent.Futures
Returns a CheckedFuture which has an exception set immediately upon construction.
immediateFailedFuture(Throwable) - Static method in class com.google.common.util.concurrent.Futures
Returns a ListenableFuture which has an exception set immediately upon construction.
immediateFuture(V) - Static method in class com.google.common.util.concurrent.Futures
Creates a ListenableFuture which has its value set immediately upon construction.
ImmutableBiMap<K,V> - Class in com.google.common.collect
An immutable BiMap with reliable user-specified iteration order.
ImmutableBiMap.Builder<K,V> - Class in com.google.common.collect
A builder for creating immutable bimap instances, especially public static final bimaps ("constant bimaps").
ImmutableBiMap.Builder() - Constructor for class com.google.common.collect.ImmutableBiMap.Builder
Creates a new builder.
immutableCell(R, C, V) - Static method in class com.google.common.collect.Tables
Returns an immutable cell with the specified row key, column key, and value.
ImmutableClassToInstanceMap<B> - Class in com.google.common.collect
A class-to-instance map backed by an ImmutableMap.
ImmutableClassToInstanceMap.Builder<B> - Class in com.google.common.collect
A builder for creating immutable class-to-instance maps.
ImmutableClassToInstanceMap.Builder() - Constructor for class com.google.common.collect.ImmutableClassToInstanceMap.Builder
 
ImmutableCollection<E> - Class in com.google.common.collect
An immutable collection.
ImmutableCollection.Builder<E> - Class in com.google.common.collect
Abstract base class for builders of ImmutableCollection types.
immutableCopy() - Method in class com.google.common.collect.Sets.SetView
Returns an immutable copy of the current contents of this set view.
immutableEntry(K, V) - Static method in class com.google.common.collect.Maps
Returns an immutable map entry with the specified key and value.
immutableEntry(E, int) - Static method in class com.google.common.collect.Multisets
Returns an immutable multiset entry with the specified element and count.
immutableEnumMap(Map<K, ? extends V>) - Static method in class com.google.common.collect.Maps
Returns an immutable map instance containing the given entries.
immutableEnumSet(E, E...) - Static method in class com.google.common.collect.Sets
Returns an immutable set instance containing the given enum elements.
immutableEnumSet(Iterable<E>) - Static method in class com.google.common.collect.Sets
Returns an immutable set instance containing the given enum elements.
ImmutableList<E> - Class in com.google.common.collect
A high-performance, immutable, random-access List implementation.
ImmutableList.Builder<E> - Class in com.google.common.collect
A builder for creating immutable list instances, especially public static final lists ("constant lists").
ImmutableList.Builder() - Constructor for class com.google.common.collect.ImmutableList.Builder
Creates a new builder.
ImmutableListMultimap<K,V> - Class in com.google.common.collect
An immutable ListMultimap with reliable user-specified key and value iteration order.
ImmutableListMultimap.Builder<K,V> - Class in com.google.common.collect
A builder for creating immutable ListMultimap instances, especially public static final multimaps ("constant multimaps").
ImmutableListMultimap.Builder() - Constructor for class com.google.common.collect.ImmutableListMultimap.Builder
Creates a new builder.
ImmutableMap<K,V> - Class in com.google.common.collect
An immutable, hash-based Map with reliable user-specified iteration order.
ImmutableMap.Builder<K,V> - Class in com.google.common.collect
A builder for creating immutable map instances, especially public static final maps ("constant maps").
ImmutableMap.Builder() - Constructor for class com.google.common.collect.ImmutableMap.Builder
Creates a new builder.
ImmutableMultimap<K,V> - Class in com.google.common.collect
An immutable Multimap.
ImmutableMultimap.Builder<K,V> - Class in com.google.common.collect
A builder for creating immutable multimap instances, especially public static final multimaps ("constant multimaps").
ImmutableMultimap.Builder() - Constructor for class com.google.common.collect.ImmutableMultimap.Builder
Creates a new builder.
ImmutableMultiset<E> - Class in com.google.common.collect
An immutable hash-based multiset.
ImmutableMultiset.Builder<E> - Class in com.google.common.collect
A builder for creating immutable multiset instances, especially public static final multisets ("constant multisets").
ImmutableMultiset.Builder() - Constructor for class com.google.common.collect.ImmutableMultiset.Builder
Creates a new builder.
ImmutableRangeMap<K extends Comparable<?>,V> - Class in com.google.common.collect
An immutable implementation of RangeMap, supporting all query operations efficiently.
ImmutableRangeMap.Builder<K extends Comparable<?>,V> - Class in com.google.common.collect
A builder for immutable range maps.
ImmutableRangeMap.Builder() - Constructor for class com.google.common.collect.ImmutableRangeMap.Builder
 
ImmutableRangeSet<C extends Comparable> - Class in com.google.common.collect
An efficient immutable implementation of a RangeSet.
ImmutableRangeSet.Builder<C extends Comparable<?>> - Class in com.google.common.collect
A builder for immutable range sets.
ImmutableRangeSet.Builder() - Constructor for class com.google.common.collect.ImmutableRangeSet.Builder
 
ImmutableSet<E> - Class in com.google.common.collect
A high-performance, immutable Set with reliable, user-specified iteration order.
ImmutableSet.Builder<E> - Class in com.google.common.collect
A builder for creating immutable set instances, especially public static final sets ("constant sets").
ImmutableSet.Builder() - Constructor for class com.google.common.collect.ImmutableSet.Builder
Creates a new builder.
ImmutableSetMultimap<K,V> - Class in com.google.common.collect
An immutable SetMultimap with reliable user-specified key and value iteration order.
ImmutableSetMultimap.Builder<K,V> - Class in com.google.common.collect
A builder for creating immutable SetMultimap instances, especially public static final multimaps ("constant multimaps").
ImmutableSetMultimap.Builder() - Constructor for class com.google.common.collect.ImmutableSetMultimap.Builder
Creates a new builder.
immutableSortedCopy(Iterable<E>) - Method in class com.google.common.collect.Ordering
Returns an immutable list containing elements sorted by this ordering.
ImmutableSortedMap<K,V> - Class in com.google.common.collect
An immutable SortedMap.
ImmutableSortedMap.Builder<K,V> - Class in com.google.common.collect
A builder for creating immutable sorted map instances, especially public static final maps ("constant maps").
ImmutableSortedMap.Builder(Comparator<? super K>) - Constructor for class com.google.common.collect.ImmutableSortedMap.Builder
Creates a new builder.
ImmutableSortedMultiset<E> - Class in com.google.common.collect
An immutable SortedMultiset that stores its elements in a sorted array.
ImmutableSortedMultiset.Builder<E> - Class in com.google.common.collect
A builder for creating immutable multiset instances, especially public static final multisets ("constant multisets").
ImmutableSortedMultiset.Builder(Comparator<? super E>) - Constructor for class com.google.common.collect.ImmutableSortedMultiset.Builder
Creates a new builder.
ImmutableSortedSet<E> - Class in com.google.common.collect
An immutable SortedSet that stores its elements in a sorted array.
ImmutableSortedSet.Builder<E> - Class in com.google.common.collect
A builder for creating immutable sorted set instances, especially public static final sets ("constant sets"), with a given comparator.
ImmutableSortedSet.Builder(Comparator<? super E>) - Constructor for class com.google.common.collect.ImmutableSortedSet.Builder
Creates a new builder.
ImmutableTable<R,C,V> - Class in com.google.common.collect
An immutable Table with reliable user-specified iteration order.
ImmutableTable.Builder<R,C,V> - Class in com.google.common.collect
A builder for creating immutable table instances, especially public static final tables ("constant tables").
ImmutableTable.Builder() - Constructor for class com.google.common.collect.ImmutableTable.Builder
Creates a new builder.
ImmutableTypeToInstanceMap<B> - Class in com.google.common.reflect
A type-to-instance map backed by an ImmutableMap.
ImmutableTypeToInstanceMap.Builder<B> - Class in com.google.common.reflect
A builder for creating immutable type-to-instance maps.
in(Collection<? extends T>) - Static method in class com.google.common.base.Predicates
Returns a predicate that evaluates to true if the object reference being tested is a member of the given collection.
inCompletionOrder(Iterable<? extends ListenableFuture<? extends T>>) - Static method in class com.google.common.util.concurrent.Futures
Returns a list of delegate futures that correspond to the futures received in the order that they complete.
increment(InetAddress) - Static method in class com.google.common.net.InetAddresses
Returns a new InetAddress that is one more than the passed in address.
incrementAndGet(K) - Method in class com.google.common.util.concurrent.AtomicLongMap
Increments by one the value currently associated with key, and returns the new value.
incrementBy(AbstractCache.StatsCounter) - Method in class com.google.common.cache.AbstractCache.SimpleStatsCounter
Increments all counters by the values in other.
index(Function<? super E, K>) - Method in class com.google.common.collect.FluentIterable
Creates an index ImmutableListMultimap that contains the results of applying a specified function to each item in this FluentIterable of values.
index(Iterable<V>, Function<? super V, K>) - Static method in class com.google.common.collect.Multimaps
Creates an index ImmutableListMultimap that contains the results of applying a specified function to each item in an Iterable of values.
index(Iterator<V>, Function<? super V, K>) - Static method in class com.google.common.collect.Multimaps
Creates an index ImmutableListMultimap that contains the results of applying a specified function to each item in an Iterator of values.
indexIn(CharSequence) - Method in class com.google.common.base.CharMatcher
Returns the index of the first matching character in a character sequence, or -1 if no matching character is present.
indexIn(CharSequence, int) - Method in class com.google.common.base.CharMatcher
Returns the index of the first matching character in a character sequence, starting from a given position, or -1 if no character matches after that position.
indexOf(Object) - Method in class com.google.common.collect.ForwardingList
 
indexOf(Object) - Method in class com.google.common.collect.ImmutableList
 
indexOf(Iterable<T>, Predicate<? super T>) - Static method in class com.google.common.collect.Iterables
Returns the index in iterable of the first element that satisfies the provided predicate, or -1 if the Iterable has no such elements.
indexOf(Iterator<T>, Predicate<? super T>) - Static method in class com.google.common.collect.Iterators
Returns the index in iterator of the first element that satisfies the provided predicate, or -1 if the Iterator has no such elements.
indexOf(boolean[], boolean) - Static method in class com.google.common.primitives.Booleans
Returns the index of the first appearance of the value target in array.
indexOf(boolean[], boolean[]) - Static method in class com.google.common.primitives.Booleans
Returns the start position of the first occurrence of the specified target within array, or -1 if there is no such occurrence.
indexOf(byte[], byte) - Static method in class com.google.common.primitives.Bytes
Returns the index of the first appearance of the value target in array.
indexOf(byte[], byte[]) - Static method in class com.google.common.primitives.Bytes
Returns the start position of the first occurrence of the specified target within array, or -1 if there is no such occurrence.
indexOf(char[], char) - Static method in class com.google.common.primitives.Chars
Returns the index of the first appearance of the value target in array.
indexOf(char[], char[]) - Static method in class com.google.common.primitives.Chars
Returns the start position of the first occurrence of the specified target within array, or -1 if there is no such occurrence.
indexOf(double[], double) - Static method in class com.google.common.primitives.Doubles
Returns the index of the first appearance of the value target in array.
indexOf(double[], double[]) - Static method in class com.google.common.primitives.Doubles
Returns the start position of the first occurrence of the specified target within array, or -1 if there is no such occurrence.
indexOf(float[], float) - Static method in class com.google.common.primitives.Floats
Returns the index of the first appearance of the value target in array.
indexOf(float[], float[]) - Static method in class com.google.common.primitives.Floats
Returns the start position of the first occurrence of the specified target within array, or -1 if there is no such occurrence.
indexOf(int[], int) - Static method in class com.google.common.primitives.Ints
Returns the index of the first appearance of the value target in array.
indexOf(int[], int[]) - Static method in class com.google.common.primitives.Ints
Returns the start position of the first occurrence of the specified target within array, or -1 if there is no such occurrence.
indexOf(long[], long) - Static method in class com.google.common.primitives.Longs
Returns the index of the first appearance of the value target in array.
indexOf(long[], long[]) - Static method in class com.google.common.primitives.Longs
Returns the start position of the first occurrence of the specified target within array, or -1 if there is no such occurrence.
indexOf(short[], short) - Static method in class com.google.common.primitives.Shorts
Returns the index of the first appearance of the value target in array.
indexOf(short[], short[]) - Static method in class com.google.common.primitives.Shorts
Returns the start position of the first occurrence of the specified target within array, or -1 if there is no such occurrence.
InetAddresses - Class in com.google.common.net
Static utility methods pertaining to InetAddress instances.
InetAddresses.TeredoInfo - Class in com.google.common.net
A simple immutable data class to encapsulate the information to be found in a Teredo address.
InetAddresses.TeredoInfo(Inet4Address, Inet4Address, int, int) - Constructor for class com.google.common.net.InetAddresses.TeredoInfo
Constructs a TeredoInfo instance.
initialCapacity(int) - Method in class com.google.common.cache.CacheBuilder
Sets the minimum total size for the internal hash tables.
initialCapacity(int) - Method in class com.google.common.collect.MapMaker
Sets the minimum total size for the internal hash tables.
initialize(Class<?>...) - Static method in class com.google.common.reflect.Reflection
Ensures that the given classes are initialized, as described in JLS Section 12.4.2.
inOrderTraversal(T) - Method in class com.google.common.collect.BinaryTreeTraverser
 
InputSupplier<T> - Interface in com.google.common.io
Deprecated.
For InputSupplier<? extends InputStream>, use ByteSource instead. For InputSupplier<? extends Reader>, use CharSource. Implementations of InputSupplier that don't fall into one of those categories do not benefit from any of the methods in common.io and should use a different interface. This interface is scheduled for removal in June 2015.
inRange(char, char) - Static method in class com.google.common.base.CharMatcher
Returns a char matcher that matches any character in a given range (both endpoints are inclusive).
instanceOf(Class<?>) - Static method in class com.google.common.base.Predicates
Returns a predicate that evaluates to true if the object being tested is an instance of the given class.
integerFunnel() - Static method in class com.google.common.hash.Funnels
Returns a funnel for integers.
integers() - Static method in class com.google.common.collect.DiscreteDomain
Returns the discrete domain for values of type Integer.
interfaces() - Method in class com.google.common.reflect.TypeToken.TypeSet
Returns the types that are interfaces implemented by this type.
intern(E) - Method in interface com.google.common.collect.Interner
Chooses and returns the representative instance for any of a collection of instances that are equal to each other.
Interner<E> - Interface in com.google.common.collect
Provides equivalent behavior to String.intern() for other immutable types.
Interners - Class in com.google.common.collect
Contains static methods pertaining to instances of Interner.
InternetDomainName - Class in com.google.common.net
An immutable well-formed internet domain name, such as com or foo.co.uk.
interruptTask() - Method in class com.google.common.util.concurrent.AbstractFuture
Subclasses can override this method to implement interruption of the future's computation.
intersection(ContiguousSet<C>) - Method in class com.google.common.collect.ContiguousSet
Returns the set of values that are contained in both this set and the other.
intersection(Multiset<E>, Multiset<?>) - Static method in class com.google.common.collect.Multisets
Returns an unmodifiable view of the intersection of two multisets.
intersection(Range<C>) - Method in class com.google.common.collect.Range
Returns the maximal range enclosed by both this range and connectedRange, if such a range exists.
intersection(Set<E>, Set<?>) - Static method in class com.google.common.collect.Sets
Returns an unmodifiable view of the intersection of two sets.
IntMath - Class in com.google.common.math
A class for arithmetic on values of type int.
Ints - Class in com.google.common.primitives
Static utility methods pertaining to int primitives, that are not already found in either Integer or Arrays.
intValue() - Method in class com.google.common.primitives.UnsignedInteger
Returns the value of this UnsignedInteger as an int.
intValue() - Method in class com.google.common.primitives.UnsignedLong
Returns the value of this UnsignedLong as an int.
intValue() - Method in class com.google.common.util.concurrent.AtomicDouble
Returns the value of this AtomicDouble as an int after a narrowing primitive conversion.
invalidate(Object) - Method in class com.google.common.cache.AbstractCache
 
invalidate(Object) - Method in interface com.google.common.cache.Cache
Discards any cached value for key key.
invalidate(Object) - Method in class com.google.common.cache.ForwardingCache
 
invalidateAll(Iterable<?>) - Method in class com.google.common.cache.AbstractCache
 
invalidateAll() - Method in class com.google.common.cache.AbstractCache
 
invalidateAll(Iterable<?>) - Method in interface com.google.common.cache.Cache
Discards any cached values for keys keys.
invalidateAll() - Method in interface com.google.common.cache.Cache
Discards all entries in the cache.
invalidateAll(Iterable<?>) - Method in class com.google.common.cache.ForwardingCache
 
invalidateAll() - Method in class com.google.common.cache.ForwardingCache
 
inverse() - Method in interface com.google.common.collect.BiMap
Returns the inverse view of this bimap, which maps each of this bimap's values to its associated key.
inverse() - Method in class com.google.common.collect.HashBiMap
 
inverse() - Method in class com.google.common.collect.ImmutableBiMap
Returns the inverse view of this bimap, which maps each of this bimap's values to its associated key.
inverse() - Method in class com.google.common.collect.ImmutableListMultimap
Returns an immutable multimap which is the inverse of this one.
inverse() - Method in class com.google.common.collect.ImmutableMultimap
Returns an immutable multimap which is the inverse of this one.
inverse() - Method in class com.google.common.collect.ImmutableSetMultimap
Returns an immutable multimap which is the inverse of this one.
invertFrom(Multimap<? extends V, ? extends K>, M) - Static method in class com.google.common.collect.Multimaps
Copies each key-value mapping in source into dest, with its key and value reversed.
INVISIBLE - Static variable in class com.google.common.base.CharMatcher
Determines whether a character is invisible; that is, if its Unicode category is any of SPACE_SEPARATOR, LINE_SEPARATOR, PARAGRAPH_SEPARATOR, CONTROL, FORMAT, SURROGATE, and PRIVATE_USE according to ICU4J.
Invokable<T,R> - Class in com.google.common.reflect
Wrapper around either a Method or a Constructor.
invoke(Object, Method, Object[]) - Method in class com.google.common.reflect.AbstractInvocationHandler
Processes a method invocation on a proxy instance and returns the result.
invoke(T, Object...) - Method in class com.google.common.reflect.Invokable
Invokes with receiver as 'this' and args passed to the underlying method and returns the return value; or calls the underlying constructor with args and returns the constructed instance.
invokeAll(Collection<? extends Callable<T>>) - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
invokeAll(Collection<? extends Callable<T>>) - Method in interface com.google.common.util.concurrent.ListeningExecutorService
Executes the given tasks, returning a list of Futures holding their status and results when all complete.
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in interface com.google.common.util.concurrent.ListeningExecutorService
Executes the given tasks, returning a list of Futures holding their status and results when all complete or the timeout expires, whichever happens first.
invokeAny(Collection<? extends Callable<T>>) - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
is(char) - Static method in class com.google.common.base.CharMatcher
Returns a char matcher that matches only one specified character.
is(MediaType) - Method in class com.google.common.net.MediaType
Returns true if this instance falls within the range (as defined by the HTTP Accept header) given by the argument according to three criteria: The type of the argument is the wildcard or equal to the type of this instance.
is6to4Address(Inet6Address) - Static method in class com.google.common.net.InetAddresses
Evaluates whether the argument is a 6to4 address.
isAnnotationPresent(Class<? extends Annotation>) - Method in class com.google.common.reflect.Parameter
 
isArray() - Method in class com.google.common.reflect.TypeToken
Returns true if this type is known to be an array type, such as int[], T[], <? extends Map<String, Integer>[]> etc.
isAssignableFrom(TypeToken<?>) - Method in class com.google.common.reflect.TypeToken
Returns true if this type is assignable from the given type.
isAssignableFrom(Type) - Method in class com.google.common.reflect.TypeToken
Check if this type is assignable from the given type.
isCancelled() - Method in class com.google.common.util.concurrent.AbstractFuture
 
isCancelled() - Method in class com.google.common.util.concurrent.ForwardingFuture
 
isCompatible(BloomFilter<T>) - Method in class com.google.common.hash.BloomFilter
Determines whether a given bloom filter is compatible with this bloom filter.
isCompatIPv4Address(Inet6Address) - Static method in class com.google.common.net.InetAddresses
Evaluates whether the argument is an IPv6 "compat" address.
isConnected(Range<C>) - Method in class com.google.common.collect.Range
Returns true if there exists a (possibly empty) range which is enclosed by both this range and other.
isDirectory() - Static method in class com.google.common.io.Files
Returns a predicate that returns the result of File.isDirectory() on input files.
isDone() - Method in class com.google.common.util.concurrent.AbstractFuture
 
isDone() - Method in class com.google.common.util.concurrent.ForwardingFuture
 
isEmpty() - Method in class com.google.common.collect.ArrayTable
Always returns false.
isEmpty() - Method in class com.google.common.collect.ConcurrentHashMultiset
 
isEmpty() - Method in class com.google.common.collect.FluentIterable
Determines whether this fluent iterable is empty.
isEmpty() - Method in class com.google.common.collect.ForwardingCollection
 
isEmpty() - Method in class com.google.common.collect.ForwardingMap
 
isEmpty() - Method in class com.google.common.collect.ForwardingMultimap
 
isEmpty() - Method in class com.google.common.collect.ForwardingTable
 
isEmpty() - Method in class com.google.common.collect.ImmutableMap
 
isEmpty() - Method in class com.google.common.collect.ImmutableRangeSet
 
isEmpty(Iterable<?>) - Static method in class com.google.common.collect.Iterables
Determines if the given iterable contains no elements.
isEmpty() - Method in class com.google.common.collect.LinkedListMultimap
 
isEmpty() - Method in interface com.google.common.collect.Multimap
Returns true if this multimap contains no key-value pairs.
isEmpty() - Method in class com.google.common.collect.Range
Returns true if this range is of the form [v..v) or (v..v].
isEmpty() - Method in interface com.google.common.collect.RangeSet
Returns true if this range set contains no ranges.
isEmpty() - Method in interface com.google.common.collect.Table
Returns true if the table contains no mappings.
isEmpty() - Method in class com.google.common.io.ByteSource
Returns whether the source has zero bytes.
isEmpty() - Method in class com.google.common.io.CharSource
Returns whether the source has zero chars.
isEmpty() - Method in class com.google.common.util.concurrent.AtomicLongMap
Returns true if this map contains no key-value mappings.
isFair() - Method in class com.google.common.util.concurrent.Monitor
Returns whether this monitor is using a fair ordering policy.
isFile() - Static method in class com.google.common.io.Files
Returns a predicate that returns the result of File.isFile() on input files.
isFinite(double) - Static method in class com.google.common.primitives.Doubles
Returns true if value represents a real number.
isFinite(float) - Static method in class com.google.common.primitives.Floats
Returns true if value represents a real number.
isHealthy() - Method in class com.google.common.util.concurrent.ServiceManager
Returns true if all services are currently in the running state.
isInetAddress(String) - Static method in class com.google.common.net.InetAddresses
Returns true if the supplied string is a valid IP string literal, false otherwise.
isIsatapAddress(Inet6Address) - Static method in class com.google.common.net.InetAddresses
Evaluates whether the argument is an ISATAP address.
isLowerCase(char) - Static method in class com.google.common.base.Ascii
Indicates whether c is one of the twenty-six lowercase ASCII alphabetic characters between 'a' and 'z' inclusive.
isMappedIPv4Address(String) - Static method in class com.google.common.net.InetAddresses
Evaluates whether the argument is an "IPv4 mapped" IPv6 address.
isMathematicalInteger(double) - Static method in class com.google.common.math.DoubleMath
Returns true if x represents a mathematical integer.
isMaximum(InetAddress) - Static method in class com.google.common.net.InetAddresses
Returns true if the InetAddress is either 255.255.255.255 for IPv4 or ffff:ffff:ffff:ffff:ffff:ffff:ffff:ffff for IPv6.
isNot(char) - Static method in class com.google.common.base.CharMatcher
Returns a char matcher that matches any character except the one specified.
isNull() - Static method in class com.google.common.base.Predicates
Returns a predicate that evaluates to true if the object reference being tested is null.
isNullOrEmpty(String) - Static method in class com.google.common.base.Strings
Returns true if the given string is null or is the empty string.
ISO_8859_1 - Static variable in class com.google.common.base.Charsets
ISO-8859-1: ISO Latin Alphabet Number 1 (ISO-LATIN-1).
isOccupied() - Method in class com.google.common.util.concurrent.Monitor
Returns whether this monitor is occupied by any thread.
isOccupiedByCurrentThread() - Method in class com.google.common.util.concurrent.Monitor
Returns whether the current thread is occupying this monitor (has entered more times than it has left).
isOrdered(Iterable<? extends T>) - Method in class com.google.common.collect.Ordering
Returns true if each element in iterable after the first is greater than or equal to the element that preceded it, according to this ordering.
isOverridable() - Method in class com.google.common.reflect.Invokable
Returns true if this is an overridable method.
isPowerOfTwo(BigInteger) - Static method in class com.google.common.math.BigIntegerMath
Returns true if x represents a power of two.
isPowerOfTwo(double) - Static method in class com.google.common.math.DoubleMath
Returns true if x is exactly equal to 2^k for some finite integer k.
isPowerOfTwo(int) - Static method in class com.google.common.math.IntMath
Returns true if x represents a power of two.
isPowerOfTwo(long) - Static method in class com.google.common.math.LongMath
Returns true if x represents a power of two.
isPresent() - Method in class com.google.common.base.Optional
Returns true if this holder contains a (non-null) instance.
isPrimitive() - Method in class com.google.common.reflect.TypeToken
Returns true if this type is one of the nine primitive types (including void).
isPublicSuffix() - Method in class com.google.common.net.InternetDomainName
Indicates whether this domain name represents a public suffix, as defined by the Mozilla Foundation's Public Suffix List (PSL).
isRunning() - Method in class com.google.common.base.Stopwatch
Returns true if Stopwatch.start() has been called on this stopwatch, and Stopwatch.stop() has not been called since the last call to start().
isRunning() - Method in class com.google.common.util.concurrent.AbstractExecutionThreadService
 
isRunning() - Method in class com.google.common.util.concurrent.AbstractIdleService
 
isRunning() - Method in class com.google.common.util.concurrent.AbstractScheduledService
 
isRunning() - Method in class com.google.common.util.concurrent.AbstractService
 
isRunning() - Method in interface com.google.common.util.concurrent.Service
Returns true if this service is running.
isSatisfied() - Method in class com.google.common.util.concurrent.Monitor.Guard
Evaluates this guard's boolean condition.
isShutdown() - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
isStrictlyOrdered(Iterable<? extends T>) - Method in class com.google.common.collect.Ordering
Returns true if each element in iterable after the first is strictly greater than the element that preceded it, according to this ordering.
isTeredoAddress(Inet6Address) - Static method in class com.google.common.net.InetAddresses
Evaluates whether the argument is a Teredo address.
isTerminated() - Method in class com.google.common.util.concurrent.ForwardingExecutorService
 
isTopPrivateDomain() - Method in class com.google.common.net.InternetDomainName
Indicates whether this domain name is composed of exactly one subdomain component followed by a public suffix.
isUnderPublicSuffix() - Method in class com.google.common.net.InternetDomainName
Indicates whether this domain name ends in a public suffix, while not being a public suffix itself.
isUpperCase(char) - Static method in class com.google.common.base.Ascii
Indicates whether c is one of the twenty-six uppercase ASCII alphabetic characters between 'A' and 'Z' inclusive.
isUriInetAddress(String) - Static method in class com.google.common.net.InetAddresses
Returns true if the supplied string is a valid URI IP string literal, false otherwise.
isValid(String) - Static method in class com.google.common.net.HostSpecifier
Determines whether specifier represents a valid HostSpecifier as described in the documentation for HostSpecifier.fromValid(String).
isValid(String) - Static method in class com.google.common.net.InternetDomainName
Indicates whether the argument is a syntactically valid domain name using lenient validation.
isVarArgs() - Method in class com.google.common.reflect.Invokable
Returns true if this was declared to take a variable number of arguments.
isWellFormed(byte[]) - Static method in class com.google.common.base.Utf8
Returns true if bytes is a well-formed UTF-8 byte sequence according to Unicode 6.0.
isWellFormed(byte[], int, int) - Static method in class com.google.common.base.Utf8
Returns whether the given byte array slice is a well-formed UTF-8 byte sequence, as defined by Utf8.isWellFormed(byte[]).
isWrapperType(Class<?>) - Static method in class com.google.common.primitives.Primitives
Returns true if type is one of the nine primitive-wrapper types, such as Integer.
Iterables - Class in com.google.common.collect
This class contains static utility methods that operate on or return objects of type Iterable.
iterator() - Method in class com.google.common.collect.ForwardingCollection
 
iterator() - Method in class com.google.common.collect.ImmutableCollection
Returns an unmodifiable iterator across the elements in this collection.
iterator() - Method in class com.google.common.collect.ImmutableList
 
iterator() - Method in class com.google.common.collect.ImmutableMultiset
 
iterator() - Method in class com.google.common.collect.ImmutableSet
 
iterator() - Method in class com.google.common.collect.ImmutableSortedSet
 
iterator() - Method in class com.google.common.collect.MinMaxPriorityQueue
Returns an iterator over the elements contained in this collection, in no particular order.
iterator() - Method in interface com.google.common.collect.Multiset
Returns an iterator over the elements in this collection.
iterator() - Method in interface com.google.common.collect.SortedMultiset
Returns an iterator over the elements in this collection.
Iterators - Class in com.google.common.collect
This class contains static utility methods that operate on or return objects of type Iterator.

J

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

K

key() - Method in enum com.google.common.base.StandardSystemProperty
Returns the key used to lookup this system property.
KEY_ARCHIVE - Static variable in class com.google.common.net.MediaType
As described in PKCS #12: Personal Information Exchange Syntax Standard, PKCS #12 defines an archive file format for storing many cryptography objects as a single file.
keyComparator() - Method in class com.google.common.collect.TreeMultimap
Returns the comparator that orders the multimap keys.
keys() - Method in class com.google.common.collect.ForwardingMultimap
 
keys() - Method in class com.google.common.collect.ImmutableMultimap
Returns a collection, which may contain duplicates, of all keys.
keys() - Method in interface com.google.common.collect.Multimap
Returns a view collection containing the key from each key-value pair in this multimap, without collapsing duplicates.
keySet() - Method in class com.google.common.collect.ForwardingMap
 
keySet() - Method in class com.google.common.collect.ForwardingMultimap
 
keySet() - Method in class com.google.common.collect.HashBiMap
 
keySet() - Method in class com.google.common.collect.ImmutableMap
Returns an immutable set of the keys in this map.
keySet() - Method in class com.google.common.collect.ImmutableMultimap
Returns an immutable set of the distinct keys in this multimap.
keySet() - Method in class com.google.common.collect.ImmutableSortedMap
Returns an immutable sorted set of the keys in this map.
keySet() - Method in interface com.google.common.collect.Multimap
Returns a view collection of all distinct keys contained in this multimap.
keySet() - Method in class com.google.common.collect.TreeMultimap
Returns a view collection of all distinct keys contained in this multimap.
keyType() - Method in class com.google.common.collect.EnumBiMap
Returns the associated key type.
keyType() - Method in class com.google.common.collect.EnumHashBiMap
Returns the associated key type.
KML - Static variable in class com.google.common.net.MediaType
 
KMZ - Static variable in class com.google.common.net.MediaType
 

L

last() - Method in class com.google.common.collect.FluentIterable
Returns an Optional containing the last element in this fluent iterable.
last() - Method in class com.google.common.collect.ForwardingSortedSet
 
last() - Method in class com.google.common.collect.ImmutableSortedSet
 
LAST_EVENT_ID - Static variable in class com.google.common.net.HttpHeaders
The HTTP Last-Event-ID header field name.
LAST_MODIFIED - Static variable in class com.google.common.net.HttpHeaders
The HTTP Last-Modified header field name.
lastEntry() - Method in class com.google.common.collect.ForwardingNavigableMap
 
lastEntry() - Method in class com.google.common.collect.ForwardingSortedMultiset
 
lastEntry() - Method in class com.google.common.collect.ImmutableSortedMap
 
lastEntry() - Method in interface com.google.common.collect.SortedMultiset
Returns the entry of the last element in this multiset, or null if this multiset is empty.
lastIndexIn(CharSequence) - Method in class com.google.common.base.CharMatcher
Returns the index of the last matching character in a character sequence, or -1 if no matching character is present.
lastIndexOf(Object) - Method in class com.google.common.collect.ForwardingList
 
lastIndexOf(Object) - Method in class com.google.common.collect.ImmutableList
 
lastIndexOf(boolean[], boolean) - Static method in class com.google.common.primitives.Booleans
Returns the index of the last appearance of the value target in array.
lastIndexOf(byte[], byte) - Static method in class com.google.common.primitives.Bytes
Returns the index of the last appearance of the value target in array.
lastIndexOf(char[], char) - Static method in class com.google.common.primitives.Chars
Returns the index of the last appearance of the value target in array.
lastIndexOf(double[], double) - Static method in class com.google.common.primitives.Doubles
Returns the index of the last appearance of the value target in array.
lastIndexOf(float[], float) - Static method in class com.google.common.primitives.Floats
Returns the index of the last appearance of the value target in array.
lastIndexOf(int[], int) - Static method in class com.google.common.primitives.Ints
Returns the index of the last appearance of the value target in array.
lastIndexOf(long[], long) - Static method in class com.google.common.primitives.Longs
Returns the index of the last appearance of the value target in array.
lastIndexOf(short[], short) - Static method in class com.google.common.primitives.Shorts
Returns the index of the last appearance of the value target in array.
lastKey() - Method in class com.google.common.collect.ForwardingSortedMap
 
lastKey() - Method in class com.google.common.collect.ImmutableSortedMap
 
lazySet(double) - Method in class com.google.common.util.concurrent.AtomicDouble
Eventually sets to the given value.
lazySet(int, double) - Method in class com.google.common.util.concurrent.AtomicDoubleArray
Eventually sets the element at position i to the given value.
lazyTransform(Future<I>, Function<? super I, ? extends O>) - Static method in class com.google.common.util.concurrent.Futures
Like Futures.transform(ListenableFuture, Function) except that the transformation function is invoked on each call to get() on the returned future.
lazyWeakLock(int) - Static method in class com.google.common.util.concurrent.Striped
Creates a Striped<Lock> with lazily initialized, weakly referenced locks.
lazyWeakReadWriteLock(int) - Static method in class com.google.common.util.concurrent.Striped
Creates a Striped<ReadWriteLock> with lazily initialized, weakly referenced read-write locks.
lazyWeakSemaphore(int, int) - Static method in class com.google.common.util.concurrent.Striped
Creates a Striped<Semaphore> with lazily initialized, weakly referenced semaphores, with the specified number of permits.
leastOf(Iterable<E>, int) - Method in class com.google.common.collect.Ordering
Returns the k least elements of the given iterable according to this ordering, in order from least to greatest.
leastOf(Iterator<E>, int) - Method in class com.google.common.collect.Ordering
Returns the k least elements from the given iterator according to this ordering, in order from least to greatest.
leave() - Method in class com.google.common.util.concurrent.Monitor
Leaves this monitor.
leftChild(T) - Method in class com.google.common.collect.BinaryTreeTraverser
Returns the left child of the specified node, or Optional.absent() if the specified node has no left child.
leftValue() - Method in interface com.google.common.collect.MapDifference.ValueDifference
Returns the value from the left map (possibly null).
length(InputSupplier<? extends InputStream>) - Static method in class com.google.common.io.ByteStreams
Deprecated.
Use ByteSource.size() instead. This method is scheduled for removal in Guava 18.0.
length() - Method in class com.google.common.util.concurrent.AtomicDoubleArray
Returns the length of the array.
lessThan(C) - Static method in class com.google.common.collect.Range
Returns a range that contains all values strictly less than endpoint.
lexicographical() - Method in class com.google.common.collect.Ordering
Returns a new ordering which sorts iterables by comparing corresponding elements pairwise until a nonzero result is found; imposes "dictionary order".
lexicographicalComparator() - Static method in class com.google.common.primitives.Booleans
Returns a comparator that compares two boolean arrays lexicographically.
lexicographicalComparator() - Static method in class com.google.common.primitives.Chars
Returns a comparator that compares two char arrays lexicographically.
lexicographicalComparator() - Static method in class com.google.common.primitives.Doubles
Returns a comparator that compares two double arrays lexicographically.
lexicographicalComparator() - Static method in class com.google.common.primitives.Floats
Returns a comparator that compares two float arrays lexicographically.
lexicographicalComparator() - Static method in class com.google.common.primitives.Ints
Returns a comparator that compares two int arrays lexicographically.
lexicographicalComparator() - Static method in class com.google.common.primitives.Longs
Returns a comparator that compares two long arrays lexicographically.
lexicographicalComparator() - Static method in class com.google.common.primitives.Shorts
Returns a comparator that compares two short arrays lexicographically.
lexicographicalComparator() - Static method in class com.google.common.primitives.SignedBytes
Returns a comparator that compares two byte arrays lexicographically.
lexicographicalComparator() - Static method in class com.google.common.primitives.UnsignedBytes
Returns a comparator that compares two byte arrays lexicographically.
lexicographicalComparator() - Static method in class com.google.common.primitives.UnsignedInts
Returns a comparator that compares two arrays of unsigned int values lexicographically.
lexicographicalComparator() - Static method in class com.google.common.primitives.UnsignedLongs
Returns a comparator that compares two arrays of unsigned long values lexicographically.
LF - Static variable in class com.google.common.base.Ascii
Line Feed ('\n'): A format effector which controls the movement of the printing position to the next printing line.
limit(int) - Method in class com.google.common.base.Splitter
Returns a splitter that behaves equivalently to this splitter but stops splitting after it reaches the limit.
limit(int) - Method in class com.google.common.collect.FluentIterable
Creates a fluent iterable with the first size elements of this fluent iterable.
limit(Iterable<T>, int) - Static method in class com.google.common.collect.Iterables
Creates an iterable with the first limitSize elements of the given iterable.
limit(Iterator<T>, int) - Static method in class com.google.common.collect.Iterators
Creates an iterator returning the first limitSize elements of the given iterator.
limit(InputStream, long) - Static method in class com.google.common.io.ByteStreams
Wraps a InputStream, limiting the number of bytes which can be read.
LineProcessor<T> - Interface in com.google.common.io
A callback to be used with the streaming readLines methods.
LineReader - Class in com.google.common.io
A class for reading lines of text.
LineReader(Readable) - Constructor for class com.google.common.io.LineReader
Creates a new instance that will read lines from the given Readable object.
LINK - Static variable in class com.google.common.net.HttpHeaders
The HTTP Link header field name.
linkedHashKeys() - Static method in class com.google.common.collect.MultimapBuilder
Uses a LinkedHashMap to map keys to value collections.
linkedHashKeys(int) - Static method in class com.google.common.collect.MultimapBuilder
Uses a LinkedHashMap to map keys to value collections, initialized to expect the specified number of keys.
LinkedHashMultimap<K,V> - Class in com.google.common.collect
Implementation of Multimap that does not allow duplicate key-value entries and that returns collections whose iterators follow the ordering in which the data was added to the multimap.
LinkedHashMultiset<E> - Class in com.google.common.collect
A Multiset implementation with predictable iteration order.
linkedHashSetValues() - Method in class com.google.common.collect.MultimapBuilder.MultimapBuilderWithKeys
Uses a LinkedHashSet to store value collections.
linkedHashSetValues(int) - Method in class com.google.common.collect.MultimapBuilder.MultimapBuilderWithKeys
Uses a LinkedHashSet to store value collections, initialized to expect the specified number of values per key.
LinkedListMultimap<K,V> - Class in com.google.common.collect
An implementation of ListMultimap that supports deterministic iteration order for both keys and values.
linkedListValues() - Method in class com.google.common.collect.MultimapBuilder.MultimapBuilderWithKeys
Uses a LinkedList to store value collections.
ListenableFuture<V> - Interface in com.google.common.util.concurrent
A Future that accepts completion listeners.
ListenableFutureTask<V> - Class in com.google.common.util.concurrent
A FutureTask that also implements the ListenableFuture interface.
ListenableScheduledFuture<V> - Interface in com.google.common.util.concurrent
Helper interface to implement both ListenableFuture and ScheduledFuture.
listeningDecorator(ExecutorService) - Static method in class com.google.common.util.concurrent.MoreExecutors
Creates an ExecutorService whose submit and invokeAll methods submit ListenableFutureTask instances to the given delegate executor.
listeningDecorator(ScheduledExecutorService) - Static method in class com.google.common.util.concurrent.MoreExecutors
Creates a ScheduledExecutorService whose submit and invokeAll methods submit ListenableFutureTask instances to the given delegate executor.
ListeningExecutorService - Interface in com.google.common.util.concurrent
An ExecutorService that returns ListenableFuture instances.
ListeningScheduledExecutorService - Interface in com.google.common.util.concurrent
A ScheduledExecutorService that returns ListenableFuture instances from its ExecutorService methods.
listenInPoolThread(Future<V>) - Static method in class com.google.common.util.concurrent.JdkFutureAdapters
Assigns a thread to the given Future to provide ListenableFuture functionality.
listenInPoolThread(Future<V>, Executor) - Static method in class com.google.common.util.concurrent.JdkFutureAdapters
Submits a blocking task for the given Future to provide ListenableFuture functionality.
listIterator() - Method in class com.google.common.collect.ForwardingList
 
listIterator(int) - Method in class com.google.common.collect.ForwardingList
 
listIterator() - Method in class com.google.common.collect.ImmutableList
 
listIterator(int) - Method in class com.google.common.collect.ImmutableList
 
ListMultimap<K,V> - Interface in com.google.common.collect
A Multimap that can hold duplicate key-value pairs and that maintains the insertion ordering of values for a given key.
Lists - Class in com.google.common.collect
Static utility methods pertaining to List instances.
LittleEndianDataInputStream - Class in com.google.common.io
An implementation of DataInput that uses little-endian byte ordering for reading short, int, float, double, and long values.
LittleEndianDataInputStream(InputStream) - Constructor for class com.google.common.io.LittleEndianDataInputStream
Creates a LittleEndianDataInputStream that wraps the given stream.
LittleEndianDataOutputStream - Class in com.google.common.io
An implementation of DataOutput that uses little-endian byte ordering for writing char, short, int, float, double, and long values.
LittleEndianDataOutputStream(OutputStream) - Constructor for class com.google.common.io.LittleEndianDataOutputStream
Creates a LittleEndianDataOutputStream that wraps the given stream.
load(K) - Method in class com.google.common.cache.CacheLoader
Computes or retrieves the value corresponding to key.
load() - Method in class com.google.common.reflect.ClassPath.ClassInfo
Loads (but doesn't link or initialize) the class.
loadAll(Iterable<? extends K>) - Method in class com.google.common.cache.CacheLoader
Computes or retrieves the values corresponding to keys.
loadCount() - Method in class com.google.common.cache.CacheStats
Returns the total number of times that Cache lookup methods attempted to load new values.
loadExceptionCount() - Method in class com.google.common.cache.CacheStats
Returns the number of times Cache lookup methods threw an exception while loading a new value.
loadExceptionRate() - Method in class com.google.common.cache.CacheStats
Returns the ratio of cache loading attempts which threw exceptions.
LoadingCache<K,V> - Interface in com.google.common.cache
A semi-persistent mapping from keys to values.
loadSuccessCount() - Method in class com.google.common.cache.CacheStats
Returns the number of times Cache lookup methods have successfully loaded a new value.
LOCATION - Static variable in class com.google.common.net.HttpHeaders
The HTTP Location header field name.
lock(int) - Static method in class com.google.common.util.concurrent.Striped
Creates a Striped<Lock> with eagerly initialized, strongly referenced locks.
log10(BigInteger, RoundingMode) - Static method in class com.google.common.math.BigIntegerMath
Returns the base-10 logarithm of x, rounded according to the specified rounding mode.
log10(int, RoundingMode) - Static method in class com.google.common.math.IntMath
Returns the base-10 logarithm of x, rounded according to the specified rounding mode.
log10(long, RoundingMode) - Static method in class com.google.common.math.LongMath
Returns the base-10 logarithm of x, rounded according to the specified rounding mode.
log2(BigInteger, RoundingMode) - Static method in class com.google.common.math.BigIntegerMath
Returns the base-2 logarithm of x, rounded according to the specified rounding mode.
log2(double) - Static method in class com.google.common.math.DoubleMath
Returns the base 2 logarithm of a double value.
log2(double, RoundingMode) - Static method in class com.google.common.math.DoubleMath
Returns the base 2 logarithm of a double value, rounded with the specified rounding mode to an int.
log2(int, RoundingMode) - Static method in class com.google.common.math.IntMath
Returns the base-2 logarithm of x, rounded according to the specified rounding mode.
log2(long, RoundingMode) - Static method in class com.google.common.math.LongMath
Returns the base-2 logarithm of x, rounded according to the specified rounding mode.
longFunnel() - Static method in class com.google.common.hash.Funnels
Returns a funnel for longs.
LongMath - Class in com.google.common.math
A class for arithmetic on values of type long.
longs() - Static method in class com.google.common.collect.DiscreteDomain
Returns the discrete domain for values of type Long.
Longs - Class in com.google.common.primitives
Static utility methods pertaining to long primitives, that are not already found in either Long or Arrays.
longValue() - Method in class com.google.common.primitives.UnsignedInteger
Returns the value of this UnsignedInteger as a long.
longValue() - Method in class com.google.common.primitives.UnsignedLong
Returns the value of this UnsignedLong as a long.
longValue() - Method in class com.google.common.util.concurrent.AtomicDouble
Returns the value of this AtomicDouble as a long after a narrowing primitive conversion.
lower(E) - Method in class com.google.common.collect.ForwardingNavigableSet
 
lower(E) - Method in class com.google.common.collect.ImmutableSortedSet
 
lowerBoundType() - Method in class com.google.common.collect.Range
Returns the type of this range's lower bound: BoundType.CLOSED if the range includes its lower endpoint, BoundType.OPEN if it does not.
lowerCase() - Method in class com.google.common.io.BaseEncoding
Returns an encoding that behaves equivalently to this encoding, but encodes and decodes with lowercase letters.
lowerEndpoint() - Method in class com.google.common.collect.Range
Returns the lower endpoint of this range.
lowerEntry(K) - Method in class com.google.common.collect.ForwardingNavigableMap
 
lowerEntry(K) - Method in class com.google.common.collect.ImmutableSortedMap
 
lowerKey(K) - Method in class com.google.common.collect.ForwardingNavigableMap
 
lowerKey(K) - Method in class com.google.common.collect.ImmutableSortedMap
 

M

makeChecked(ListenableFuture<V>, Function<Exception, X>) - Static method in class com.google.common.util.concurrent.Futures
Creates a CheckedFuture out of a normal ListenableFuture and a Function that maps from Exception instances into the appropriate checked type.
makeMap() - Method in class com.google.common.collect.MapMaker
Builds a thread-safe map, without on-demand computation of values.
map(File) - Static method in class com.google.common.io.Files
Fully maps a file read-only in to memory as per FileChannel.map(java.nio.channels.FileChannel.MapMode, long, long).
map(File, FileChannel.MapMode) - Static method in class com.google.common.io.Files
Fully maps a file in to memory as per FileChannel.map(java.nio.channels.FileChannel.MapMode, long, long) using the requested FileChannel.MapMode.
map(File, FileChannel.MapMode, long) - Static method in class com.google.common.io.Files
MapConstraint<K,V> - Interface in com.google.common.collect
A constraint on the keys and values that may be added to a Map or Multimap.
MapConstraints - Class in com.google.common.collect
Factory and utilities pertaining to the MapConstraint interface.
MapDifference<K,V> - Interface in com.google.common.collect
An object representing the differences between two maps.
MapDifference.ValueDifference<V> - Interface in com.google.common.collect
A difference between the mappings from two maps with the same key.
mapException(Exception) - Method in class com.google.common.util.concurrent.AbstractCheckedFuture
Translates from an InterruptedException, CancellationException or ExecutionException thrown by get to an exception of type X to be thrown by checkedGet.
MapMaker - Class in com.google.common.collect
A builder of ConcurrentMap instances having any combination of the following features: keys or values automatically wrapped in weak or soft references notification of evicted (or otherwise removed) entries on-demand computation of values for keys not already present
MapMaker() - Constructor for class com.google.common.collect.MapMaker
Constructs a new MapMaker instance with default settings, including strong keys, strong values, and no automatic eviction of any kind.
Maps - Class in com.google.common.collect
Static utility methods pertaining to Map instances (including instances of SortedMap, BiMap, etc.).
Maps.EntryTransformer<K,V1,V2> - Interface in com.google.common.collect
A transformation of the value of a key-value pair, using both key and value as inputs.
mark(int) - Method in class com.google.common.hash.HashingInputStream
mark() is not supported for HashingInputStream
mark(int) - Method in class com.google.common.io.CountingInputStream
 
markSupported() - Method in class com.google.common.hash.HashingInputStream
mark() is not supported for HashingInputStream
matches(char) - Method in class com.google.common.base.CharMatcher
Determines a true or false value for the given character.
matchesAllOf(CharSequence) - Method in class com.google.common.base.CharMatcher
Returns true if a character sequence contains only matching characters.
matchesAnyOf(CharSequence) - Method in class com.google.common.base.CharMatcher
Returns true if a character sequence contains at least one matching character.
matchesNoneOf(CharSequence) - Method in class com.google.common.base.CharMatcher
Returns true if a character sequence contains no matching characters.
MAX - Static variable in class com.google.common.base.Ascii
The maximum value of an ASCII character.
max(Iterator<E>) - Method in class com.google.common.collect.Ordering
Returns the greatest of the specified values according to this ordering.
max(Iterable<E>) - Method in class com.google.common.collect.Ordering
Returns the greatest of the specified values according to this ordering.
max(E, E) - Method in class com.google.common.collect.Ordering
Returns the greater of the two values according to this ordering.
max(E, E, E, E...) - Method in class com.google.common.collect.Ordering
Returns the greatest of the specified values according to this ordering.
max(char...) - Static method in class com.google.common.primitives.Chars
Returns the greatest value present in array.
max(double...) - Static method in class com.google.common.primitives.Doubles
Returns the greatest value present in array, using the same rules of comparison as Math.max(double, double).
max(float...) - Static method in class com.google.common.primitives.Floats
Returns the greatest value present in array, using the same rules of comparison as Math.min(float, float).
max(int...) - Static method in class com.google.common.primitives.Ints
Returns the greatest value present in array.
max(long...) - Static method in class com.google.common.primitives.Longs
Returns the greatest value present in array.
max(short...) - Static method in class com.google.common.primitives.Shorts
Returns the greatest value present in array.
max(byte...) - Static method in class com.google.common.primitives.SignedBytes
Returns the greatest value present in array.
max(byte...) - Static method in class com.google.common.primitives.UnsignedBytes
Returns the greatest value present in array.
max(int...) - Static method in class com.google.common.primitives.UnsignedInts
Returns the greatest value present in array, treating values as unsigned.
max(long...) - Static method in class com.google.common.primitives.UnsignedLongs
Returns the greatest value present in array, treating values as unsigned.
MAX_FORWARDS - Static variable in class com.google.common.net.HttpHeaders
The HTTP Max-Forwards header field name.
MAX_POWER_OF_TWO - Static variable in class com.google.common.primitives.Ints
The largest power of two that can be represented as an int.
MAX_POWER_OF_TWO - Static variable in class com.google.common.primitives.Longs
The largest power of two that can be represented as a long.
MAX_POWER_OF_TWO - Static variable in class com.google.common.primitives.Shorts
The largest power of two that can be represented as a short.
MAX_POWER_OF_TWO - Static variable in class com.google.common.primitives.SignedBytes
The largest power of two that can be represented as a signed byte.
MAX_POWER_OF_TWO - Static variable in class com.google.common.primitives.UnsignedBytes
The largest power of two that can be represented as an unsigned byte.
MAX_VALUE - Static variable in class com.google.common.primitives.UnsignedBytes
The largest value that fits into an unsigned byte.
MAX_VALUE - Static variable in class com.google.common.primitives.UnsignedInteger
 
MAX_VALUE - Static variable in class com.google.common.primitives.UnsignedLong
 
MAX_VALUE - Static variable in class com.google.common.primitives.UnsignedLongs
 
maximumSize(long) - Method in class com.google.common.cache.CacheBuilder
Specifies the maximum number of entries the cache may contain.
maximumSize(int) - Method in class com.google.common.collect.MinMaxPriorityQueue.Builder
Configures this builder to build MinMaxPriorityQueue instances that are limited to maximumSize elements.
maximumSize(int) - Static method in class com.google.common.collect.MinMaxPriorityQueue
Creates and returns a new builder, configured to build MinMaxPriorityQueue instances that are limited to maximumSize elements.
maximumWeight(long) - Method in class com.google.common.cache.CacheBuilder
Specifies the maximum weight of entries the cache may contain.
maxValue() - Method in class com.google.common.collect.DiscreteDomain
Returns the maximum value of type C, if it has one.
MBOX - Static variable in class com.google.common.net.MediaType
 
md5() - Static method in class com.google.common.hash.Hashing
Returns a hash function implementing the MD5 hash algorithm (128 hash bits) by delegating to the MD5 MessageDigest.
mean(double...) - Static method in class com.google.common.math.DoubleMath
Returns the arithmetic mean of the values.
mean(int...) - Static method in class com.google.common.math.DoubleMath
Returns the arithmetic mean of the values.
mean(long...) - Static method in class com.google.common.math.DoubleMath
Returns the arithmetic mean of the values.
mean(Iterable<? extends Number>) - Static method in class com.google.common.math.DoubleMath
Returns the arithmetic mean of the values.
mean(Iterator<? extends Number>) - Static method in class com.google.common.math.DoubleMath
Returns the arithmetic mean of the values.
mean(int, int) - Static method in class com.google.common.math.IntMath
Returns the arithmetic mean of x and y, rounded towards negative infinity.
mean(long, long) - Static method in class com.google.common.math.LongMath
Returns the arithmetic mean of x and y, rounded toward negative infinity.
MediaType - Class in com.google.common.net
Represents an Internet Media Type (also known as a MIME Type or Content Type).
memoize(Supplier<T>) - Static method in class com.google.common.base.Suppliers
Returns a supplier which caches the instance retrieved during the first call to get() and returns that value on subsequent calls to get().
memoizeWithExpiration(Supplier<T>, long, TimeUnit) - Static method in class com.google.common.base.Suppliers
Returns a supplier that caches the instance supplied by the delegate and removes the cached value after the specified time has passed.
mergeSorted(Iterable<? extends Iterable<? extends T>>, Comparator<? super T>) - Static method in class com.google.common.collect.Iterables
Returns an iterable over the merged contents of all given iterables.
mergeSorted(Iterable<? extends Iterator<? extends T>>, Comparator<? super T>) - Static method in class com.google.common.collect.Iterators
Returns an iterator over the merged contents of all given iterators, traversing every element of the input iterators.
method(Method) - Method in class com.google.common.reflect.TypeToken
Returns the Invokable for method, which must be a member of T.
MICROSOFT_EXCEL - Static variable in class com.google.common.net.MediaType
 
MICROSOFT_POWERPOINT - Static variable in class com.google.common.net.MediaType
 
MICROSOFT_WORD - Static variable in class com.google.common.net.MediaType
 
mightContain(T) - Method in class com.google.common.hash.BloomFilter
Returns true if the element might have been put in this Bloom filter,