| Package | Description | 
|---|---|
| com.google.common.base | Basic utility libraries and interfaces. | 
| com.google.common.collect | This package contains generic collection interfaces and implementations, and
 other utilities for working with collections. | 
| com.google.common.escape | Interfaces, utilities, and simple implementations of escapers and encoders. | 
| 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 | Hash functions and related structures. | 
| com.google.common.html | Escapers
 for
 HTML. | 
| 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.net | This package contains utility methods and classes for working with net
 addresses (numeric IP and domain names). | 
| 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 | This package contains utilities to work with Java reflection. | 
| com.google.common.util.concurrent | Concurrency utilities. | 
| com.google.common.xml | Escapers
 for
 XML. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CharMatcher | 
| class  | Converter<A,B>A function from  AtoBwith an associated reverse function fromBtoA; used for converting back and forth between different representations of the same
 information. | 
| class  | EnumsUtility methods for working with  Enuminstances. | 
| static class  | Splitter.MapSplitterAn object that splits strings into maps as  Splittersplits
 iterables and lists. | 
| class  | StandardSystemPropertyRepresents a standard system property. | 
| class  | TickerA time source; returns a time value representing the number of nanoseconds elapsed since some
 fixed but arbitrary point in time. | 
| class  | Utf8Low-level, high-performance utility methods related to the UTF-8
 character encoding. | 
| class  | VerifyStatic convenience methods that serve the same purpose as Java language
 
 assertions, except that they are always enabled. | 
| class  | VerifyExceptionException thrown upon the failure of a
 verification
 check, including those performed by the convenience methods of the  Verifyclass. | 
| Modifier and Type | Method and Description | 
|---|---|
| <A extends Appendable>  | Joiner.MapJoiner. appendTo(A appendable,
                Iterable<? extends Map.Entry<?,?>> entries)Appends the string representation of each entry in  entries, using the previously
 configured separator and key-value separator, toappendable. | 
| <A extends Appendable>  | Joiner.MapJoiner. appendTo(A appendable,
                Iterator<? extends Map.Entry<?,?>> parts)Appends the string representation of each entry in  entries, using the previously
 configured separator and key-value separator, toappendable. | 
| StringBuilder | Joiner.MapJoiner. appendTo(StringBuilder builder,
                Iterable<? extends Map.Entry<?,?>> entries)Appends the string representation of each entry in  entries, using the previously
 configured separator and key-value separator, tobuilder. | 
| StringBuilder | Joiner.MapJoiner. appendTo(StringBuilder builder,
                Iterator<? extends Map.Entry<?,?>> entries)Appends the string representation of each entry in  entries, using the previously
 configured separator and key-value separator, tobuilder. | 
| static Predicate<Class<?>> | Predicates. assignableFrom(Class<?> clazz)Returns a predicate that evaluates to  trueif the class being
 tested is assignable from the given class. | 
| Converter<String,String> | CaseFormat. converterTo(CaseFormat targetFormat)Returns a  Converterthat converts strings from this format totargetFormat. | 
| static boolean | Ascii. equalsIgnoreCase(CharSequence s1,
                                CharSequence s2)Indicates whether the contents of the given character sequences  s1ands2are
 equal, ignoring the case of any ASCII alphabetic characters between'a'and'z'or'A'and'Z'inclusive. | 
| Predicate<T> | Equivalence. equivalentTo(T target)Returns a predicate that evaluates to true if and only if the input is
 equivalent to  targetaccording to this equivalence relation. | 
| static <T> Function<Object,T> | Functions. forSupplier(Supplier<T> supplier)Returns a function that always returns the result of invoking  Supplier.get()onsupplier, regardless of its input. | 
| static List<Throwable> | Throwables. getCausalChain(Throwable throwable)Gets a  Throwablecause chain as a list. | 
| String | Joiner.MapJoiner. join(Iterable<? extends Map.Entry<?,?>> entries)Returns a string containing the string representation of each entry in  entries, using
 the previously configured separator and key-value separator. | 
| String | Joiner.MapJoiner. join(Iterator<? extends Map.Entry<?,?>> entries)Returns a string containing the string representation of each entry in  entries, using
 the previously configured separator and key-value separator. | 
| static List<StackTraceElement> | Throwables. lazyStackTrace(Throwable throwable)Returns the stack trace of  throwable, possibly providing slower iteration over the full
 trace but faster iteration over parts of the trace. | 
| static boolean | Throwables. lazyStackTraceIsLazy()Returns whether  Throwables.lazyStackTrace(java.lang.Throwable)will use the special implementation described in its
 documentation. | 
| abstract T | Optional. or(Supplier<? extends T> supplier)Returns the contained instance if it is present;  supplier.get()otherwise. | 
| static <T> Iterable<T> | Optional. presentInstances(Iterable<? extends Optional<? extends T>> optionals)Returns the value of each present instance from the supplied  optionals, in order,
 skipping over occurrences ofOptional.absent(). | 
| List<String> | Splitter. splitToList(CharSequence sequence)Splits  sequenceinto string components and returns them as
 an immutable list. | 
| static <T> Function<Supplier<T>,T> | Suppliers. supplierFunction()Returns a function that accepts a supplier and returns the result of
 invoking  Supplier.get()on that supplier. | 
| static String | Ascii. truncate(CharSequence seq,
                int maxLength,
                String truncationIndicator)Truncates the given character sequence to the given maximum length. | 
| Splitter.MapSplitter | Splitter. withKeyValueSeparator(char separator)Returns a  MapSplitterwhich splits entries based on this splitter,
 and splits entries into keys and values using the specified separator. | 
| Splitter.MapSplitter | Splitter. withKeyValueSeparator(Splitter keyValueSplitter)Returns a  MapSplitterwhich splits entries based on this splitter,
 and splits entries into keys and values using the specified key-value
 splitter. | 
| Splitter.MapSplitter | Splitter. withKeyValueSeparator(String separator)Returns a  MapSplitterwhich splits entries based on this splitter,
 and splits entries into keys and values using the specified separator. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ArrayTable<R,C,V>Fixed-size  Tableimplementation backed by a two-dimensional array. | 
| class  | BinaryTreeTraverser<T>A variant of  TreeTraverserfor binary trees, providing additional traversals specific to
 binary trees. | 
| class  | ContiguousSet<C extends Comparable>A sorted set of contiguous values in a given  DiscreteDomain. | 
| class  | DiscreteDomain<C extends Comparable>A descriptor for a discrete  Comparabledomain such as allIntegerinstances. | 
| class  | EvictingQueue<E>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. | 
| protected class  | ForwardingMap.StandardEntrySetA sensible implementation of  Map.entrySet()in terms of the following
 methods:ForwardingMap.clear(),ForwardingMap.containsKey(java.lang.Object),ForwardingMap.get(java.lang.Object),ForwardingMap.isEmpty(),ForwardingMap.remove(java.lang.Object), andForwardingMap.size(). | 
| protected class  | ForwardingMap.StandardKeySetA sensible implementation of  Map.keySet()in terms of the following
 methods:ForwardingMap.clear(),ForwardingMap.containsKey(java.lang.Object),ForwardingMap.isEmpty(),ForwardingMap.remove(java.lang.Object),ForwardingMap.size(), and theSet.iterator()method ofForwardingMap.entrySet(). | 
| protected class  | ForwardingMap.StandardValuesA sensible implementation of  Map.values()in terms of the following
 methods:ForwardingMap.clear(),ForwardingMap.containsValue(java.lang.Object),ForwardingMap.isEmpty(),ForwardingMap.size(), and theSet.iterator()method ofForwardingMap.entrySet(). | 
| protected class  | ForwardingMultiset.StandardElementSetA sensible implementation of  Multiset.elementSet()in terms of the
 following methods:ForwardingCollection.clear(),ForwardingCollection.contains(java.lang.Object),ForwardingCollection.containsAll(java.util.Collection<?>),ForwardingMultiset.count(java.lang.Object),ForwardingCollection.isEmpty(), theSet.size()andSet.iterator()methods ofForwardingMultiset.entrySet(), andForwardingMultiset.remove(Object,
 int). | 
| protected class  | ForwardingNavigableMap.StandardDescendingMapA sensible implementation of  NavigableMap.descendingMap()in terms of the methods of
 thisNavigableMap. | 
| protected class  | ForwardingNavigableMap.StandardNavigableKeySetA sensible implementation of  NavigableMap.navigableKeySet()in terms of the methods of
 thisNavigableMap. | 
| protected class  | ForwardingNavigableSet.StandardDescendingSetA sensible implementation of  NavigableSet.descendingSet()in terms of the other methods
 ofNavigableSet, notably includingNavigableSet.descendingIterator(). | 
| protected class  | ForwardingSortedMap.StandardKeySetA sensible implementation of  SortedMap.keySet()in terms of the methods ofForwardingSortedMap. | 
| class  | ForwardingSortedMultiset<E>A sorted multiset which forwards all its method calls to another sorted multiset. | 
| class  | ImmutableRangeMap<K extends Comparable<?>,V>A  RangeMapwhose contents will never change, with many other important properties
 detailed atImmutableCollection. | 
| class  | ImmutableRangeSet<C extends Comparable>A  RangeSetwhose contents will never change, with many other important properties
 detailed atImmutableCollection. | 
| class  | ImmutableSortedMultiset<E>A  SortedMultisetwhose contents will never change, with many other important properties
 detailed atImmutableCollection. | 
| interface  | Interner<E>Provides equivalent behavior to  String.intern()for other immutable
 types. | 
| class  | InternersContains static methods pertaining to instances of  Interner. | 
| interface  | MapConstraint<K,V>Deprecated. 
 Use  Preconditionsfor basic checks. In place of
     constrained maps, we encourage you to check your preconditions
     explicitly instead of leaving that work to the map implementation.
     For the specific case of rejecting null, considerImmutableMap.
     This class is scheduled for removal in Guava 20.0. | 
| class  | MapConstraintsDeprecated. 
 Use  Preconditionsfor basic checks. In place of
     constrained maps, we encourage you to check your preconditions
     explicitly instead of leaving that work to the map implementation.
     For the specific case of rejecting null, considerImmutableMap.
     This class is scheduled for removal in Guava 20.0. | 
| class  | MinMaxPriorityQueue<E>A double-ended priority queue, which provides constant-time access to both
 its least element and its greatest element, as determined by the queue's
 specified comparator. | 
| static class  | MinMaxPriorityQueue.Builder<B>The builder class used in creation of min-max priority queues. | 
| class  | MultimapBuilder<K0,V0>A builder for a multimap implementation that allows customization of the backing map and value
 collection implementations used in a particular multimap. | 
| interface  | RangeMap<K extends Comparable,V>A mapping from disjoint nonempty ranges to non-null values. | 
| interface  | RangeSet<C extends Comparable> | 
| interface  | RowSortedTable<R,C,V>Interface that extends  Tableand whose rows are sorted. | 
| interface  | SortedMultiset<E>A  Multisetwhich maintains the ordering of its elements, according to
 either their natural order or an explicitComparator. | 
| class  | TreeBasedTable<R,C,V>Implementation of  Tablewhose row keys and column keys are ordered
 by their natural ordering or by supplied comparators. | 
| class  | TreeRangeMap<K extends Comparable,V>An implementation of  RangeMapbased on aTreeMap, supporting
 all optional operations. | 
| class  | TreeRangeSet<C extends Comparable<?>> | 
| class  | TreeTraverser<T>Views elements of a type  Tas nodes in a tree, and provides methods to traverse the trees
 induced by this traverser. | 
| Modifier and Type | Method and Description | 
|---|---|
| FluentIterable<E> | FluentIterable. append(E... elements)Returns a fluent iterable whose iterators traverse first the elements of this fluent iterable,
 followed by  elements. | 
| FluentIterable<E> | FluentIterable. append(Iterable<? extends E> other)Returns a fluent iterable whose iterators traverse first the elements of this fluent iterable,
 followed by those of  other. | 
| static <A,B> Converter<A,B> | Maps. asConverter(BiMap<A,B> bimap)Returns a  Converterthat converts values usingbimap.get(),
 and whose inverse view converts values usingbimap.inverse().get(). | 
| static <K,V> Map<K,List<V>> | Multimaps. asMap(ListMultimap<K,V> multimap) | 
| static <K,V> Map<K,Collection<V>> | Multimaps. asMap(Multimap<K,V> multimap)Returns  multimap.asMap(). | 
| static <K,V> Map<K,Set<V>> | Multimaps. asMap(SetMultimap<K,V> multimap) | 
| static <K,V> Map<K,SortedSet<V>> | Multimaps. asMap(SortedSetMultimap<K,V> multimap)Returns  multimap.asMap(), with its type
 corrected fromMap<K, Collection<V>>toMap<K, SortedSet<V>>. | 
| ImmutableSetMultimap<K,V> | ImmutableMap. asMultimap()Returns a multimap view of the map. | 
| static List<Character> | Lists. charactersOf(CharSequence sequence)Returns a view of the specified  CharSequenceas aList<Character>, viewingsequenceas a sequence of Unicode code
 units. | 
| static ImmutableList<Character> | Lists. charactersOf(String string)Returns a view of the specified string as an immutable list of  Charactervalues. | 
| static <E> ImmutableMultiset<E> | Multisets. copyHighestCountFirst(Multiset<E> multiset)Returns a copy of  multisetas anImmutableMultisetwhose iteration order is
 highest count first, with ties broken by the iteration order of the original multiset. | 
| static <K,V> ImmutableSetMultimap<K,V> | ImmutableSetMultimap. copyOf(Iterable<? extends Map.Entry<? extends K,? extends V>> entries)Returns an immutable multimap containing the specified entries. | 
| static <K,V> ImmutableMap<K,V> | ImmutableMap. copyOf(Iterable<? extends Map.Entry<? extends K,? extends V>> entries)Returns an immutable map containing the specified entries. | 
| static <K,V> ImmutableMultimap<K,V> | ImmutableMultimap. copyOf(Iterable<? extends Map.Entry<? extends K,? extends V>> entries)Returns an immutable multimap containing the specified entries. | 
| static <K,V> ImmutableListMultimap<K,V> | ImmutableListMultimap. copyOf(Iterable<? extends Map.Entry<? extends K,? extends V>> entries)Returns an immutable multimap containing the specified entries. | 
| static <K,V> ImmutableSortedMap<K,V> | ImmutableSortedMap. copyOf(Iterable<? extends Map.Entry<? extends K,? extends V>> entries)Returns an immutable map containing the given entries, with keys sorted
 by the provided comparator. | 
| static <K,V> ImmutableBiMap<K,V> | ImmutableBiMap. copyOf(Iterable<? extends Map.Entry<? extends K,? extends V>> entries)Returns an immutable bimap containing the given entries. | 
| static <K,V> ImmutableSortedMap<K,V> | ImmutableSortedMap. copyOf(Iterable<? extends Map.Entry<? extends K,? extends V>> entries,
            Comparator<? super K> comparator)Returns an immutable map containing the given entries, with keys sorted
 by the provided comparator. | 
| static <E> ConcurrentHashMultiset<E> | ConcurrentHashMultiset. create(MapMaker mapMaker)Creates a new, empty  ConcurrentHashMultisetusingmapMakerto construct the internal backing map. | 
| static <K,V> MapDifference<K,V> | Maps. difference(Map<? extends K,? extends V> left,
                    Map<? extends K,? extends V> right,
                    Equivalence<? super V> valueEquivalence)Computes the difference between two maps. | 
| static <E> Multiset<E> | Multisets. difference(Multiset<E> multiset1,
                    Multiset<?> multiset2)Returns an unmodifiable view of the difference of two multisets. | 
| static <E> int | Queues. drain(BlockingQueue<E> q,
          Collection<? super E> buffer,
          int numElements,
          long timeout,
          TimeUnit unit)Drains the queue as  BlockingQueue.drainTo(Collection, int), but if the requestednumElementselements are not available, it will wait for them up to the specified
 timeout. | 
| static <E> int | Queues. drainUninterruptibly(BlockingQueue<E> q,
                                        Collection<? super E> buffer,
                                        int numElements,
                                        long timeout,
                                        TimeUnit unit)Drains the queue as Queues.drain(BlockingQueue, Collection, int, long, TimeUnit),
 but with a different behavior in case it is interrupted while waiting. | 
| static <E> Multiset<E> | Multisets. filter(Multiset<E> unfiltered,
            Predicate<? super E> predicate)Returns a view of the elements of  unfilteredthat satisfy a predicate. | 
| static <K extends Enum<K>,V>  | Maps. immutableEnumMap(Map<K,? extends V> map)Returns an immutable map instance containing the given entries. | 
| String | FluentIterable. join(Joiner joiner)Returns a  Stringcontaining all of the elements of this fluent iterable joined withjoiner. | 
| static <T> Iterable<T> | Iterables. mergeSorted(Iterable<? extends Iterable<? extends T>> iterables,
                      Comparator<? super T> comparator)Returns an iterable over the merged contents of all given
  iterables. | 
| static <T> UnmodifiableIterator<T> | Iterators. mergeSorted(Iterable<? extends Iterator<? extends T>> iterators,
                      Comparator<? super T> comparator)Returns an iterator over the merged contents of all given
  iterators, traversing every element of the input iterators. | 
| static <R,C,V> Table<R,C,V> | Tables. newCustomTable(Map<R,Map<C,V>> backingMap,
                            Supplier<? extends Map<C,V>> factory)Creates a table that uses the specified backing map and factory. | 
| static <E> FluentIterable<E> | FluentIterable. of(E[] elements)Returns a fluent iterable containing  elementsin the specified order. | 
| static <E extends Comparable<? super E>>  | Collections2. orderedPermutations(Iterable<E> elements)Returns a  Collectionof all the permutations of the specifiedIterable. | 
| static <E> Collection<List<E>> | Collections2. orderedPermutations(Iterable<E> elements,
                                      Comparator<? super E> comparator)Returns a  Collectionof all the permutations of the specifiedIterableusing the specifiedComparatorfor establishing
 the lexicographical ordering. | 
| ImmutableMap.Builder<K,V> | ImmutableMap.Builder. orderEntriesByValue(Comparator<? super V> valueComparator)Configures this  Builderto order entries by value according to the specified
 comparator. | 
| ImmutableSortedMap.Builder<K,V> | ImmutableSortedMap.Builder. orderEntriesByValue(Comparator<? super V> valueComparator)Deprecated. 
 Unsupported by ImmutableSortedMap.Builder. | 
| ImmutableBiMap.Builder<K,V> | ImmutableBiMap.Builder. orderEntriesByValue(Comparator<? super V> valueComparator)Configures this  Builderto order entries by value according to the specified
 comparator. | 
| static <E> Collection<List<E>> | Collections2. permutations(Collection<E> elements)Returns a  Collectionof all the permutations of the specifiedCollection. | 
| ImmutableSetMultimap.Builder<K,V> | ImmutableSetMultimap.Builder. putAll(Iterable<? extends Map.Entry<? extends K,? extends V>> entries)Adds entries to the built multimap. | 
| ImmutableMap.Builder<K,V> | ImmutableMap.Builder. putAll(Iterable<? extends Map.Entry<? extends K,? extends V>> entries)Adds all of the given entries to the built map. | 
| ImmutableMultimap.Builder<K,V> | ImmutableMultimap.Builder. putAll(Iterable<? extends Map.Entry<? extends K,? extends V>> entries)Adds entries to the built multimap. | 
| ImmutableListMultimap.Builder<K,V> | ImmutableListMultimap.Builder. putAll(Iterable<? extends Map.Entry<? extends K,? extends V>> entries)Adds entries to the built multimap. | 
| ImmutableSortedMap.Builder<K,V> | ImmutableSortedMap.Builder. putAll(Iterable<? extends Map.Entry<? extends K,? extends V>> entries)Adds all the given entries to the built map. | 
| ImmutableBiMap.Builder<K,V> | ImmutableBiMap.Builder. putAll(Iterable<? extends Map.Entry<? extends K,? extends V>> entries)Adds all of the given entries to the built bimap. | 
| protected boolean | ForwardingMultiset. standardAddAll(Collection<? extends E> elementsToAdd)A sensible definition of  ForwardingCollection.addAll(Collection)in terms ofForwardingCollection.add(Object)andForwardingMultiset.add(Object, int). | 
| protected boolean | ForwardingSortedSet. standardContains(Object object)A sensible definition of  ForwardingCollection.contains(java.lang.Object)in terms of thefirst()method ofForwardingSortedSet.tailSet(E). | 
| protected boolean | ForwardingMap. standardContainsKey(Object key)A sensible, albeit inefficient, definition of  ForwardingMap.containsKey(java.lang.Object)in terms
 of theiteratormethod ofForwardingMap.entrySet(). | 
| protected boolean | ForwardingSortedMap. standardContainsKey(Object key)A sensible definition of  ForwardingMap.containsKey(java.lang.Object)in terms of thefirstKey()method ofForwardingSortedMap.tailMap(K). | 
| protected int | ForwardingMultiset. standardCount(Object object)A sensible, albeit inefficient, definition of  ForwardingMultiset.count(java.lang.Object)in terms ofForwardingMultiset.entrySet(). | 
| protected NavigableSet<K> | ForwardingNavigableMap. standardDescendingKeySet()A sensible definition of  ForwardingNavigableMap.descendingKeySet()as thenavigableKeySetofForwardingNavigableMap.descendingMap(). | 
| protected boolean | ForwardingList. standardEquals(Object object)A sensible definition of  ForwardingList.equals(Object)in terms ofForwardingCollection.size()andForwardingCollection.iterator(). | 
| protected int | ForwardingList. standardHashCode()A sensible definition of  ForwardingList.hashCode()in terms ofForwardingCollection.iterator(). | 
| protected ListIterator<E> | ForwardingList. standardListIterator(int start)A sensible default implementation of  ForwardingList.listIterator(int), in terms
 ofForwardingCollection.size(),ForwardingList.get(int),ForwardingList.set(int, Object),ForwardingList.add(int, Object), andForwardingList.remove(int). | 
| protected V | ForwardingMap. standardRemove(Object key)A sensible, albeit inefficient, definition of  ForwardingMap.remove(java.lang.Object)in terms of
 theiteratormethod ofForwardingMap.entrySet(). | 
| protected boolean | ForwardingSortedSet. standardRemove(Object object)A sensible definition of  ForwardingCollection.remove(java.lang.Object)in terms of theiterator()method ofForwardingSortedSet.tailSet(E). | 
| protected List<E> | ForwardingList. standardSubList(int fromIndex,
                              int toIndex)A sensible default implementation of  ForwardingList.subList(int, int). | 
| protected SortedMap<K,V> | ForwardingSortedMap. standardSubMap(K fromKey,
                            K toKey)A sensible default implementation of  ForwardingSortedMap.subMap(Object, Object)in
 terms ofForwardingSortedMap.headMap(Object)andForwardingSortedMap.tailMap(Object). | 
| protected NavigableSet<E> | ForwardingNavigableSet. standardSubSet(E fromElement,
                            boolean fromInclusive,
                            E toElement,
                            boolean toInclusive)A sensible definition of  ForwardingNavigableSet.subSet(Object, boolean, Object, boolean)in terms of theheadSetandtailSetmethods. | 
| protected SortedSet<E> | ForwardingSortedSet. standardSubSet(E fromElement,
                            E toElement)A sensible default implementation of  ForwardingSortedSet.subSet(Object, Object)in
 terms ofForwardingSortedSet.headSet(Object)andForwardingSortedSet.tailSet(Object). | 
| protected String | ForwardingMapEntry. standardToString()A sensible definition of  ForwardingObject.toString()in terms ofForwardingMapEntry.getKey()andForwardingMapEntry.getValue(). | 
| static <E> Multiset<E> | Multisets. sum(Multiset<? extends E> multiset1,
      Multiset<? extends E> multiset2)Returns an unmodifiable view of the sum of two multisets. | 
| static <R,C,V1,V2>  | Tables. transformValues(Table<R,C,V1> fromTable,
                              Function<? super V1,V2> function)Returns a view of a table where each value is transformed by a function. | 
| static <E> Multiset<E> | Multisets. union(Multiset<? extends E> multiset1,
          Multiset<? extends E> multiset2)Returns an unmodifiable view of the union of two multisets. | 
| static <R,C,V> RowSortedTable<R,C,V> | Tables. unmodifiableRowSortedTable(RowSortedTable<R,? extends C,? extends V> table)Returns an unmodifiable view of the specified row-sorted table. | 
| static <E> SortedMultiset<E> | Multisets. unmodifiableSortedMultiset(SortedMultiset<E> sortedMultiset)Returns an unmodifiable view of the specified sorted multiset. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ArrayBasedCharEscaperA  CharEscaperthat uses an array to quickly look up replacement
 characters for a givencharvalue. | 
| class  | ArrayBasedEscaperMapAn implementation-specific parameter class suitable for initializing
  ArrayBasedCharEscaperorArrayBasedUnicodeEscaperinstances. | 
| class  | ArrayBasedUnicodeEscaperA  UnicodeEscaperthat uses an array to quickly look up replacement
 characters for a given code point. | 
| class  | CharEscaperAn object that converts literal text into a format safe for inclusion in a particular context
 (such as an XML document). | 
| class  | CharEscaperBuilderSimple helper class to build a "sparse" array of objects based on the indexes that were added to
 it. | 
| class  | EscaperAn object that converts literal text into a format safe for inclusion in a particular context
 (such as an XML document). | 
| class  | EscapersStatic utility methods pertaining to  Escaperinstances. | 
| static class  | Escapers.BuilderA builder for simple, fast escapers. | 
| class  | UnicodeEscaperAn  Escaperthat converts literal text into a format safe for
 inclusion in a particular context (such as an XML document). | 
| Modifier and Type | Class and Description | 
|---|---|
| interface  | AllowConcurrentEventsMarks an event subscriber method as being thread-safe. | 
| class  | AsyncEventBusAn  EventBusthat takes the Executor of your choice and uses it to
 dispatch events, allowing dispatch to occur asynchronously. | 
| class  | DeadEventWraps an event that was posted, but which had no subscribers and thus could
 not be delivered. | 
| class  | EventBusDispatches events to listeners, and provides ways for listeners to register
 themselves. | 
| interface  | SubscribeMarks a method as an event subscriber. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | BloomFilter<T>A Bloom filter for instances of  T. | 
| interface  | Funnel<T>An object which can send data from an object of type  Tinto aPrimitiveSink. | 
| class  | FunnelsFunnels for common types. | 
| class  | HashCodeAn immutable hash code of arbitrary bit length. | 
| interface  | HasherA  PrimitiveSinkthat can compute a hash code after reading the input. | 
| interface  | HashFunctionA hash function is a collision-averse pure function that maps an arbitrary block of
 data to a number called a hash code. | 
| class  | HashingStatic methods to obtain  HashFunctioninstances, and other static hashing-related
 utilities. | 
| class  | HashingInputStreamAn  InputStreamthat maintains a hash of the data read from it. | 
| class  | HashingOutputStreamAn  OutputStreamthat maintains a hash of the data written to it. | 
| interface  | PrimitiveSinkAn object which can receive a stream of primitive values. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | HtmlEscapersEscaperinstances suitable for strings to be included in HTML
 attribute values and most elements' text contents. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | BaseEncodingA binary encoding scheme for reversibly translating between byte sequences and printable ASCII
 strings. | 
| interface  | ByteProcessor<T>A callback interface to process bytes from a stream. | 
| class  | ByteStreamsProvides utility methods for working with byte arrays and I/O streams. | 
| class  | CharStreamsProvides utility methods for working with character streams. | 
| class  | CloseablesUtility methods for working with  Closeableobjects. | 
| class  | Closer | 
| class  | CountingInputStreamAn  InputStreamthat counts the number of bytes read. | 
| class  | CountingOutputStreamAn OutputStream that counts the number of bytes written. | 
| class  | FileBackedOutputStreamAn  OutputStreamthat starts buffering to a byte array, but
 switches to file buffering once the data reaches a configurable size. | 
| class  | FilesProvides utility methods for working with files. | 
| class  | FlushablesUtility methods for working with  Flushableobjects. | 
| interface  | LineProcessor<T>A callback to be used with the streaming  readLinesmethods. | 
| class  | LineReaderA class for reading lines of text. | 
| class  | LittleEndianDataInputStreamAn implementation of  DataInputthat uses little-endian byte ordering
 for readingshort,int,float,double, andlongvalues. | 
| class  | LittleEndianDataOutputStreamAn implementation of  DataOutputthat uses little-endian byte ordering
 for writingchar,short,int,float,double, andlongvalues. | 
| class  | PatternFilenameFilterFile name filter that only accepts files matching a regular expression. | 
| class  | ResourcesProvides utility methods for working with resources in the classpath. | 
| Modifier and Type | Method and Description | 
|---|---|
| long | CharSource. length()Returns the length of this source in chars, even if doing so requires opening and traversing
 an entire stream. | 
| Optional<Long> | CharSource. lengthIfKnown()Returns the size of this source in chars, if the size can be easily determined without
 actually opening the data stream. | 
| <T> T | ByteSource. read(ByteProcessor<T> processor)Reads the contents of this byte source using the given  processorto process bytes as
 they are read. | 
| <T> T | CharSource. readLines(LineProcessor<T> processor)Reads lines of text from this source, processing each line as it is read using the given
  processor. | 
| Optional<Long> | ByteSource. sizeIfKnown()Returns the size of this source in bytes, if the size can be easily determined without
 actually opening the data stream. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | HostAndPortAn immutable representation of a host and port. | 
| class  | HostSpecifierA syntactically valid host specifier, suitable for use in a URI. | 
| class  | InetAddressesStatic utility methods pertaining to  InetAddressinstances. | 
| static class  | InetAddresses.TeredoInfoA simple immutable data class to encapsulate the information to be found in a
 Teredo address. | 
| class  | InternetDomainNameAn immutable well-formed internet domain name, such as  comorfoo.co.uk. | 
| class  | MediaTypeRepresents an Internet Media Type
 (also known as a MIME Type or Content Type). | 
| class  | PercentEscaperA  UnicodeEscaperthat escapes some set of Java characters using a
 UTF-8 based percent encoding scheme. | 
| class  | UrlEscapersEscaperinstances suitable for strings to be included in particular
 sections of URLs. | 
| Modifier and Type | Field and Description | 
|---|---|
| static String | HttpHeaders. FOLLOW_ONLY_WHEN_PRERENDER_SHOWNThe HTTP  Follow-Only-When-Prerender-Shownheader field name. | 
| static String | HttpHeaders. PUBLIC_KEY_PINSThe HTTP 
  Public-Key-Pinsheader field name. | 
| static String | HttpHeaders. PUBLIC_KEY_PINS_REPORT_ONLYThe HTTP 
  Public-Key-Pins-Report-Onlyheader field name. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | UnsignedIntsStatic utility methods pertaining to  intprimitives that interpret values as
 unsigned (that is, any negative valuexis treated as the positive value2^32 + x). | 
| class  | UnsignedLongsStatic utility methods pertaining to  longprimitives that interpret values as
 unsigned (that is, any negative valuexis treated as the positive value2^64 + x). | 
| Modifier and Type | Method and Description | 
|---|---|
| static int | Booleans. countTrue(boolean... values)Returns the number of  valuesthat aretrue. | 
| static byte | UnsignedBytes. parseUnsignedByte(String string)Returns the unsigned  bytevalue represented by the given decimal string. | 
| static byte | UnsignedBytes. parseUnsignedByte(String string,
                                  int radix)Returns the unsigned  bytevalue represented by a string with the given radix. | 
| static Converter<String,Double> | Doubles. stringConverter()Returns a serializable converter object that converts between strings and
 doubles using  Double.valueOf(java.lang.String)andDouble.toString(). | 
| static Converter<String,Integer> | Ints. stringConverter()Returns a serializable converter object that converts between strings and
 integers using  Integer.decode(java.lang.String)andInteger.toString(). | 
| static Converter<String,Short> | Shorts. stringConverter()Returns a serializable converter object that converts between strings and
 shorts using  Short.decode(java.lang.String)andShort.toString(). | 
| static Converter<String,Float> | Floats. stringConverter()Returns a serializable converter object that converts between strings and
 floats using  Float.valueOf(java.lang.String)andFloat.toString(). | 
| static Converter<String,Long> | Longs. stringConverter()Returns a serializable converter object that converts between strings and
 longs using  Long.decode(java.lang.String)andLong.toString(). | 
| static String | UnsignedBytes. toString(byte x)Returns a string representation of x, where x is treated as unsigned. | 
| static String | UnsignedBytes. toString(byte x,
                int radix)Returns a string representation of  xfor the given radix, wherexis treated
 as unsigned. | 
| static Double | Doubles. tryParse(String string)Parses the specified string as a double-precision floating point value. | 
| static Integer | Ints. tryParse(String string)Parses the specified string as a signed decimal integer value. | 
| static Float | Floats. tryParse(String string)Parses the specified string as a single-precision floating point value. | 
| static Long | Longs. tryParse(String string)Parses the specified string as a signed decimal long value. | 
| static Integer | Ints. tryParse(String string,
                int radix)Parses the specified string as a signed integer value using the specified
 radix. | 
| static Long | Longs. tryParse(String string,
                int radix)Parses the specified string as a signed long value using the specified
 radix. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractInvocationHandlerAbstract implementation of  InvocationHandlerthat handlesObject.equals(java.lang.Object),Object.hashCode()andObject.toString(). | 
| class  | ClassPathScans the source of a  ClassLoaderand finds all loadable classes and resources. | 
| static class  | ClassPath.ClassInfoRepresents a class that can be loaded through  ClassPath.ClassInfo.load(). | 
| static class  | ClassPath.ResourceInfoRepresents a class path resource that can be either a class file or any other resource file
 loadable from the class path. | 
| class  | ImmutableTypeToInstanceMap<B>A type-to-instance map backed by an  ImmutableMap. | 
| static class  | ImmutableTypeToInstanceMap.Builder<B>A builder for creating immutable type-to-instance maps. | 
| class  | Invokable<T,R>Wrapper around either a  Methodor aConstructor. | 
| class  | MutableTypeToInstanceMap<B>A mutable type-to-instance map. | 
| class  | ParameterRepresents a method or constructor parameter. | 
| class  | ReflectionStatic utilities relating to Java reflection. | 
| class  | TypeParameter<T>Captures a free type variable that can be used in  TypeToken.where(com.google.common.reflect.TypeParameter<X>, com.google.common.reflect.TypeToken<X>). | 
| class  | TypeResolverAn object of this class encapsulates type mappings from type variables. | 
| interface  | TypeToInstanceMap<B>A map, each entry of which maps a  TypeTokento an instance of that type. | 
| class  | TypeToken<T>A  Typewith generics. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractCheckedFuture<V,X extends Exception>A delegating wrapper around a  ListenableFuturethat adds support for
 theAbstractCheckedFuture.checkedGet()andAbstractCheckedFuture.checkedGet(long, TimeUnit)methods. | 
| class  | AbstractExecutionThreadServiceBase class for services that can implement  AbstractExecutionThreadService.startUp(),AbstractExecutionThreadService.run()andAbstractExecutionThreadService.shutDown()methods. | 
| class  | AbstractIdleServiceBase class for services that do not need a thread while "running"
 but may need one during startup and shutdown. | 
| class  | AbstractListeningExecutorServiceAbstract  ListeningExecutorServiceimplementation that createsListenableFutureinstances for eachRunnableandCallablesubmitted to it. | 
| class  | AbstractScheduledServiceBase class for services that can implement  AbstractScheduledService.startUp()andAbstractScheduledService.shutDown()but while in 
 the "running" state need to perform a periodic task. | 
| static class  | AbstractScheduledService.CustomSchedulerA  AbstractScheduledService.Schedulerthat provides a convenient way for theAbstractScheduledServiceto 
 use a dynamically changing schedule. | 
| protected static class  | AbstractScheduledService.CustomScheduler.ScheduleA value object that represents an absolute delay until a task should be invoked. | 
| class  | AbstractServiceBase class for implementing services that can handle  AbstractService.doStart()andAbstractService.doStop()requests, responding to them withAbstractService.notifyStarted()andAbstractService.notifyStopped()callbacks. | 
| interface  | CheckedFuture<V,X extends Exception>A  CheckedFutureis aListenableFuturethat includes versions
 of thegetmethods that can throw a checked exception. | 
| class  | CycleDetectingLockFactoryThe  CycleDetectingLockFactorycreatesReentrantLockinstances andReentrantReadWriteLockinstances that detect potential deadlock by checking
 for cycles in lock acquisition order. | 
| static class  | CycleDetectingLockFactory.PoliciesPre-defined  CycleDetectingLockFactory.Policyimplementations. | 
| static interface  | CycleDetectingLockFactory.PolicyEncapsulates the action to be taken when a potential deadlock is
 encountered. | 
| static class  | CycleDetectingLockFactory.PotentialDeadlockExceptionRepresents a detected cycle in lock acquisition ordering. | 
| static class  | CycleDetectingLockFactory.WithExplicitOrdering<E extends Enum<E>>A  CycleDetectingLockFactory.WithExplicitOrderingprovides the
 additional enforcement of an application-specified ordering of lock
 acquisitions. | 
| class  | FakeTimeLimiterA TimeLimiter implementation which actually does not attempt to limit time
 at all. | 
| class  | ForwardingCheckedFuture<V,X extends Exception>A future which forwards all its method calls to another future. | 
| static class  | ForwardingCheckedFuture.SimpleForwardingCheckedFuture<V,X extends Exception>A simplified version of  ForwardingCheckedFuturewhere subclasses
 can pass in an already constructedCheckedFutureas the delegate. | 
| interface  | FutureFallback<V>Deprecated. 
 This interface's main user,  Futures.withFallback, has been updated to useAsyncFunction. We
     recommend that other APIs be updated in the same way. This interface will be removed in Guava
     release 20.0. | 
| class  | FuturesStatic utility methods pertaining to the  Futureinterface. | 
| class  | JdkFutureAdaptersUtilities necessary for working with libraries that supply plain  Futureinstances. | 
| interface  | ListenableScheduledFuture<V>Helper interface to implement both  ListenableFutureandScheduledFuture. | 
| interface  | ListeningScheduledExecutorServiceA  ScheduledExecutorServicethat returnsListenableFutureinstances from itsExecutorServicemethods. | 
| class  | MonitorA synchronization abstraction supporting waiting on arbitrary boolean conditions. | 
| static class  | Monitor.GuardA boolean condition for which a thread may wait. | 
| class  | RateLimiterA rate limiter. | 
| class  | RunnablesStatic utility methods pertaining to the  Runnableinterface. | 
| interface  | ServiceAn object with an operational state, plus asynchronous  Service.startAsync()andService.stopAsync()lifecycle methods to transition between states. | 
| static class  | Service.ListenerA listener for the various state changes that a  Servicegoes through in its lifecycle. | 
| static class  | Service.StateThe lifecycle states of a service. | 
| class  | ServiceManagerA manager for monitoring and controlling a set of services. | 
| static class  | ServiceManager.ListenerA listener for the aggregate state changes of the services that are under management. | 
| class  | SimpleTimeLimiterA TimeLimiter that runs method calls in the background using an
  ExecutorService. | 
| class  | Striped<L>A striped  Lock/Semaphore/ReadWriteLock. | 
| interface  | TimeLimiterProduces proxies that impose a time limit on method
 calls to the proxied object. | 
| class  | UninterruptiblesUtilities for treating interruptible operations as uninterruptible. | 
| Modifier and Type | Method and Description | 
|---|---|
| static void | MoreExecutors. addDelayedShutdownHook(ExecutorService service,
                                            long terminationTimeout,
                                            TimeUnit timeUnit)Add a shutdown hook to wait for thread completion in the given
  service. | 
| static <V> ListenableFuture<List<V>> | Futures. allAsList(Iterable<? extends ListenableFuture<? extends V>> futures)Creates a new  ListenableFuturewhose value is a list containing the
 values of all its input futures, if all succeed. | 
| static <V> ListenableFuture<List<V>> | Futures. allAsList(ListenableFuture<? extends V>... futures)Creates a new  ListenableFuturewhose value is a list containing the
 values of all its input futures, if all succeed. | 
| static ExecutorService | MoreExecutors. getExitingExecutorService(ThreadPoolExecutor executor)Converts the given ThreadPoolExecutor into an ExecutorService that exits
 when the application is complete. | 
| static ExecutorService | MoreExecutors. getExitingExecutorService(ThreadPoolExecutor executor,
                                                  long terminationTimeout,
                                                  TimeUnit timeUnit)Converts the given ThreadPoolExecutor into an ExecutorService that exits
 when the application is complete. | 
| static ScheduledExecutorService | MoreExecutors. getExitingScheduledExecutorService(ScheduledThreadPoolExecutor executor)Converts the given ThreadPoolExecutor into a ScheduledExecutorService that
 exits when the application is complete. | 
| static ScheduledExecutorService | MoreExecutors. getExitingScheduledExecutorService(ScheduledThreadPoolExecutor executor,
                                                                    long terminationTimeout,
                                                                    TimeUnit timeUnit)Converts the given ScheduledThreadPoolExecutor into a
 ScheduledExecutorService that exits when the application is complete. | 
| static <T> ImmutableList<ListenableFuture<T>> | Futures. inCompletionOrder(Iterable<? extends ListenableFuture<? extends T>> futures)Returns a list of delegate futures that correspond to the futures received in the order
 that they complete. | 
| static ThreadFactory | MoreExecutors. platformThreadFactory()Returns a default thread factory used to create new threads. | 
| boolean | SettableFuture. setFuture(ListenableFuture<? extends V> future) | 
| protected boolean | AbstractFuture. setFuture(ListenableFuture<? extends V> future)Sets the result of this  Futureto match the supplied inputFutureonce the
 suppliedFutureis done, unless thisFuturehas already been cancelled or set
 (including "set asynchronously," defined below). | 
| static boolean | MoreExecutors. shutdownAndAwaitTermination(ExecutorService service,
                                                      long timeout,
                                                      TimeUnit unit)Shuts down the given executor gradually, first disabling new submissions and later cancelling
 existing tasks. | 
| static <V> ListenableFuture<List<V>> | Futures. successfulAsList(Iterable<? extends ListenableFuture<? extends V>> futures)Creates a new  ListenableFuturewhose value is a list containing the
 values of all its successful input futures. | 
| static <V> ListenableFuture<List<V>> | Futures. successfulAsList(ListenableFuture<? extends V>... futures)Creates a new  ListenableFuturewhose value is a list containing the
 values of all its successful input futures. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | XmlEscapersEscaperinstances suitable for strings to be included in XML
 attribute values and elements' text contents. | 
Copyright © 2010-2015. All Rights Reserved.