Source compatibility report for the CDK library between 1.5.2 and 1.5.3 versions

Test Info


Library NameCDK
Version #11.5.2
Version #21.5.3

Test Results


Total Java ARchives1
Total Methods / Classes36389 / 3624
VerdictIncompatible
(1.2%)

Problem Summary


SeverityCount
Added Methods-3766
Removed MethodsHigh365
Problems with
Data Types
High76
Medium0
Low80
Problems with
Methods
High2
Medium0
Low0
Other Changes
in Data Types
-2

Added Methods (3766)


cdk-1.5.3.jar, AbstractAtomicDescriptor.class
package org.openscience.cdk.qsar
AbstractAtomicDescriptor.initialise ( IChemObjectBuilder x0 )  :  void

cdk-1.5.3.jar, AbstractAtomPairDescriptor.class
package org.openscience.cdk.qsar
AbstractAtomPairDescriptor.AbstractAtomPairDescriptor ( )
AbstractAtomPairDescriptor.initialise ( IChemObjectBuilder x0 )  :  void

cdk-1.5.3.jar, AbstractBondDescriptor.class
package org.openscience.cdk.qsar
AbstractBondDescriptor.initialise ( IChemObjectBuilder x0 )  :  void

cdk-1.5.3.jar, AbstractCache.class
package com.google.common.cache
AbstractCache.AbstractCache ( )
AbstractCache.asMap ( )  :  ConcurrentMap
AbstractCache.cleanUp ( )  :  void
AbstractCache.get ( Object key, Callable valueLoader )  :  Object
AbstractCache.getAllPresent ( Iterable keys )  :  ImmutableMap
AbstractCache.invalidate ( Object key )  :  void
AbstractCache.invalidateAll ( )  :  void
AbstractCache.invalidateAll ( Iterable keys )  :  void
AbstractCache.put ( Object key, Object value )  :  void
AbstractCache.putAll ( Map m )  :  void
AbstractCache.size ( )  :  long
AbstractCache.stats ( )  :  CacheStats

cdk-1.5.3.jar, AbstractCheckedFuture.class
package com.google.common.util.concurrent
AbstractCheckedFuture.AbstractCheckedFuture ( ListenableFuture delegate )
AbstractCheckedFuture.checkedGet ( )  :  Object
AbstractCheckedFuture.checkedGet ( long timeout, TimeUnit unit )  :  Object
AbstractCheckedFuture.mapException ( Exception p1 ) [abstract]  :  Exception

cdk-1.5.3.jar, AbstractExecutionThreadService.class
package com.google.common.util.concurrent
AbstractExecutionThreadService.AbstractExecutionThreadService ( )
AbstractExecutionThreadService.addListener ( Service.Listener listener, Executor executor )  :  void
AbstractExecutionThreadService.executor ( )  :  Executor
AbstractExecutionThreadService.failureCause ( )  :  Throwable
AbstractExecutionThreadService.isRunning ( )  :  boolean
AbstractExecutionThreadService.run ( ) [abstract]  :  void
AbstractExecutionThreadService.serviceName ( )  :  String
AbstractExecutionThreadService.shutDown ( )  :  void
AbstractExecutionThreadService.start ( )  :  ListenableFuture
AbstractExecutionThreadService.startAndWait ( )  :  Service.State
AbstractExecutionThreadService.startUp ( )  :  void
AbstractExecutionThreadService.state ( )  :  Service.State
AbstractExecutionThreadService.stop ( )  :  ListenableFuture
AbstractExecutionThreadService.stopAndWait ( )  :  Service.State
AbstractExecutionThreadService.toString ( )  :  String
AbstractExecutionThreadService.triggerShutdown ( )  :  void

cdk-1.5.3.jar, AbstractFuture.class
package com.google.common.util.concurrent
AbstractFuture.AbstractFuture ( )
AbstractFuture.addListener ( Runnable listener, Executor exec )  :  void
AbstractFuture.cancel ( boolean mayInterruptIfRunning )  :  boolean
AbstractFuture.get ( )  :  Object
AbstractFuture.get ( long timeout, TimeUnit unit )  :  Object
AbstractFuture.interruptTask ( )  :  void
AbstractFuture.isCancelled ( )  :  boolean
AbstractFuture.isDone ( )  :  boolean
AbstractFuture.set ( Object value )  :  boolean
AbstractFuture.setException ( Throwable throwable )  :  boolean
AbstractFuture.wasInterrupted ( )  :  boolean

cdk-1.5.3.jar, AbstractIdleService.class
package com.google.common.util.concurrent
AbstractIdleService.AbstractIdleService ( )
AbstractIdleService.addListener ( Service.Listener listener, Executor executor )  :  void
AbstractIdleService.executor ( )  :  Executor
AbstractIdleService.failureCause ( )  :  Throwable
AbstractIdleService.isRunning ( )  :  boolean
AbstractIdleService.serviceName ( )  :  String
AbstractIdleService.shutDown ( ) [abstract]  :  void
AbstractIdleService.start ( )  :  ListenableFuture
AbstractIdleService.startAndWait ( )  :  Service.State
AbstractIdleService.startUp ( ) [abstract]  :  void
AbstractIdleService.state ( )  :  Service.State
AbstractIdleService.stop ( )  :  ListenableFuture
AbstractIdleService.stopAndWait ( )  :  Service.State
AbstractIdleService.toString ( )  :  String

cdk-1.5.3.jar, AbstractInvocationHandler.class
package com.google.common.reflect
AbstractInvocationHandler.AbstractInvocationHandler ( )
AbstractInvocationHandler.equals ( Object obj )  :  boolean
AbstractInvocationHandler.handleInvocation ( Object p1, Method p2, Object[ ] p3 ) [abstract]  :  Object
AbstractInvocationHandler.hashCode ( )  :  int
AbstractInvocationHandler.invoke ( Object proxy, Method method, Object[ ] args )  :  Object
AbstractInvocationHandler.toString ( )  :  String

cdk-1.5.3.jar, AbstractIterator.class
package com.google.common.collect
AbstractIterator.AbstractIterator ( )
AbstractIterator.computeNext ( ) [abstract]  :  Object
AbstractIterator.endOfData ( )  :  Object
AbstractIterator.hasNext ( )  :  boolean
AbstractIterator.next ( )  :  Object
AbstractIterator.peek ( )  :  Object

cdk-1.5.3.jar, AbstractListeningExecutorService.class
package com.google.common.util.concurrent
AbstractListeningExecutorService.AbstractListeningExecutorService ( )
AbstractListeningExecutorService.invokeAll ( Collection tasks )  :  List
AbstractListeningExecutorService.invokeAll ( Collection tasks, long timeout, TimeUnit unit )  :  List
AbstractListeningExecutorService.invokeAny ( Collection tasks )  :  Object
AbstractListeningExecutorService.invokeAny ( Collection tasks, long timeout, TimeUnit unit )  :  Object
AbstractListeningExecutorService.submit ( Callable task )  :  ListenableFuture
AbstractListeningExecutorService.submit ( Callable x0 )  :  Future
AbstractListeningExecutorService.submit ( Runnable task )  :  ListenableFuture
AbstractListeningExecutorService.submit ( Runnable task, Object result )  :  ListenableFuture
AbstractListeningExecutorService.submit ( Runnable x0 )  :  Future
AbstractListeningExecutorService.submit ( Runnable x0, Object x1 )  :  Future

cdk-1.5.3.jar, AbstractLoadingCache.class
package com.google.common.cache
AbstractLoadingCache.AbstractLoadingCache ( )
AbstractLoadingCache.apply ( Object key )  :  Object
AbstractLoadingCache.getAll ( Iterable keys )  :  ImmutableMap
AbstractLoadingCache.getUnchecked ( Object key )  :  Object
AbstractLoadingCache.refresh ( Object key )  :  void

cdk-1.5.3.jar, AbstractMolecularDescriptor.class
package org.openscience.cdk.qsar
AbstractMolecularDescriptor.AbstractMolecularDescriptor ( )
AbstractMolecularDescriptor.initialise ( IChemObjectBuilder x0 )  :  void

cdk-1.5.3.jar, AbstractResourceFormat.class
package org.openscience.cdk.io.formats
AbstractResourceFormat.AbstractResourceFormat ( )
AbstractResourceFormat.equals ( Object that )  :  boolean
AbstractResourceFormat.hashCode ( )  :  int

cdk-1.5.3.jar, AbstractScheduledService.class
package com.google.common.util.concurrent
AbstractScheduledService.AbstractScheduledService ( )
AbstractScheduledService.addListener ( Service.Listener listener, Executor executor )  :  void
AbstractScheduledService.executor ( )  :  ScheduledExecutorService
AbstractScheduledService.failureCause ( )  :  Throwable
AbstractScheduledService.isRunning ( )  :  boolean
AbstractScheduledService.runOneIteration ( ) [abstract]  :  void
AbstractScheduledService.scheduler ( ) [abstract]  :  AbstractScheduledService.Scheduler
AbstractScheduledService.serviceName ( )  :  String
AbstractScheduledService.shutDown ( )  :  void
AbstractScheduledService.start ( )  :  ListenableFuture
AbstractScheduledService.startAndWait ( )  :  Service.State
AbstractScheduledService.startUp ( )  :  void
AbstractScheduledService.state ( )  :  Service.State
AbstractScheduledService.stop ( )  :  ListenableFuture
AbstractScheduledService.stopAndWait ( )  :  Service.State
AbstractScheduledService.toString ( )  :  String

cdk-1.5.3.jar, AbstractSequentialIterator.class
package com.google.common.collect
AbstractSequentialIterator.AbstractSequentialIterator ( Object firstOrNull )
AbstractSequentialIterator.computeNext ( Object p1 ) [abstract]  :  Object
AbstractSequentialIterator.hasNext ( )  :  boolean
AbstractSequentialIterator.next ( )  :  Object

cdk-1.5.3.jar, AbstractService.class
package com.google.common.util.concurrent
AbstractService.AbstractService ( )
AbstractService.addListener ( Service.Listener listener, Executor executor )  :  void
AbstractService.doStart ( ) [abstract]  :  void
AbstractService.doStop ( ) [abstract]  :  void
AbstractService.failureCause ( )  :  Throwable
AbstractService.isRunning ( )  :  boolean
AbstractService.notifyFailed ( Throwable cause )  :  void
AbstractService.notifyStarted ( )  :  void
AbstractService.notifyStopped ( )  :  void
AbstractService.start ( )  :  ListenableFuture
AbstractService.startAndWait ( )  :  Service.State
AbstractService.state ( )  :  Service.State
AbstractService.stop ( )  :  ListenableFuture
AbstractService.stopAndWait ( )  :  Service.State
AbstractService.toString ( )  :  String

cdk-1.5.3.jar, AbstractStreamingHasher.class
package com.google.common.hash
AbstractStreamingHashFunction.AbstractStreamingHasher.AbstractStreamingHashFunction.AbstractStreamingHasher ( int chunkSize )
AbstractStreamingHashFunction.AbstractStreamingHasher.AbstractStreamingHashFunction.AbstractStreamingHasher ( int chunkSize, int bufferSize )
AbstractStreamingHashFunction.AbstractStreamingHasher.hash ( )  :  HashCode
AbstractStreamingHashFunction.AbstractStreamingHasher.process ( ByteBuffer p1 ) [abstract]  :  void
AbstractStreamingHashFunction.AbstractStreamingHasher.processRemaining ( ByteBuffer bb )  :  void
AbstractStreamingHashFunction.AbstractStreamingHasher.putByte ( byte b )  :  Hasher
AbstractStreamingHashFunction.AbstractStreamingHasher.putByte ( byte x0 )  :  PrimitiveSink
AbstractStreamingHashFunction.AbstractStreamingHasher.putBytes ( byte[ ] bytes )  :  Hasher
AbstractStreamingHashFunction.AbstractStreamingHasher.putBytes ( byte[ ] bytes, int off, int len )  :  Hasher
AbstractStreamingHashFunction.AbstractStreamingHasher.putBytes ( byte[ ] x0 )  :  PrimitiveSink
AbstractStreamingHashFunction.AbstractStreamingHasher.putBytes ( byte[ ] x0, int x1, int x2 )  :  PrimitiveSink
AbstractStreamingHashFunction.AbstractStreamingHasher.putChar ( char c )  :  Hasher
AbstractStreamingHashFunction.AbstractStreamingHasher.putChar ( char x0 )  :  PrimitiveSink
AbstractStreamingHashFunction.AbstractStreamingHasher.putInt ( int i )  :  Hasher
AbstractStreamingHashFunction.AbstractStreamingHasher.putInt ( int x0 )  :  PrimitiveSink
AbstractStreamingHashFunction.AbstractStreamingHasher.putLong ( long l )  :  Hasher
AbstractStreamingHashFunction.AbstractStreamingHasher.putLong ( long x0 )  :  PrimitiveSink
AbstractStreamingHashFunction.AbstractStreamingHasher.putObject ( Object instance, Funnel funnel )  :  Hasher
AbstractStreamingHashFunction.AbstractStreamingHasher.putShort ( short s )  :  Hasher
AbstractStreamingHashFunction.AbstractStreamingHasher.putShort ( short x0 )  :  PrimitiveSink
AbstractStreamingHashFunction.AbstractStreamingHasher.putString ( CharSequence charSequence )  :  Hasher
AbstractStreamingHashFunction.AbstractStreamingHasher.putString ( CharSequence x0 )  :  PrimitiveSink

cdk-1.5.3.jar, AbstractVertexSignature.class
package signature
AbstractVertexSignature.convertEdgeLabelToColor ( String p1 ) [abstract]  :  int

cdk-1.5.3.jar, AcidicGroupCountDescriptor.class
package org.openscience.cdk.qsar.descriptors.molecular
AcidicGroupCountDescriptor.AcidicGroupCountDescriptor ( )
AcidicGroupCountDescriptor.initialise ( IChemObjectBuilder builder )  :  void

cdk-1.5.3.jar, AllCycles.class
package org.openscience.cdk.graph
AllCycles.AllCycles ( int[ ][ ] graph, int maxCycleSize, int maxDegree )
AllCycles.completed ( )  :  boolean
AllCycles.paths ( )  :  int[ ][ ]
AllCycles.size ( )  :  int

cdk-1.5.3.jar, AllRingsFinder.class
package org.openscience.cdk.ringsearch
AllRingsFinder.findAllRings ( IAtomContainer container, int maxRingSize )  :  IRingSet
AllRingsFinder.findAllRingsInIsolatedRingSystem ( IAtomContainer atomContainer, int maxRingSize )  :  IRingSet
AllRingsFinder.usingThreshold ( AllRingsFinder.Threshold threshold ) [static]  :  AllRingsFinder

cdk-1.5.3.jar, AminoAcids.class
package org.openscience.cdk.templates
AminoAcids.getHashMapByThreeLetterCode ( ) [static]  :  Map

cdk-1.5.3.jar, ArrayListMultimap.class
package com.google.common.collect
ArrayListMultimap.asMap ( )  :  Map
ArrayListMultimap.clear ( )  :  void
ArrayListMultimap.containsEntry ( Object x0, Object x1 )  :  boolean
ArrayListMultimap.containsKey ( Object x0 )  :  boolean
ArrayListMultimap.containsValue ( Object x0 )  :  boolean
ArrayListMultimap.create ( ) [static]  :  ArrayListMultimap
ArrayListMultimap.create ( int expectedKeys, int expectedValuesPerKey ) [static]  :  ArrayListMultimap
ArrayListMultimap.create ( Multimap multimap ) [static]  :  ArrayListMultimap
ArrayListMultimap.entries ( )  :  Collection
ArrayListMultimap.equals ( Object x0 )  :  boolean
ArrayListMultimap.get ( Object x0 )  :  List
ArrayListMultimap.hashCode ( )  :  int
ArrayListMultimap.isEmpty ( )  :  boolean
ArrayListMultimap.keys ( )  :  Multiset
ArrayListMultimap.keySet ( )  :  Set
ArrayListMultimap.put ( Object x0, Object x1 )  :  boolean
ArrayListMultimap.putAll ( Multimap x0 )  :  boolean
ArrayListMultimap.putAll ( Object x0, Iterable x1 )  :  boolean
ArrayListMultimap.remove ( Object x0, Object x1 )  :  boolean
ArrayListMultimap.removeAll ( Object x0 )  :  List
ArrayListMultimap.replaceValues ( Object x0, Iterable x1 )  :  List
ArrayListMultimap.size ( )  :  int
ArrayListMultimap.toString ( )  :  String
ArrayListMultimap.trimToSize ( )  :  void
ArrayListMultimap.values ( )  :  Collection

cdk-1.5.3.jar, ArrayTable.class
package com.google.common.collect
ArrayTable.at ( int rowIndex, int columnIndex )  :  Object
ArrayTable.cellSet ( )  :  Set
ArrayTable.clear ( )  :  void *DEPRECATED*
ArrayTable.column ( Object columnKey )  :  Map
ArrayTable.columnKeyList ( )  :  ImmutableList
ArrayTable.columnKeySet ( )  :  ImmutableSet
ArrayTable.columnKeySet ( )  :  Set
ArrayTable.columnMap ( )  :  Map
ArrayTable.contains ( Object rowKey, Object columnKey )  :  boolean
ArrayTable.containsColumn ( Object columnKey )  :  boolean
ArrayTable.containsRow ( Object rowKey )  :  boolean
ArrayTable.containsValue ( Object value )  :  boolean
ArrayTable.create ( ArrayTable table ) [static]  :  ArrayTable
ArrayTable.create ( Iterable rowKeys, Iterable columnKeys ) [static]  :  ArrayTable
ArrayTable.create ( Table table ) [static]  :  ArrayTable
ArrayTable.equals ( Object obj )  :  boolean
ArrayTable.erase ( Object rowKey, Object columnKey )  :  Object
ArrayTable.eraseAll ( )  :  void
ArrayTable.get ( Object rowKey, Object columnKey )  :  Object
ArrayTable.hashCode ( )  :  int
ArrayTable.isEmpty ( )  :  boolean
ArrayTable.put ( Object rowKey, Object columnKey, Object value )  :  Object
ArrayTable.putAll ( Table table )  :  void
ArrayTable.remove ( Object rowKey, Object columnKey )  :  Object *DEPRECATED*
ArrayTable.row ( Object rowKey )  :  Map
ArrayTable.rowKeyList ( )  :  ImmutableList
ArrayTable.rowKeySet ( )  :  ImmutableSet
ArrayTable.rowKeySet ( )  :  Set
ArrayTable.rowMap ( )  :  Map
ArrayTable.set ( int rowIndex, int columnIndex, Object value )  :  Object
ArrayTable.size ( )  :  int
ArrayTable.toArray ( Class valueClass )  :  Object[ ][ ]
ArrayTable.toString ( )  :  String
ArrayTable.values ( )  :  Collection

cdk-1.5.3.jar, Ascii.class
package com.google.common.base
Ascii.isLowerCase ( char c ) [static]  :  boolean
Ascii.isUpperCase ( char c ) [static]  :  boolean
Ascii.toLowerCase ( char c ) [static]  :  char
Ascii.toLowerCase ( CharSequence chars ) [static]  :  String
Ascii.toLowerCase ( String string ) [static]  :  String
Ascii.toUpperCase ( char c ) [static]  :  char
Ascii.toUpperCase ( CharSequence chars ) [static]  :  String
Ascii.toUpperCase ( String string ) [static]  :  String

cdk-1.5.3.jar, AsyncEventBus.class
package com.google.common.eventbus
AsyncEventBus.AsyncEventBus ( Executor executor )
AsyncEventBus.AsyncEventBus ( String identifier, Executor executor )
AsyncEventBus.dispatchQueuedEvents ( )  :  void

cdk-1.5.3.jar, AsyncFunction.class
package com.google.common.util.concurrent
AsyncFunction.apply ( Object p1 ) [abstract]  :  ListenableFuture

cdk-1.5.3.jar, AtomContainerManipulator.class
package org.openscience.cdk.tools.manipulator
AtomContainerManipulator.removeNonChiralHydrogens ( IAtomContainer atomContainer ) [static]  :  IAtomContainer

cdk-1.5.3.jar, AtomEncoder.class
package org.openscience.cdk.hash
AtomEncoder.encode ( IAtom p1, IAtomContainer p2 ) [abstract]  :  int

cdk-1.5.3.jar, AtomicDouble.class
package com.google.common.util.concurrent
AtomicDouble.addAndGet ( double delta )  :  double
AtomicDouble.AtomicDouble ( )
AtomicDouble.AtomicDouble ( double initialValue )
AtomicDouble.compareAndSet ( double expect, double update )  :  boolean
AtomicDouble.doubleValue ( )  :  double
AtomicDouble.floatValue ( )  :  float
AtomicDouble.get ( )  :  double
AtomicDouble.getAndAdd ( double delta )  :  double
AtomicDouble.getAndSet ( double newValue )  :  double
AtomicDouble.intValue ( )  :  int
AtomicDouble.lazySet ( double newValue )  :  void
AtomicDouble.longValue ( )  :  long
AtomicDouble.set ( double newValue )  :  void
AtomicDouble.toString ( )  :  String
AtomicDouble.weakCompareAndSet ( double expect, double update )  :  boolean

cdk-1.5.3.jar, AtomicDoubleArray.class
package com.google.common.util.concurrent
AtomicDoubleArray.addAndGet ( int i, double delta )  :  double
AtomicDoubleArray.AtomicDoubleArray ( double[ ] array )
AtomicDoubleArray.AtomicDoubleArray ( int length )
AtomicDoubleArray.compareAndSet ( int i, double expect, double update )  :  boolean
AtomicDoubleArray.get ( int i )  :  double
AtomicDoubleArray.getAndAdd ( int i, double delta )  :  double
AtomicDoubleArray.getAndSet ( int i, double newValue )  :  double
AtomicDoubleArray.lazySet ( int i, double newValue )  :  void
AtomicDoubleArray.length ( )  :  int
AtomicDoubleArray.set ( int i, double newValue )  :  void
AtomicDoubleArray.toString ( )  :  String
AtomicDoubleArray.weakCompareAndSet ( int i, double expect, double update )  :  boolean

cdk-1.5.3.jar, AtomicLongMap.class
package com.google.common.util.concurrent
AtomicLongMap.addAndGet ( Object key, long delta )  :  long
AtomicLongMap.asMap ( )  :  Map
AtomicLongMap.clear ( )  :  void
AtomicLongMap.containsKey ( Object key )  :  boolean
AtomicLongMap.create ( ) [static]  :  AtomicLongMap
AtomicLongMap.create ( Map m ) [static]  :  AtomicLongMap
AtomicLongMap.decrementAndGet ( Object key )  :  long
AtomicLongMap.get ( Object key )  :  long
AtomicLongMap.getAndAdd ( Object key, long delta )  :  long
AtomicLongMap.getAndDecrement ( Object key )  :  long
AtomicLongMap.getAndIncrement ( Object key )  :  long
AtomicLongMap.incrementAndGet ( Object key )  :  long
AtomicLongMap.isEmpty ( )  :  boolean
AtomicLongMap.put ( Object key, long newValue )  :  long
AtomicLongMap.putAll ( Map m )  :  void
AtomicLongMap.remove ( Object key )  :  long
AtomicLongMap.removeAllZeros ( )  :  void
AtomicLongMap.size ( )  :  int
AtomicLongMap.sum ( )  :  long
AtomicLongMap.toString ( )  :  String

cdk-1.5.3.jar, Atomics.class
package com.google.common.util.concurrent
Atomics.newReference ( ) [static]  :  AtomicReference
Atomics.newReference ( Object initialValue ) [static]  :  AtomicReference
Atomics.newReferenceArray ( int length ) [static]  :  AtomicReferenceArray
Atomics.newReferenceArray ( Object[ ] array ) [static]  :  AtomicReferenceArray

cdk-1.5.3.jar, AtomSignature.class
package org.openscience.cdk.signature
AtomSignature.convertEdgeLabelToColor ( String edgeLabel )  :  int

cdk-1.5.3.jar, BaseEncoding.class
package com.google.common.io
BaseEncoding.base16 ( ) [static]  :  BaseEncoding
BaseEncoding.base32 ( ) [static]  :  BaseEncoding
BaseEncoding.base32Hex ( ) [static]  :  BaseEncoding
BaseEncoding.base64 ( ) [static]  :  BaseEncoding
BaseEncoding.base64Url ( ) [static]  :  BaseEncoding
BaseEncoding.decode ( CharSequence chars )  :  byte[ ]
BaseEncoding.decodingSource ( CharSource encodedSource )  :  ByteSource
BaseEncoding.decodingStream ( InputSupplier readerSupplier )  :  InputSupplier
BaseEncoding.decodingStream ( Reader reader )  :  InputStream
BaseEncoding.encode ( byte[ ] bytes )  :  String
BaseEncoding.encode ( byte[ ] bytes, int off, int len )  :  String
BaseEncoding.encodingSink ( CharSink encodedSink )  :  ByteSink
BaseEncoding.encodingStream ( OutputSupplier writerSupplier )  :  OutputSupplier
BaseEncoding.encodingStream ( Writer writer )  :  OutputStream
BaseEncoding.lowerCase ( ) [abstract]  :  BaseEncoding
BaseEncoding.omitPadding ( ) [abstract]  :  BaseEncoding
BaseEncoding.upperCase ( ) [abstract]  :  BaseEncoding
BaseEncoding.withPadChar ( char p1 ) [abstract]  :  BaseEncoding
BaseEncoding.withSeparator ( String p1, int p2 ) [abstract]  :  BaseEncoding

cdk-1.5.3.jar, BasicAtomEncoder.class
package org.openscience.cdk.hash
BasicAtomEncoder.valueOf ( String name ) [static]  :  BasicAtomEncoder
BasicAtomEncoder.values ( ) [static]  :  BasicAtomEncoder[ ]

cdk-1.5.3.jar, BasicGroupCountDescriptor.class
package org.openscience.cdk.qsar.descriptors.molecular
BasicGroupCountDescriptor.BasicGroupCountDescriptor ( )
BasicGroupCountDescriptor.initialise ( IChemObjectBuilder builder )  :  void

cdk-1.5.3.jar, BigIntegerMath.class
package com.google.common.math
BigIntegerMath.binomial ( int n, int k ) [static]  :  BigInteger
BigIntegerMath.divide ( BigInteger p, BigInteger q, RoundingMode mode ) [static]  :  BigInteger
BigIntegerMath.factorial ( int n ) [static]  :  BigInteger
BigIntegerMath.isPowerOfTwo ( BigInteger x ) [static]  :  boolean
BigIntegerMath.log10 ( BigInteger x, RoundingMode mode ) [static]  :  int
BigIntegerMath.log2 ( BigInteger x, RoundingMode mode ) [static]  :  int
BigIntegerMath.sqrt ( BigInteger x, RoundingMode mode ) [static]  :  BigInteger

cdk-1.5.3.jar, BiMap.class
package com.google.common.collect
BiMap.forcePut ( Object p1, Object p2 ) [abstract]  :  Object
BiMap.inverse ( ) [abstract]  :  BiMap
BiMap.put ( Object p1, Object p2 ) [abstract]  :  Object
BiMap.putAll ( Map p1 ) [abstract]  :  void
BiMap.values ( ) [abstract]  :  Set

cdk-1.5.3.jar, BloomFilter.class
package com.google.common.hash
BloomFilter.apply ( Object input )  :  boolean
BloomFilter.copy ( )  :  BloomFilter
BloomFilter.create ( Funnel funnel, int expectedInsertions ) [static]  :  BloomFilter
BloomFilter.create ( Funnel funnel, int expectedInsertions, double fpp ) [static]  :  BloomFilter
BloomFilter.equals ( Object object )  :  boolean
BloomFilter.expectedFalsePositiveProbability ( )  :  double *DEPRECATED*
BloomFilter.expectedFpp ( )  :  double
BloomFilter.hashCode ( )  :  int
BloomFilter.mightContain ( Object object )  :  boolean
BloomFilter.put ( Object object )  :  boolean

cdk-1.5.3.jar, Booleans.class
package com.google.common.primitives
Booleans.asList ( boolean[ ] backingArray ) [static]  :  List
Booleans.compare ( boolean a, boolean b ) [static]  :  int
Booleans.concat ( boolean[ ][ ] arrays ) [static]  :  boolean[ ]
Booleans.contains ( boolean[ ] array, boolean target ) [static]  :  boolean
Booleans.ensureCapacity ( boolean[ ] array, int minLength, int padding ) [static]  :  boolean[ ]
Booleans.hashCode ( boolean value ) [static]  :  int
Booleans.indexOf ( boolean[ ] array, boolean target ) [static]  :  int
Booleans.indexOf ( boolean[ ] array, boolean[ ] target ) [static]  :  int
Booleans.join ( String separator, boolean[ ] array ) [static]  :  String
Booleans.lastIndexOf ( boolean[ ] array, boolean target ) [static]  :  int
Booleans.lexicographicalComparator ( ) [static]  :  Comparator
Booleans.toArray ( Collection collection ) [static]  :  boolean[ ]

cdk-1.5.3.jar, BoundType.class
package com.google.common.collect
BoundType.valueOf ( String name ) [static]  :  BoundType
BoundType.values ( ) [static]  :  BoundType[ ]

cdk-1.5.3.jar, Builder.class
package com.google.common.collect
ImmutableBiMap.Builder.build ( )  :  ImmutableBiMap
ImmutableBiMap.Builder.build ( )  :  ImmutableMap
ImmutableBiMap.Builder.ImmutableBiMap.Builder ( )
ImmutableBiMap.Builder.put ( Object key, Object value )  :  ImmutableBiMap.Builder
ImmutableBiMap.Builder.put ( Object x0, Object x1 )  :  ImmutableMap.Builder
ImmutableBiMap.Builder.putAll ( Map map )  :  ImmutableBiMap.Builder
ImmutableBiMap.Builder.putAll ( Map x0 )  :  ImmutableMap.Builder
ImmutableClassToInstanceMap.Builder.build ( )  :  ImmutableClassToInstanceMap
ImmutableClassToInstanceMap.Builder.ImmutableClassToInstanceMap.Builder ( )
ImmutableClassToInstanceMap.Builder.put ( Class key, Object value )  :  ImmutableClassToInstanceMap.Builder
ImmutableClassToInstanceMap.Builder.putAll ( Map map )  :  ImmutableClassToInstanceMap.Builder
ImmutableCollection.Builder.add ( Object p1 ) [abstract]  :  ImmutableCollection.Builder
ImmutableCollection.Builder.add ( Object[ ] elements )  :  ImmutableCollection.Builder
ImmutableCollection.Builder.addAll ( Iterable elements )  :  ImmutableCollection.Builder
ImmutableCollection.Builder.addAll ( Iterator elements )  :  ImmutableCollection.Builder
ImmutableCollection.Builder.build ( ) [abstract]  :  ImmutableCollection
ImmutableList.Builder.add ( Object element )  :  ImmutableList.Builder
ImmutableList.Builder.add ( Object x0 )  :  ImmutableCollection.Builder
ImmutableList.Builder.add ( Object[ ] elements )  :  ImmutableList.Builder
ImmutableList.Builder.add ( Object[ ] x0 )  :  ImmutableCollection.Builder
ImmutableList.Builder.addAll ( Iterable elements )  :  ImmutableList.Builder
ImmutableList.Builder.addAll ( Iterable x0 )  :  ImmutableCollection.Builder
ImmutableList.Builder.addAll ( Iterator elements )  :  ImmutableList.Builder
ImmutableList.Builder.addAll ( Iterator x0 )  :  ImmutableCollection.Builder
ImmutableList.Builder.build ( )  :  ImmutableCollection
ImmutableList.Builder.build ( )  :  ImmutableList
ImmutableList.Builder.ImmutableList.Builder ( )
ImmutableListMultimap.Builder.build ( )  :  ImmutableListMultimap
ImmutableListMultimap.Builder.build ( )  :  ImmutableMultimap
ImmutableListMultimap.Builder.ImmutableListMultimap.Builder ( )
ImmutableListMultimap.Builder.orderKeysBy ( Comparator keyComparator )  :  ImmutableListMultimap.Builder
ImmutableListMultimap.Builder.orderKeysBy ( Comparator x0 )  :  ImmutableMultimap.Builder
ImmutableListMultimap.Builder.orderValuesBy ( Comparator valueComparator )  :  ImmutableListMultimap.Builder
ImmutableListMultimap.Builder.orderValuesBy ( Comparator x0 )  :  ImmutableMultimap.Builder
ImmutableListMultimap.Builder.put ( Map.Entry entry )  :  ImmutableListMultimap.Builder
ImmutableListMultimap.Builder.put ( Map.Entry x0 )  :  ImmutableMultimap.Builder
ImmutableListMultimap.Builder.put ( Object key, Object value )  :  ImmutableListMultimap.Builder
ImmutableListMultimap.Builder.put ( Object x0, Object x1 )  :  ImmutableMultimap.Builder
ImmutableListMultimap.Builder.putAll ( Multimap multimap )  :  ImmutableListMultimap.Builder
ImmutableListMultimap.Builder.putAll ( Multimap x0 )  :  ImmutableMultimap.Builder
ImmutableListMultimap.Builder.putAll ( Object key, Iterable values )  :  ImmutableListMultimap.Builder
ImmutableListMultimap.Builder.putAll ( Object key, Object[ ] values )  :  ImmutableListMultimap.Builder
ImmutableListMultimap.Builder.putAll ( Object x0, Iterable x1 )  :  ImmutableMultimap.Builder
ImmutableListMultimap.Builder.putAll ( Object x0, Object[ ] x1 )  :  ImmutableMultimap.Builder
ImmutableMap.Builder.build ( )  :  ImmutableMap
ImmutableMap.Builder.ImmutableMap.Builder ( )
ImmutableMap.Builder.put ( Map.Entry entry )  :  ImmutableMap.Builder
ImmutableMap.Builder.put ( Object key, Object value )  :  ImmutableMap.Builder
ImmutableMap.Builder.putAll ( Map map )  :  ImmutableMap.Builder
ImmutableMultimap.Builder.build ( )  :  ImmutableMultimap
ImmutableMultimap.Builder.ImmutableMultimap.Builder ( )
ImmutableMultimap.Builder.orderKeysBy ( Comparator keyComparator )  :  ImmutableMultimap.Builder
ImmutableMultimap.Builder.orderValuesBy ( Comparator valueComparator )  :  ImmutableMultimap.Builder
ImmutableMultimap.Builder.put ( Map.Entry entry )  :  ImmutableMultimap.Builder
ImmutableMultimap.Builder.put ( Object key, Object value )  :  ImmutableMultimap.Builder
ImmutableMultimap.Builder.putAll ( Multimap multimap )  :  ImmutableMultimap.Builder
ImmutableMultimap.Builder.putAll ( Object key, Iterable values )  :  ImmutableMultimap.Builder
ImmutableMultimap.Builder.putAll ( Object key, Object[ ] values )  :  ImmutableMultimap.Builder
ImmutableMultiset.Builder.add ( Object element )  :  ImmutableMultiset.Builder
ImmutableMultiset.Builder.add ( Object x0 )  :  ImmutableCollection.Builder
ImmutableMultiset.Builder.add ( Object[ ] elements )  :  ImmutableMultiset.Builder
ImmutableMultiset.Builder.add ( Object[ ] x0 )  :  ImmutableCollection.Builder
ImmutableMultiset.Builder.addAll ( Iterable elements )  :  ImmutableMultiset.Builder
ImmutableMultiset.Builder.addAll ( Iterable x0 )  :  ImmutableCollection.Builder
ImmutableMultiset.Builder.addAll ( Iterator elements )  :  ImmutableMultiset.Builder
ImmutableMultiset.Builder.addAll ( Iterator x0 )  :  ImmutableCollection.Builder
ImmutableMultiset.Builder.addCopies ( Object element, int occurrences )  :  ImmutableMultiset.Builder
ImmutableMultiset.Builder.build ( )  :  ImmutableCollection
ImmutableMultiset.Builder.build ( )  :  ImmutableMultiset
ImmutableMultiset.Builder.ImmutableMultiset.Builder ( )
ImmutableMultiset.Builder.setCount ( Object element, int count )  :  ImmutableMultiset.Builder
ImmutableRangeMap.Builder.build ( )  :  ImmutableRangeMap
ImmutableRangeMap.Builder.ImmutableRangeMap.Builder ( )
ImmutableRangeMap.Builder.put ( Range range, Object value )  :  ImmutableRangeMap.Builder
ImmutableRangeMap.Builder.putAll ( RangeMap rangeMap )  :  ImmutableRangeMap.Builder
ImmutableRangeSet.Builder.add ( Range range )  :  ImmutableRangeSet.Builder
ImmutableRangeSet.Builder.addAll ( RangeSet ranges )  :  ImmutableRangeSet.Builder
ImmutableRangeSet.Builder.build ( )  :  ImmutableRangeSet
ImmutableRangeSet.Builder.ImmutableRangeSet.Builder ( )
ImmutableSet.Builder.add ( Object element )  :  ImmutableSet.Builder
ImmutableSet.Builder.add ( Object x0 )  :  ImmutableCollection.Builder
ImmutableSet.Builder.add ( Object[ ] elements )  :  ImmutableSet.Builder
ImmutableSet.Builder.add ( Object[ ] x0 )  :  ImmutableCollection.Builder
ImmutableSet.Builder.addAll ( Iterable elements )  :  ImmutableSet.Builder
ImmutableSet.Builder.addAll ( Iterable x0 )  :  ImmutableCollection.Builder
ImmutableSet.Builder.addAll ( Iterator elements )  :  ImmutableSet.Builder
ImmutableSet.Builder.addAll ( Iterator x0 )  :  ImmutableCollection.Builder
ImmutableSet.Builder.build ( )  :  ImmutableCollection
ImmutableSet.Builder.build ( )  :  ImmutableSet
ImmutableSet.Builder.ImmutableSet.Builder ( )
ImmutableSetMultimap.Builder.build ( )  :  ImmutableMultimap
ImmutableSetMultimap.Builder.build ( )  :  ImmutableSetMultimap
ImmutableSetMultimap.Builder.ImmutableSetMultimap.Builder ( )
ImmutableSetMultimap.Builder.orderKeysBy ( Comparator keyComparator )  :  ImmutableSetMultimap.Builder
ImmutableSetMultimap.Builder.orderKeysBy ( Comparator x0 )  :  ImmutableMultimap.Builder
ImmutableSetMultimap.Builder.orderValuesBy ( Comparator valueComparator )  :  ImmutableSetMultimap.Builder
ImmutableSetMultimap.Builder.orderValuesBy ( Comparator x0 )  :  ImmutableMultimap.Builder
ImmutableSetMultimap.Builder.put ( Map.Entry entry )  :  ImmutableSetMultimap.Builder
ImmutableSetMultimap.Builder.put ( Map.Entry x0 )  :  ImmutableMultimap.Builder
ImmutableSetMultimap.Builder.put ( Object key, Object value )  :  ImmutableSetMultimap.Builder
ImmutableSetMultimap.Builder.put ( Object x0, Object x1 )  :  ImmutableMultimap.Builder
ImmutableSetMultimap.Builder.putAll ( Multimap multimap )  :  ImmutableSetMultimap.Builder
ImmutableSetMultimap.Builder.putAll ( Multimap x0 )  :  ImmutableMultimap.Builder
ImmutableSetMultimap.Builder.putAll ( Object key, Iterable values )  :  ImmutableSetMultimap.Builder
ImmutableSetMultimap.Builder.putAll ( Object key, Object[ ] values )  :  ImmutableSetMultimap.Builder
ImmutableSetMultimap.Builder.putAll ( Object x0, Iterable x1 )  :  ImmutableMultimap.Builder
ImmutableSetMultimap.Builder.putAll ( Object x0, Object[ ] x1 )  :  ImmutableMultimap.Builder
ImmutableSortedMap.Builder.build ( )  :  ImmutableMap
ImmutableSortedMap.Builder.build ( )  :  ImmutableSortedMap
ImmutableSortedMap.Builder.ImmutableSortedMap.Builder ( Comparator comparator )
ImmutableSortedMap.Builder.put ( Map.Entry entry )  :  ImmutableSortedMap.Builder
ImmutableSortedMap.Builder.put ( Map.Entry x0 )  :  ImmutableMap.Builder
ImmutableSortedMap.Builder.put ( Object key, Object value )  :  ImmutableSortedMap.Builder
ImmutableSortedMap.Builder.put ( Object x0, Object x1 )  :  ImmutableMap.Builder
ImmutableSortedMap.Builder.putAll ( Map map )  :  ImmutableSortedMap.Builder
ImmutableSortedMap.Builder.putAll ( Map x0 )  :  ImmutableMap.Builder
ImmutableSortedMultiset.Builder.add ( Object element )  :  ImmutableSortedMultiset.Builder
ImmutableSortedMultiset.Builder.add ( Object x0 )  :  ImmutableCollection.Builder
ImmutableSortedMultiset.Builder.add ( Object x0 )  :  ImmutableMultiset.Builder
ImmutableSortedMultiset.Builder.add ( Object[ ] elements )  :  ImmutableSortedMultiset.Builder
ImmutableSortedMultiset.Builder.add ( Object[ ] x0 )  :  ImmutableCollection.Builder
ImmutableSortedMultiset.Builder.add ( Object[ ] x0 )  :  ImmutableMultiset.Builder
ImmutableSortedMultiset.Builder.addAll ( Iterable elements )  :  ImmutableSortedMultiset.Builder
ImmutableSortedMultiset.Builder.addAll ( Iterable x0 )  :  ImmutableCollection.Builder
ImmutableSortedMultiset.Builder.addAll ( Iterable x0 )  :  ImmutableMultiset.Builder
ImmutableSortedMultiset.Builder.addAll ( Iterator elements )  :  ImmutableSortedMultiset.Builder
ImmutableSortedMultiset.Builder.addAll ( Iterator x0 )  :  ImmutableCollection.Builder
ImmutableSortedMultiset.Builder.addAll ( Iterator x0 )  :  ImmutableMultiset.Builder
ImmutableSortedMultiset.Builder.addCopies ( Object element, int occurrences )  :  ImmutableSortedMultiset.Builder
ImmutableSortedMultiset.Builder.addCopies ( Object x0, int x1 )  :  ImmutableMultiset.Builder
ImmutableSortedMultiset.Builder.build ( )  :  ImmutableCollection
ImmutableSortedMultiset.Builder.build ( )  :  ImmutableMultiset
ImmutableSortedMultiset.Builder.build ( )  :  ImmutableSortedMultiset
ImmutableSortedMultiset.Builder.ImmutableSortedMultiset.Builder ( Comparator comparator )
ImmutableSortedMultiset.Builder.setCount ( Object element, int count )  :  ImmutableSortedMultiset.Builder
ImmutableSortedMultiset.Builder.setCount ( Object x0, int x1 )  :  ImmutableMultiset.Builder
ImmutableSortedSet.Builder.add ( Object element )  :  ImmutableSortedSet.Builder
ImmutableSortedSet.Builder.add ( Object x0 )  :  ImmutableCollection.Builder
ImmutableSortedSet.Builder.add ( Object x0 )  :  ImmutableSet.Builder
ImmutableSortedSet.Builder.add ( Object[ ] elements )  :  ImmutableSortedSet.Builder
ImmutableSortedSet.Builder.add ( Object[ ] x0 )  :  ImmutableCollection.Builder
ImmutableSortedSet.Builder.add ( Object[ ] x0 )  :  ImmutableSet.Builder
ImmutableSortedSet.Builder.addAll ( Iterable elements )  :  ImmutableSortedSet.Builder
ImmutableSortedSet.Builder.addAll ( Iterable x0 )  :  ImmutableCollection.Builder
ImmutableSortedSet.Builder.addAll ( Iterable x0 )  :  ImmutableSet.Builder
ImmutableSortedSet.Builder.addAll ( Iterator elements )  :  ImmutableSortedSet.Builder
ImmutableSortedSet.Builder.addAll ( Iterator x0 )  :  ImmutableCollection.Builder
ImmutableSortedSet.Builder.addAll ( Iterator x0 )  :  ImmutableSet.Builder
ImmutableSortedSet.Builder.build ( )  :  ImmutableCollection
ImmutableSortedSet.Builder.build ( )  :  ImmutableSet
ImmutableSortedSet.Builder.build ( )  :  ImmutableSortedSet
ImmutableSortedSet.Builder.ImmutableSortedSet.Builder ( Comparator comparator )
ImmutableTable.Builder.build ( )  :  ImmutableTable
ImmutableTable.Builder.ImmutableTable.Builder ( )
ImmutableTable.Builder.orderColumnsBy ( Comparator columnComparator )  :  ImmutableTable.Builder
ImmutableTable.Builder.orderRowsBy ( Comparator rowComparator )  :  ImmutableTable.Builder
ImmutableTable.Builder.put ( Object rowKey, Object columnKey, Object value )  :  ImmutableTable.Builder
ImmutableTable.Builder.put ( Table.Cell cell )  :  ImmutableTable.Builder
ImmutableTable.Builder.putAll ( Table table )  :  ImmutableTable.Builder
MinMaxPriorityQueue.Builder.create ( )  :  MinMaxPriorityQueue
MinMaxPriorityQueue.Builder.create ( Iterable initialContents )  :  MinMaxPriorityQueue
MinMaxPriorityQueue.Builder.expectedSize ( int expectedSize )  :  MinMaxPriorityQueue.Builder
MinMaxPriorityQueue.Builder.maximumSize ( int maximumSize )  :  MinMaxPriorityQueue.Builder
package com.google.common.reflect
ImmutableTypeToInstanceMap.Builder.build ( )  :  ImmutableTypeToInstanceMap
ImmutableTypeToInstanceMap.Builder.put ( Class key, Object value )  :  ImmutableTypeToInstanceMap.Builder
ImmutableTypeToInstanceMap.Builder.put ( TypeToken key, Object value )  :  ImmutableTypeToInstanceMap.Builder

cdk-1.5.3.jar, ByteArrayDataInput.class
package com.google.common.io
ByteArrayDataInput.readBoolean ( ) [abstract]  :  boolean
ByteArrayDataInput.readByte ( ) [abstract]  :  byte
ByteArrayDataInput.readChar ( ) [abstract]  :  char
ByteArrayDataInput.readDouble ( ) [abstract]  :  double
ByteArrayDataInput.readFloat ( ) [abstract]  :  float
ByteArrayDataInput.readFully ( byte[ ] p1 ) [abstract]  :  void
ByteArrayDataInput.readFully ( byte[ ] p1, int p2, int p3 ) [abstract]  :  void
ByteArrayDataInput.readInt ( ) [abstract]  :  int
ByteArrayDataInput.readLine ( ) [abstract]  :  String
ByteArrayDataInput.readLong ( ) [abstract]  :  long
ByteArrayDataInput.readShort ( ) [abstract]  :  short
ByteArrayDataInput.readUnsignedByte ( ) [abstract]  :  int
ByteArrayDataInput.readUnsignedShort ( ) [abstract]  :  int
ByteArrayDataInput.readUTF ( ) [abstract]  :  String
ByteArrayDataInput.skipBytes ( int p1 ) [abstract]  :  int

cdk-1.5.3.jar, ByteArrayDataOutput.class
package com.google.common.io
ByteArrayDataOutput.toByteArray ( ) [abstract]  :  byte[ ]
ByteArrayDataOutput.write ( byte[ ] p1 ) [abstract]  :  void
ByteArrayDataOutput.write ( byte[ ] p1, int p2, int p3 ) [abstract]  :  void
ByteArrayDataOutput.write ( int p1 ) [abstract]  :  void
ByteArrayDataOutput.writeBoolean ( boolean p1 ) [abstract]  :  void
ByteArrayDataOutput.writeByte ( int p1 ) [abstract]  :  void
ByteArrayDataOutput.writeBytes ( String p1 ) [abstract]  :  void *DEPRECATED*
ByteArrayDataOutput.writeChar ( int p1 ) [abstract]  :  void
ByteArrayDataOutput.writeChars ( String p1 ) [abstract]  :  void
ByteArrayDataOutput.writeDouble ( double p1 ) [abstract]  :  void
ByteArrayDataOutput.writeFloat ( float p1 ) [abstract]  :  void
ByteArrayDataOutput.writeInt ( int p1 ) [abstract]  :  void
ByteArrayDataOutput.writeLong ( long p1 ) [abstract]  :  void
ByteArrayDataOutput.writeShort ( int p1 ) [abstract]  :  void
ByteArrayDataOutput.writeUTF ( String p1 ) [abstract]  :  void

cdk-1.5.3.jar, ByteProcessor.class
package com.google.common.io
ByteProcessor.getResult ( ) [abstract]  :  Object
ByteProcessor.processBytes ( byte[ ] p1, int p2, int p3 ) [abstract]  :  boolean

cdk-1.5.3.jar, Bytes.class
package com.google.common.primitives
Bytes.asList ( byte[ ] backingArray ) [static]  :  List
Bytes.concat ( byte[ ][ ] arrays ) [static]  :  byte[ ]
Bytes.contains ( byte[ ] array, byte target ) [static]  :  boolean
Bytes.ensureCapacity ( byte[ ] array, int minLength, int padding ) [static]  :  byte[ ]
Bytes.hashCode ( byte value ) [static]  :  int
Bytes.indexOf ( byte[ ] array, byte target ) [static]  :  int
Bytes.indexOf ( byte[ ] array, byte[ ] target ) [static]  :  int
Bytes.lastIndexOf ( byte[ ] array, byte target ) [static]  :  int
Bytes.toArray ( Collection collection ) [static]  :  byte[ ]

cdk-1.5.3.jar, ByteSink.class
package com.google.common.io
ByteSink.asCharSink ( Charset charset )  :  CharSink
ByteSink.ByteSink ( )
ByteSink.openBufferedStream ( )  :  BufferedOutputStream
ByteSink.openStream ( ) [abstract]  :  OutputStream
ByteSink.write ( byte[ ] bytes )  :  void
ByteSink.writeFrom ( InputStream input )  :  long

cdk-1.5.3.jar, ByteSource.class
package com.google.common.io
ByteSource.asCharSource ( Charset charset )  :  CharSource
ByteSource.ByteSource ( )
ByteSource.contentEquals ( ByteSource other )  :  boolean
ByteSource.copyTo ( ByteSink sink )  :  long
ByteSource.copyTo ( OutputStream output )  :  long
ByteSource.hash ( HashFunction hashFunction )  :  HashCode
ByteSource.openBufferedStream ( )  :  BufferedInputStream
ByteSource.openStream ( ) [abstract]  :  InputStream
ByteSource.read ( )  :  byte[ ]
ByteSource.size ( )  :  long
ByteSource.slice ( long offset, long length )  :  ByteSource

cdk-1.5.3.jar, ByteStreams.class
package com.google.common.io
ByteStreams.asByteSource ( byte[ ] b ) [static]  :  ByteSource
ByteStreams.copy ( InputStream from, OutputStream to ) [static]  :  long
ByteStreams.copy ( InputStream from, OutputSupplier to ) [static]  :  long
ByteStreams.copy ( InputSupplier from, OutputStream to ) [static]  :  long
ByteStreams.copy ( InputSupplier from, OutputSupplier to ) [static]  :  long
ByteStreams.copy ( ReadableByteChannel from, WritableByteChannel to ) [static]  :  long
ByteStreams.equal ( InputSupplier supplier1, InputSupplier supplier2 ) [static]  :  boolean
ByteStreams.getChecksum ( InputSupplier supplier, Checksum checksum ) [static]  :  long *DEPRECATED*
ByteStreams.hash ( InputSupplier supplier, HashFunction hashFunction ) [static]  :  HashCode
ByteStreams.join ( InputSupplier[ ] suppliers ) [static]  :  InputSupplier
ByteStreams.join ( Iterable suppliers ) [static]  :  InputSupplier
ByteStreams.length ( InputSupplier supplier ) [static]  :  long
ByteStreams.limit ( InputStream in, long limit ) [static]  :  InputStream
ByteStreams.newDataInput ( byte[ ] bytes ) [static]  :  ByteArrayDataInput
ByteStreams.newDataInput ( byte[ ] bytes, int start ) [static]  :  ByteArrayDataInput
ByteStreams.newDataOutput ( ) [static]  :  ByteArrayDataOutput
ByteStreams.newDataOutput ( int size ) [static]  :  ByteArrayDataOutput
ByteStreams.newInputStreamSupplier ( byte[ ] b ) [static]  :  InputSupplier
ByteStreams.newInputStreamSupplier ( byte[ ] b, int off, int len ) [static]  :  InputSupplier
ByteStreams.nullOutputStream ( ) [static]  :  OutputStream
ByteStreams.read ( InputStream in, byte[ ] b, int off, int len ) [static]  :  int
ByteStreams.readBytes ( InputStream input, ByteProcessor processor ) [static]  :  Object
ByteStreams.readBytes ( InputSupplier supplier, ByteProcessor processor ) [static]  :  Object
ByteStreams.readFully ( InputStream in, byte[ ] b ) [static]  :  void
ByteStreams.readFully ( InputStream in, byte[ ] b, int off, int len ) [static]  :  void
ByteStreams.skipFully ( InputStream in, long n ) [static]  :  void
ByteStreams.slice ( InputSupplier supplier, long offset, long length ) [static]  :  InputSupplier
ByteStreams.toByteArray ( InputStream in ) [static]  :  byte[ ]
ByteStreams.toByteArray ( InputSupplier supplier ) [static]  :  byte[ ]
ByteStreams.write ( byte[ ] from, OutputSupplier to ) [static]  :  void

cdk-1.5.3.jar, Cache.class
package com.google.common.cache
Cache.asMap ( ) [abstract]  :  ConcurrentMap
Cache.cleanUp ( ) [abstract]  :  void
Cache.get ( Object p1, Callable p2 ) [abstract]  :  Object
Cache.getAllPresent ( Iterable p1 ) [abstract]  :  ImmutableMap
Cache.getIfPresent ( Object p1 ) [abstract]  :  Object
Cache.invalidate ( Object p1 ) [abstract]  :  void
Cache.invalidateAll ( ) [abstract]  :  void
Cache.invalidateAll ( Iterable p1 ) [abstract]  :  void
Cache.put ( Object p1, Object p2 ) [abstract]  :  void
Cache.putAll ( Map p1 ) [abstract]  :  void
Cache.size ( ) [abstract]  :  long
Cache.stats ( ) [abstract]  :  CacheStats

cdk-1.5.3.jar, CacheBuilder.class
package com.google.common.cache
CacheBuilder.build ( )  :  Cache
CacheBuilder.build ( CacheLoader loader )  :  LoadingCache
CacheBuilder.concurrencyLevel ( int concurrencyLevel )  :  CacheBuilder
CacheBuilder.expireAfterAccess ( long duration, TimeUnit unit )  :  CacheBuilder
CacheBuilder.expireAfterWrite ( long duration, TimeUnit unit )  :  CacheBuilder
CacheBuilder.from ( CacheBuilderSpec spec ) [static]  :  CacheBuilder
CacheBuilder.from ( String spec ) [static]  :  CacheBuilder
CacheBuilder.initialCapacity ( int initialCapacity )  :  CacheBuilder
CacheBuilder.maximumSize ( long size )  :  CacheBuilder
CacheBuilder.maximumWeight ( long weight )  :  CacheBuilder
CacheBuilder.newBuilder ( ) [static]  :  CacheBuilder
CacheBuilder.recordStats ( )  :  CacheBuilder
CacheBuilder.refreshAfterWrite ( long duration, TimeUnit unit )  :  CacheBuilder
CacheBuilder.removalListener ( RemovalListener listener )  :  CacheBuilder
CacheBuilder.softValues ( )  :  CacheBuilder
CacheBuilder.ticker ( Ticker ticker )  :  CacheBuilder
CacheBuilder.toString ( )  :  String
CacheBuilder.weakKeys ( )  :  CacheBuilder
CacheBuilder.weakValues ( )  :  CacheBuilder
CacheBuilder.weigher ( Weigher weigher )  :  CacheBuilder

cdk-1.5.3.jar, CacheBuilderSpec.class
package com.google.common.cache
CacheBuilderSpec.disableCaching ( ) [static]  :  CacheBuilderSpec
CacheBuilderSpec.equals ( Object obj )  :  boolean
CacheBuilderSpec.hashCode ( )  :  int
CacheBuilderSpec.parse ( String cacheBuilderSpecification ) [static]  :  CacheBuilderSpec
CacheBuilderSpec.toParsableString ( )  :  String
CacheBuilderSpec.toString ( )  :  String

cdk-1.5.3.jar, CacheLoader.class
package com.google.common.cache
CacheLoader.CacheLoader ( )
CacheLoader.from ( Function function ) [static]  :  CacheLoader
CacheLoader.from ( Supplier supplier ) [static]  :  CacheLoader
CacheLoader.load ( Object p1 ) [abstract]  :  Object
CacheLoader.loadAll ( Iterable keys )  :  Map
CacheLoader.reload ( Object key, Object oldValue )  :  ListenableFuture

cdk-1.5.3.jar, CacheStats.class
package com.google.common.cache
CacheStats.averageLoadPenalty ( )  :  double
CacheStats.CacheStats ( long hitCount, long missCount, long loadSuccessCount, long loadExceptionCount, long totalLoadTime, long evictionCount )
CacheStats.equals ( Object object )  :  boolean
CacheStats.evictionCount ( )  :  long
CacheStats.hashCode ( )  :  int
CacheStats.hitCount ( )  :  long
CacheStats.hitRate ( )  :  double
CacheStats.loadCount ( )  :  long
CacheStats.loadExceptionCount ( )  :  long
CacheStats.loadExceptionRate ( )  :  double
CacheStats.loadSuccessCount ( )  :  long
CacheStats.minus ( CacheStats other )  :  CacheStats
CacheStats.missCount ( )  :  long
CacheStats.missRate ( )  :  double
CacheStats.plus ( CacheStats other )  :  CacheStats
CacheStats.requestCount ( )  :  long
CacheStats.toString ( )  :  String
CacheStats.totalLoadTime ( )  :  long

cdk-1.5.3.jar, Callables.class
package com.google.common.util.concurrent
Callables.returning ( Object value ) [static]  :  Callable

cdk-1.5.3.jar, CaseFormat.class
package com.google.common.base
CaseFormat.to ( CaseFormat format, String str )  :  String
CaseFormat.valueOf ( String name ) [static]  :  CaseFormat
CaseFormat.values ( ) [static]  :  CaseFormat[ ]

cdk-1.5.3.jar, Cell.class
package com.google.common.collect
Table.Cell.equals ( Object p1 ) [abstract]  :  boolean
Table.Cell.getColumnKey ( ) [abstract]  :  Object
Table.Cell.getRowKey ( ) [abstract]  :  Object
Table.Cell.getValue ( ) [abstract]  :  Object
Table.Cell.hashCode ( ) [abstract]  :  int

cdk-1.5.3.jar, CharMatcher.class
package com.google.common.base
CharMatcher.and ( CharMatcher other )  :  CharMatcher
CharMatcher.anyOf ( CharSequence sequence ) [static]  :  CharMatcher
CharMatcher.apply ( Character character )  :  boolean
CharMatcher.apply ( Object x0 )  :  boolean
CharMatcher.CharMatcher ( )
CharMatcher.collapseFrom ( CharSequence sequence, char replacement )  :  String
CharMatcher.countIn ( CharSequence sequence )  :  int
CharMatcher.forPredicate ( Predicate predicate ) [static]  :  CharMatcher
CharMatcher.indexIn ( CharSequence sequence )  :  int
CharMatcher.indexIn ( CharSequence sequence, int start )  :  int
CharMatcher.inRange ( char startInclusive, char endInclusive ) [static]  :  CharMatcher
CharMatcher.is ( char match ) [static]  :  CharMatcher
CharMatcher.isNot ( char match ) [static]  :  CharMatcher
CharMatcher.lastIndexIn ( CharSequence sequence )  :  int
CharMatcher.matches ( char p1 ) [abstract]  :  boolean
CharMatcher.matchesAllOf ( CharSequence sequence )  :  boolean
CharMatcher.matchesAnyOf ( CharSequence sequence )  :  boolean
CharMatcher.matchesNoneOf ( CharSequence sequence )  :  boolean
CharMatcher.negate ( )  :  CharMatcher
CharMatcher.noneOf ( CharSequence sequence ) [static]  :  CharMatcher
CharMatcher.or ( CharMatcher other )  :  CharMatcher
CharMatcher.precomputed ( )  :  CharMatcher
CharMatcher.removeFrom ( CharSequence sequence )  :  String
CharMatcher.replaceFrom ( CharSequence sequence, char replacement )  :  String
CharMatcher.replaceFrom ( CharSequence sequence, CharSequence replacement )  :  String
CharMatcher.retainFrom ( CharSequence sequence )  :  String
CharMatcher.toString ( )  :  String
CharMatcher.trimAndCollapseFrom ( CharSequence sequence, char replacement )  :  String
CharMatcher.trimFrom ( CharSequence sequence )  :  String
CharMatcher.trimLeadingFrom ( CharSequence sequence )  :  String
CharMatcher.trimTrailingFrom ( CharSequence sequence )  :  String

cdk-1.5.3.jar, Chars.class
package com.google.common.primitives
Chars.asList ( char[ ] backingArray ) [static]  :  List
Chars.checkedCast ( long value ) [static]  :  char
Chars.compare ( char a, char b ) [static]  :  int
Chars.concat ( char[ ][ ] arrays ) [static]  :  char[ ]
Chars.contains ( char[ ] array, char target ) [static]  :  boolean
Chars.ensureCapacity ( char[ ] array, int minLength, int padding ) [static]  :  char[ ]
Chars.fromByteArray ( byte[ ] bytes ) [static]  :  char
Chars.fromBytes ( byte b1, byte b2 ) [static]  :  char
Chars.hashCode ( char value ) [static]  :  int
Chars.indexOf ( char[ ] array, char target ) [static]  :  int
Chars.indexOf ( char[ ] array, char[ ] target ) [static]  :  int
Chars.join ( String separator, char[ ] array ) [static]  :  String
Chars.lastIndexOf ( char[ ] array, char target ) [static]  :  int
Chars.lexicographicalComparator ( ) [static]  :  Comparator
Chars.max ( char[ ] array ) [static]  :  char
Chars.min ( char[ ] array ) [static]  :  char
Chars.saturatedCast ( long value ) [static]  :  char
Chars.toArray ( Collection collection ) [static]  :  char[ ]
Chars.toByteArray ( char value ) [static]  :  byte[ ]

cdk-1.5.3.jar, CharSink.class
package com.google.common.io
CharSink.CharSink ( )
CharSink.openBufferedStream ( )  :  BufferedWriter
CharSink.openStream ( ) [abstract]  :  Writer
CharSink.write ( CharSequence charSequence )  :  void
CharSink.writeFrom ( Readable readable )  :  long
CharSink.writeLines ( Iterable lines )  :  void
CharSink.writeLines ( Iterable lines, String lineSeparator )  :  void

cdk-1.5.3.jar, CharSource.class
package com.google.common.io
CharSource.CharSource ( )
CharSource.copyTo ( Appendable appendable )  :  long
CharSource.copyTo ( CharSink sink )  :  long
CharSource.openBufferedStream ( )  :  BufferedReader
CharSource.openStream ( ) [abstract]  :  Reader
CharSource.read ( )  :  String
CharSource.readFirstLine ( )  :  String
CharSource.readLines ( )  :  ImmutableList

cdk-1.5.3.jar, CharStreams.class
package com.google.common.io
CharStreams.asCharSource ( String string ) [static]  :  CharSource
CharStreams.asWriter ( Appendable target ) [static]  :  Writer
CharStreams.copy ( InputSupplier from, Appendable to ) [static]  :  long
CharStreams.copy ( InputSupplier from, OutputSupplier to ) [static]  :  long
CharStreams.copy ( Readable from, Appendable to ) [static]  :  long
CharStreams.join ( InputSupplier[ ] suppliers ) [static]  :  InputSupplier
CharStreams.join ( Iterable suppliers ) [static]  :  InputSupplier
CharStreams.newReaderSupplier ( InputSupplier in, Charset charset ) [static]  :  InputSupplier
CharStreams.newReaderSupplier ( String value ) [static]  :  InputSupplier
CharStreams.newWriterSupplier ( OutputSupplier out, Charset charset ) [static]  :  OutputSupplier
CharStreams.readFirstLine ( InputSupplier supplier ) [static]  :  String
CharStreams.readLines ( InputSupplier supplier ) [static]  :  List
CharStreams.readLines ( InputSupplier supplier, LineProcessor callback ) [static]  :  Object
CharStreams.readLines ( Readable r ) [static]  :  List
CharStreams.readLines ( Readable readable, LineProcessor processor ) [static]  :  Object
CharStreams.skipFully ( Reader reader, long n ) [static]  :  void
CharStreams.toString ( InputSupplier supplier ) [static]  :  String
CharStreams.toString ( Readable r ) [static]  :  String
CharStreams.write ( CharSequence from, OutputSupplier to ) [static]  :  void

cdk-1.5.3.jar, CheckedFuture.class
package com.google.common.util.concurrent
CheckedFuture.checkedGet ( ) [abstract]  :  Object
CheckedFuture.checkedGet ( long p1, TimeUnit p2 ) [abstract]  :  Object

cdk-1.5.3.jar, ClassInfo.class
package com.google.common.reflect
ClassPath.ClassInfo.getName ( )  :  String
ClassPath.ClassInfo.getPackageName ( )  :  String
ClassPath.ClassInfo.getSimpleName ( )  :  String
ClassPath.ClassInfo.load ( )  :  Class
ClassPath.ClassInfo.toString ( )  :  String

cdk-1.5.3.jar, ClassPath.class
package com.google.common.reflect
ClassPath.from ( ClassLoader classloader ) [static]  :  ClassPath
ClassPath.getResources ( )  :  ImmutableSet
ClassPath.getTopLevelClasses ( )  :  ImmutableSet
ClassPath.getTopLevelClasses ( String packageName )  :  ImmutableSet
ClassPath.getTopLevelClassesRecursive ( String packageName )  :  ImmutableSet

cdk-1.5.3.jar, ClassToInstanceMap.class
package com.google.common.collect
ClassToInstanceMap.getInstance ( Class p1 ) [abstract]  :  Object
ClassToInstanceMap.putInstance ( Class p1, Object p2 ) [abstract]  :  Object

cdk-1.5.3.jar, Closeables.class
package com.google.common.io
Closeables.close ( Closeable closeable, boolean swallowIOException ) [static]  :  void
Closeables.closeQuietly ( Closeable closeable ) [static]  :  void *DEPRECATED*

cdk-1.5.3.jar, Closer.class
package com.google.common.io
Closer.close ( )  :  void
Closer.create ( ) [static]  :  Closer
Closer.register ( Closeable closeable )  :  Closeable
Closer.rethrow ( Throwable e )  :  RuntimeException
Closer.rethrow ( Throwable e, Class declaredType )  :  RuntimeException
Closer.rethrow ( Throwable e, Class declaredType1, Class declaredType2 )  :  RuntimeException

cdk-1.5.3.jar, Collections2.class
package com.google.common.collect
Collections2.filter ( Collection unfiltered, Predicate predicate ) [static]  :  Collection
Collections2.orderedPermutations ( Iterable elements ) [static]  :  Collection
Collections2.orderedPermutations ( Iterable elements, Comparator comparator ) [static]  :  Collection
Collections2.permutations ( Collection elements ) [static]  :  Collection
Collections2.transform ( Collection fromCollection, Function function ) [static]  :  Collection

cdk-1.5.3.jar, ComparisonChain.class
package com.google.common.collect
ComparisonChain.compare ( boolean left, boolean right )  :  ComparisonChain *DEPRECATED*
ComparisonChain.compare ( Comparable p1, Comparable p2 ) [abstract]  :  ComparisonChain
ComparisonChain.compare ( double p1, double p2 ) [abstract]  :  ComparisonChain
ComparisonChain.compare ( float p1, float p2 ) [abstract]  :  ComparisonChain
ComparisonChain.compare ( int p1, int p2 ) [abstract]  :  ComparisonChain
ComparisonChain.compare ( long p1, long p2 ) [abstract]  :  ComparisonChain
ComparisonChain.compare ( Object p1, Object p2, Comparator p3 ) [abstract]  :  ComparisonChain
ComparisonChain.compareFalseFirst ( boolean p1, boolean p2 ) [abstract]  :  ComparisonChain
ComparisonChain.compareTrueFirst ( boolean p1, boolean p2 ) [abstract]  :  ComparisonChain
ComparisonChain.result ( ) [abstract]  :  int
ComparisonChain.start ( ) [static]  :  ComparisonChain

cdk-1.5.3.jar, ComputationException.class
package com.google.common.collect
ComputationException.ComputationException ( Throwable cause )

cdk-1.5.3.jar, ConcurrentHashMultiset.class
package com.google.common.collect
ConcurrentHashMultiset.add ( Object element, int occurrences )  :  int
ConcurrentHashMultiset.add ( Object x0 )  :  boolean
ConcurrentHashMultiset.addAll ( Collection x0 )  :  boolean
ConcurrentHashMultiset.clear ( )  :  void
ConcurrentHashMultiset.contains ( Object x0 )  :  boolean
ConcurrentHashMultiset.count ( Object element )  :  int
ConcurrentHashMultiset.create ( ) [static]  :  ConcurrentHashMultiset
ConcurrentHashMultiset.create ( GenericMapMaker mapMaker ) [static]  :  ConcurrentHashMultiset
ConcurrentHashMultiset.create ( Iterable elements ) [static]  :  ConcurrentHashMultiset
ConcurrentHashMultiset.elementSet ( )  :  Set
ConcurrentHashMultiset.entrySet ( )  :  Set
ConcurrentHashMultiset.equals ( Object x0 )  :  boolean
ConcurrentHashMultiset.hashCode ( )  :  int
ConcurrentHashMultiset.isEmpty ( )  :  boolean
ConcurrentHashMultiset.iterator ( )  :  Iterator
ConcurrentHashMultiset.remove ( Object element, int occurrences )  :  int
ConcurrentHashMultiset.remove ( Object x0 )  :  boolean
ConcurrentHashMultiset.removeAll ( Collection x0 )  :  boolean
ConcurrentHashMultiset.removeExactly ( Object element, int occurrences )  :  boolean
ConcurrentHashMultiset.retainAll ( Collection x0 )  :  boolean
ConcurrentHashMultiset.setCount ( Object element, int count )  :  int
ConcurrentHashMultiset.setCount ( Object element, int expectedOldCount, int newCount )  :  boolean
ConcurrentHashMultiset.size ( )  :  int
ConcurrentHashMultiset.toArray ( )  :  Object[ ]
ConcurrentHashMultiset.toArray ( Object[ ] array )  :  Object[ ]
ConcurrentHashMultiset.toString ( )  :  String

cdk-1.5.3.jar, Constraint.class
package com.google.common.collect
Constraint.checkElement ( Object p1 ) [abstract]  :  Object
Constraint.toString ( ) [abstract]  :  String

cdk-1.5.3.jar, Constraints.class
package com.google.common.collect
Constraints.constrainedCollection ( Collection collection, Constraint constraint ) [static]  :  Collection
Constraints.constrainedList ( List list, Constraint constraint ) [static]  :  List
Constraints.constrainedMultiset ( Multiset multiset, Constraint constraint ) [static]  :  Multiset
Constraints.constrainedSet ( Set set, Constraint constraint ) [static]  :  Set
Constraints.constrainedSortedSet ( SortedSet sortedSet, Constraint constraint ) [static]  :  SortedSet
Constraints.notNull ( ) [static]  :  Constraint

cdk-1.5.3.jar, ContiguousSet.class
package com.google.common.collect
ContiguousSet.create ( Range range, DiscreteDomain domain ) [static]  :  ContiguousSet
ContiguousSet.headSet ( Comparable toElement )  :  ContiguousSet
ContiguousSet.headSet ( Comparable toElement, boolean inclusive )  :  ContiguousSet
ContiguousSet.headSet ( Object x0 )  :  ImmutableSortedSet
ContiguousSet.headSet ( Object x0 )  :  SortedSet
ContiguousSet.headSet ( Object x0, boolean x1 )  :  ImmutableSortedSet
ContiguousSet.headSet ( Object x0, boolean x1 )  :  NavigableSet
ContiguousSet.intersection ( ContiguousSet p1 ) [abstract]  :  ContiguousSet
ContiguousSet.range ( ) [abstract]  :  Range
ContiguousSet.range ( BoundType p1, BoundType p2 ) [abstract]  :  Range
ContiguousSet.subSet ( Comparable fromElement, boolean fromInclusive, Comparable toElement, boolean toInclusive )  :  ContiguousSet
ContiguousSet.subSet ( Comparable fromElement, Comparable toElement )  :  ContiguousSet
ContiguousSet.subSet ( Object x0, boolean x1, Object x2, boolean x3 )  :  ImmutableSortedSet
ContiguousSet.subSet ( Object x0, boolean x1, Object x2, boolean x3 )  :  NavigableSet
ContiguousSet.subSet ( Object x0, Object x1 )  :  ImmutableSortedSet
ContiguousSet.subSet ( Object x0, Object x1 )  :  SortedSet
ContiguousSet.tailSet ( Comparable fromElement )  :  ContiguousSet
ContiguousSet.tailSet ( Comparable fromElement, boolean inclusive )  :  ContiguousSet
ContiguousSet.tailSet ( Object x0 )  :  ImmutableSortedSet
ContiguousSet.tailSet ( Object x0 )  :  SortedSet
ContiguousSet.tailSet ( Object x0, boolean x1 )  :  ImmutableSortedSet
ContiguousSet.tailSet ( Object x0, boolean x1 )  :  NavigableSet
ContiguousSet.toString ( )  :  String

cdk-1.5.3.jar, CountingInputStream.class
package com.google.common.io
CountingInputStream.CountingInputStream ( InputStream in )
CountingInputStream.getCount ( )  :  long
CountingInputStream.mark ( int readlimit )  :  void
CountingInputStream.read ( )  :  int
CountingInputStream.read ( byte[ ] b, int off, int len )  :  int
CountingInputStream.reset ( )  :  void
CountingInputStream.skip ( long n )  :  long

cdk-1.5.3.jar, CountingOutputStream.class
package com.google.common.io
CountingOutputStream.CountingOutputStream ( OutputStream out )
CountingOutputStream.getCount ( )  :  long
CountingOutputStream.write ( byte[ ] b, int off, int len )  :  void
CountingOutputStream.write ( int b )  :  void

cdk-1.5.3.jar, CustomScheduler.class
package com.google.common.util.concurrent
AbstractScheduledService.CustomScheduler.AbstractScheduledService.CustomScheduler ( )
AbstractScheduledService.CustomScheduler.getNextSchedule ( ) [abstract]  :  AbstractScheduledService.CustomScheduler.Schedule

cdk-1.5.3.jar, CycleDetectingLockFactory.class
package com.google.common.util.concurrent
CycleDetectingLockFactory.newInstance ( CycleDetectingLockFactory.Policy policy ) [static]  :  CycleDetectingLockFactory
CycleDetectingLockFactory.newInstanceWithExplicitOrdering ( Class enumClass, CycleDetectingLockFactory.Policy policy ) [static]  :  CycleDetectingLockFactory.WithExplicitOrdering
CycleDetectingLockFactory.newReentrantLock ( String lockName )  :  ReentrantLock
CycleDetectingLockFactory.newReentrantLock ( String lockName, boolean fair )  :  ReentrantLock
CycleDetectingLockFactory.newReentrantReadWriteLock ( String lockName )  :  ReentrantReadWriteLock
CycleDetectingLockFactory.newReentrantReadWriteLock ( String lockName, boolean fair )  :  ReentrantReadWriteLock

cdk-1.5.3.jar, DeadEvent.class
package com.google.common.eventbus
DeadEvent.DeadEvent ( Object source, Object event )
DeadEvent.getEvent ( )  :  Object
DeadEvent.getSource ( )  :  Object

cdk-1.5.3.jar, Defaults.class
package com.google.common.base
Defaults.defaultValue ( Class type ) [static]  :  Object

cdk-1.5.3.jar, DescriptorEngine.class
package org.openscience.cdk.qsar
DescriptorEngine.DescriptorEngine ( Class c, IChemObjectBuilder builder )

cdk-1.5.3.jar, DiscreteDomain.class
package com.google.common.collect
DiscreteDomain.DiscreteDomain ( )
DiscreteDomain.distance ( Comparable p1, Comparable p2 ) [abstract]  :  long
DiscreteDomain.integers ( ) [static]  :  DiscreteDomain
DiscreteDomain.longs ( ) [static]  :  DiscreteDomain
DiscreteDomain.maxValue ( )  :  Comparable
DiscreteDomain.minValue ( )  :  Comparable
DiscreteDomain.next ( Comparable p1 ) [abstract]  :  Comparable
DiscreteDomain.previous ( Comparable p1 ) [abstract]  :  Comparable

cdk-1.5.3.jar, DiscreteDomains.class
package com.google.common.collect
DiscreteDomains.integers ( ) [static]  :  DiscreteDomain
DiscreteDomains.longs ( ) [static]  :  DiscreteDomain

cdk-1.5.3.jar, DoubleMath.class
package com.google.common.math
DoubleMath.factorial ( int n ) [static]  :  double
DoubleMath.fuzzyCompare ( double a, double b, double tolerance ) [static]  :  int
DoubleMath.fuzzyEquals ( double a, double b, double tolerance ) [static]  :  boolean
DoubleMath.isMathematicalInteger ( double x ) [static]  :  boolean
DoubleMath.isPowerOfTwo ( double x ) [static]  :  boolean
DoubleMath.log2 ( double x ) [static]  :  double
DoubleMath.log2 ( double x, RoundingMode mode ) [static]  :  int
DoubleMath.roundToBigInteger ( double x, RoundingMode mode ) [static]  :  BigInteger
DoubleMath.roundToInt ( double x, RoundingMode mode ) [static]  :  int
DoubleMath.roundToLong ( double x, RoundingMode mode ) [static]  :  long

cdk-1.5.3.jar, Doubles.class
package com.google.common.primitives
Doubles.asList ( double[ ] backingArray ) [static]  :  List
Doubles.compare ( double a, double b ) [static]  :  int
Doubles.concat ( double[ ][ ] arrays ) [static]  :  double[ ]
Doubles.contains ( double[ ] array, double target ) [static]  :  boolean
Doubles.ensureCapacity ( double[ ] array, int minLength, int padding ) [static]  :  double[ ]
Doubles.hashCode ( double value ) [static]  :  int
Doubles.indexOf ( double[ ] array, double target ) [static]  :  int
Doubles.indexOf ( double[ ] array, double[ ] target ) [static]  :  int
Doubles.isFinite ( double value ) [static]  :  boolean
Doubles.join ( String separator, double[ ] array ) [static]  :  String
Doubles.lastIndexOf ( double[ ] array, double target ) [static]  :  int
Doubles.lexicographicalComparator ( ) [static]  :  Comparator
Doubles.max ( double[ ] array ) [static]  :  double
Doubles.min ( double[ ] array ) [static]  :  double
Doubles.toArray ( Collection collection ) [static]  :  double[ ]
Doubles.tryParse ( String string ) [static]  :  Double

cdk-1.5.3.jar, Entry.class
package com.google.common.collect
Multiset.Entry.equals ( Object p1 ) [abstract]  :  boolean
Multiset.Entry.getCount ( ) [abstract]  :  int
Multiset.Entry.getElement ( ) [abstract]  :  Object
Multiset.Entry.hashCode ( ) [abstract]  :  int
Multiset.Entry.toString ( ) [abstract]  :  String

cdk-1.5.3.jar, EntryTransformer.class
package com.google.common.collect
Maps.EntryTransformer.transformEntry ( Object p1, Object p2 ) [abstract]  :  Object

cdk-1.5.3.jar, EnumBiMap.class
package com.google.common.collect
EnumBiMap.clear ( )  :  void
EnumBiMap.containsValue ( Object x0 )  :  boolean
EnumBiMap.create ( Class keyType, Class valueType ) [static]  :  EnumBiMap
EnumBiMap.create ( Map map ) [static]  :  EnumBiMap
EnumBiMap.entrySet ( )  :  Set
EnumBiMap.inverse ( )  :  BiMap
EnumBiMap.keySet ( )  :  Set
EnumBiMap.keyType ( )  :  Class
EnumBiMap.putAll ( Map x0 )  :  void
EnumBiMap.values ( )  :  Set
EnumBiMap.valueType ( )  :  Class

cdk-1.5.3.jar, EnumHashBiMap.class
package com.google.common.collect
EnumHashBiMap.clear ( )  :  void
EnumHashBiMap.containsValue ( Object x0 )  :  boolean
EnumHashBiMap.create ( Class keyType ) [static]  :  EnumHashBiMap
EnumHashBiMap.create ( Map map ) [static]  :  EnumHashBiMap
EnumHashBiMap.entrySet ( )  :  Set
EnumHashBiMap.forcePut ( Enum key, Object value )  :  Object
EnumHashBiMap.forcePut ( Object x0, Object x1 )  :  Object
EnumHashBiMap.inverse ( )  :  BiMap
EnumHashBiMap.keySet ( )  :  Set
EnumHashBiMap.keyType ( )  :  Class
EnumHashBiMap.put ( Enum key, Object value )  :  Object
EnumHashBiMap.put ( Object x0, Object x1 )  :  Object
EnumHashBiMap.putAll ( Map x0 )  :  void
EnumHashBiMap.remove ( Object x0 )  :  Object
EnumHashBiMap.values ( )  :  Set

cdk-1.5.3.jar, EnumMultiset.class
package com.google.common.collect
EnumMultiset.addAll ( Collection x0 )  :  boolean
EnumMultiset.clear ( )  :  void
EnumMultiset.contains ( Object x0 )  :  boolean
EnumMultiset.count ( Object x0 )  :  int
EnumMultiset.create ( Class type ) [static]  :  EnumMultiset
EnumMultiset.create ( Iterable elements ) [static]  :  EnumMultiset
EnumMultiset.create ( Iterable elements, Class type ) [static]  :  EnumMultiset
EnumMultiset.elementSet ( )  :  Set
EnumMultiset.entrySet ( )  :  Set
EnumMultiset.equals ( Object x0 )  :  boolean
EnumMultiset.hashCode ( )  :  int
EnumMultiset.isEmpty ( )  :  boolean
EnumMultiset.iterator ( )  :  Iterator
EnumMultiset.remove ( Object x0 )  :  boolean
EnumMultiset.remove ( Object x0, int x1 )  :  int
EnumMultiset.removeAll ( Collection x0 )  :  boolean
EnumMultiset.retainAll ( Collection x0 )  :  boolean
EnumMultiset.size ( )  :  int
EnumMultiset.toString ( )  :  String

cdk-1.5.3.jar, Enums.class
package com.google.common.base
Enums.getField ( Enum enumValue ) [static]  :  Field
Enums.getIfPresent ( Class enumClass, String value ) [static]  :  Optional
Enums.valueOfFunction ( Class enumClass ) [static]  :  Function

cdk-1.5.3.jar, Equivalence.class
package com.google.common.base
Equivalence.doEquivalent ( Object p1, Object p2 ) [abstract]  :  boolean
Equivalence.doHash ( Object p1 ) [abstract]  :  int
Equivalence.equals ( ) [static]  :  Equivalence
Equivalence.Equivalence ( )
Equivalence.equivalent ( Object a, Object b )  :  boolean
Equivalence.equivalentTo ( Object target )  :  Predicate
Equivalence.hash ( Object t )  :  int
Equivalence.identity ( ) [static]  :  Equivalence
Equivalence.onResultOf ( Function function )  :  Equivalence
Equivalence.pairwise ( )  :  Equivalence
Equivalence.wrap ( Object reference )  :  Equivalence.Wrapper

cdk-1.5.3.jar, EssentialCycles.class
package org.openscience.cdk.graph
EssentialCycles.EssentialCycles ( int[ ][ ] graph )
EssentialCycles.paths ( )  :  int[ ][ ]
EssentialCycles.size ( )  :  int

cdk-1.5.3.jar, EventBus.class
package com.google.common.eventbus
EventBus.EventBus ( )
EventBus.EventBus ( String identifier )
EventBus.post ( Object event )  :  void
EventBus.register ( Object object )  :  void
EventBus.unregister ( Object object )  :  void

cdk-1.5.3.jar, ExecutionError.class
package com.google.common.util.concurrent
ExecutionError.ExecutionError ( )
ExecutionError.ExecutionError ( Error cause )
ExecutionError.ExecutionError ( String message )
ExecutionError.ExecutionError ( String message, Error cause )

cdk-1.5.3.jar, ExecutionList.class
package com.google.common.util.concurrent
ExecutionList.add ( Runnable runnable, Executor executor )  :  void
ExecutionList.execute ( )  :  void
ExecutionList.ExecutionList ( )

cdk-1.5.3.jar, FakeTimeLimiter.class
package com.google.common.util.concurrent
FakeTimeLimiter.callWithTimeout ( Callable callable, long timeoutDuration, TimeUnit timeoutUnit, boolean amInterruptible )  :  Object
FakeTimeLimiter.FakeTimeLimiter ( )
FakeTimeLimiter.newProxy ( Object target, Class interfaceType, long timeoutDuration, TimeUnit timeoutUnit )  :  Object

cdk-1.5.3.jar, FileBackedOutputStream.class
package com.google.common.io
FileBackedOutputStream.close ( )  :  void
FileBackedOutputStream.FileBackedOutputStream ( int fileThreshold )
FileBackedOutputStream.FileBackedOutputStream ( int fileThreshold, boolean resetOnFinalize )
FileBackedOutputStream.flush ( )  :  void
FileBackedOutputStream.getSupplier ( )  :  InputSupplier
FileBackedOutputStream.reset ( )  :  void
FileBackedOutputStream.write ( byte[ ] b )  :  void
FileBackedOutputStream.write ( byte[ ] b, int off, int len )  :  void
FileBackedOutputStream.write ( int b )  :  void

cdk-1.5.3.jar, Files.class
package com.google.common.io
Files.append ( CharSequence from, File to, Charset charset ) [static]  :  void
Files.asByteSink ( File file, FileWriteMode[ ] modes ) [static]  :  ByteSink
Files.asByteSource ( File file ) [static]  :  ByteSource
Files.asCharSink ( File file, Charset charset, FileWriteMode[ ] modes ) [static]  :  CharSink
Files.asCharSource ( File file, Charset charset ) [static]  :  CharSource
Files.copy ( File from, Charset charset, Appendable to ) [static]  :  void
Files.copy ( File from, Charset charset, OutputSupplier to ) [static]  :  void
Files.copy ( File from, File to ) [static]  :  void
Files.copy ( File from, OutputStream to ) [static]  :  void
Files.copy ( File from, OutputSupplier to ) [static]  :  void
Files.copy ( InputSupplier from, File to ) [static]  :  void
Files.copy ( InputSupplier from, File to, Charset charset ) [static]  :  void
Files.createParentDirs ( File file ) [static]  :  void
Files.createTempDir ( ) [static]  :  File
Files.equal ( File file1, File file2 ) [static]  :  boolean
Files.getChecksum ( File file, Checksum checksum ) [static]  :  long *DEPRECATED*
Files.getFileExtension ( String fullName ) [static]  :  String
Files.getNameWithoutExtension ( String file ) [static]  :  String
Files.hash ( File file, HashFunction hashFunction ) [static]  :  HashCode
Files.map ( File file ) [static]  :  MappedByteBuffer
Files.map ( File file, FileChannel.MapMode mode ) [static]  :  MappedByteBuffer
Files.map ( File file, FileChannel.MapMode mode, long size ) [static]  :  MappedByteBuffer
Files.move ( File from, File to ) [static]  :  void
Files.newInputStreamSupplier ( File file ) [static]  :  InputSupplier
Files.newOutputStreamSupplier ( File file ) [static]  :  OutputSupplier
Files.newOutputStreamSupplier ( File file, boolean append ) [static]  :  OutputSupplier
Files.newReader ( File file, Charset charset ) [static]  :  BufferedReader
Files.newReaderSupplier ( File file, Charset charset ) [static]  :  InputSupplier
Files.newWriter ( File file, Charset charset ) [static]  :  BufferedWriter
Files.newWriterSupplier ( File file, Charset charset ) [static]  :  OutputSupplier
Files.newWriterSupplier ( File file, Charset charset, boolean append ) [static]  :  OutputSupplier
Files.readBytes ( File file, ByteProcessor processor ) [static]  :  Object
Files.readFirstLine ( File file, Charset charset ) [static]  :  String
Files.readLines ( File file, Charset charset ) [static]  :  List
Files.readLines ( File file, Charset charset, LineProcessor callback ) [static]  :  Object
Files.simplifyPath ( String pathname ) [static]  :  String
Files.toByteArray ( File file ) [static]  :  byte[ ]
Files.toString ( File file, Charset charset ) [static]  :  String
Files.touch ( File file ) [static]  :  void
Files.write ( byte[ ] from, File to ) [static]  :  void
Files.write ( CharSequence from, File to, Charset charset ) [static]  :  void

cdk-1.5.3.jar, FileWriteMode.class
package com.google.common.io
FileWriteMode.valueOf ( String name ) [static]  :  FileWriteMode
FileWriteMode.values ( ) [static]  :  FileWriteMode[ ]

cdk-1.5.3.jar, FinalizablePhantomReference.class
package com.google.common.base
FinalizablePhantomReference.FinalizablePhantomReference ( Object referent, FinalizableReferenceQueue queue )

cdk-1.5.3.jar, FinalizableReference.class
package com.google.common.base
FinalizableReference.finalizeReferent ( ) [abstract]  :  void

cdk-1.5.3.jar, FinalizableReferenceQueue.class
package com.google.common.base
FinalizableReferenceQueue.close ( )  :  void
FinalizableReferenceQueue.FinalizableReferenceQueue ( )

cdk-1.5.3.jar, FinalizableSoftReference.class
package com.google.common.base
FinalizableSoftReference.FinalizableSoftReference ( Object referent, FinalizableReferenceQueue queue )

cdk-1.5.3.jar, FinalizableWeakReference.class
package com.google.common.base
FinalizableWeakReference.FinalizableWeakReference ( Object referent, FinalizableReferenceQueue queue )

cdk-1.5.3.jar, Floats.class
package com.google.common.primitives
Floats.asList ( float[ ] backingArray ) [static]  :  List
Floats.compare ( float a, float b ) [static]  :  int
Floats.concat ( float[ ][ ] arrays ) [static]  :  float[ ]
Floats.contains ( float[ ] array, float target ) [static]  :  boolean
Floats.ensureCapacity ( float[ ] array, int minLength, int padding ) [static]  :  float[ ]
Floats.hashCode ( float value ) [static]  :  int
Floats.indexOf ( float[ ] array, float target ) [static]  :  int
Floats.indexOf ( float[ ] array, float[ ] target ) [static]  :  int
Floats.isFinite ( float value ) [static]  :  boolean
Floats.join ( String separator, float[ ] array ) [static]  :  String
Floats.lastIndexOf ( float[ ] array, float target ) [static]  :  int
Floats.lexicographicalComparator ( ) [static]  :  Comparator
Floats.max ( float[ ] array ) [static]  :  float
Floats.min ( float[ ] array ) [static]  :  float
Floats.toArray ( Collection collection ) [static]  :  float[ ]
Floats.tryParse ( String string ) [static]  :  Float

cdk-1.5.3.jar, FluentIterable.class
package com.google.common.collect
FluentIterable.allMatch ( Predicate predicate )  :  boolean
FluentIterable.anyMatch ( Predicate predicate )  :  boolean
FluentIterable.contains ( Object element )  :  boolean
FluentIterable.copyInto ( Collection collection )  :  Collection
FluentIterable.cycle ( )  :  FluentIterable
FluentIterable.filter ( Class type )  :  FluentIterable
FluentIterable.filter ( Predicate predicate )  :  FluentIterable
FluentIterable.first ( )  :  Optional
FluentIterable.firstMatch ( Predicate predicate )  :  Optional
FluentIterable.FluentIterable ( )
FluentIterable.from ( FluentIterable iterable ) [static]  :  FluentIterable *DEPRECATED*
FluentIterable.from ( Iterable iterable ) [static]  :  FluentIterable
FluentIterable.get ( int position )  :  Object
FluentIterable.index ( Function keyFunction )  :  ImmutableListMultimap
FluentIterable.isEmpty ( )  :  boolean
FluentIterable.last ( )  :  Optional
FluentIterable.limit ( int size )  :  FluentIterable
FluentIterable.size ( )  :  int
FluentIterable.skip ( int numberToSkip )  :  FluentIterable
FluentIterable.toArray ( Class type )  :  Object[ ]
FluentIterable.toImmutableList ( )  :  ImmutableList *DEPRECATED*
FluentIterable.toImmutableSet ( )  :  ImmutableSet *DEPRECATED*
FluentIterable.toImmutableSortedSet ( Comparator comparator )  :  ImmutableSortedSet *DEPRECATED*
FluentIterable.toList ( )  :  ImmutableList
FluentIterable.toMap ( Function valueFunction )  :  ImmutableMap
FluentIterable.toSet ( )  :  ImmutableSet
FluentIterable.toSortedImmutableList ( Comparator comparator )  :  ImmutableList *DEPRECATED*
FluentIterable.toSortedList ( Comparator comparator )  :  ImmutableList
FluentIterable.toSortedSet ( Comparator comparator )  :  ImmutableSortedSet
FluentIterable.toString ( )  :  String
FluentIterable.transform ( Function function )  :  FluentIterable
FluentIterable.transformAndConcat ( Function function )  :  FluentIterable
FluentIterable.uniqueIndex ( Function keyFunction )  :  ImmutableMap

cdk-1.5.3.jar, Flushables.class
package com.google.common.io
Flushables.flush ( Flushable flushable, boolean swallowIOException ) [static]  :  void
Flushables.flushQuietly ( Flushable flushable ) [static]  :  void

cdk-1.5.3.jar, ForwardingBlockingDeque.class
package com.google.common.collect
ForwardingBlockingDeque.delegate ( )  :  Collection
ForwardingBlockingDeque.delegate ( )  :  Deque
ForwardingBlockingDeque.delegate ( )  :  Object
ForwardingBlockingDeque.delegate ( )  :  Queue
ForwardingBlockingDeque.delegate ( ) [abstract]  :  BlockingDeque
ForwardingBlockingDeque.drainTo ( Collection c )  :  int
ForwardingBlockingDeque.drainTo ( Collection c, int maxElements )  :  int
ForwardingBlockingDeque.ForwardingBlockingDeque ( )
ForwardingBlockingDeque.offer ( Object e, long timeout, TimeUnit unit )  :  boolean
ForwardingBlockingDeque.offerFirst ( Object e, long timeout, TimeUnit unit )  :  boolean
ForwardingBlockingDeque.offerLast ( Object e, long timeout, TimeUnit unit )  :  boolean
ForwardingBlockingDeque.poll ( long timeout, TimeUnit unit )  :  Object
ForwardingBlockingDeque.pollFirst ( long timeout, TimeUnit unit )  :  Object
ForwardingBlockingDeque.pollLast ( long timeout, TimeUnit unit )  :  Object
ForwardingBlockingDeque.put ( Object e )  :  void
ForwardingBlockingDeque.putFirst ( Object e )  :  void
ForwardingBlockingDeque.putLast ( Object e )  :  void
ForwardingBlockingDeque.remainingCapacity ( )  :  int
ForwardingBlockingDeque.take ( )  :  Object
ForwardingBlockingDeque.takeFirst ( )  :  Object
ForwardingBlockingDeque.takeLast ( )  :  Object

cdk-1.5.3.jar, ForwardingBlockingQueue.class
package com.google.common.util.concurrent
ForwardingBlockingQueue.delegate ( )  :  Collection
ForwardingBlockingQueue.delegate ( )  :  Object
ForwardingBlockingQueue.delegate ( )  :  Queue
ForwardingBlockingQueue.delegate ( ) [abstract]  :  BlockingQueue
ForwardingBlockingQueue.drainTo ( Collection c )  :  int
ForwardingBlockingQueue.drainTo ( Collection c, int maxElements )  :  int
ForwardingBlockingQueue.ForwardingBlockingQueue ( )
ForwardingBlockingQueue.offer ( Object e, long timeout, TimeUnit unit )  :  boolean
ForwardingBlockingQueue.poll ( long timeout, TimeUnit unit )  :  Object
ForwardingBlockingQueue.put ( Object e )  :  void
ForwardingBlockingQueue.remainingCapacity ( )  :  int
ForwardingBlockingQueue.take ( )  :  Object

cdk-1.5.3.jar, ForwardingCache.class
package com.google.common.cache
ForwardingCache.asMap ( )  :  ConcurrentMap
ForwardingCache.cleanUp ( )  :  void
ForwardingCache.delegate ( )  :  Object
ForwardingCache.delegate ( ) [abstract]  :  Cache
ForwardingCache.ForwardingCache ( )
ForwardingCache.get ( Object key, Callable valueLoader )  :  Object
ForwardingCache.getAllPresent ( Iterable keys )  :  ImmutableMap
ForwardingCache.getIfPresent ( Object key )  :  Object
ForwardingCache.invalidate ( Object key )  :  void
ForwardingCache.invalidateAll ( )  :  void
ForwardingCache.invalidateAll ( Iterable keys )  :  void
ForwardingCache.put ( Object key, Object value )  :  void
ForwardingCache.putAll ( Map m )  :  void
ForwardingCache.size ( )  :  long
ForwardingCache.stats ( )  :  CacheStats

cdk-1.5.3.jar, ForwardingCheckedFuture.class
package com.google.common.util.concurrent
ForwardingCheckedFuture.checkedGet ( )  :  Object
ForwardingCheckedFuture.checkedGet ( long timeout, TimeUnit unit )  :  Object
ForwardingCheckedFuture.delegate ( )  :  Future
ForwardingCheckedFuture.delegate ( )  :  ListenableFuture
ForwardingCheckedFuture.delegate ( )  :  Object
ForwardingCheckedFuture.delegate ( ) [abstract]  :  CheckedFuture
ForwardingCheckedFuture.ForwardingCheckedFuture ( )

cdk-1.5.3.jar, ForwardingCollection.class
package com.google.common.collect
ForwardingCollection.add ( Object element )  :  boolean
ForwardingCollection.addAll ( Collection collection )  :  boolean
ForwardingCollection.clear ( )  :  void
ForwardingCollection.contains ( Object object )  :  boolean
ForwardingCollection.containsAll ( Collection collection )  :  boolean
ForwardingCollection.delegate ( )  :  Object
ForwardingCollection.delegate ( ) [abstract]  :  Collection
ForwardingCollection.ForwardingCollection ( )
ForwardingCollection.isEmpty ( )  :  boolean
ForwardingCollection.iterator ( )  :  Iterator
ForwardingCollection.remove ( Object object )  :  boolean
ForwardingCollection.removeAll ( Collection collection )  :  boolean
ForwardingCollection.retainAll ( Collection collection )  :  boolean
ForwardingCollection.size ( )  :  int
ForwardingCollection.standardAddAll ( Collection collection )  :  boolean
ForwardingCollection.standardClear ( )  :  void
ForwardingCollection.standardContains ( Object object )  :  boolean
ForwardingCollection.standardContainsAll ( Collection collection )  :  boolean
ForwardingCollection.standardIsEmpty ( )  :  boolean
ForwardingCollection.standardRemove ( Object object )  :  boolean
ForwardingCollection.standardRemoveAll ( Collection collection )  :  boolean
ForwardingCollection.standardRetainAll ( Collection collection )  :  boolean
ForwardingCollection.standardToArray ( )  :  Object[ ]
ForwardingCollection.standardToArray ( Object[ ] array )  :  Object[ ]
ForwardingCollection.standardToString ( )  :  String
ForwardingCollection.toArray ( )  :  Object[ ]
ForwardingCollection.toArray ( Object[ ] array )  :  Object[ ]

cdk-1.5.3.jar, ForwardingConcurrentMap.class
package com.google.common.collect
ForwardingConcurrentMap.delegate ( )  :  Map
ForwardingConcurrentMap.delegate ( )  :  Object
ForwardingConcurrentMap.delegate ( ) [abstract]  :  ConcurrentMap
ForwardingConcurrentMap.ForwardingConcurrentMap ( )
ForwardingConcurrentMap.putIfAbsent ( Object key, Object value )  :  Object
ForwardingConcurrentMap.remove ( Object key, Object value )  :  boolean
ForwardingConcurrentMap.replace ( Object key, Object oldValue, Object newValue )  :  boolean
ForwardingConcurrentMap.replace ( Object key, Object value )  :  Object

cdk-1.5.3.jar, ForwardingDeque.class
package com.google.common.collect
ForwardingDeque.addFirst ( Object e )  :  void
ForwardingDeque.addLast ( Object e )  :  void
ForwardingDeque.delegate ( )  :  Collection
ForwardingDeque.delegate ( )  :  Object
ForwardingDeque.delegate ( )  :  Queue
ForwardingDeque.delegate ( ) [abstract]  :  Deque
ForwardingDeque.descendingIterator ( )  :  Iterator
ForwardingDeque.ForwardingDeque ( )
ForwardingDeque.getFirst ( )  :  Object
ForwardingDeque.getLast ( )  :  Object
ForwardingDeque.offerFirst ( Object e )  :  boolean
ForwardingDeque.offerLast ( Object e )  :  boolean
ForwardingDeque.peekFirst ( )  :  Object
ForwardingDeque.peekLast ( )  :  Object
ForwardingDeque.pollFirst ( )  :  Object
ForwardingDeque.pollLast ( )  :  Object
ForwardingDeque.pop ( )  :  Object
ForwardingDeque.push ( Object e )  :  void
ForwardingDeque.removeFirst ( )  :  Object
ForwardingDeque.removeFirstOccurrence ( Object o )  :  boolean
ForwardingDeque.removeLast ( )  :  Object
ForwardingDeque.removeLastOccurrence ( Object o )  :  boolean

cdk-1.5.3.jar, ForwardingExecutorService.class
package com.google.common.util.concurrent
ForwardingExecutorService.awaitTermination ( long timeout, TimeUnit unit )  :  boolean
ForwardingExecutorService.delegate ( )  :  Object
ForwardingExecutorService.delegate ( ) [abstract]  :  ExecutorService
ForwardingExecutorService.execute ( Runnable command )  :  void
ForwardingExecutorService.ForwardingExecutorService ( )
ForwardingExecutorService.invokeAll ( Collection tasks )  :  List
ForwardingExecutorService.invokeAll ( Collection tasks, long timeout, TimeUnit unit )  :  List
ForwardingExecutorService.invokeAny ( Collection tasks )  :  Object
ForwardingExecutorService.invokeAny ( Collection tasks, long timeout, TimeUnit unit )  :  Object
ForwardingExecutorService.isShutdown ( )  :  boolean
ForwardingExecutorService.isTerminated ( )  :  boolean
ForwardingExecutorService.shutdown ( )  :  void
ForwardingExecutorService.shutdownNow ( )  :  List
ForwardingExecutorService.submit ( Callable task )  :  Future
ForwardingExecutorService.submit ( Runnable task )  :  Future
ForwardingExecutorService.submit ( Runnable task, Object result )  :  Future

cdk-1.5.3.jar, ForwardingFuture.class
package com.google.common.util.concurrent
ForwardingFuture.cancel ( boolean mayInterruptIfRunning )  :  boolean
ForwardingFuture.delegate ( )  :  Object
ForwardingFuture.delegate ( ) [abstract]  :  Future
ForwardingFuture.ForwardingFuture ( )
ForwardingFuture.get ( )  :  Object
ForwardingFuture.get ( long timeout, TimeUnit unit )  :  Object
ForwardingFuture.isCancelled ( )  :  boolean
ForwardingFuture.isDone ( )  :  boolean

cdk-1.5.3.jar, ForwardingIterator.class
package com.google.common.collect
ForwardingIterator.delegate ( )  :  Object
ForwardingIterator.delegate ( ) [abstract]  :  Iterator
ForwardingIterator.ForwardingIterator ( )
ForwardingIterator.hasNext ( )  :  boolean
ForwardingIterator.next ( )  :  Object
ForwardingIterator.remove ( )  :  void

cdk-1.5.3.jar, ForwardingList.class
package com.google.common.collect
ForwardingList.add ( int index, Object element )  :  void
ForwardingList.addAll ( int index, Collection elements )  :  boolean
ForwardingList.delegate ( )  :  Collection
ForwardingList.delegate ( )  :  Object
ForwardingList.delegate ( ) [abstract]  :  List
ForwardingList.equals ( Object object )  :  boolean
ForwardingList.ForwardingList ( )
ForwardingList.get ( int index )  :  Object
ForwardingList.hashCode ( )  :  int
ForwardingList.indexOf ( Object element )  :  int
ForwardingList.lastIndexOf ( Object element )  :  int
ForwardingList.listIterator ( )  :  ListIterator
ForwardingList.listIterator ( int index )  :  ListIterator
ForwardingList.remove ( int index )  :  Object
ForwardingList.set ( int index, Object element )  :  Object
ForwardingList.standardAdd ( Object element )  :  boolean
ForwardingList.standardAddAll ( int index, Iterable elements )  :  boolean
ForwardingList.standardEquals ( Object object )  :  boolean
ForwardingList.standardHashCode ( )  :  int
ForwardingList.standardIndexOf ( Object element )  :  int
ForwardingList.standardIterator ( )  :  Iterator
ForwardingList.standardLastIndexOf ( Object element )  :  int
ForwardingList.standardListIterator ( )  :  ListIterator
ForwardingList.standardListIterator ( int start )  :  ListIterator
ForwardingList.standardSubList ( int fromIndex, int toIndex )  :  List
ForwardingList.subList ( int fromIndex, int toIndex )  :  List

cdk-1.5.3.jar, ForwardingListenableFuture.class
package com.google.common.util.concurrent
ForwardingListenableFuture.addListener ( Runnable listener, Executor exec )  :  void
ForwardingListenableFuture.delegate ( )  :  Future
ForwardingListenableFuture.delegate ( )  :  Object
ForwardingListenableFuture.delegate ( ) [abstract]  :  ListenableFuture
ForwardingListenableFuture.ForwardingListenableFuture ( )

cdk-1.5.3.jar, ForwardingListeningExecutorService.class
package com.google.common.util.concurrent
ForwardingListeningExecutorService.delegate ( )  :  ExecutorService
ForwardingListeningExecutorService.delegate ( )  :  Object
ForwardingListeningExecutorService.delegate ( ) [abstract]  :  ListeningExecutorService
ForwardingListeningExecutorService.ForwardingListeningExecutorService ( )
ForwardingListeningExecutorService.submit ( Callable task )  :  ListenableFuture
ForwardingListeningExecutorService.submit ( Callable x0 )  :  Future
ForwardingListeningExecutorService.submit ( Runnable task )  :  ListenableFuture
ForwardingListeningExecutorService.submit ( Runnable task, Object result )  :  ListenableFuture
ForwardingListeningExecutorService.submit ( Runnable x0 )  :  Future
ForwardingListeningExecutorService.submit ( Runnable x0, Object x1 )  :  Future

cdk-1.5.3.jar, ForwardingListIterator.class
package com.google.common.collect
ForwardingListIterator.add ( Object element )  :  void
ForwardingListIterator.delegate ( )  :  Iterator
ForwardingListIterator.delegate ( )  :  Object
ForwardingListIterator.delegate ( ) [abstract]  :  ListIterator
ForwardingListIterator.ForwardingListIterator ( )
ForwardingListIterator.hasPrevious ( )  :  boolean
ForwardingListIterator.nextIndex ( )  :  int
ForwardingListIterator.previous ( )  :  Object
ForwardingListIterator.previousIndex ( )  :  int
ForwardingListIterator.set ( Object element )  :  void

cdk-1.5.3.jar, ForwardingListMultimap.class
package com.google.common.collect
ForwardingListMultimap.delegate ( )  :  Multimap
ForwardingListMultimap.delegate ( )  :  Object
ForwardingListMultimap.delegate ( ) [abstract]  :  ListMultimap
ForwardingListMultimap.ForwardingListMultimap ( )
ForwardingListMultimap.get ( Object key )  :  List
ForwardingListMultimap.get ( Object x0 )  :  Collection
ForwardingListMultimap.removeAll ( Object key )  :  List
ForwardingListMultimap.removeAll ( Object x0 )  :  Collection
ForwardingListMultimap.replaceValues ( Object key, Iterable values )  :  List
ForwardingListMultimap.replaceValues ( Object x0, Iterable x1 )  :  Collection

cdk-1.5.3.jar, ForwardingLoadingCache.class
package com.google.common.cache
ForwardingLoadingCache.apply ( Object key )  :  Object
ForwardingLoadingCache.delegate ( )  :  Cache
ForwardingLoadingCache.delegate ( )  :  Object
ForwardingLoadingCache.delegate ( ) [abstract]  :  LoadingCache
ForwardingLoadingCache.ForwardingLoadingCache ( )
ForwardingLoadingCache.get ( Object key )  :  Object
ForwardingLoadingCache.getAll ( Iterable keys )  :  ImmutableMap
ForwardingLoadingCache.getUnchecked ( Object key )  :  Object
ForwardingLoadingCache.refresh ( Object key )  :  void

cdk-1.5.3.jar, ForwardingMap.class
package com.google.common.collect
ForwardingMap.clear ( )  :  void
ForwardingMap.containsKey ( Object key )  :  boolean
ForwardingMap.containsValue ( Object value )  :  boolean
ForwardingMap.delegate ( )  :  Object
ForwardingMap.delegate ( ) [abstract]  :  Map
ForwardingMap.entrySet ( )  :  Set
ForwardingMap.equals ( Object object )  :  boolean
ForwardingMap.ForwardingMap ( )
ForwardingMap.get ( Object key )  :  Object
ForwardingMap.hashCode ( )  :  int
ForwardingMap.isEmpty ( )  :  boolean
ForwardingMap.keySet ( )  :  Set
ForwardingMap.put ( Object key, Object value )  :  Object
ForwardingMap.putAll ( Map map )  :  void
ForwardingMap.remove ( Object object )  :  Object
ForwardingMap.size ( )  :  int
ForwardingMap.standardClear ( )  :  void
ForwardingMap.standardContainsKey ( Object key )  :  boolean
ForwardingMap.standardContainsValue ( Object value )  :  boolean
ForwardingMap.standardEquals ( Object object )  :  boolean
ForwardingMap.standardHashCode ( )  :  int
ForwardingMap.standardIsEmpty ( )  :  boolean
ForwardingMap.standardPutAll ( Map map )  :  void
ForwardingMap.standardRemove ( Object key )  :  Object
ForwardingMap.standardToString ( )  :  String
ForwardingMap.values ( )  :  Collection

cdk-1.5.3.jar, ForwardingMapEntry.class
package com.google.common.collect
ForwardingMapEntry.delegate ( )  :  Object
ForwardingMapEntry.delegate ( ) [abstract]  :  Map.Entry
ForwardingMapEntry.equals ( Object object )  :  boolean
ForwardingMapEntry.ForwardingMapEntry ( )
ForwardingMapEntry.getKey ( )  :  Object
ForwardingMapEntry.getValue ( )  :  Object
ForwardingMapEntry.hashCode ( )  :  int
ForwardingMapEntry.setValue ( Object value )  :  Object
ForwardingMapEntry.standardEquals ( Object object )  :  boolean
ForwardingMapEntry.standardHashCode ( )  :  int
ForwardingMapEntry.standardToString ( )  :  String

cdk-1.5.3.jar, ForwardingMultimap.class
package com.google.common.collect
ForwardingMultimap.asMap ( )  :  Map
ForwardingMultimap.clear ( )  :  void
ForwardingMultimap.containsEntry ( Object key, Object value )  :  boolean
ForwardingMultimap.containsKey ( Object key )  :  boolean
ForwardingMultimap.containsValue ( Object value )  :  boolean
ForwardingMultimap.delegate ( )  :  Object
ForwardingMultimap.delegate ( ) [abstract]  :  Multimap
ForwardingMultimap.entries ( )  :  Collection
ForwardingMultimap.equals ( Object object )  :  boolean
ForwardingMultimap.ForwardingMultimap ( )
ForwardingMultimap.get ( Object key )  :  Collection
ForwardingMultimap.hashCode ( )  :  int
ForwardingMultimap.isEmpty ( )  :  boolean
ForwardingMultimap.keys ( )  :  Multiset
ForwardingMultimap.keySet ( )  :  Set
ForwardingMultimap.put ( Object key, Object value )  :  boolean
ForwardingMultimap.putAll ( Multimap multimap )  :  boolean
ForwardingMultimap.putAll ( Object key, Iterable values )  :  boolean
ForwardingMultimap.remove ( Object key, Object value )  :  boolean
ForwardingMultimap.removeAll ( Object key )  :  Collection
ForwardingMultimap.replaceValues ( Object key, Iterable values )  :  Collection
ForwardingMultimap.size ( )  :  int
ForwardingMultimap.values ( )  :  Collection

cdk-1.5.3.jar, ForwardingMultiset.class
package com.google.common.collect
ForwardingMultiset.add ( Object element, int occurrences )  :  int
ForwardingMultiset.count ( Object element )  :  int
ForwardingMultiset.delegate ( )  :  Collection
ForwardingMultiset.delegate ( )  :  Object
ForwardingMultiset.delegate ( ) [abstract]  :  Multiset
ForwardingMultiset.elementSet ( )  :  Set
ForwardingMultiset.entrySet ( )  :  Set
ForwardingMultiset.equals ( Object object )  :  boolean
ForwardingMultiset.ForwardingMultiset ( )
ForwardingMultiset.hashCode ( )  :  int
ForwardingMultiset.remove ( Object element, int occurrences )  :  int
ForwardingMultiset.setCount ( Object element, int count )  :  int
ForwardingMultiset.setCount ( Object element, int oldCount, int newCount )  :  boolean
ForwardingMultiset.standardAdd ( Object element )  :  boolean
ForwardingMultiset.standardAddAll ( Collection elementsToAdd )  :  boolean
ForwardingMultiset.standardClear ( )  :  void
ForwardingMultiset.standardContains ( Object object )  :  boolean
ForwardingMultiset.standardCount ( Object object )  :  int
ForwardingMultiset.standardEquals ( Object object )  :  boolean
ForwardingMultiset.standardHashCode ( )  :  int
ForwardingMultiset.standardIterator ( )  :  Iterator
ForwardingMultiset.standardRemove ( Object element )  :  boolean
ForwardingMultiset.standardRemoveAll ( Collection elementsToRemove )  :  boolean
ForwardingMultiset.standardRetainAll ( Collection elementsToRetain )  :  boolean
ForwardingMultiset.standardSetCount ( Object element, int count )  :  int
ForwardingMultiset.standardSetCount ( Object element, int oldCount, int newCount )  :  boolean
ForwardingMultiset.standardSize ( )  :  int
ForwardingMultiset.standardToString ( )  :  String

cdk-1.5.3.jar, ForwardingNavigableMap.class
package com.google.common.collect
ForwardingNavigableMap.ceilingEntry ( Object key )  :  Map.Entry
ForwardingNavigableMap.ceilingKey ( Object key )  :  Object
ForwardingNavigableMap.delegate ( )  :  Map
ForwardingNavigableMap.delegate ( )  :  Object
ForwardingNavigableMap.delegate ( )  :  SortedMap
ForwardingNavigableMap.delegate ( ) [abstract]  :  NavigableMap
ForwardingNavigableMap.descendingKeySet ( )  :  NavigableSet
ForwardingNavigableMap.descendingMap ( )  :  NavigableMap
ForwardingNavigableMap.firstEntry ( )  :  Map.Entry
ForwardingNavigableMap.floorEntry ( Object key )  :  Map.Entry
ForwardingNavigableMap.floorKey ( Object key )  :  Object
ForwardingNavigableMap.ForwardingNavigableMap ( )
ForwardingNavigableMap.headMap ( Object toKey, boolean inclusive )  :  NavigableMap
ForwardingNavigableMap.higherEntry ( Object key )  :  Map.Entry
ForwardingNavigableMap.higherKey ( Object key )  :  Object
ForwardingNavigableMap.lastEntry ( )  :  Map.Entry
ForwardingNavigableMap.lowerEntry ( Object key )  :  Map.Entry
ForwardingNavigableMap.lowerKey ( Object key )  :  Object
ForwardingNavigableMap.navigableKeySet ( )  :  NavigableSet
ForwardingNavigableMap.pollFirstEntry ( )  :  Map.Entry
ForwardingNavigableMap.pollLastEntry ( )  :  Map.Entry
ForwardingNavigableMap.standardCeilingEntry ( Object key )  :  Map.Entry
ForwardingNavigableMap.standardCeilingKey ( Object key )  :  Object
ForwardingNavigableMap.standardDescendingKeySet ( )  :  NavigableSet
ForwardingNavigableMap.standardFirstEntry ( )  :  Map.Entry
ForwardingNavigableMap.standardFirstKey ( )  :  Object
ForwardingNavigableMap.standardFloorEntry ( Object key )  :  Map.Entry
ForwardingNavigableMap.standardFloorKey ( Object key )  :  Object
ForwardingNavigableMap.standardHeadMap ( Object toKey )  :  SortedMap
ForwardingNavigableMap.standardHigherEntry ( Object key )  :  Map.Entry
ForwardingNavigableMap.standardHigherKey ( Object key )  :  Object
ForwardingNavigableMap.standardLastEntry ( )  :  Map.Entry
ForwardingNavigableMap.standardLastKey ( )  :  Object
ForwardingNavigableMap.standardLowerEntry ( Object key )  :  Map.Entry
ForwardingNavigableMap.standardLowerKey ( Object key )  :  Object
ForwardingNavigableMap.standardPollFirstEntry ( )  :  Map.Entry
ForwardingNavigableMap.standardPollLastEntry ( )  :  Map.Entry
ForwardingNavigableMap.standardSubMap ( Object fromKey, Object toKey )  :  SortedMap
ForwardingNavigableMap.standardTailMap ( Object fromKey )  :  SortedMap
ForwardingNavigableMap.subMap ( Object fromKey, boolean fromInclusive, Object toKey, boolean toInclusive )  :  NavigableMap
ForwardingNavigableMap.tailMap ( Object fromKey, boolean inclusive )  :  NavigableMap

cdk-1.5.3.jar, ForwardingNavigableSet.class
package com.google.common.collect
ForwardingNavigableSet.ceiling ( Object e )  :  Object
ForwardingNavigableSet.delegate ( )  :  Collection
ForwardingNavigableSet.delegate ( )  :  Object
ForwardingNavigableSet.delegate ( )  :  Set
ForwardingNavigableSet.delegate ( )  :  SortedSet
ForwardingNavigableSet.delegate ( ) [abstract]  :  NavigableSet
ForwardingNavigableSet.descendingIterator ( )  :  Iterator
ForwardingNavigableSet.descendingSet ( )  :  NavigableSet
ForwardingNavigableSet.floor ( Object e )  :  Object
ForwardingNavigableSet.ForwardingNavigableSet ( )
ForwardingNavigableSet.headSet ( Object toElement, boolean inclusive )  :  NavigableSet
ForwardingNavigableSet.higher ( Object e )  :  Object
ForwardingNavigableSet.lower ( Object e )  :  Object
ForwardingNavigableSet.pollFirst ( )  :  Object
ForwardingNavigableSet.pollLast ( )  :  Object
ForwardingNavigableSet.standardCeiling ( Object e )  :  Object
ForwardingNavigableSet.standardFirst ( )  :  Object
ForwardingNavigableSet.standardFloor ( Object e )  :  Object
ForwardingNavigableSet.standardHeadSet ( Object toElement )  :  SortedSet
ForwardingNavigableSet.standardHigher ( Object e )  :  Object
ForwardingNavigableSet.standardLast ( )  :  Object
ForwardingNavigableSet.standardLower ( Object e )  :  Object
ForwardingNavigableSet.standardPollFirst ( )  :  Object
ForwardingNavigableSet.standardPollLast ( )  :  Object
ForwardingNavigableSet.standardSubSet ( Object fromElement, boolean fromInclusive, Object toElement, boolean toInclusive )  :  NavigableSet
ForwardingNavigableSet.standardSubSet ( Object fromElement, Object toElement )  :  SortedSet
ForwardingNavigableSet.standardTailSet ( Object fromElement )  :  SortedSet
ForwardingNavigableSet.subSet ( Object fromElement, boolean fromInclusive, Object toElement, boolean toInclusive )  :  NavigableSet
ForwardingNavigableSet.tailSet ( Object fromElement, boolean inclusive )  :  NavigableSet

cdk-1.5.3.jar, ForwardingObject.class
package com.google.common.collect
ForwardingObject.delegate ( ) [abstract]  :  Object
ForwardingObject.ForwardingObject ( )
ForwardingObject.toString ( )  :  String

cdk-1.5.3.jar, ForwardingQueue.class
package com.google.common.collect
ForwardingQueue.delegate ( )  :  Collection
ForwardingQueue.delegate ( )  :  Object
ForwardingQueue.delegate ( ) [abstract]  :  Queue
ForwardingQueue.element ( )  :  Object
ForwardingQueue.ForwardingQueue ( )
ForwardingQueue.offer ( Object o )  :  boolean
ForwardingQueue.peek ( )  :  Object
ForwardingQueue.poll ( )  :  Object
ForwardingQueue.remove ( )  :  Object
ForwardingQueue.standardOffer ( Object e )  :  boolean
ForwardingQueue.standardPeek ( )  :  Object
ForwardingQueue.standardPoll ( )  :  Object

cdk-1.5.3.jar, ForwardingService.class
package com.google.common.util.concurrent
ForwardingService.addListener ( Service.Listener listener, Executor executor )  :  void
ForwardingService.delegate ( )  :  Object
ForwardingService.delegate ( ) [abstract]  :  Service
ForwardingService.failureCause ( )  :  Throwable
ForwardingService.ForwardingService ( )
ForwardingService.isRunning ( )  :  boolean
ForwardingService.standardStartAndWait ( )  :  Service.State
ForwardingService.standardStopAndWait ( )  :  Service.State
ForwardingService.start ( )  :  ListenableFuture
ForwardingService.startAndWait ( )  :  Service.State
ForwardingService.state ( )  :  Service.State
ForwardingService.stop ( )  :  ListenableFuture
ForwardingService.stopAndWait ( )  :  Service.State

cdk-1.5.3.jar, ForwardingSet.class
package com.google.common.collect
ForwardingSet.delegate ( )  :  Collection
ForwardingSet.delegate ( )  :  Object
ForwardingSet.delegate ( ) [abstract]  :  Set
ForwardingSet.equals ( Object object )  :  boolean
ForwardingSet.ForwardingSet ( )
ForwardingSet.hashCode ( )  :  int
ForwardingSet.standardEquals ( Object object )  :  boolean
ForwardingSet.standardHashCode ( )  :  int
ForwardingSet.standardRemoveAll ( Collection collection )  :  boolean

cdk-1.5.3.jar, ForwardingSetMultimap.class
package com.google.common.collect
ForwardingSetMultimap.delegate ( )  :  Multimap
ForwardingSetMultimap.delegate ( )  :  Object
ForwardingSetMultimap.delegate ( ) [abstract]  :  SetMultimap
ForwardingSetMultimap.entries ( )  :  Collection
ForwardingSetMultimap.entries ( )  :  Set
ForwardingSetMultimap.ForwardingSetMultimap ( )
ForwardingSetMultimap.get ( Object key )  :  Set
ForwardingSetMultimap.get ( Object x0 )  :  Collection
ForwardingSetMultimap.removeAll ( Object key )  :  Set
ForwardingSetMultimap.removeAll ( Object x0 )  :  Collection
ForwardingSetMultimap.replaceValues ( Object key, Iterable values )  :  Set
ForwardingSetMultimap.replaceValues ( Object x0, Iterable x1 )  :  Collection

cdk-1.5.3.jar, ForwardingSortedMap.class
package com.google.common.collect
ForwardingSortedMap.comparator ( )  :  Comparator
ForwardingSortedMap.delegate ( )  :  Map
ForwardingSortedMap.delegate ( )  :  Object
ForwardingSortedMap.delegate ( ) [abstract]  :  SortedMap
ForwardingSortedMap.firstKey ( )  :  Object
ForwardingSortedMap.ForwardingSortedMap ( )
ForwardingSortedMap.headMap ( Object toKey )  :  SortedMap
ForwardingSortedMap.lastKey ( )  :  Object
ForwardingSortedMap.standardContainsKey ( Object key )  :  boolean
ForwardingSortedMap.standardRemove ( Object key )  :  Object
ForwardingSortedMap.standardSubMap ( Object fromKey, Object toKey )  :  SortedMap
ForwardingSortedMap.subMap ( Object fromKey, Object toKey )  :  SortedMap
ForwardingSortedMap.tailMap ( Object fromKey )  :  SortedMap

cdk-1.5.3.jar, ForwardingSortedSet.class
package com.google.common.collect
ForwardingSortedSet.comparator ( )  :  Comparator
ForwardingSortedSet.delegate ( )  :  Collection
ForwardingSortedSet.delegate ( )  :  Object
ForwardingSortedSet.delegate ( )  :  Set
ForwardingSortedSet.delegate ( ) [abstract]  :  SortedSet
ForwardingSortedSet.first ( )  :  Object
ForwardingSortedSet.ForwardingSortedSet ( )
ForwardingSortedSet.headSet ( Object toElement )  :  SortedSet
ForwardingSortedSet.last ( )  :  Object
ForwardingSortedSet.standardContains ( Object object )  :  boolean
ForwardingSortedSet.standardRemove ( Object object )  :  boolean
ForwardingSortedSet.standardSubSet ( Object fromElement, Object toElement )  :  SortedSet
ForwardingSortedSet.subSet ( Object fromElement, Object toElement )  :  SortedSet
ForwardingSortedSet.tailSet ( Object fromElement )  :  SortedSet

cdk-1.5.3.jar, ForwardingSortedSetMultimap.class
package com.google.common.collect
ForwardingSortedSetMultimap.delegate ( )  :  Multimap
ForwardingSortedSetMultimap.delegate ( )  :  Object
ForwardingSortedSetMultimap.delegate ( )  :  SetMultimap
ForwardingSortedSetMultimap.delegate ( ) [abstract]  :  SortedSetMultimap
ForwardingSortedSetMultimap.ForwardingSortedSetMultimap ( )
ForwardingSortedSetMultimap.get ( Object key )  :  SortedSet
ForwardingSortedSetMultimap.get ( Object x0 )  :  Collection
ForwardingSortedSetMultimap.get ( Object x0 )  :  Set
ForwardingSortedSetMultimap.removeAll ( Object key )  :  SortedSet
ForwardingSortedSetMultimap.removeAll ( Object x0 )  :  Collection
ForwardingSortedSetMultimap.removeAll ( Object x0 )  :  Set
ForwardingSortedSetMultimap.replaceValues ( Object key, Iterable values )  :  SortedSet
ForwardingSortedSetMultimap.replaceValues ( Object x0, Iterable x1 )  :  Collection
ForwardingSortedSetMultimap.replaceValues ( Object x0, Iterable x1 )  :  Set
ForwardingSortedSetMultimap.valueComparator ( )  :  Comparator

cdk-1.5.3.jar, ForwardingTable.class
package com.google.common.collect
ForwardingTable.cellSet ( )  :  Set
ForwardingTable.clear ( )  :  void
ForwardingTable.column ( Object columnKey )  :  Map
ForwardingTable.columnKeySet ( )  :  Set
ForwardingTable.columnMap ( )  :  Map
ForwardingTable.contains ( Object rowKey, Object columnKey )  :  boolean
ForwardingTable.containsColumn ( Object columnKey )  :  boolean
ForwardingTable.containsRow ( Object rowKey )  :  boolean
ForwardingTable.containsValue ( Object value )  :  boolean
ForwardingTable.delegate ( )  :  Object
ForwardingTable.delegate ( ) [abstract]  :  Table
ForwardingTable.equals ( Object obj )  :  boolean
ForwardingTable.ForwardingTable ( )
ForwardingTable.get ( Object rowKey, Object columnKey )  :  Object
ForwardingTable.hashCode ( )  :  int
ForwardingTable.isEmpty ( )  :  boolean
ForwardingTable.put ( Object rowKey, Object columnKey, Object value )  :  Object
ForwardingTable.putAll ( Table table )  :  void
ForwardingTable.remove ( Object rowKey, Object columnKey )  :  Object
ForwardingTable.row ( Object rowKey )  :  Map
ForwardingTable.rowKeySet ( )  :  Set
ForwardingTable.rowMap ( )  :  Map
ForwardingTable.size ( )  :  int
ForwardingTable.values ( )  :  Collection

cdk-1.5.3.jar, Function.class
package com.google.common.base
Function.apply ( Object p1 ) [abstract]  :  Object
Function.equals ( Object p1 ) [abstract]  :  boolean

cdk-1.5.3.jar, Functions.class
package com.google.common.base
Functions.compose ( Function g, Function f ) [static]  :  Function
Functions.constant ( Object value ) [static]  :  Function
Functions.forMap ( Map map ) [static]  :  Function
Functions.forMap ( Map map, Object defaultValue ) [static]  :  Function
Functions.forPredicate ( Predicate predicate ) [static]  :  Function
Functions.forSupplier ( Supplier supplier ) [static]  :  Function
Functions.identity ( ) [static]  :  Function
Functions.toStringFunction ( ) [static]  :  Function

cdk-1.5.3.jar, Funnel.class
package com.google.common.hash
Funnel.funnel ( Object p1, PrimitiveSink p2 ) [abstract]  :  void

cdk-1.5.3.jar, Funnels.class
package com.google.common.hash
Funnels.asOutputStream ( PrimitiveSink sink ) [static]  :  OutputStream
Funnels.byteArrayFunnel ( ) [static]  :  Funnel
Funnels.integerFunnel ( ) [static]  :  Funnel
Funnels.longFunnel ( ) [static]  :  Funnel
Funnels.stringFunnel ( ) [static]  :  Funnel

cdk-1.5.3.jar, FutureCallback.class
package com.google.common.util.concurrent
FutureCallback.onFailure ( Throwable p1 ) [abstract]  :  void
FutureCallback.onSuccess ( Object p1 ) [abstract]  :  void

cdk-1.5.3.jar, FutureFallback.class
package com.google.common.util.concurrent
FutureFallback.create ( Throwable p1 ) [abstract]  :  ListenableFuture

cdk-1.5.3.jar, Futures.class
package com.google.common.util.concurrent
Futures.addCallback ( ListenableFuture future, FutureCallback callback ) [static]  :  void
Futures.addCallback ( ListenableFuture future, FutureCallback callback, Executor executor ) [static]  :  void
Futures.allAsList ( Iterable futures ) [static]  :  ListenableFuture
Futures.allAsList ( ListenableFuture[ ] futures ) [static]  :  ListenableFuture
Futures.dereference ( ListenableFuture nested ) [static]  :  ListenableFuture
Futures.get ( Future future, Class exceptionClass ) [static]  :  Object
Futures.get ( Future future, long timeout, TimeUnit unit, Class exceptionClass ) [static]  :  Object
Futures.getUnchecked ( Future future ) [static]  :  Object
Futures.immediateCancelledFuture ( ) [static]  :  ListenableFuture
Futures.immediateCheckedFuture ( Object value ) [static]  :  CheckedFuture
Futures.immediateFailedCheckedFuture ( Exception exception ) [static]  :  CheckedFuture
Futures.immediateFailedFuture ( Throwable throwable ) [static]  :  ListenableFuture
Futures.immediateFuture ( Object value ) [static]  :  ListenableFuture
Futures.lazyTransform ( Future input, Function function ) [static]  :  Future
Futures.makeChecked ( ListenableFuture future, Function mapper ) [static]  :  CheckedFuture
Futures.successfulAsList ( Iterable futures ) [static]  :  ListenableFuture
Futures.successfulAsList ( ListenableFuture[ ] futures ) [static]  :  ListenableFuture
Futures.transform ( ListenableFuture input, AsyncFunction function ) [static]  :  ListenableFuture
Futures.transform ( ListenableFuture input, AsyncFunction function, Executor executor ) [static]  :  ListenableFuture
Futures.transform ( ListenableFuture input, Function function ) [static]  :  ListenableFuture
Futures.transform ( ListenableFuture input, Function function, Executor executor ) [static]  :  ListenableFuture
Futures.withFallback ( ListenableFuture input, FutureFallback fallback ) [static]  :  ListenableFuture
Futures.withFallback ( ListenableFuture input, FutureFallback fallback, Executor executor ) [static]  :  ListenableFuture

cdk-1.5.3.jar, GenericMapMaker.class
package com.google.common.collect
GenericMapMaker.concurrencyLevel ( int p1 ) [abstract]  :  GenericMapMaker
GenericMapMaker.initialCapacity ( int p1 ) [abstract]  :  GenericMapMaker
GenericMapMaker.makeComputingMap ( Function p1 ) [abstract]  :  ConcurrentMap *DEPRECATED*
GenericMapMaker.makeMap ( ) [abstract]  :  ConcurrentMap
GenericMapMaker.softValues ( ) [abstract]  :  GenericMapMaker
GenericMapMaker.weakKeys ( ) [abstract]  :  GenericMapMaker
GenericMapMaker.weakValues ( ) [abstract]  :  GenericMapMaker

cdk-1.5.3.jar, GeometricCumulativeDoubleBondFactory.class
package org.openscience.cdk.hash.stereo
GeometricCumulativeDoubleBondFactory.create ( IAtomContainer container, int[ ][ ] graph )  :  StereoEncoder
GeometricCumulativeDoubleBondFactory.GeometricCumulativeDoubleBondFactory ( )

cdk-1.5.3.jar, GeometricDoubleBondEncoderFactory.class
package org.openscience.cdk.hash.stereo
GeometricDoubleBondEncoderFactory.create ( IAtomContainer container, int[ ][ ] graph )  :  StereoEncoder
GeometricDoubleBondEncoderFactory.GeometricDoubleBondEncoderFactory ( )

cdk-1.5.3.jar, GeometricTetrahedralEncoderFactory.class
package org.openscience.cdk.hash.stereo
GeometricTetrahedralEncoderFactory.create ( IAtomContainer container, int[ ][ ] graph )  :  StereoEncoder
GeometricTetrahedralEncoderFactory.GeometricTetrahedralEncoderFactory ( )

cdk-1.5.3.jar, GraphUtil.class
package org.openscience.cdk.graph
GraphUtil.cycle ( int[ ][ ] graph, int[ ] vertices ) [static]  :  int[ ]
GraphUtil.subgraph ( int[ ][ ] graph, int[ ] include ) [static]  :  int[ ][ ]
GraphUtil.toAdjList ( IAtomContainer container ) [static]  :  int[ ][ ]

cdk-1.5.3.jar, Guard.class
package com.google.common.util.concurrent
Monitor.Guard.equals ( Object other )  :  boolean
Monitor.Guard.hashCode ( )  :  int
Monitor.Guard.isSatisfied ( ) [abstract]  :  boolean
Monitor.Guard.Monitor.Guard ( Monitor monitor )

cdk-1.5.3.jar, GwtCompatible.class
package com.google.common.annotations
GwtCompatible.emulated ( ) [abstract]  :  boolean
GwtCompatible.serializable ( ) [abstract]  :  boolean

cdk-1.5.3.jar, GwtIncompatible.class
package com.google.common.annotations
GwtIncompatible.value ( ) [abstract]  :  String

cdk-1.5.3.jar, HashBasedTable.class
package com.google.common.collect
HashBasedTable.cellSet ( )  :  Set
HashBasedTable.clear ( )  :  void
HashBasedTable.column ( Object x0 )  :  Map
HashBasedTable.columnKeySet ( )  :  Set
HashBasedTable.columnMap ( )  :  Map
HashBasedTable.contains ( Object rowKey, Object columnKey )  :  boolean
HashBasedTable.containsColumn ( Object columnKey )  :  boolean
HashBasedTable.containsRow ( Object rowKey )  :  boolean
HashBasedTable.containsValue ( Object value )  :  boolean
HashBasedTable.create ( ) [static]  :  HashBasedTable
HashBasedTable.create ( int expectedRows, int expectedCellsPerRow ) [static]  :  HashBasedTable
HashBasedTable.create ( Table table ) [static]  :  HashBasedTable
HashBasedTable.equals ( Object obj )  :  boolean
HashBasedTable.get ( Object rowKey, Object columnKey )  :  Object
HashBasedTable.hashCode ( )  :  int
HashBasedTable.isEmpty ( )  :  boolean
HashBasedTable.put ( Object x0, Object x1, Object x2 )  :  Object
HashBasedTable.putAll ( Table x0 )  :  void
HashBasedTable.remove ( Object rowKey, Object columnKey )  :  Object
HashBasedTable.row ( Object x0 )  :  Map
HashBasedTable.rowKeySet ( )  :  Set
HashBasedTable.rowMap ( )  :  Map
HashBasedTable.size ( )  :  int
HashBasedTable.toString ( )  :  String
HashBasedTable.values ( )  :  Collection

cdk-1.5.3.jar, HashBiMap.class
package com.google.common.collect
HashBiMap.clear ( )  :  void
HashBiMap.containsKey ( Object key )  :  boolean
HashBiMap.containsValue ( Object value )  :  boolean
HashBiMap.create ( ) [static]  :  HashBiMap
HashBiMap.create ( int expectedSize ) [static]  :  HashBiMap
HashBiMap.create ( Map map ) [static]  :  HashBiMap
HashBiMap.entrySet ( )  :  Set
HashBiMap.forcePut ( Object key, Object value )  :  Object
HashBiMap.get ( Object key )  :  Object
HashBiMap.inverse ( )  :  BiMap
HashBiMap.keySet ( )  :  Set
HashBiMap.put ( Object key, Object value )  :  Object
HashBiMap.remove ( Object key )  :  Object
HashBiMap.size ( )  :  int
HashBiMap.values ( )  :  Collection
HashBiMap.values ( )  :  Set

cdk-1.5.3.jar, HashCode.class
package com.google.common.hash
HashCode.asBytes ( ) [abstract]  :  byte[ ]
HashCode.asInt ( ) [abstract]  :  int
HashCode.asLong ( ) [abstract]  :  long
HashCode.bits ( ) [abstract]  :  int
HashCode.equals ( Object object )  :  boolean
HashCode.hashCode ( )  :  int
HashCode.padToLong ( ) [abstract]  :  long
HashCode.toString ( )  :  String
HashCode.writeBytesTo ( byte[ ] dest, int offset, int maxLength )  :  int

cdk-1.5.3.jar, HashCodes.class
package com.google.common.hash
HashCodes.fromBytes ( byte[ ] bytes ) [static]  :  HashCode
HashCodes.fromInt ( int hash ) [static]  :  HashCode
HashCodes.fromLong ( long hash ) [static]  :  HashCode

cdk-1.5.3.jar, Hasher.class
package com.google.common.hash
Hasher.hash ( ) [abstract]  :  HashCode
Hasher.putBoolean ( boolean p1 ) [abstract]  :  Hasher
Hasher.putByte ( byte p1 ) [abstract]  :  Hasher
Hasher.putBytes ( byte[ ] p1 ) [abstract]  :  Hasher
Hasher.putBytes ( byte[ ] p1, int p2, int p3 ) [abstract]  :  Hasher
Hasher.putChar ( char p1 ) [abstract]  :  Hasher
Hasher.putDouble ( double p1 ) [abstract]  :  Hasher
Hasher.putFloat ( float p1 ) [abstract]  :  Hasher
Hasher.putInt ( int p1 ) [abstract]  :  Hasher
Hasher.putLong ( long p1 ) [abstract]  :  Hasher
Hasher.putObject ( Object p1, Funnel p2 ) [abstract]  :  Hasher
Hasher.putShort ( short p1 ) [abstract]  :  Hasher
Hasher.putString ( CharSequence p1 ) [abstract]  :  Hasher
Hasher.putString ( CharSequence p1, Charset p2 ) [abstract]  :  Hasher

cdk-1.5.3.jar, HashFunction.class
package com.google.common.hash
HashFunction.bits ( ) [abstract]  :  int
HashFunction.hashBytes ( byte[ ] p1 ) [abstract]  :  HashCode
HashFunction.hashBytes ( byte[ ] p1, int p2, int p3 ) [abstract]  :  HashCode
HashFunction.hashInt ( int p1 ) [abstract]  :  HashCode
HashFunction.hashLong ( long p1 ) [abstract]  :  HashCode
HashFunction.hashObject ( Object p1, Funnel p2 ) [abstract]  :  HashCode
HashFunction.hashString ( CharSequence p1 ) [abstract]  :  HashCode
HashFunction.hashString ( CharSequence p1, Charset p2 ) [abstract]  :  HashCode
HashFunction.newHasher ( ) [abstract]  :  Hasher
HashFunction.newHasher ( int p1 ) [abstract]  :  Hasher

cdk-1.5.3.jar, HashGeneratorMaker.class
package org.openscience.cdk.hash
HashGeneratorMaker.encode ( AtomEncoder encoder )  :  HashGeneratorMaker

cdk-1.5.3.jar, Hashing.class
package com.google.common.hash
Hashing.adler32 ( ) [static]  :  HashFunction
Hashing.combineOrdered ( Iterable hashCodes ) [static]  :  HashCode
Hashing.combineUnordered ( Iterable hashCodes ) [static]  :  HashCode
Hashing.consistentHash ( HashCode hashCode, int buckets ) [static]  :  int
Hashing.consistentHash ( long input, int buckets ) [static]  :  int
Hashing.crc32 ( ) [static]  :  HashFunction
Hashing.goodFastHash ( int minimumBits ) [static]  :  HashFunction
Hashing.md5 ( ) [static]  :  HashFunction
Hashing.murmur3_128 ( ) [static]  :  HashFunction
Hashing.murmur3_128 ( int seed ) [static]  :  HashFunction
Hashing.murmur3_32 ( ) [static]  :  HashFunction
Hashing.murmur3_32 ( int seed ) [static]  :  HashFunction
Hashing.padToLong ( HashCode hashCode ) [static]  :  long *DEPRECATED*
Hashing.sha1 ( ) [static]  :  HashFunction
Hashing.sha256 ( ) [static]  :  HashFunction
Hashing.sha512 ( ) [static]  :  HashFunction

cdk-1.5.3.jar, HashMultimap.class
package com.google.common.collect
HashMultimap.asMap ( )  :  Map
HashMultimap.clear ( )  :  void
HashMultimap.containsEntry ( Object x0, Object x1 )  :  boolean
HashMultimap.containsKey ( Object x0 )  :  boolean
HashMultimap.containsValue ( Object x0 )  :  boolean
HashMultimap.create ( ) [static]  :  HashMultimap
HashMultimap.create ( int expectedKeys, int expectedValuesPerKey ) [static]  :  HashMultimap
HashMultimap.create ( Multimap multimap ) [static]  :  HashMultimap
HashMultimap.entries ( )  :  Set
HashMultimap.equals ( Object x0 )  :  boolean
HashMultimap.get ( Object x0 )  :  Set
HashMultimap.hashCode ( )  :  int
HashMultimap.isEmpty ( )  :  boolean
HashMultimap.keys ( )  :  Multiset
HashMultimap.keySet ( )  :  Set
HashMultimap.put ( Object x0, Object x1 )  :  boolean
HashMultimap.putAll ( Multimap x0 )  :  boolean
HashMultimap.putAll ( Object x0, Iterable x1 )  :  boolean
HashMultimap.remove ( Object x0, Object x1 )  :  boolean
HashMultimap.removeAll ( Object x0 )  :  Set
HashMultimap.replaceValues ( Object x0, Iterable x1 )  :  Set
HashMultimap.size ( )  :  int
HashMultimap.toString ( )  :  String
HashMultimap.values ( )  :  Collection

cdk-1.5.3.jar, HashMultiset.class
package com.google.common.collect
HashMultiset.add ( Object x0 )  :  boolean
HashMultiset.add ( Object x0, int x1 )  :  int
HashMultiset.addAll ( Collection x0 )  :  boolean
HashMultiset.clear ( )  :  void
HashMultiset.contains ( Object x0 )  :  boolean
HashMultiset.count ( Object x0 )  :  int
HashMultiset.create ( ) [static]  :  HashMultiset
HashMultiset.create ( int distinctElements ) [static]  :  HashMultiset
HashMultiset.create ( Iterable elements ) [static]  :  HashMultiset
HashMultiset.elementSet ( )  :  Set
HashMultiset.entrySet ( )  :  Set
HashMultiset.equals ( Object x0 )  :  boolean
HashMultiset.hashCode ( )  :  int
HashMultiset.isEmpty ( )  :  boolean
HashMultiset.iterator ( )  :  Iterator
HashMultiset.remove ( Object x0 )  :  boolean
HashMultiset.remove ( Object x0, int x1 )  :  int
HashMultiset.removeAll ( Collection x0 )  :  boolean
HashMultiset.retainAll ( Collection x0 )  :  boolean
HashMultiset.setCount ( Object x0, int x1 )  :  int
HashMultiset.setCount ( Object x0, int x1, int x2 )  :  boolean
HashMultiset.size ( )  :  int
HashMultiset.toString ( )  :  String

cdk-1.5.3.jar, HostAndPort.class
package com.google.common.net
HostAndPort.equals ( Object other )  :  boolean
HostAndPort.fromParts ( String host, int port ) [static]  :  HostAndPort
HostAndPort.fromString ( String hostPortString ) [static]  :  HostAndPort
HostAndPort.getHostText ( )  :  String
HostAndPort.getPort ( )  :  int
HostAndPort.getPortOrDefault ( int defaultPort )  :  int
HostAndPort.hashCode ( )  :  int
HostAndPort.hasPort ( )  :  boolean
HostAndPort.requireBracketsForIPv6 ( )  :  HostAndPort
HostAndPort.toString ( )  :  String
HostAndPort.withDefaultPort ( int defaultPort )  :  HostAndPort

cdk-1.5.3.jar, HostSpecifier.class
package com.google.common.net
HostSpecifier.equals ( Object other )  :  boolean
HostSpecifier.from ( String specifier ) [static]  :  HostSpecifier
HostSpecifier.fromValid ( String specifier ) [static]  :  HostSpecifier
HostSpecifier.hashCode ( )  :  int
HostSpecifier.isValid ( String specifier ) [static]  :  boolean
HostSpecifier.toString ( )  :  String

cdk-1.5.3.jar, IDescriptor.class
package org.openscience.cdk.qsar
IDescriptor.initialise ( IChemObjectBuilder p1 ) [abstract]  :  void

cdk-1.5.3.jar, ImmutableBiMap.class
package com.google.common.collect
ImmutableBiMap.builder ( ) [static]  :  ImmutableBiMap.Builder
ImmutableBiMap.copyOf ( Map map ) [static]  :  ImmutableBiMap
ImmutableBiMap.forcePut ( Object key, Object value )  :  Object *DEPRECATED*
ImmutableBiMap.inverse ( )  :  BiMap
ImmutableBiMap.inverse ( ) [abstract]  :  ImmutableBiMap
ImmutableBiMap.of ( ) [static]  :  ImmutableBiMap
ImmutableBiMap.of ( Object k1, Object v1 ) [static]  :  ImmutableBiMap
ImmutableBiMap.of ( Object k1, Object v1, Object k2, Object v2 ) [static]  :  ImmutableBiMap
ImmutableBiMap.of ( Object k1, Object v1, Object k2, Object v2, Object k3, Object v3 ) [static]  :  ImmutableBiMap
ImmutableBiMap.of ( Object k1, Object v1, Object k2, Object v2, Object k3, Object v3, Object k4, Object v4 ) [static]  :  ImmutableBiMap
ImmutableBiMap.of ( Object k1, Object v1, Object k2, Object v2, Object k3, Object v3, Object k4, Object v4, Object k5, Object v5 ) [static]  :  ImmutableBiMap
ImmutableBiMap.values ( )  :  Collection
ImmutableBiMap.values ( )  :  ImmutableCollection
ImmutableBiMap.values ( )  :  ImmutableSet
ImmutableBiMap.values ( )  :  Set

cdk-1.5.3.jar, ImmutableClassToInstanceMap.class
package com.google.common.collect
ImmutableClassToInstanceMap.builder ( ) [static]  :  ImmutableClassToInstanceMap.Builder
ImmutableClassToInstanceMap.copyOf ( Map map ) [static]  :  ImmutableClassToInstanceMap
ImmutableClassToInstanceMap.delegate ( )  :  Map
ImmutableClassToInstanceMap.delegate ( )  :  Object
ImmutableClassToInstanceMap.getInstance ( Class type )  :  Object
ImmutableClassToInstanceMap.putInstance ( Class type, Object value )  :  Object *DEPRECATED*

cdk-1.5.3.jar, ImmutableCollection.class
package com.google.common.collect
ImmutableCollection.add ( Object e )  :  boolean *DEPRECATED*
ImmutableCollection.addAll ( Collection newElements )  :  boolean *DEPRECATED*
ImmutableCollection.asList ( )  :  ImmutableList
ImmutableCollection.clear ( )  :  void *DEPRECATED*
ImmutableCollection.contains ( Object object )  :  boolean
ImmutableCollection.containsAll ( Collection targets )  :  boolean
ImmutableCollection.isEmpty ( )  :  boolean
ImmutableCollection.iterator ( )  :  Iterator
ImmutableCollection.iterator ( ) [abstract]  :  UnmodifiableIterator
ImmutableCollection.remove ( Object object )  :  boolean *DEPRECATED*
ImmutableCollection.removeAll ( Collection oldElements )  :  boolean *DEPRECATED*
ImmutableCollection.retainAll ( Collection elementsToKeep )  :  boolean *DEPRECATED*
ImmutableCollection.toArray ( )  :  Object[ ]
ImmutableCollection.toArray ( Object[ ] other )  :  Object[ ]
ImmutableCollection.toString ( )  :  String

cdk-1.5.3.jar, ImmutableList.class
package com.google.common.collect
ImmutableList.add ( int index, Object element )  :  void *DEPRECATED*
ImmutableList.addAll ( int index, Collection newElements )  :  boolean *DEPRECATED*
ImmutableList.asList ( )  :  ImmutableList
ImmutableList.builder ( ) [static]  :  ImmutableList.Builder
ImmutableList.contains ( Object object )  :  boolean
ImmutableList.copyOf ( Collection elements ) [static]  :  ImmutableList
ImmutableList.copyOf ( Iterable elements ) [static]  :  ImmutableList
ImmutableList.copyOf ( Iterator elements ) [static]  :  ImmutableList
ImmutableList.copyOf ( Object[ ] elements ) [static]  :  ImmutableList
ImmutableList.equals ( Object obj )  :  boolean
ImmutableList.hashCode ( )  :  int
ImmutableList.indexOf ( Object object )  :  int
ImmutableList.iterator ( )  :  Iterator
ImmutableList.iterator ( )  :  UnmodifiableIterator
ImmutableList.lastIndexOf ( Object object )  :  int
ImmutableList.listIterator ( )  :  ListIterator
ImmutableList.listIterator ( )  :  UnmodifiableListIterator
ImmutableList.listIterator ( int index )  :  UnmodifiableListIterator
ImmutableList.listIterator ( int x0 )  :  ListIterator
ImmutableList.of ( ) [static]  :  ImmutableList
ImmutableList.of ( Object e1, Object e2 ) [static]  :  ImmutableList
ImmutableList.of ( Object e1, Object e2, Object e3 ) [static]  :  ImmutableList
ImmutableList.of ( Object e1, Object e2, Object e3, Object e4 ) [static]  :  ImmutableList
ImmutableList.of ( Object e1, Object e2, Object e3, Object e4, Object e5 ) [static]  :  ImmutableList
ImmutableList.of ( Object e1, Object e2, Object e3, Object e4, Object e5, Object e6 ) [static]  :  ImmutableList
ImmutableList.of ( Object e1, Object e2, Object e3, Object e4, Object e5, Object e6, Object e7 ) [static]  :  ImmutableList
ImmutableList.of ( Object e1, Object e2, Object e3, Object e4, Object e5, Object e6, Object e7, Object e8 ) [static]  :  ImmutableList
ImmutableList.of ( Object e1, Object e2, Object e3, Object e4, Object e5, Object e6, Object e7, Object e8, Object e9 ) [static]  :  ImmutableList
ImmutableList.of ( Object e1, Object e2, Object e3, Object e4, Object e5, Object e6, Object e7, Object e8, Object e9, Object e10 ) [static]  :  ImmutableList
ImmutableList.of ( Object e1, Object e2, Object e3, Object e4, Object e5, Object e6, Object e7, Object e8, Object e9, Object e10, Object e11 ) [static]  :  ImmutableList
ImmutableList.of ( Object e1, Object e2, Object e3, Object e4, Object e5, Object e6, Object e7, Object e8, Object e9, Object e10, Object e11, Object e12, Object[ ] others ) [static]  :  ImmutableList
ImmutableList.of ( Object element ) [static]  :  ImmutableList
ImmutableList.remove ( int index )  :  Object *DEPRECATED*
ImmutableList.reverse ( )  :  ImmutableList
ImmutableList.set ( int index, Object element )  :  Object *DEPRECATED*
ImmutableList.subList ( int fromIndex, int toIndex )  :  ImmutableList
ImmutableList.subList ( int x0, int x1 )  :  List

cdk-1.5.3.jar, ImmutableListMultimap.class
package com.google.common.collect
ImmutableListMultimap.builder ( ) [static]  :  ImmutableListMultimap.Builder
ImmutableListMultimap.copyOf ( Multimap multimap ) [static]  :  ImmutableListMultimap
ImmutableListMultimap.get ( Object key )  :  ImmutableList
ImmutableListMultimap.get ( Object x0 )  :  Collection
ImmutableListMultimap.get ( Object x0 )  :  ImmutableCollection
ImmutableListMultimap.get ( Object x0 )  :  List
ImmutableListMultimap.inverse ( )  :  ImmutableListMultimap
ImmutableListMultimap.inverse ( )  :  ImmutableMultimap
ImmutableListMultimap.of ( ) [static]  :  ImmutableListMultimap
ImmutableListMultimap.of ( Object k1, Object v1 ) [static]  :  ImmutableListMultimap
ImmutableListMultimap.of ( Object k1, Object v1, Object k2, Object v2 ) [static]  :  ImmutableListMultimap
ImmutableListMultimap.of ( Object k1, Object v1, Object k2, Object v2, Object k3, Object v3 ) [static]  :  ImmutableListMultimap
ImmutableListMultimap.of ( Object k1, Object v1, Object k2, Object v2, Object k3, Object v3, Object k4, Object v4 ) [static]  :  ImmutableListMultimap
ImmutableListMultimap.of ( Object k1, Object v1, Object k2, Object v2, Object k3, Object v3, Object k4, Object v4, Object k5, Object v5 ) [static]  :  ImmutableListMultimap
ImmutableListMultimap.removeAll ( Object key )  :  ImmutableList *DEPRECATED*
ImmutableListMultimap.removeAll ( Object x0 )  :  Collection
ImmutableListMultimap.removeAll ( Object x0 )  :  ImmutableCollection
ImmutableListMultimap.removeAll ( Object x0 )  :  List
ImmutableListMultimap.replaceValues ( Object key, Iterable values )  :  ImmutableList *DEPRECATED*
ImmutableListMultimap.replaceValues ( Object x0, Iterable x1 )  :  Collection
ImmutableListMultimap.replaceValues ( Object x0, Iterable x1 )  :  ImmutableCollection
ImmutableListMultimap.replaceValues ( Object x0, Iterable x1 )  :  List

cdk-1.5.3.jar, ImmutableMap.class
package com.google.common.collect
ImmutableMap.asMultimap ( )  :  ImmutableSetMultimap
ImmutableMap.builder ( ) [static]  :  ImmutableMap.Builder
ImmutableMap.clear ( )  :  void *DEPRECATED*
ImmutableMap.containsKey ( Object key )  :  boolean
ImmutableMap.containsValue ( Object value )  :  boolean
ImmutableMap.copyOf ( Map map ) [static]  :  ImmutableMap
ImmutableMap.entrySet ( )  :  ImmutableSet
ImmutableMap.entrySet ( )  :  Set
ImmutableMap.equals ( Object object )  :  boolean
ImmutableMap.get ( Object p1 ) [abstract]  :  Object
ImmutableMap.hashCode ( )  :  int
ImmutableMap.isEmpty ( )  :  boolean
ImmutableMap.keySet ( )  :  ImmutableSet
ImmutableMap.keySet ( )  :  Set
ImmutableMap.of ( ) [static]  :  ImmutableMap
ImmutableMap.of ( Object k1, Object v1 ) [static]  :  ImmutableMap
ImmutableMap.of ( Object k1, Object v1, Object k2, Object v2 ) [static]  :  ImmutableMap
ImmutableMap.of ( Object k1, Object v1, Object k2, Object v2, Object k3, Object v3 ) [static]  :  ImmutableMap
ImmutableMap.of ( Object k1, Object v1, Object k2, Object v2, Object k3, Object v3, Object k4, Object v4 ) [static]  :  ImmutableMap
ImmutableMap.of ( Object k1, Object v1, Object k2, Object v2, Object k3, Object v3, Object k4, Object v4, Object k5, Object v5 ) [static]  :  ImmutableMap
ImmutableMap.put ( Object k, Object v )  :  Object *DEPRECATED*
ImmutableMap.putAll ( Map map )  :  void *DEPRECATED*
ImmutableMap.remove ( Object o )  :  Object *DEPRECATED*
ImmutableMap.toString ( )  :  String
ImmutableMap.values ( )  :  Collection
ImmutableMap.values ( )  :  ImmutableCollection

cdk-1.5.3.jar, ImmutableMultimap.class
package com.google.common.collect
ImmutableMultimap.asMap ( )  :  ImmutableMap
ImmutableMultimap.asMap ( )  :  Map
ImmutableMultimap.builder ( ) [static]  :  ImmutableMultimap.Builder
ImmutableMultimap.clear ( )  :  void *DEPRECATED*
ImmutableMultimap.containsEntry ( Object x0, Object x1 )  :  boolean
ImmutableMultimap.containsKey ( Object key )  :  boolean
ImmutableMultimap.containsValue ( Object x0 )  :  boolean
ImmutableMultimap.copyOf ( Multimap multimap ) [static]  :  ImmutableMultimap
ImmutableMultimap.entries ( )  :  Collection
ImmutableMultimap.entries ( )  :  ImmutableCollection
ImmutableMultimap.equals ( Object x0 )  :  boolean
ImmutableMultimap.get ( Object p1 ) [abstract]  :  ImmutableCollection
ImmutableMultimap.get ( Object x0 )  :  Collection
ImmutableMultimap.hashCode ( )  :  int
ImmutableMultimap.inverse ( ) [abstract]  :  ImmutableMultimap
ImmutableMultimap.isEmpty ( )  :  boolean
ImmutableMultimap.keys ( )  :  ImmutableMultiset
ImmutableMultimap.keys ( )  :  Multiset
ImmutableMultimap.keySet ( )  :  ImmutableSet
ImmutableMultimap.keySet ( )  :  Set
ImmutableMultimap.of ( ) [static]  :  ImmutableMultimap
ImmutableMultimap.of ( Object k1, Object v1 ) [static]  :  ImmutableMultimap
ImmutableMultimap.of ( Object k1, Object v1, Object k2, Object v2 ) [static]  :  ImmutableMultimap
ImmutableMultimap.of ( Object k1, Object v1, Object k2, Object v2, Object k3, Object v3 ) [static]  :  ImmutableMultimap
ImmutableMultimap.of ( Object k1, Object v1, Object k2, Object v2, Object k3, Object v3, Object k4, Object v4 ) [static]  :  ImmutableMultimap
ImmutableMultimap.of ( Object k1, Object v1, Object k2, Object v2, Object k3, Object v3, Object k4, Object v4, Object k5, Object v5 ) [static]  :  ImmutableMultimap
ImmutableMultimap.put ( Object key, Object value )  :  boolean *DEPRECATED*
ImmutableMultimap.putAll ( Multimap multimap )  :  boolean *DEPRECATED*
ImmutableMultimap.putAll ( Object key, Iterable values )  :  boolean *DEPRECATED*
ImmutableMultimap.remove ( Object key, Object value )  :  boolean *DEPRECATED*
ImmutableMultimap.removeAll ( Object key )  :  ImmutableCollection *DEPRECATED*
ImmutableMultimap.removeAll ( Object x0 )  :  Collection
ImmutableMultimap.replaceValues ( Object key, Iterable values )  :  ImmutableCollection *DEPRECATED*
ImmutableMultimap.replaceValues ( Object x0, Iterable x1 )  :  Collection
ImmutableMultimap.size ( )  :  int
ImmutableMultimap.toString ( )  :  String
ImmutableMultimap.values ( )  :  Collection
ImmutableMultimap.values ( )  :  ImmutableCollection

cdk-1.5.3.jar, ImmutableMultiset.class
package com.google.common.collect
ImmutableMultiset.add ( Object element, int occurrences )  :  int *DEPRECATED*
ImmutableMultiset.builder ( ) [static]  :  ImmutableMultiset.Builder
ImmutableMultiset.contains ( Object object )  :  boolean
ImmutableMultiset.containsAll ( Collection targets )  :  boolean
ImmutableMultiset.copyOf ( Iterable elements ) [static]  :  ImmutableMultiset
ImmutableMultiset.copyOf ( Iterator elements ) [static]  :  ImmutableMultiset
ImmutableMultiset.copyOf ( Object[ ] elements ) [static]  :  ImmutableMultiset
ImmutableMultiset.entrySet ( )  :  ImmutableSet
ImmutableMultiset.entrySet ( )  :  Set
ImmutableMultiset.equals ( Object object )  :  boolean
ImmutableMultiset.hashCode ( )  :  int
ImmutableMultiset.iterator ( )  :  Iterator
ImmutableMultiset.iterator ( )  :  UnmodifiableIterator
ImmutableMultiset.of ( ) [static]  :  ImmutableMultiset
ImmutableMultiset.of ( Object e1, Object e2 ) [static]  :  ImmutableMultiset
ImmutableMultiset.of ( Object e1, Object e2, Object e3 ) [static]  :  ImmutableMultiset
ImmutableMultiset.of ( Object e1, Object e2, Object e3, Object e4 ) [static]  :  ImmutableMultiset
ImmutableMultiset.of ( Object e1, Object e2, Object e3, Object e4, Object e5 ) [static]  :  ImmutableMultiset
ImmutableMultiset.of ( Object e1, Object e2, Object e3, Object e4, Object e5, Object e6, Object[ ] others ) [static]  :  ImmutableMultiset
ImmutableMultiset.of ( Object element ) [static]  :  ImmutableMultiset
ImmutableMultiset.remove ( Object element, int occurrences )  :  int *DEPRECATED*
ImmutableMultiset.setCount ( Object element, int count )  :  int *DEPRECATED*
ImmutableMultiset.setCount ( Object element, int oldCount, int newCount )  :  boolean *DEPRECATED*
ImmutableMultiset.toString ( )  :  String

cdk-1.5.3.jar, ImmutableRangeMap.class
package com.google.common.collect
ImmutableRangeMap.asMapOfRanges ( )  :  ImmutableMap
ImmutableRangeMap.asMapOfRanges ( )  :  Map
ImmutableRangeMap.builder ( ) [static]  :  ImmutableRangeMap.Builder
ImmutableRangeMap.clear ( )  :  void
ImmutableRangeMap.copyOf ( RangeMap rangeMap ) [static]  :  ImmutableRangeMap
ImmutableRangeMap.equals ( Object o )  :  boolean
ImmutableRangeMap.get ( Comparable key )  :  Object
ImmutableRangeMap.getEntry ( Comparable key )  :  Map.Entry
ImmutableRangeMap.hashCode ( )  :  int
ImmutableRangeMap.of ( ) [static]  :  ImmutableRangeMap
ImmutableRangeMap.of ( Range range, Object value ) [static]  :  ImmutableRangeMap
ImmutableRangeMap.put ( Range range, Object value )  :  void
ImmutableRangeMap.putAll ( RangeMap rangeMap )  :  void
ImmutableRangeMap.remove ( Range range )  :  void
ImmutableRangeMap.span ( )  :  Range
ImmutableRangeMap.subRangeMap ( Range range )  :  ImmutableRangeMap
ImmutableRangeMap.subRangeMap ( Range x0 )  :  RangeMap
ImmutableRangeMap.toString ( )  :  String

cdk-1.5.3.jar, ImmutableRangeSet.class
package com.google.common.collect
ImmutableRangeSet.add ( Range range )  :  void
ImmutableRangeSet.addAll ( RangeSet other )  :  void
ImmutableRangeSet.asRanges ( )  :  ImmutableSet
ImmutableRangeSet.asRanges ( )  :  Set
ImmutableRangeSet.asSet ( DiscreteDomain domain )  :  ImmutableSortedSet
ImmutableRangeSet.builder ( ) [static]  :  ImmutableRangeSet.Builder
ImmutableRangeSet.clear ( )  :  void
ImmutableRangeSet.complement ( )  :  ImmutableRangeSet
ImmutableRangeSet.complement ( )  :  RangeSet
ImmutableRangeSet.contains ( Comparable x0 )  :  boolean
ImmutableRangeSet.copyOf ( RangeSet rangeSet ) [static]  :  ImmutableRangeSet
ImmutableRangeSet.encloses ( Range otherRange )  :  boolean
ImmutableRangeSet.enclosesAll ( RangeSet x0 )  :  boolean
ImmutableRangeSet.equals ( Object x0 )  :  boolean
ImmutableRangeSet.isEmpty ( )  :  boolean
ImmutableRangeSet.of ( ) [static]  :  ImmutableRangeSet
ImmutableRangeSet.of ( Range range ) [static]  :  ImmutableRangeSet
ImmutableRangeSet.rangeContaining ( Comparable value )  :  Range
ImmutableRangeSet.remove ( Range range )  :  void
ImmutableRangeSet.removeAll ( RangeSet other )  :  void
ImmutableRangeSet.span ( )  :  Range
ImmutableRangeSet.subRangeSet ( Range range )  :  ImmutableRangeSet
ImmutableRangeSet.subRangeSet ( Range x0 )  :  RangeSet

cdk-1.5.3.jar, ImmutableSet.class
package com.google.common.collect
ImmutableSet.builder ( ) [static]  :  ImmutableSet.Builder
ImmutableSet.copyOf ( Collection elements ) [static]  :  ImmutableSet
ImmutableSet.copyOf ( Iterable elements ) [static]  :  ImmutableSet
ImmutableSet.copyOf ( Iterator elements ) [static]  :  ImmutableSet
ImmutableSet.copyOf ( Object[ ] elements ) [static]  :  ImmutableSet
ImmutableSet.equals ( Object object )  :  boolean
ImmutableSet.hashCode ( )  :  int
ImmutableSet.iterator ( )  :  Iterator
ImmutableSet.iterator ( ) [abstract]  :  UnmodifiableIterator
ImmutableSet.of ( ) [static]  :  ImmutableSet
ImmutableSet.of ( Object e1, Object e2 ) [static]  :  ImmutableSet
ImmutableSet.of ( Object e1, Object e2, Object e3 ) [static]  :  ImmutableSet
ImmutableSet.of ( Object e1, Object e2, Object e3, Object e4 ) [static]  :  ImmutableSet
ImmutableSet.of ( Object e1, Object e2, Object e3, Object e4, Object e5 ) [static]  :  ImmutableSet
ImmutableSet.of ( Object e1, Object e2, Object e3, Object e4, Object e5, Object e6, Object[ ] others ) [static]  :  ImmutableSet
ImmutableSet.of ( Object element ) [static]  :  ImmutableSet

cdk-1.5.3.jar, ImmutableSetMultimap.class
package com.google.common.collect
ImmutableSetMultimap.builder ( ) [static]  :  ImmutableSetMultimap.Builder
ImmutableSetMultimap.copyOf ( Multimap multimap ) [static]  :  ImmutableSetMultimap
ImmutableSetMultimap.entries ( )  :  Collection
ImmutableSetMultimap.entries ( )  :  ImmutableCollection
ImmutableSetMultimap.entries ( )  :  ImmutableSet
ImmutableSetMultimap.entries ( )  :  Set
ImmutableSetMultimap.get ( Object key )  :  ImmutableSet
ImmutableSetMultimap.get ( Object x0 )  :  Collection
ImmutableSetMultimap.get ( Object x0 )  :  ImmutableCollection
ImmutableSetMultimap.get ( Object x0 )  :  Set
ImmutableSetMultimap.inverse ( )  :  ImmutableMultimap
ImmutableSetMultimap.inverse ( )  :  ImmutableSetMultimap
ImmutableSetMultimap.of ( ) [static]  :  ImmutableSetMultimap
ImmutableSetMultimap.of ( Object k1, Object v1 ) [static]  :  ImmutableSetMultimap
ImmutableSetMultimap.of ( Object k1, Object v1, Object k2, Object v2 ) [static]  :  ImmutableSetMultimap
ImmutableSetMultimap.of ( Object k1, Object v1, Object k2, Object v2, Object k3, Object v3 ) [static]  :  ImmutableSetMultimap
ImmutableSetMultimap.of ( Object k1, Object v1, Object k2, Object v2, Object k3, Object v3, Object k4, Object v4 ) [static]  :  ImmutableSetMultimap
ImmutableSetMultimap.of ( Object k1, Object v1, Object k2, Object v2, Object k3, Object v3, Object k4, Object v4, Object k5, Object v5 ) [static]  :  ImmutableSetMultimap
ImmutableSetMultimap.removeAll ( Object key )  :  ImmutableSet *DEPRECATED*
ImmutableSetMultimap.removeAll ( Object x0 )  :  Collection
ImmutableSetMultimap.removeAll ( Object x0 )  :  ImmutableCollection
ImmutableSetMultimap.removeAll ( Object x0 )  :  Set
ImmutableSetMultimap.replaceValues ( Object key, Iterable values )  :  ImmutableSet *DEPRECATED*
ImmutableSetMultimap.replaceValues ( Object x0, Iterable x1 )  :  Collection
ImmutableSetMultimap.replaceValues ( Object x0, Iterable x1 )  :  ImmutableCollection
ImmutableSetMultimap.replaceValues ( Object x0, Iterable x1 )  :  Set

cdk-1.5.3.jar, ImmutableSortedMap.class
package com.google.common.collect
ImmutableSortedMap.ceilingEntry ( Object key )  :  Map.Entry
ImmutableSortedMap.ceilingKey ( Object key )  :  Object
ImmutableSortedMap.comparator ( )  :  Comparator
ImmutableSortedMap.containsValue ( Object value )  :  boolean
ImmutableSortedMap.copyOf ( Map map ) [static]  :  ImmutableSortedMap
ImmutableSortedMap.copyOf ( Map map, Comparator comparator ) [static]  :  ImmutableSortedMap
ImmutableSortedMap.copyOfSorted ( SortedMap map ) [static]  :  ImmutableSortedMap
ImmutableSortedMap.descendingKeySet ( )  :  ImmutableSortedSet
ImmutableSortedMap.descendingKeySet ( )  :  NavigableSet
ImmutableSortedMap.descendingMap ( )  :  ImmutableSortedMap
ImmutableSortedMap.descendingMap ( )  :  NavigableMap
ImmutableSortedMap.entrySet ( )  :  ImmutableSet
ImmutableSortedMap.entrySet ( )  :  Set
ImmutableSortedMap.firstEntry ( )  :  Map.Entry
ImmutableSortedMap.firstKey ( )  :  Object
ImmutableSortedMap.floorEntry ( Object key )  :  Map.Entry
ImmutableSortedMap.floorKey ( Object key )  :  Object
ImmutableSortedMap.headMap ( Object p1, boolean p2 ) [abstract]  :  ImmutableSortedMap
ImmutableSortedMap.headMap ( Object toKey )  :  ImmutableSortedMap
ImmutableSortedMap.headMap ( Object x0 )  :  SortedMap
ImmutableSortedMap.headMap ( Object x0, boolean x1 )  :  NavigableMap
ImmutableSortedMap.higherEntry ( Object key )  :  Map.Entry
ImmutableSortedMap.higherKey ( Object key )  :  Object
ImmutableSortedMap.keySet ( )  :  ImmutableSet
ImmutableSortedMap.keySet ( )  :  Set
ImmutableSortedMap.keySet ( ) [abstract]  :  ImmutableSortedSet
ImmutableSortedMap.lastEntry ( )  :  Map.Entry
ImmutableSortedMap.lastKey ( )  :  Object
ImmutableSortedMap.lowerEntry ( Object key )  :  Map.Entry
ImmutableSortedMap.lowerKey ( Object key )  :  Object
ImmutableSortedMap.naturalOrder ( ) [static]  :  ImmutableSortedMap.Builder
ImmutableSortedMap.navigableKeySet ( )  :  ImmutableSortedSet
ImmutableSortedMap.navigableKeySet ( )  :  NavigableSet
ImmutableSortedMap.of ( ) [static]  :  ImmutableSortedMap
ImmutableSortedMap.of ( Comparable k1, Object v1 ) [static]  :  ImmutableSortedMap
ImmutableSortedMap.of ( Comparable k1, Object v1, Comparable k2, Object v2 ) [static]  :  ImmutableSortedMap
ImmutableSortedMap.of ( Comparable k1, Object v1, Comparable k2, Object v2, Comparable k3, Object v3 ) [static]  :  ImmutableSortedMap
ImmutableSortedMap.of ( Comparable k1, Object v1, Comparable k2, Object v2, Comparable k3, Object v3, Comparable k4, Object v4 ) [static]  :  ImmutableSortedMap
ImmutableSortedMap.of ( Comparable k1, Object v1, Comparable k2, Object v2, Comparable k3, Object v3, Comparable k4, Object v4, Comparable k5, Object v5 ) [static]  :  ImmutableSortedMap
ImmutableSortedMap.orderedBy ( Comparator comparator ) [static]  :  ImmutableSortedMap.Builder
ImmutableSortedMap.pollFirstEntry ( )  :  Map.Entry *DEPRECATED*
ImmutableSortedMap.pollLastEntry ( )  :  Map.Entry *DEPRECATED*
ImmutableSortedMap.reverseOrder ( ) [static]  :  ImmutableSortedMap.Builder
ImmutableSortedMap.size ( )  :  int
ImmutableSortedMap.subMap ( Object fromKey, boolean fromInclusive, Object toKey, boolean toInclusive )  :  ImmutableSortedMap
ImmutableSortedMap.subMap ( Object fromKey, Object toKey )  :  ImmutableSortedMap
ImmutableSortedMap.subMap ( Object x0, boolean x1, Object x2, boolean x3 )  :  NavigableMap
ImmutableSortedMap.subMap ( Object x0, Object x1 )  :  SortedMap
ImmutableSortedMap.tailMap ( Object fromKey )  :  ImmutableSortedMap
ImmutableSortedMap.tailMap ( Object p1, boolean p2 ) [abstract]  :  ImmutableSortedMap
ImmutableSortedMap.tailMap ( Object x0 )  :  SortedMap
ImmutableSortedMap.tailMap ( Object x0, boolean x1 )  :  NavigableMap
ImmutableSortedMap.values ( )  :  Collection
ImmutableSortedMap.values ( ) [abstract]  :  ImmutableCollection

cdk-1.5.3.jar, ImmutableSortedMultiset.class
package com.google.common.collect
ImmutableSortedMultiset.comparator ( )  :  Comparator
ImmutableSortedMultiset.copyOf ( Comparable[ ] elements ) [static]  :  ImmutableSortedMultiset
ImmutableSortedMultiset.copyOf ( Comparator comparator, Iterable elements ) [static]  :  ImmutableSortedMultiset
ImmutableSortedMultiset.copyOf ( Comparator comparator, Iterator elements ) [static]  :  ImmutableSortedMultiset
ImmutableSortedMultiset.copyOf ( Iterable elements ) [static]  :  ImmutableSortedMultiset
ImmutableSortedMultiset.copyOf ( Iterator elements ) [static]  :  ImmutableSortedMultiset
ImmutableSortedMultiset.copyOfSorted ( SortedMultiset sortedMultiset ) [static]  :  ImmutableSortedMultiset
ImmutableSortedMultiset.descendingMultiset ( )  :  ImmutableSortedMultiset
ImmutableSortedMultiset.descendingMultiset ( )  :  SortedMultiset
ImmutableSortedMultiset.elementSet ( )  :  NavigableSet
ImmutableSortedMultiset.elementSet ( )  :  Set
ImmutableSortedMultiset.elementSet ( )  :  SortedSet
ImmutableSortedMultiset.elementSet ( ) [abstract]  :  ImmutableSortedSet
ImmutableSortedMultiset.headMultiset ( Object p1, BoundType p2 ) [abstract]  :  ImmutableSortedMultiset
ImmutableSortedMultiset.headMultiset ( Object x0, BoundType x1 )  :  SortedMultiset
ImmutableSortedMultiset.naturalOrder ( ) [static]  :  ImmutableSortedMultiset.Builder
ImmutableSortedMultiset.of ( ) [static]  :  ImmutableSortedMultiset
ImmutableSortedMultiset.of ( Comparable e1, Comparable e2 ) [static]  :  ImmutableSortedMultiset
ImmutableSortedMultiset.of ( Comparable e1, Comparable e2, Comparable e3 ) [static]  :  ImmutableSortedMultiset
ImmutableSortedMultiset.of ( Comparable e1, Comparable e2, Comparable e3, Comparable e4 ) [static]  :  ImmutableSortedMultiset
ImmutableSortedMultiset.of ( Comparable e1, Comparable e2, Comparable e3, Comparable e4, Comparable e5 ) [static]  :  ImmutableSortedMultiset
ImmutableSortedMultiset.of ( Comparable e1, Comparable e2, Comparable e3, Comparable e4, Comparable e5, Comparable e6, Comparable[ ] remaining ) [static]  :  ImmutableSortedMultiset
ImmutableSortedMultiset.of ( Comparable element ) [static]  :  ImmutableSortedMultiset
ImmutableSortedMultiset.orderedBy ( Comparator comparator ) [static]  :  ImmutableSortedMultiset.Builder
ImmutableSortedMultiset.pollFirstEntry ( )  :  Multiset.Entry *DEPRECATED*
ImmutableSortedMultiset.pollLastEntry ( )  :  Multiset.Entry *DEPRECATED*
ImmutableSortedMultiset.reverseOrder ( ) [static]  :  ImmutableSortedMultiset.Builder
ImmutableSortedMultiset.subMultiset ( Object lowerBound, BoundType lowerBoundType, Object upperBound, BoundType upperBoundType )  :  ImmutableSortedMultiset
ImmutableSortedMultiset.subMultiset ( Object x0, BoundType x1, Object x2, BoundType x3 )  :  SortedMultiset
ImmutableSortedMultiset.tailMultiset ( Object p1, BoundType p2 ) [abstract]  :  ImmutableSortedMultiset
ImmutableSortedMultiset.tailMultiset ( Object x0, BoundType x1 )  :  SortedMultiset

cdk-1.5.3.jar, ImmutableSortedSet.class
package com.google.common.collect
ImmutableSortedSet.ceiling ( Object e )  :  Object
ImmutableSortedSet.comparator ( )  :  Comparator
ImmutableSortedSet.copyOf ( Collection elements ) [static]  :  ImmutableSortedSet
ImmutableSortedSet.copyOf ( Comparable[ ] elements ) [static]  :  ImmutableSortedSet
ImmutableSortedSet.copyOf ( Comparator comparator, Collection elements ) [static]  :  ImmutableSortedSet
ImmutableSortedSet.copyOf ( Comparator comparator, Iterable elements ) [static]  :  ImmutableSortedSet
ImmutableSortedSet.copyOf ( Comparator comparator, Iterator elements ) [static]  :  ImmutableSortedSet
ImmutableSortedSet.copyOf ( Iterable elements ) [static]  :  ImmutableSortedSet
ImmutableSortedSet.copyOf ( Iterator elements ) [static]  :  ImmutableSortedSet
ImmutableSortedSet.copyOfSorted ( SortedSet sortedSet ) [static]  :  ImmutableSortedSet
ImmutableSortedSet.descendingIterator ( )  :  Iterator
ImmutableSortedSet.descendingIterator ( ) [abstract]  :  UnmodifiableIterator
ImmutableSortedSet.descendingSet ( )  :  ImmutableSortedSet
ImmutableSortedSet.descendingSet ( )  :  NavigableSet
ImmutableSortedSet.first ( )  :  Object
ImmutableSortedSet.floor ( Object e )  :  Object
ImmutableSortedSet.headSet ( Object toElement )  :  ImmutableSortedSet
ImmutableSortedSet.headSet ( Object toElement, boolean inclusive )  :  ImmutableSortedSet
ImmutableSortedSet.headSet ( Object x0 )  :  SortedSet
ImmutableSortedSet.headSet ( Object x0, boolean x1 )  :  NavigableSet
ImmutableSortedSet.higher ( Object e )  :  Object
ImmutableSortedSet.iterator ( )  :  Iterator
ImmutableSortedSet.iterator ( ) [abstract]  :  UnmodifiableIterator
ImmutableSortedSet.last ( )  :  Object
ImmutableSortedSet.lower ( Object e )  :  Object
ImmutableSortedSet.naturalOrder ( ) [static]  :  ImmutableSortedSet.Builder
ImmutableSortedSet.of ( ) [static]  :  ImmutableSortedSet
ImmutableSortedSet.of ( Comparable e1, Comparable e2 ) [static]  :  ImmutableSortedSet
ImmutableSortedSet.of ( Comparable e1, Comparable e2, Comparable e3 ) [static]  :  ImmutableSortedSet
ImmutableSortedSet.of ( Comparable e1, Comparable e2, Comparable e3, Comparable e4 ) [static]  :  ImmutableSortedSet
ImmutableSortedSet.of ( Comparable e1, Comparable e2, Comparable e3, Comparable e4, Comparable e5 ) [static]  :  ImmutableSortedSet
ImmutableSortedSet.of ( Comparable e1, Comparable e2, Comparable e3, Comparable e4, Comparable e5, Comparable e6, Comparable[ ] remaining ) [static]  :  ImmutableSortedSet
ImmutableSortedSet.of ( Comparable element ) [static]  :  ImmutableSortedSet
ImmutableSortedSet.orderedBy ( Comparator comparator ) [static]  :  ImmutableSortedSet.Builder
ImmutableSortedSet.pollFirst ( )  :  Object *DEPRECATED*
ImmutableSortedSet.pollLast ( )  :  Object *DEPRECATED*
ImmutableSortedSet.reverseOrder ( ) [static]  :  ImmutableSortedSet.Builder
ImmutableSortedSet.subSet ( Object fromElement, boolean fromInclusive, Object toElement, boolean toInclusive )  :  ImmutableSortedSet
ImmutableSortedSet.subSet ( Object fromElement, Object toElement )  :  ImmutableSortedSet
ImmutableSortedSet.subSet ( Object x0, boolean x1, Object x2, boolean x3 )  :  NavigableSet
ImmutableSortedSet.subSet ( Object x0, Object x1 )  :  SortedSet
ImmutableSortedSet.tailSet ( Object fromElement )  :  ImmutableSortedSet
ImmutableSortedSet.tailSet ( Object fromElement, boolean inclusive )  :  ImmutableSortedSet
ImmutableSortedSet.tailSet ( Object x0 )  :  SortedSet
ImmutableSortedSet.tailSet ( Object x0, boolean x1 )  :  NavigableSet

cdk-1.5.3.jar, ImmutableTable.class
package com.google.common.collect
ImmutableTable.builder ( ) [static]  :  ImmutableTable.Builder
ImmutableTable.cellSet ( )  :  Set
ImmutableTable.cellSet ( ) [abstract]  :  ImmutableSet
ImmutableTable.clear ( )  :  void *DEPRECATED*
ImmutableTable.column ( Object p1 ) [abstract]  :  ImmutableMap
ImmutableTable.column ( Object x0 )  :  Map
ImmutableTable.columnKeySet ( )  :  Set
ImmutableTable.columnKeySet ( ) [abstract]  :  ImmutableSet
ImmutableTable.columnMap ( )  :  Map
ImmutableTable.columnMap ( ) [abstract]  :  ImmutableMap
ImmutableTable.copyOf ( Table table ) [static]  :  ImmutableTable
ImmutableTable.equals ( Object obj )  :  boolean
ImmutableTable.hashCode ( )  :  int
ImmutableTable.of ( ) [static]  :  ImmutableTable
ImmutableTable.of ( Object rowKey, Object columnKey, Object value ) [static]  :  ImmutableTable
ImmutableTable.put ( Object rowKey, Object columnKey, Object value )  :  Object *DEPRECATED*
ImmutableTable.putAll ( Table table )  :  void *DEPRECATED*
ImmutableTable.remove ( Object rowKey, Object columnKey )  :  Object *DEPRECATED*
ImmutableTable.row ( Object p1 ) [abstract]  :  ImmutableMap
ImmutableTable.row ( Object x0 )  :  Map
ImmutableTable.rowKeySet ( )  :  Set
ImmutableTable.rowKeySet ( ) [abstract]  :  ImmutableSet
ImmutableTable.rowMap ( )  :  Map
ImmutableTable.rowMap ( ) [abstract]  :  ImmutableMap
ImmutableTable.toString ( )  :  String

cdk-1.5.3.jar, ImmutableTypeToInstanceMap.class
package com.google.common.reflect
ImmutableTypeToInstanceMap.builder ( ) [static]  :  ImmutableTypeToInstanceMap.Builder
ImmutableTypeToInstanceMap.delegate ( )  :  Map
ImmutableTypeToInstanceMap.delegate ( )  :  Object
ImmutableTypeToInstanceMap.getInstance ( Class type )  :  Object
ImmutableTypeToInstanceMap.getInstance ( TypeToken type )  :  Object
ImmutableTypeToInstanceMap.of ( ) [static]  :  ImmutableTypeToInstanceMap
ImmutableTypeToInstanceMap.putInstance ( Class type, Object value )  :  Object
ImmutableTypeToInstanceMap.putInstance ( TypeToken type, Object value )  :  Object

cdk-1.5.3.jar, InetAddresses.class
package com.google.common.net
InetAddresses.coerceToInteger ( InetAddress ip ) [static]  :  int
InetAddresses.forString ( String ipString ) [static]  :  InetAddress
InetAddresses.forUriString ( String hostAddr ) [static]  :  InetAddress
InetAddresses.fromInteger ( int address ) [static]  :  Inet4Address
InetAddresses.fromLittleEndianByteArray ( byte[ ] addr ) [static]  :  InetAddress
InetAddresses.get6to4IPv4Address ( Inet6Address ip ) [static]  :  Inet4Address
InetAddresses.getCoercedIPv4Address ( InetAddress ip ) [static]  :  Inet4Address
InetAddresses.getCompatIPv4Address ( Inet6Address ip ) [static]  :  Inet4Address
InetAddresses.getEmbeddedIPv4ClientAddress ( Inet6Address ip ) [static]  :  Inet4Address
InetAddresses.getIsatapIPv4Address ( Inet6Address ip ) [static]  :  Inet4Address
InetAddresses.getTeredoInfo ( Inet6Address ip ) [static]  :  InetAddresses.TeredoInfo
InetAddresses.hasEmbeddedIPv4ClientAddress ( Inet6Address ip ) [static]  :  boolean
InetAddresses.increment ( InetAddress address ) [static]  :  InetAddress
InetAddresses.is6to4Address ( Inet6Address ip ) [static]  :  boolean
InetAddresses.isCompatIPv4Address ( Inet6Address ip ) [static]  :  boolean
InetAddresses.isInetAddress ( String ipString ) [static]  :  boolean
InetAddresses.isIsatapAddress ( Inet6Address ip ) [static]  :  boolean
InetAddresses.isMappedIPv4Address ( String ipString ) [static]  :  boolean
InetAddresses.isMaximum ( InetAddress address ) [static]  :  boolean
InetAddresses.isTeredoAddress ( Inet6Address ip ) [static]  :  boolean
InetAddresses.isUriInetAddress ( String ipString ) [static]  :  boolean
InetAddresses.toAddrString ( InetAddress ip ) [static]  :  String
InetAddresses.toUriString ( InetAddress ip ) [static]  :  String

cdk-1.5.3.jar, InputSupplier.class
package com.google.common.io
InputSupplier.getInput ( ) [abstract]  :  Object

cdk-1.5.3.jar, Interner.class
package com.google.common.collect
Interner.intern ( Object p1 ) [abstract]  :  Object

cdk-1.5.3.jar, Interners.class
package com.google.common.collect
Interners.asFunction ( Interner interner ) [static]  :  Function
Interners.newStrongInterner ( ) [static]  :  Interner
Interners.newWeakInterner ( ) [static]  :  Interner

cdk-1.5.3.jar, InternetDomainName.class
package com.google.common.net
InternetDomainName.child ( String leftParts )  :  InternetDomainName
InternetDomainName.equals ( Object object )  :  boolean
InternetDomainName.from ( String domain ) [static]  :  InternetDomainName
InternetDomainName.fromLenient ( String domain ) [static]  :  InternetDomainName *DEPRECATED*
InternetDomainName.hashCode ( )  :  int
InternetDomainName.hasParent ( )  :  boolean
InternetDomainName.hasPublicSuffix ( )  :  boolean
InternetDomainName.isPublicSuffix ( )  :  boolean
InternetDomainName.isTopPrivateDomain ( )  :  boolean
InternetDomainName.isUnderPublicSuffix ( )  :  boolean
InternetDomainName.isValid ( String name ) [static]  :  boolean
InternetDomainName.isValidLenient ( String name ) [static]  :  boolean *DEPRECATED*
InternetDomainName.name ( )  :  String
InternetDomainName.parent ( )  :  InternetDomainName
InternetDomainName.parts ( )  :  ImmutableList
InternetDomainName.publicSuffix ( )  :  InternetDomainName
InternetDomainName.topPrivateDomain ( )  :  InternetDomainName
InternetDomainName.toString ( )  :  String

cdk-1.5.3.jar, IntMath.class
package com.google.common.math
IntMath.binomial ( int n, int k ) [static]  :  int
IntMath.checkedAdd ( int a, int b ) [static]  :  int
IntMath.checkedMultiply ( int a, int b ) [static]  :  int
IntMath.checkedPow ( int b, int k ) [static]  :  int
IntMath.checkedSubtract ( int a, int b ) [static]  :  int
IntMath.divide ( int p, int q, RoundingMode mode ) [static]  :  int
IntMath.factorial ( int n ) [static]  :  int
IntMath.gcd ( int a, int b ) [static]  :  int
IntMath.isPowerOfTwo ( int x ) [static]  :  boolean
IntMath.log10 ( int x, RoundingMode mode ) [static]  :  int
IntMath.log2 ( int x, RoundingMode mode ) [static]  :  int
IntMath.mean ( int x, int y ) [static]  :  int
IntMath.mod ( int x, int m ) [static]  :  int
IntMath.pow ( int b, int k ) [static]  :  int
IntMath.sqrt ( int x, RoundingMode mode ) [static]  :  int

cdk-1.5.3.jar, Ints.class
package com.google.common.primitives
Ints.asList ( int[ ] backingArray ) [static]  :  List
Ints.checkedCast ( long value ) [static]  :  int
Ints.compare ( int a, int b ) [static]  :  int
Ints.concat ( int[ ][ ] arrays ) [static]  :  int[ ]
Ints.contains ( int[ ] array, int target ) [static]  :  boolean
Ints.ensureCapacity ( int[ ] array, int minLength, int padding ) [static]  :  int[ ]
Ints.fromByteArray ( byte[ ] bytes ) [static]  :  int
Ints.fromBytes ( byte b1, byte b2, byte b3, byte b4 ) [static]  :  int
Ints.hashCode ( int value ) [static]  :  int
Ints.indexOf ( int[ ] array, int target ) [static]  :  int
Ints.indexOf ( int[ ] array, int[ ] target ) [static]  :  int
Ints.join ( String separator, int[ ] array ) [static]  :  String
Ints.lastIndexOf ( int[ ] array, int target ) [static]  :  int
Ints.lexicographicalComparator ( ) [static]  :  Comparator
Ints.max ( int[ ] array ) [static]  :  int
Ints.min ( int[ ] array ) [static]  :  int
Ints.saturatedCast ( long value ) [static]  :  int
Ints.toArray ( Collection collection ) [static]  :  int[ ]
Ints.toByteArray ( int value ) [static]  :  byte[ ]
Ints.tryParse ( String string ) [static]  :  Integer

cdk-1.5.3.jar, InvalidCacheLoadException.class
package com.google.common.cache
CacheLoader.InvalidCacheLoadException.CacheLoader.InvalidCacheLoadException ( String message )

cdk-1.5.3.jar, Invokable.class
package com.google.common.reflect
Invokable.equals ( Object x0 )  :  boolean
Invokable.from ( Constructor constructor ) [static]  :  Invokable
Invokable.from ( Method method ) [static]  :  Invokable
Invokable.getDeclaringClass ( )  :  Class
Invokable.getExceptionTypes ( )  :  ImmutableList
Invokable.getOwnerType ( )  :  TypeToken
Invokable.getParameters ( )  :  ImmutableList
Invokable.getReturnType ( )  :  TypeToken
Invokable.hashCode ( )  :  int
Invokable.invoke ( Object receiver, Object[ ] args )  :  Object
Invokable.isOverridable ( ) [abstract]  :  boolean
Invokable.isVarArgs ( ) [abstract]  :  boolean
Invokable.returning ( Class returnType )  :  Invokable
Invokable.returning ( TypeToken returnType )  :  Invokable
Invokable.toString ( )  :  String

cdk-1.5.3.jar, IsotopeFactory.class
package org.openscience.cdk.config
IsotopeFactory.getIsotopes ( )  :  IIsotope[ ]
IsotopeFactory.getIsotopes ( double exactMass, double difference )  :  IIsotope[ ]

cdk-1.5.3.jar, Iterables.class
package com.google.common.collect
Iterables.addAll ( Collection addTo, Iterable elementsToAdd ) [static]  :  boolean
Iterables.all ( Iterable iterable, Predicate predicate ) [static]  :  boolean
Iterables.any ( Iterable iterable, Predicate predicate ) [static]  :  boolean
Iterables.concat ( Iterable a, Iterable b ) [static]  :  Iterable
Iterables.concat ( Iterable a, Iterable b, Iterable c ) [static]  :  Iterable
Iterables.concat ( Iterable a, Iterable b, Iterable c, Iterable d ) [static]  :  Iterable
Iterables.concat ( Iterable inputs ) [static]  :  Iterable
Iterables.concat ( Iterable[ ] inputs ) [static]  :  Iterable
Iterables.consumingIterable ( Iterable iterable ) [static]  :  Iterable
Iterables.contains ( Iterable iterable, Object element ) [static]  :  boolean
Iterables.cycle ( Iterable iterable ) [static]  :  Iterable
Iterables.cycle ( Object[ ] elements ) [static]  :  Iterable
Iterables.elementsEqual ( Iterable iterable1, Iterable iterable2 ) [static]  :  boolean
Iterables.filter ( Iterable unfiltered, Class type ) [static]  :  Iterable
Iterables.filter ( Iterable unfiltered, Predicate predicate ) [static]  :  Iterable
Iterables.find ( Iterable iterable, Predicate predicate ) [static]  :  Object
Iterables.find ( Iterable iterable, Predicate predicate, Object defaultValue ) [static]  :  Object
Iterables.frequency ( Iterable iterable, Object element ) [static]  :  int
Iterables.get ( Iterable iterable, int position ) [static]  :  Object
Iterables.get ( Iterable iterable, int position, Object defaultValue ) [static]  :  Object
Iterables.getFirst ( Iterable iterable, Object defaultValue ) [static]  :  Object
Iterables.getLast ( Iterable iterable ) [static]  :  Object
Iterables.getLast ( Iterable iterable, Object defaultValue ) [static]  :  Object
Iterables.getOnlyElement ( Iterable iterable ) [static]  :  Object
Iterables.getOnlyElement ( Iterable iterable, Object defaultValue ) [static]  :  Object
Iterables.indexOf ( Iterable iterable, Predicate predicate ) [static]  :  int
Iterables.isEmpty ( Iterable iterable ) [static]  :  boolean
Iterables.limit ( Iterable iterable, int limitSize ) [static]  :  Iterable
Iterables.mergeSorted ( Iterable iterables, Comparator comparator ) [static]  :  Iterable
Iterables.paddedPartition ( Iterable iterable, int size ) [static]  :  Iterable
Iterables.partition ( Iterable iterable, int size ) [static]  :  Iterable
Iterables.removeAll ( Iterable removeFrom, Collection elementsToRemove ) [static]  :  boolean
Iterables.removeIf ( Iterable removeFrom, Predicate predicate ) [static]  :  boolean
Iterables.retainAll ( Iterable removeFrom, Collection elementsToRetain ) [static]  :  boolean
Iterables.size ( Iterable iterable ) [static]  :  int
Iterables.skip ( Iterable iterable, int numberToSkip ) [static]  :  Iterable
Iterables.toArray ( Iterable iterable, Class type ) [static]  :  Object[ ]
Iterables.toString ( Iterable iterable ) [static]  :  String
Iterables.transform ( Iterable fromIterable, Function function ) [static]  :  Iterable
Iterables.tryFind ( Iterable iterable, Predicate predicate ) [static]  :  Optional
Iterables.unmodifiableIterable ( ImmutableCollection iterable ) [static]  :  Iterable *DEPRECATED*
Iterables.unmodifiableIterable ( Iterable iterable ) [static]  :  Iterable

cdk-1.5.3.jar, Iterators.class
package com.google.common.collect
Iterators.addAll ( Collection addTo, Iterator iterator ) [static]  :  boolean
Iterators.advance ( Iterator iterator, int numberToAdvance ) [static]  :  int
Iterators.all ( Iterator iterator, Predicate predicate ) [static]  :  boolean
Iterators.any ( Iterator iterator, Predicate predicate ) [static]  :  boolean
Iterators.asEnumeration ( Iterator iterator ) [static]  :  Enumeration
Iterators.concat ( Iterator a, Iterator b ) [static]  :  Iterator
Iterators.concat ( Iterator a, Iterator b, Iterator c ) [static]  :  Iterator
Iterators.concat ( Iterator a, Iterator b, Iterator c, Iterator d ) [static]  :  Iterator
Iterators.concat ( Iterator inputs ) [static]  :  Iterator
Iterators.concat ( Iterator[ ] inputs ) [static]  :  Iterator
Iterators.consumingIterator ( Iterator iterator ) [static]  :  Iterator
Iterators.contains ( Iterator iterator, Object element ) [static]  :  boolean
Iterators.cycle ( Iterable iterable ) [static]  :  Iterator
Iterators.cycle ( Object[ ] elements ) [static]  :  Iterator
Iterators.elementsEqual ( Iterator iterator1, Iterator iterator2 ) [static]  :  boolean
Iterators.emptyIterator ( ) [static]  :  UnmodifiableIterator
Iterators.filter ( Iterator unfiltered, Class type ) [static]  :  UnmodifiableIterator
Iterators.filter ( Iterator unfiltered, Predicate predicate ) [static]  :  UnmodifiableIterator
Iterators.find ( Iterator iterator, Predicate predicate ) [static]  :  Object
Iterators.find ( Iterator iterator, Predicate predicate, Object defaultValue ) [static]  :  Object
Iterators.forArray ( Object[ ] array ) [static]  :  UnmodifiableIterator
Iterators.forEnumeration ( Enumeration enumeration ) [static]  :  UnmodifiableIterator
Iterators.frequency ( Iterator iterator, Object element ) [static]  :  int
Iterators.get ( Iterator iterator, int position ) [static]  :  Object
Iterators.get ( Iterator iterator, int position, Object defaultValue ) [static]  :  Object
Iterators.getLast ( Iterator iterator ) [static]  :  Object
Iterators.getLast ( Iterator iterator, Object defaultValue ) [static]  :  Object
Iterators.getNext ( Iterator iterator, Object defaultValue ) [static]  :  Object
Iterators.getOnlyElement ( Iterator iterator ) [static]  :  Object
Iterators.getOnlyElement ( Iterator iterator, Object defaultValue ) [static]  :  Object
Iterators.indexOf ( Iterator iterator, Predicate predicate ) [static]  :  int
Iterators.limit ( Iterator iterator, int limitSize ) [static]  :  Iterator
Iterators.mergeSorted ( Iterable iterators, Comparator comparator ) [static]  :  UnmodifiableIterator
Iterators.paddedPartition ( Iterator iterator, int size ) [static]  :  UnmodifiableIterator
Iterators.partition ( Iterator iterator, int size ) [static]  :  UnmodifiableIterator
Iterators.peekingIterator ( Iterator iterator ) [static]  :  PeekingIterator
Iterators.peekingIterator ( PeekingIterator iterator ) [static]  :  PeekingIterator *DEPRECATED*
Iterators.removeAll ( Iterator removeFrom, Collection elementsToRemove ) [static]  :  boolean
Iterators.removeIf ( Iterator removeFrom, Predicate predicate ) [static]  :  boolean
Iterators.retainAll ( Iterator removeFrom, Collection elementsToRetain ) [static]  :  boolean
Iterators.singletonIterator ( Object value ) [static]  :  UnmodifiableIterator
Iterators.size ( Iterator iterator ) [static]  :  int
Iterators.toArray ( Iterator iterator, Class type ) [static]  :  Object[ ]
Iterators.toString ( Iterator iterator ) [static]  :  String
Iterators.transform ( Iterator fromIterator, Function function ) [static]  :  Iterator
Iterators.tryFind ( Iterator iterator, Predicate predicate ) [static]  :  Optional
Iterators.unmodifiableIterator ( Iterator iterator ) [static]  :  UnmodifiableIterator
Iterators.unmodifiableIterator ( UnmodifiableIterator iterator ) [static]  :  UnmodifiableIterator *DEPRECATED*

cdk-1.5.3.jar, JdkFutureAdapters.class
package com.google.common.util.concurrent
JdkFutureAdapters.listenInPoolThread ( Future future ) [static]  :  ListenableFuture
JdkFutureAdapters.listenInPoolThread ( Future future, Executor executor ) [static]  :  ListenableFuture

cdk-1.5.3.jar, Joiner.class
package com.google.common.base
Joiner.appendTo ( Appendable appendable, Iterable parts )  :  Appendable
Joiner.appendTo ( Appendable appendable, Iterator parts )  :  Appendable
Joiner.appendTo ( Appendable appendable, Object first, Object second, Object[ ] rest )  :  Appendable
Joiner.appendTo ( Appendable appendable, Object parts )  :  Appendable *DEPRECATED*
Joiner.appendTo ( Appendable appendable, Object[ ] parts )  :  Appendable
Joiner.appendTo ( StringBuilder builder, Iterable parts )  :  StringBuilder
Joiner.appendTo ( StringBuilder builder, Iterator parts )  :  StringBuilder
Joiner.appendTo ( StringBuilder builder, Object first, Object second, Object[ ] rest )  :  StringBuilder
Joiner.appendTo ( StringBuilder builder, Object parts )  :  StringBuilder *DEPRECATED*
Joiner.appendTo ( StringBuilder builder, Object[ ] parts )  :  StringBuilder
Joiner.join ( Iterable parts )  :  String
Joiner.join ( Iterator parts )  :  String
Joiner.join ( Object first, Object second, Object[ ] rest )  :  String
Joiner.join ( Object parts )  :  String *DEPRECATED*
Joiner.join ( Object[ ] parts )  :  String
Joiner.on ( char separator ) [static]  :  Joiner
Joiner.on ( String separator ) [static]  :  Joiner
Joiner.skipNulls ( )  :  Joiner
Joiner.useForNull ( String nullText )  :  Joiner
Joiner.withKeyValueSeparator ( String keyValueSeparator )  :  Joiner.MapJoiner

cdk-1.5.3.jar, KeyAbsentBehavior.class
package com.google.common.collect
SortedLists.KeyAbsentBehavior.valueOf ( String name ) [static]  :  SortedLists.KeyAbsentBehavior
SortedLists.KeyAbsentBehavior.values ( ) [static]  :  SortedLists.KeyAbsentBehavior[ ]

cdk-1.5.3.jar, KeyPresentBehavior.class
package com.google.common.collect
SortedLists.KeyPresentBehavior.valueOf ( String name ) [static]  :  SortedLists.KeyPresentBehavior
SortedLists.KeyPresentBehavior.values ( ) [static]  :  SortedLists.KeyPresentBehavior[ ]

cdk-1.5.3.jar, LimitInputStream.class
package com.google.common.io
LimitInputStream.available ( )  :  int
LimitInputStream.LimitInputStream ( InputStream in, long limit )
LimitInputStream.mark ( int readlimit )  :  void
LimitInputStream.read ( )  :  int
LimitInputStream.read ( byte[ ] b, int off, int len )  :  int
LimitInputStream.reset ( )  :  void
LimitInputStream.skip ( long n )  :  long

cdk-1.5.3.jar, LineProcessor.class
package com.google.common.io
LineProcessor.getResult ( ) [abstract]  :  Object
LineProcessor.processLine ( String p1 ) [abstract]  :  boolean

cdk-1.5.3.jar, LineReader.class
package com.google.common.io
LineReader.LineReader ( Readable readable )
LineReader.readLine ( )  :  String

cdk-1.5.3.jar, LinkedHashMultimap.class
package com.google.common.collect
LinkedHashMultimap.asMap ( )  :  Map
LinkedHashMultimap.clear ( )  :  void
LinkedHashMultimap.containsEntry ( Object x0, Object x1 )  :  boolean
LinkedHashMultimap.containsKey ( Object x0 )  :  boolean
LinkedHashMultimap.containsValue ( Object x0 )  :  boolean
LinkedHashMultimap.create ( ) [static]  :  LinkedHashMultimap
LinkedHashMultimap.create ( int expectedKeys, int expectedValuesPerKey ) [static]  :  LinkedHashMultimap
LinkedHashMultimap.create ( Multimap multimap ) [static]  :  LinkedHashMultimap
LinkedHashMultimap.entries ( )  :  Collection
LinkedHashMultimap.entries ( )  :  Set
LinkedHashMultimap.equals ( Object x0 )  :  boolean
LinkedHashMultimap.get ( Object x0 )  :  Set
LinkedHashMultimap.hashCode ( )  :  int
LinkedHashMultimap.isEmpty ( )  :  boolean
LinkedHashMultimap.keys ( )  :  Multiset
LinkedHashMultimap.keySet ( )  :  Set
LinkedHashMultimap.put ( Object x0, Object x1 )  :  boolean
LinkedHashMultimap.putAll ( Multimap x0 )  :  boolean
LinkedHashMultimap.putAll ( Object x0, Iterable x1 )  :  boolean
LinkedHashMultimap.remove ( Object x0, Object x1 )  :  boolean
LinkedHashMultimap.removeAll ( Object x0 )  :  Set
LinkedHashMultimap.replaceValues ( Object key, Iterable values )  :  Set
LinkedHashMultimap.replaceValues ( Object x0, Iterable x1 )  :  Collection
LinkedHashMultimap.size ( )  :  int
LinkedHashMultimap.toString ( )  :  String
LinkedHashMultimap.values ( )  :  Collection

cdk-1.5.3.jar, LinkedHashMultiset.class
package com.google.common.collect
LinkedHashMultiset.add ( Object x0 )  :  boolean
LinkedHashMultiset.add ( Object x0, int x1 )  :  int
LinkedHashMultiset.addAll ( Collection x0 )  :  boolean
LinkedHashMultiset.clear ( )  :  void
LinkedHashMultiset.contains ( Object x0 )  :  boolean
LinkedHashMultiset.count ( Object x0 )  :  int
LinkedHashMultiset.create ( ) [static]  :  LinkedHashMultiset
LinkedHashMultiset.create ( int distinctElements ) [static]  :  LinkedHashMultiset
LinkedHashMultiset.create ( Iterable elements ) [static]  :  LinkedHashMultiset
LinkedHashMultiset.elementSet ( )  :  Set
LinkedHashMultiset.entrySet ( )  :  Set
LinkedHashMultiset.equals ( Object x0 )  :  boolean
LinkedHashMultiset.hashCode ( )  :  int
LinkedHashMultiset.isEmpty ( )  :  boolean
LinkedHashMultiset.iterator ( )  :  Iterator
LinkedHashMultiset.remove ( Object x0 )  :  boolean
LinkedHashMultiset.remove ( Object x0, int x1 )  :  int
LinkedHashMultiset.removeAll ( Collection x0 )  :  boolean
LinkedHashMultiset.retainAll ( Collection x0 )  :  boolean
LinkedHashMultiset.setCount ( Object x0, int x1 )  :  int
LinkedHashMultiset.setCount ( Object x0, int x1, int x2 )  :  boolean
LinkedHashMultiset.size ( )  :  int
LinkedHashMultiset.toString ( )  :  String

cdk-1.5.3.jar, LinkedListMultimap.class
package com.google.common.collect
LinkedListMultimap.asMap ( )  :  Map
LinkedListMultimap.clear ( )  :  void
LinkedListMultimap.containsEntry ( Object key, Object value )  :  boolean
LinkedListMultimap.containsKey ( Object key )  :  boolean
LinkedListMultimap.containsValue ( Object value )  :  boolean
LinkedListMultimap.create ( ) [static]  :  LinkedListMultimap
LinkedListMultimap.create ( int expectedKeys ) [static]  :  LinkedListMultimap
LinkedListMultimap.create ( Multimap multimap ) [static]  :  LinkedListMultimap
LinkedListMultimap.entries ( )  :  Collection
LinkedListMultimap.entries ( )  :  List
LinkedListMultimap.equals ( Object other )  :  boolean
LinkedListMultimap.get ( Object key )  :  List
LinkedListMultimap.get ( Object x0 )  :  Collection
LinkedListMultimap.hashCode ( )  :  int
LinkedListMultimap.isEmpty ( )  :  boolean
LinkedListMultimap.keys ( )  :  Multiset
LinkedListMultimap.keySet ( )  :  Set
LinkedListMultimap.put ( Object key, Object value )  :  boolean
LinkedListMultimap.putAll ( Multimap multimap )  :  boolean
LinkedListMultimap.putAll ( Object key, Iterable values )  :  boolean
LinkedListMultimap.remove ( Object key, Object value )  :  boolean
LinkedListMultimap.removeAll ( Object key )  :  List
LinkedListMultimap.removeAll ( Object x0 )  :  Collection
LinkedListMultimap.replaceValues ( Object key, Iterable values )  :  List
LinkedListMultimap.replaceValues ( Object x0, Iterable x1 )  :  Collection
LinkedListMultimap.size ( )  :  int
LinkedListMultimap.toString ( )  :  String
LinkedListMultimap.values ( )  :  Collection
LinkedListMultimap.values ( )  :  List

cdk-1.5.3.jar, ListenableFuture.class
package com.google.common.util.concurrent
ListenableFuture.addListener ( Runnable p1, Executor p2 ) [abstract]  :  void

cdk-1.5.3.jar, ListenableFutureTask.class
package com.google.common.util.concurrent
ListenableFutureTask.addListener ( Runnable listener, Executor exec )  :  void
ListenableFutureTask.create ( Callable callable ) [static]  :  ListenableFutureTask
ListenableFutureTask.create ( Runnable runnable, Object result ) [static]  :  ListenableFutureTask
ListenableFutureTask.done ( )  :  void

cdk-1.5.3.jar, Listener.class
package com.google.common.util.concurrent
Service.Listener.failed ( Service.State p1, Throwable p2 ) [abstract]  :  void
Service.Listener.running ( ) [abstract]  :  void
Service.Listener.starting ( ) [abstract]  :  void
Service.Listener.stopping ( Service.State p1 ) [abstract]  :  void
Service.Listener.terminated ( Service.State p1 ) [abstract]  :  void
ServiceManager.Listener.failure ( Service p1 ) [abstract]  :  void
ServiceManager.Listener.healthy ( ) [abstract]  :  void
ServiceManager.Listener.stopped ( ) [abstract]  :  void

cdk-1.5.3.jar, ListeningExecutorService.class
package com.google.common.util.concurrent
ListeningExecutorService.invokeAll ( Collection p1 ) [abstract]  :  List
ListeningExecutorService.invokeAll ( Collection p1, long p2, TimeUnit p3 ) [abstract]  :  List
ListeningExecutorService.submit ( Callable p1 ) [abstract]  :  ListenableFuture
ListeningExecutorService.submit ( Runnable p1 ) [abstract]  :  ListenableFuture
ListeningExecutorService.submit ( Runnable p1, Object p2 ) [abstract]  :  ListenableFuture

cdk-1.5.3.jar, ListMultimap.class
package com.google.common.collect
ListMultimap.asMap ( ) [abstract]  :  Map
ListMultimap.equals ( Object p1 ) [abstract]  :  boolean
ListMultimap.get ( Object p1 ) [abstract]  :  List
ListMultimap.removeAll ( Object p1 ) [abstract]  :  List
ListMultimap.replaceValues ( Object p1, Iterable p2 ) [abstract]  :  List

cdk-1.5.3.jar, Lists.class
package com.google.common.collect
Lists.asList ( Object first, Object second, Object[ ] rest ) [static]  :  List
Lists.asList ( Object first, Object[ ] rest ) [static]  :  List
Lists.charactersOf ( CharSequence sequence ) [static]  :  List
Lists.charactersOf ( String string ) [static]  :  ImmutableList
Lists.newArrayList ( ) [static]  :  ArrayList
Lists.newArrayList ( Iterable elements ) [static]  :  ArrayList
Lists.newArrayList ( Iterator elements ) [static]  :  ArrayList
Lists.newArrayList ( Object[ ] elements ) [static]  :  ArrayList
Lists.newArrayListWithCapacity ( int initialArraySize ) [static]  :  ArrayList
Lists.newArrayListWithExpectedSize ( int estimatedSize ) [static]  :  ArrayList
Lists.newCopyOnWriteArrayList ( ) [static]  :  CopyOnWriteArrayList
Lists.newCopyOnWriteArrayList ( Iterable elements ) [static]  :  CopyOnWriteArrayList
Lists.newLinkedList ( ) [static]  :  LinkedList
Lists.newLinkedList ( Iterable elements ) [static]  :  LinkedList
Lists.partition ( List list, int size ) [static]  :  List
Lists.reverse ( List list ) [static]  :  List
Lists.transform ( List fromList, Function function ) [static]  :  List

cdk-1.5.3.jar, LittleEndianDataInputStream.class
package com.google.common.io
LittleEndianDataInputStream.LittleEndianDataInputStream ( InputStream in )
LittleEndianDataInputStream.readBoolean ( )  :  boolean
LittleEndianDataInputStream.readByte ( )  :  byte
LittleEndianDataInputStream.readChar ( )  :  char
LittleEndianDataInputStream.readDouble ( )  :  double
LittleEndianDataInputStream.readFloat ( )  :  float
LittleEndianDataInputStream.readFully ( byte[ ] b )  :  void
LittleEndianDataInputStream.readFully ( byte[ ] b, int off, int len )  :  void
LittleEndianDataInputStream.readInt ( )  :  int
LittleEndianDataInputStream.readLine ( )  :  String
LittleEndianDataInputStream.readLong ( )  :  long
LittleEndianDataInputStream.readShort ( )  :  short
LittleEndianDataInputStream.readUnsignedByte ( )  :  int
LittleEndianDataInputStream.readUnsignedShort ( )  :  int
LittleEndianDataInputStream.readUTF ( )  :  String
LittleEndianDataInputStream.skipBytes ( int n )  :  int

cdk-1.5.3.jar, LittleEndianDataOutputStream.class
package com.google.common.io
LittleEndianDataOutputStream.LittleEndianDataOutputStream ( OutputStream out )
LittleEndianDataOutputStream.write ( byte[ ] b, int off, int len )  :  void
LittleEndianDataOutputStream.writeBoolean ( boolean v )  :  void
LittleEndianDataOutputStream.writeByte ( int v )  :  void
LittleEndianDataOutputStream.writeBytes ( String s )  :  void *DEPRECATED*
LittleEndianDataOutputStream.writeChar ( int v )  :  void
LittleEndianDataOutputStream.writeChars ( String s )  :  void
LittleEndianDataOutputStream.writeDouble ( double v )  :  void
LittleEndianDataOutputStream.writeFloat ( float v )  :  void
LittleEndianDataOutputStream.writeInt ( int v )  :  void
LittleEndianDataOutputStream.writeLong ( long v )  :  void
LittleEndianDataOutputStream.writeShort ( int v )  :  void
LittleEndianDataOutputStream.writeUTF ( String str )  :  void

cdk-1.5.3.jar, LoadingCache.class
package com.google.common.cache
LoadingCache.apply ( Object p1 ) [abstract]  :  Object
LoadingCache.asMap ( ) [abstract]  :  ConcurrentMap
LoadingCache.get ( Object p1 ) [abstract]  :  Object
LoadingCache.getAll ( Iterable p1 ) [abstract]  :  ImmutableMap
LoadingCache.getUnchecked ( Object p1 ) [abstract]  :  Object
LoadingCache.refresh ( Object p1 ) [abstract]  :  void

cdk-1.5.3.jar, LongMath.class
package com.google.common.math
LongMath.binomial ( int n, int k ) [static]  :  long
LongMath.checkedAdd ( long a, long b ) [static]  :  long
LongMath.checkedMultiply ( long a, long b ) [static]  :  long
LongMath.checkedPow ( long b, int k ) [static]  :  long
LongMath.checkedSubtract ( long a, long b ) [static]  :  long
LongMath.divide ( long p, long q, RoundingMode mode ) [static]  :  long
LongMath.factorial ( int n ) [static]  :  long
LongMath.gcd ( long a, long b ) [static]  :  long
LongMath.isPowerOfTwo ( long x ) [static]  :  boolean
LongMath.log10 ( long x, RoundingMode mode ) [static]  :  int
LongMath.log2 ( long x, RoundingMode mode ) [static]  :  int
LongMath.mean ( long x, long y ) [static]  :  long
LongMath.mod ( long x, int m ) [static]  :  int
LongMath.mod ( long x, long m ) [static]  :  long
LongMath.pow ( long b, int k ) [static]  :  long
LongMath.sqrt ( long x, RoundingMode mode ) [static]  :  long

cdk-1.5.3.jar, Longs.class
package com.google.common.primitives
Longs.asList ( long[ ] backingArray ) [static]  :  List
Longs.compare ( long a, long b ) [static]  :  int
Longs.concat ( long[ ][ ] arrays ) [static]  :  long[ ]
Longs.contains ( long[ ] array, long target ) [static]  :  boolean
Longs.ensureCapacity ( long[ ] array, int minLength, int padding ) [static]  :  long[ ]
Longs.fromByteArray ( byte[ ] bytes ) [static]  :  long
Longs.fromBytes ( byte b1, byte b2, byte b3, byte b4, byte b5, byte b6, byte b7, byte b8 ) [static]  :  long
Longs.hashCode ( long value ) [static]  :  int
Longs.indexOf ( long[ ] array, long target ) [static]  :  int
Longs.indexOf ( long[ ] array, long[ ] target ) [static]  :  int
Longs.join ( String separator, long[ ] array ) [static]  :  String
Longs.lastIndexOf ( long[ ] array, long target ) [static]  :  int
Longs.lexicographicalComparator ( ) [static]  :  Comparator
Longs.max ( long[ ] array ) [static]  :  long
Longs.min ( long[ ] array ) [static]  :  long
Longs.toArray ( Collection collection ) [static]  :  long[ ]
Longs.toByteArray ( long value ) [static]  :  byte[ ]
Longs.tryParse ( String string ) [static]  :  Long

cdk-1.5.3.jar, MapConstraint.class
package com.google.common.collect
MapConstraint.checkKeyValue ( Object p1, Object p2 ) [abstract]  :  void
MapConstraint.toString ( ) [abstract]  :  String

cdk-1.5.3.jar, MapConstraints.class
package com.google.common.collect
MapConstraints.constrainedBiMap ( BiMap map, MapConstraint constraint ) [static]  :  BiMap
MapConstraints.constrainedListMultimap ( ListMultimap multimap, MapConstraint constraint ) [static]  :  ListMultimap
MapConstraints.constrainedMap ( Map map, MapConstraint constraint ) [static]  :  Map
MapConstraints.constrainedMultimap ( Multimap multimap, MapConstraint constraint ) [static]  :  Multimap
MapConstraints.constrainedSetMultimap ( SetMultimap multimap, MapConstraint constraint ) [static]  :  SetMultimap
MapConstraints.constrainedSortedSetMultimap ( SortedSetMultimap multimap, MapConstraint constraint ) [static]  :  SortedSetMultimap
MapConstraints.notNull ( ) [static]  :  MapConstraint

cdk-1.5.3.jar, MapDifference.class
package com.google.common.collect
MapDifference.areEqual ( ) [abstract]  :  boolean
MapDifference.entriesDiffering ( ) [abstract]  :  Map
MapDifference.entriesInCommon ( ) [abstract]  :  Map
MapDifference.entriesOnlyOnLeft ( ) [abstract]  :  Map
MapDifference.entriesOnlyOnRight ( ) [abstract]  :  Map
MapDifference.equals ( Object p1 ) [abstract]  :  boolean
MapDifference.hashCode ( ) [abstract]  :  int

cdk-1.5.3.jar, MapJoiner.class
package com.google.common.base
Joiner.MapJoiner.appendTo ( Appendable appendable, Iterable entries )  :  Appendable
Joiner.MapJoiner.appendTo ( Appendable appendable, Iterator parts )  :  Appendable
Joiner.MapJoiner.appendTo ( Appendable appendable, Map map )  :  Appendable
Joiner.MapJoiner.appendTo ( Appendable appendable, Object entries )  :  Appendable *DEPRECATED*
Joiner.MapJoiner.appendTo ( StringBuilder builder, Iterable entries )  :  StringBuilder
Joiner.MapJoiner.appendTo ( StringBuilder builder, Iterator entries )  :  StringBuilder
Joiner.MapJoiner.appendTo ( StringBuilder builder, Map map )  :  StringBuilder
Joiner.MapJoiner.appendTo ( StringBuilder builder, Object entries )  :  StringBuilder *DEPRECATED*
Joiner.MapJoiner.join ( Iterable entries )  :  String
Joiner.MapJoiner.join ( Iterator entries )  :  String
Joiner.MapJoiner.join ( Map map )  :  String
Joiner.MapJoiner.join ( Object entries )  :  String *DEPRECATED*
Joiner.MapJoiner.useForNull ( String nullText )  :  Joiner.MapJoiner

cdk-1.5.3.jar, MapMaker.class
package com.google.common.collect
MapMaker.concurrencyLevel ( int concurrencyLevel )  :  MapMaker
MapMaker.concurrencyLevel ( int x0 )  :  GenericMapMaker
MapMaker.initialCapacity ( int initialCapacity )  :  MapMaker
MapMaker.initialCapacity ( int x0 )  :  GenericMapMaker
MapMaker.makeComputingMap ( Function computingFunction )  :  ConcurrentMap *DEPRECATED*
MapMaker.makeMap ( )  :  ConcurrentMap
MapMaker.MapMaker ( )
MapMaker.softValues ( )  :  GenericMapMaker
MapMaker.softValues ( )  :  MapMaker
MapMaker.toString ( )  :  String
MapMaker.weakKeys ( )  :  GenericMapMaker
MapMaker.weakKeys ( )  :  MapMaker
MapMaker.weakValues ( )  :  GenericMapMaker
MapMaker.weakValues ( )  :  MapMaker

cdk-1.5.3.jar, Maps.class
package com.google.common.collect
Maps.asMap ( NavigableSet set, Function function ) [static]  :  NavigableMap
Maps.asMap ( Set set, Function function ) [static]  :  Map
Maps.asMap ( SortedSet set, Function function ) [static]  :  SortedMap
Maps.difference ( Map left, Map right ) [static]  :  MapDifference
Maps.difference ( Map left, Map right, Equivalence valueEquivalence ) [static]  :  MapDifference
Maps.difference ( SortedMap left, Map right ) [static]  :  SortedMapDifference
Maps.filterEntries ( BiMap unfiltered, Predicate entryPredicate ) [static]  :  BiMap
Maps.filterEntries ( Map unfiltered, Predicate entryPredicate ) [static]  :  Map
Maps.filterEntries ( NavigableMap unfiltered, Predicate entryPredicate ) [static]  :  NavigableMap
Maps.filterEntries ( SortedMap unfiltered, Predicate entryPredicate ) [static]  :  SortedMap
Maps.filterKeys ( BiMap unfiltered, Predicate keyPredicate ) [static]  :  BiMap
Maps.filterKeys ( Map unfiltered, Predicate keyPredicate ) [static]  :  Map
Maps.filterKeys ( NavigableMap unfiltered, Predicate keyPredicate ) [static]  :  NavigableMap
Maps.filterKeys ( SortedMap unfiltered, Predicate keyPredicate ) [static]  :  SortedMap
Maps.filterValues ( BiMap unfiltered, Predicate valuePredicate ) [static]  :  BiMap
Maps.filterValues ( Map unfiltered, Predicate valuePredicate ) [static]  :  Map
Maps.filterValues ( NavigableMap unfiltered, Predicate valuePredicate ) [static]  :  NavigableMap
Maps.filterValues ( SortedMap unfiltered, Predicate valuePredicate ) [static]  :  SortedMap
Maps.fromProperties ( Properties properties ) [static]  :  ImmutableMap
Maps.immutableEntry ( Object key, Object value ) [static]  :  Map.Entry
Maps.immutableEnumMap ( Map map ) [static]  :  ImmutableMap
Maps.newConcurrentMap ( ) [static]  :  ConcurrentMap
Maps.newEnumMap ( Class type ) [static]  :  EnumMap
Maps.newEnumMap ( Map map ) [static]  :  EnumMap
Maps.newHashMap ( ) [static]  :  HashMap
Maps.newHashMap ( Map map ) [static]  :  HashMap
Maps.newHashMapWithExpectedSize ( int expectedSize ) [static]  :  HashMap
Maps.newIdentityHashMap ( ) [static]  :  IdentityHashMap
Maps.newLinkedHashMap ( ) [static]  :  LinkedHashMap
Maps.newLinkedHashMap ( Map map ) [static]  :  LinkedHashMap
Maps.newTreeMap ( ) [static]  :  TreeMap
Maps.newTreeMap ( Comparator comparator ) [static]  :  TreeMap
Maps.newTreeMap ( SortedMap map ) [static]  :  TreeMap
Maps.synchronizedBiMap ( BiMap bimap ) [static]  :  BiMap
Maps.synchronizedNavigableMap ( NavigableMap navigableMap ) [static]  :  NavigableMap
Maps.toMap ( Iterable keys, Function valueFunction ) [static]  :  ImmutableMap
Maps.toMap ( Iterator keys, Function valueFunction ) [static]  :  ImmutableMap
Maps.transformEntries ( Map fromMap, Maps.EntryTransformer transformer ) [static]  :  Map
Maps.transformEntries ( NavigableMap fromMap, Maps.EntryTransformer transformer ) [static]  :  NavigableMap
Maps.transformEntries ( SortedMap fromMap, Maps.EntryTransformer transformer ) [static]  :  SortedMap
Maps.transformValues ( Map fromMap, Function function ) [static]  :  Map
Maps.transformValues ( NavigableMap fromMap, Function function ) [static]  :  NavigableMap
Maps.transformValues ( SortedMap fromMap, Function function ) [static]  :  SortedMap
Maps.uniqueIndex ( Iterable values, Function keyFunction ) [static]  :  ImmutableMap
Maps.uniqueIndex ( Iterator values, Function keyFunction ) [static]  :  ImmutableMap
Maps.unmodifiableBiMap ( BiMap bimap ) [static]  :  BiMap
Maps.unmodifiableNavigableMap ( NavigableMap map ) [static]  :  NavigableMap

cdk-1.5.3.jar, MapSplitter.class
package com.google.common.base
Splitter.MapSplitter.split ( CharSequence sequence )  :  Map

cdk-1.5.3.jar, MediaType.class
package com.google.common.net
MediaType.charset ( )  :  Optional
MediaType.create ( String type, String subtype ) [static]  :  MediaType
MediaType.equals ( Object obj )  :  boolean
MediaType.hashCode ( )  :  int
MediaType.hasWildcard ( )  :  boolean
MediaType.is ( MediaType mediaTypeRange )  :  boolean
MediaType.parameters ( )  :  ImmutableListMultimap
MediaType.parse ( String input ) [static]  :  MediaType
MediaType.subtype ( )  :  String
MediaType.toString ( )  :  String
MediaType.type ( )  :  String
MediaType.withCharset ( Charset charset )  :  MediaType
MediaType.withoutParameters ( )  :  MediaType
MediaType.withParameter ( String attribute, String value )  :  MediaType
MediaType.withParameters ( Multimap parameters )  :  MediaType

cdk-1.5.3.jar, MinimumCycleBasis.class
package org.openscience.cdk.graph
MinimumCycleBasis.MinimumCycleBasis ( int[ ][ ] graph )
MinimumCycleBasis.paths ( )  :  int[ ][ ]
MinimumCycleBasis.size ( )  :  int

cdk-1.5.3.jar, MinMaxPriorityQueue.class
package com.google.common.collect
MinMaxPriorityQueue.add ( Object element )  :  boolean
MinMaxPriorityQueue.addAll ( Collection newElements )  :  boolean
MinMaxPriorityQueue.clear ( )  :  void
MinMaxPriorityQueue.comparator ( )  :  Comparator
MinMaxPriorityQueue.create ( ) [static]  :  MinMaxPriorityQueue
MinMaxPriorityQueue.create ( Iterable initialContents ) [static]  :  MinMaxPriorityQueue
MinMaxPriorityQueue.expectedSize ( int expectedSize ) [static]  :  MinMaxPriorityQueue.Builder
MinMaxPriorityQueue.iterator ( )  :  Iterator
MinMaxPriorityQueue.maximumSize ( int maximumSize ) [static]  :  MinMaxPriorityQueue.Builder
MinMaxPriorityQueue.offer ( Object element )  :  boolean
MinMaxPriorityQueue.orderedBy ( Comparator comparator ) [static]  :  MinMaxPriorityQueue.Builder
MinMaxPriorityQueue.peek ( )  :  Object
MinMaxPriorityQueue.peekFirst ( )  :  Object
MinMaxPriorityQueue.peekLast ( )  :  Object
MinMaxPriorityQueue.poll ( )  :  Object
MinMaxPriorityQueue.pollFirst ( )  :  Object
MinMaxPriorityQueue.pollLast ( )  :  Object
MinMaxPriorityQueue.removeFirst ( )  :  Object
MinMaxPriorityQueue.removeLast ( )  :  Object
MinMaxPriorityQueue.size ( )  :  int
MinMaxPriorityQueue.toArray ( )  :  Object[ ]

cdk-1.5.3.jar, Monitor.class
package com.google.common.util.concurrent
Monitor.enter ( )  :  void
Monitor.enter ( long time, TimeUnit unit )  :  boolean
Monitor.enterIf ( Monitor.Guard guard )  :  boolean
Monitor.enterIf ( Monitor.Guard guard, long time, TimeUnit unit )  :  boolean
Monitor.enterIfInterruptibly ( Monitor.Guard guard )  :  boolean
Monitor.enterIfInterruptibly ( Monitor.Guard guard, long time, TimeUnit unit )  :  boolean
Monitor.enterInterruptibly ( )  :  void
Monitor.enterInterruptibly ( long time, TimeUnit unit )  :  boolean
Monitor.enterWhen ( Monitor.Guard guard )  :  void
Monitor.enterWhen ( Monitor.Guard guard, long time, TimeUnit unit )  :  boolean
Monitor.enterWhenUninterruptibly ( Monitor.Guard guard )  :  void
Monitor.enterWhenUninterruptibly ( Monitor.Guard guard, long time, TimeUnit unit )  :  boolean
Monitor.getOccupiedDepth ( )  :  int
Monitor.getQueueLength ( )  :  int
Monitor.getWaitQueueLength ( Monitor.Guard guard )  :  int
Monitor.hasQueuedThread ( Thread thread )  :  boolean
Monitor.hasQueuedThreads ( )  :  boolean
Monitor.hasWaiters ( Monitor.Guard guard )  :  boolean
Monitor.isFair ( )  :  boolean
Monitor.isOccupied ( )  :  boolean
Monitor.isOccupiedByCurrentThread ( )  :  boolean
Monitor.leave ( )  :  void
Monitor.Monitor ( )
Monitor.Monitor ( boolean fair )
Monitor.tryEnter ( )  :  boolean
Monitor.tryEnterIf ( Monitor.Guard guard )  :  boolean
Monitor.waitFor ( Monitor.Guard guard )  :  void
Monitor.waitFor ( Monitor.Guard guard, long time, TimeUnit unit )  :  boolean
Monitor.waitForUninterruptibly ( Monitor.Guard guard )  :  void
Monitor.waitForUninterruptibly ( Monitor.Guard guard, long time, TimeUnit unit )  :  boolean

cdk-1.5.3.jar, MoreExecutors.class
package com.google.common.util.concurrent
MoreExecutors.addDelayedShutdownHook ( ExecutorService service, long terminationTimeout, TimeUnit timeUnit ) [static]  :  void
MoreExecutors.getExitingExecutorService ( ThreadPoolExecutor executor ) [static]  :  ExecutorService
MoreExecutors.getExitingExecutorService ( ThreadPoolExecutor executor, long terminationTimeout, TimeUnit timeUnit ) [static]  :  ExecutorService
MoreExecutors.getExitingScheduledExecutorService ( ScheduledThreadPoolExecutor executor ) [static]  :  ScheduledExecutorService
MoreExecutors.getExitingScheduledExecutorService ( ScheduledThreadPoolExecutor executor, long terminationTimeout, TimeUnit timeUnit ) [static]  :  ScheduledExecutorService
MoreExecutors.listeningDecorator ( ExecutorService delegate ) [static]  :  ListeningExecutorService
MoreExecutors.listeningDecorator ( ScheduledExecutorService delegate ) [static]  :  ListeningScheduledExecutorService
MoreExecutors.platformThreadFactory ( ) [static]  :  ThreadFactory
MoreExecutors.sameThreadExecutor ( ) [static]  :  ListeningExecutorService

cdk-1.5.3.jar, Multimap.class
package com.google.common.collect
Multimap.asMap ( ) [abstract]  :  Map
Multimap.clear ( ) [abstract]  :  void
Multimap.containsEntry ( Object p1, Object p2 ) [abstract]  :  boolean
Multimap.containsKey ( Object p1 ) [abstract]  :  boolean
Multimap.containsValue ( Object p1 ) [abstract]  :  boolean
Multimap.entries ( ) [abstract]  :  Collection
Multimap.equals ( Object p1 ) [abstract]  :  boolean
Multimap.get ( Object p1 ) [abstract]  :  Collection
Multimap.hashCode ( ) [abstract]  :  int
Multimap.isEmpty ( ) [abstract]  :  boolean
Multimap.keys ( ) [abstract]  :  Multiset
Multimap.keySet ( ) [abstract]  :  Set
Multimap.put ( Object p1, Object p2 ) [abstract]  :  boolean
Multimap.putAll ( Multimap p1 ) [abstract]  :  boolean
Multimap.putAll ( Object p1, Iterable p2 ) [abstract]  :  boolean
Multimap.remove ( Object p1, Object p2 ) [abstract]  :  boolean
Multimap.removeAll ( Object p1 ) [abstract]  :  Collection
Multimap.replaceValues ( Object p1, Iterable p2 ) [abstract]  :  Collection
Multimap.size ( ) [abstract]  :  int
Multimap.values ( ) [abstract]  :  Collection

cdk-1.5.3.jar, Multimaps.class
package com.google.common.collect
Multimaps.filterEntries ( Multimap unfiltered, Predicate entryPredicate ) [static]  :  Multimap
Multimaps.filterKeys ( Multimap unfiltered, Predicate keyPredicate ) [static]  :  Multimap
Multimaps.filterValues ( Multimap unfiltered, Predicate valuePredicate ) [static]  :  Multimap
Multimaps.forMap ( Map map ) [static]  :  SetMultimap
Multimaps.index ( Iterable values, Function keyFunction ) [static]  :  ImmutableListMultimap
Multimaps.index ( Iterator values, Function keyFunction ) [static]  :  ImmutableListMultimap
Multimaps.invertFrom ( Multimap source, Multimap dest ) [static]  :  Multimap
Multimaps.newListMultimap ( Map map, Supplier factory ) [static]  :  ListMultimap
Multimaps.newMultimap ( Map map, Supplier factory ) [static]  :  Multimap
Multimaps.newSetMultimap ( Map map, Supplier factory ) [static]  :  SetMultimap
Multimaps.newSortedSetMultimap ( Map map, Supplier factory ) [static]  :  SortedSetMultimap
Multimaps.synchronizedListMultimap ( ListMultimap multimap ) [static]  :  ListMultimap
Multimaps.synchronizedMultimap ( Multimap multimap ) [static]  :  Multimap
Multimaps.synchronizedSetMultimap ( SetMultimap multimap ) [static]  :  SetMultimap
Multimaps.synchronizedSortedSetMultimap ( SortedSetMultimap multimap ) [static]  :  SortedSetMultimap
Multimaps.transformEntries ( ListMultimap fromMap, Maps.EntryTransformer transformer ) [static]  :  ListMultimap
Multimaps.transformEntries ( Multimap fromMap, Maps.EntryTransformer transformer ) [static]  :  Multimap
Multimaps.transformValues ( ListMultimap fromMultimap, Function function ) [static]  :  ListMultimap
Multimaps.transformValues ( Multimap fromMultimap, Function function ) [static]  :  Multimap
Multimaps.unmodifiableListMultimap ( ImmutableListMultimap delegate ) [static]  :  ListMultimap *DEPRECATED*
Multimaps.unmodifiableListMultimap ( ListMultimap delegate ) [static]  :  ListMultimap
Multimaps.unmodifiableMultimap ( ImmutableMultimap delegate ) [static]  :  Multimap *DEPRECATED*
Multimaps.unmodifiableMultimap ( Multimap delegate ) [static]  :  Multimap
Multimaps.unmodifiableSetMultimap ( ImmutableSetMultimap delegate ) [static]  :  SetMultimap *DEPRECATED*
Multimaps.unmodifiableSetMultimap ( SetMultimap delegate ) [static]  :  SetMultimap
Multimaps.unmodifiableSortedSetMultimap ( SortedSetMultimap delegate ) [static]  :  SortedSetMultimap

cdk-1.5.3.jar, Multiset.class
package com.google.common.collect
Multiset.add ( Object p1 ) [abstract]  :  boolean
Multiset.add ( Object p1, int p2 ) [abstract]  :  int
Multiset.contains ( Object p1 ) [abstract]  :  boolean
Multiset.containsAll ( Collection p1 ) [abstract]  :  boolean
Multiset.count ( Object p1 ) [abstract]  :  int
Multiset.elementSet ( ) [abstract]  :  Set
Multiset.entrySet ( ) [abstract]  :  Set
Multiset.equals ( Object p1 ) [abstract]  :  boolean
Multiset.hashCode ( ) [abstract]  :  int
Multiset.iterator ( ) [abstract]  :  Iterator
Multiset.remove ( Object p1 ) [abstract]  :  boolean
Multiset.remove ( Object p1, int p2 ) [abstract]  :  int
Multiset.removeAll ( Collection p1 ) [abstract]  :  boolean
Multiset.retainAll ( Collection p1 ) [abstract]  :  boolean
Multiset.setCount ( Object p1, int p2 ) [abstract]  :  int
Multiset.setCount ( Object p1, int p2, int p3 ) [abstract]  :  boolean
Multiset.toString ( ) [abstract]  :  String

cdk-1.5.3.jar, Multisets.class
package com.google.common.collect
Multisets.containsOccurrences ( Multiset superMultiset, Multiset subMultiset ) [static]  :  boolean
Multisets.copyHighestCountFirst ( Multiset multiset ) [static]  :  ImmutableMultiset
Multisets.difference ( Multiset multiset1, Multiset multiset2 ) [static]  :  Multiset
Multisets.filter ( Multiset unfiltered, Predicate predicate ) [static]  :  Multiset
Multisets.immutableEntry ( Object e, int n ) [static]  :  Multiset.Entry
Multisets.intersection ( Multiset multiset1, Multiset multiset2 ) [static]  :  Multiset
Multisets.removeOccurrences ( Multiset multisetToModify, Multiset occurrencesToRemove ) [static]  :  boolean
Multisets.retainOccurrences ( Multiset multisetToModify, Multiset multisetToRetain ) [static]  :  boolean
Multisets.sum ( Multiset multiset1, Multiset multiset2 ) [static]  :  Multiset
Multisets.union ( Multiset multiset1, Multiset multiset2 ) [static]  :  Multiset
Multisets.unmodifiableMultiset ( ImmutableMultiset multiset ) [static]  :  Multiset *DEPRECATED*
Multisets.unmodifiableMultiset ( Multiset multiset ) [static]  :  Multiset
Multisets.unmodifiableSortedMultiset ( SortedMultiset sortedMultiset ) [static]  :  SortedMultiset

cdk-1.5.3.jar, MurckoFragmenter.class
package org.openscience.cdk.fragment
MurckoFragmenter.MurckoFragmenter ( boolean singleFrameworkOnly, int minimumFragmentSize, MoleculeHashGenerator generator )

cdk-1.5.3.jar, MutableClassToInstanceMap.class
package com.google.common.collect
MutableClassToInstanceMap.create ( ) [static]  :  MutableClassToInstanceMap
MutableClassToInstanceMap.create ( Map backingMap ) [static]  :  MutableClassToInstanceMap
MutableClassToInstanceMap.entrySet ( )  :  Set
MutableClassToInstanceMap.getInstance ( Class type )  :  Object
MutableClassToInstanceMap.putAll ( Map x0 )  :  void
MutableClassToInstanceMap.putInstance ( Class type, Object value )  :  Object

cdk-1.5.3.jar, MutableTypeToInstanceMap.class
package com.google.common.reflect
MutableTypeToInstanceMap.delegate ( )  :  Map
MutableTypeToInstanceMap.delegate ( )  :  Object
MutableTypeToInstanceMap.getInstance ( Class type )  :  Object
MutableTypeToInstanceMap.getInstance ( TypeToken type )  :  Object
MutableTypeToInstanceMap.MutableTypeToInstanceMap ( )
MutableTypeToInstanceMap.put ( Object x0, Object x1 )  :  Object
MutableTypeToInstanceMap.put ( TypeToken key, Object value )  :  Object
MutableTypeToInstanceMap.putAll ( Map map )  :  void
MutableTypeToInstanceMap.putInstance ( Class type, Object value )  :  Object
MutableTypeToInstanceMap.putInstance ( TypeToken type, Object value )  :  Object

cdk-1.5.3.jar, NullOutputStream.class
package com.google.common.io
NullOutputStream.NullOutputStream ( )
NullOutputStream.write ( byte[ ] b, int off, int len )  :  void
NullOutputStream.write ( int b )  :  void

cdk-1.5.3.jar, ObjectArrays.class
package com.google.common.collect
ObjectArrays.concat ( Object element, Object[ ] array ) [static]  :  Object[ ]
ObjectArrays.concat ( Object[ ] array, Object element ) [static]  :  Object[ ]
ObjectArrays.concat ( Object[ ] first, Object[ ] second, Class type ) [static]  :  Object[ ]
ObjectArrays.newArray ( Class type, int length ) [static]  :  Object[ ]
ObjectArrays.newArray ( Object[ ] reference, int length ) [static]  :  Object[ ]

cdk-1.5.3.jar, Objects.class
package com.google.common.base
Objects.equal ( Object a, Object b ) [static]  :  boolean
Objects.firstNonNull ( Object first, Object second ) [static]  :  Object
Objects.hashCode ( Object[ ] objects ) [static]  :  int
Objects.toStringHelper ( Class clazz ) [static]  :  Objects.ToStringHelper
Objects.toStringHelper ( Object self ) [static]  :  Objects.ToStringHelper
Objects.toStringHelper ( String className ) [static]  :  Objects.ToStringHelper

cdk-1.5.3.jar, Optional.class
package com.google.common.base
Optional.absent ( ) [static]  :  Optional
Optional.asSet ( ) [abstract]  :  Set
Optional.equals ( Object p1 ) [abstract]  :  boolean
Optional.fromNullable ( Object nullableReference ) [static]  :  Optional
Optional.get ( ) [abstract]  :  Object
Optional.hashCode ( ) [abstract]  :  int
Optional.isPresent ( ) [abstract]  :  boolean
Optional.of ( Object reference ) [static]  :  Optional
Optional.or ( Object p1 ) [abstract]  :  Object
Optional.or ( Optional p1 ) [abstract]  :  Optional
Optional.or ( Supplier p1 ) [abstract]  :  Object
Optional.orNull ( ) [abstract]  :  Object
Optional.presentInstances ( Iterable optionals ) [static]  :  Iterable
Optional.toString ( ) [abstract]  :  String
Optional.transform ( Function p1 ) [abstract]  :  Optional

cdk-1.5.3.jar, Ordering.class
package com.google.common.collect
Ordering.allEqual ( ) [static]  :  Ordering
Ordering.arbitrary ( ) [static]  :  Ordering
Ordering.binarySearch ( List sortedList, Object key )  :  int
Ordering.compare ( Object p1, Object p2 ) [abstract]  :  int
Ordering.compound ( Comparator secondaryComparator )  :  Ordering
Ordering.compound ( Iterable comparators ) [static]  :  Ordering
Ordering.explicit ( List valuesInOrder ) [static]  :  Ordering
Ordering.explicit ( Object leastValue, Object[ ] remainingValuesInOrder ) [static]  :  Ordering
Ordering.from ( Comparator comparator ) [static]  :  Ordering
Ordering.from ( Ordering ordering ) [static]  :  Ordering *DEPRECATED*
Ordering.greatestOf ( Iterable iterable, int k )  :  List
Ordering.greatestOf ( Iterator iterator, int k )  :  List
Ordering.immutableSortedCopy ( Iterable iterable )  :  ImmutableList
Ordering.isOrdered ( Iterable iterable )  :  boolean
Ordering.isStrictlyOrdered ( Iterable iterable )  :  boolean
Ordering.leastOf ( Iterable iterable, int k )  :  List
Ordering.leastOf ( Iterator elements, int k )  :  List
Ordering.lexicographical ( )  :  Ordering
Ordering.max ( Iterable iterable )  :  Object
Ordering.max ( Iterator iterator )  :  Object
Ordering.max ( Object a, Object b )  :  Object
Ordering.max ( Object a, Object b, Object c, Object[ ] rest )  :  Object
Ordering.min ( Iterable iterable )  :  Object
Ordering.min ( Iterator iterator )  :  Object
Ordering.min ( Object a, Object b )  :  Object
Ordering.min ( Object a, Object b, Object c, Object[ ] rest )  :  Object
Ordering.natural ( ) [static]  :  Ordering
Ordering.nullsFirst ( )  :  Ordering
Ordering.nullsLast ( )  :  Ordering
Ordering.onResultOf ( Function function )  :  Ordering
Ordering.Ordering ( )
Ordering.reverse ( )  :  Ordering
Ordering.sortedCopy ( Iterable iterable )  :  List
Ordering.usingToString ( ) [static]  :  Ordering

cdk-1.5.3.jar, OutputSupplier.class
package com.google.common.io
OutputSupplier.getOutput ( ) [abstract]  :  Object

cdk-1.5.3.jar, Parameter.class
package com.google.common.reflect
Parameter.equals ( Object obj )  :  boolean
Parameter.getAnnotation ( Class annotationType )  :  Annotation
Parameter.getAnnotations ( )  :  Annotation[ ]
Parameter.getDeclaredAnnotations ( )  :  Annotation[ ]
Parameter.getDeclaringInvokable ( )  :  Invokable
Parameter.getType ( )  :  TypeToken
Parameter.hashCode ( )  :  int
Parameter.isAnnotationPresent ( Class annotationType )  :  boolean
Parameter.toString ( )  :  String

cdk-1.5.3.jar, PatternFilenameFilter.class
package com.google.common.io
PatternFilenameFilter.accept ( File dir, String fileName )  :  boolean
PatternFilenameFilter.PatternFilenameFilter ( Pattern pattern )
PatternFilenameFilter.PatternFilenameFilter ( String patternStr )

cdk-1.5.3.jar, PeekingIterator.class
package com.google.common.collect
PeekingIterator.next ( ) [abstract]  :  Object
PeekingIterator.peek ( ) [abstract]  :  Object
PeekingIterator.remove ( ) [abstract]  :  void

cdk-1.5.3.jar, Policies.class
package com.google.common.util.concurrent
CycleDetectingLockFactory.Policies.valueOf ( String name ) [static]  :  CycleDetectingLockFactory.Policies
CycleDetectingLockFactory.Policies.values ( ) [static]  :  CycleDetectingLockFactory.Policies[ ]

cdk-1.5.3.jar, Policy.class
package com.google.common.util.concurrent
CycleDetectingLockFactory.Policy.handlePotentialDeadlock ( CycleDetectingLockFactory.PotentialDeadlockException p1 ) [abstract]  :  void

cdk-1.5.3.jar, PotentialDeadlockException.class
package com.google.common.util.concurrent
CycleDetectingLockFactory.PotentialDeadlockException.getConflictingStackTrace ( )  :  CycleDetectingLockFactory.ExampleStackTrace
CycleDetectingLockFactory.PotentialDeadlockException.getMessage ( )  :  String

cdk-1.5.3.jar, Preconditions.class
package com.google.common.base
Preconditions.checkArgument ( boolean expression ) [static]  :  void
Preconditions.checkArgument ( boolean expression, Object errorMessage ) [static]  :  void
Preconditions.checkArgument ( boolean expression, String errorMessageTemplate, Object[ ] errorMessageArgs ) [static]  :  void
Preconditions.checkElementIndex ( int index, int size ) [static]  :  int
Preconditions.checkElementIndex ( int index, int size, String desc ) [static]  :  int
Preconditions.checkNotNull ( Object reference ) [static]  :  Object
Preconditions.checkNotNull ( Object reference, Object errorMessage ) [static]  :  Object
Preconditions.checkNotNull ( Object reference, String errorMessageTemplate, Object[ ] errorMessageArgs ) [static]  :  Object
Preconditions.checkPositionIndex ( int index, int size ) [static]  :  int
Preconditions.checkPositionIndex ( int index, int size, String desc ) [static]  :  int
Preconditions.checkPositionIndexes ( int start, int end, int size ) [static]  :  void
Preconditions.checkState ( boolean expression ) [static]  :  void
Preconditions.checkState ( boolean expression, Object errorMessage ) [static]  :  void
Preconditions.checkState ( boolean expression, String errorMessageTemplate, Object[ ] errorMessageArgs ) [static]  :  void

cdk-1.5.3.jar, Predicate.class
package com.google.common.base
Predicate.apply ( Object p1 ) [abstract]  :  boolean
Predicate.equals ( Object p1 ) [abstract]  :  boolean

cdk-1.5.3.jar, Predicates.class
package com.google.common.base
Predicates.alwaysFalse ( ) [static]  :  Predicate
Predicates.alwaysTrue ( ) [static]  :  Predicate
Predicates.and ( Iterable components ) [static]  :  Predicate
Predicates.and ( Predicate first, Predicate second ) [static]  :  Predicate
Predicates.and ( Predicate[ ] components ) [static]  :  Predicate
Predicates.assignableFrom ( Class clazz ) [static]  :  Predicate
Predicates.compose ( Predicate predicate, Function function ) [static]  :  Predicate
Predicates.contains ( Pattern pattern ) [static]  :  Predicate
Predicates.containsPattern ( String pattern ) [static]  :  Predicate
Predicates.equalTo ( Object target ) [static]  :  Predicate
Predicates.in ( Collection target ) [static]  :  Predicate
Predicates.instanceOf ( Class clazz ) [static]  :  Predicate
Predicates.isNull ( ) [static]  :  Predicate
Predicates.not ( Predicate predicate ) [static]  :  Predicate
Predicates.notNull ( ) [static]  :  Predicate
Predicates.or ( Iterable components ) [static]  :  Predicate
Predicates.or ( Predicate first, Predicate second ) [static]  :  Predicate
Predicates.or ( Predicate[ ] components ) [static]  :  Predicate

cdk-1.5.3.jar, Primitives.class
package com.google.common.primitives
Primitives.allPrimitiveTypes ( ) [static]  :  Set
Primitives.allWrapperTypes ( ) [static]  :  Set
Primitives.isWrapperType ( Class type ) [static]  :  boolean
Primitives.unwrap ( Class type ) [static]  :  Class
Primitives.wrap ( Class type ) [static]  :  Class

cdk-1.5.3.jar, PrimitiveSink.class
package com.google.common.hash
PrimitiveSink.putBoolean ( boolean p1 ) [abstract]  :  PrimitiveSink
PrimitiveSink.putByte ( byte p1 ) [abstract]  :  PrimitiveSink
PrimitiveSink.putBytes ( byte[ ] p1 ) [abstract]  :  PrimitiveSink
PrimitiveSink.putBytes ( byte[ ] p1, int p2, int p3 ) [abstract]  :  PrimitiveSink
PrimitiveSink.putChar ( char p1 ) [abstract]  :  PrimitiveSink
PrimitiveSink.putDouble ( double p1 ) [abstract]  :  PrimitiveSink
PrimitiveSink.putFloat ( float p1 ) [abstract]  :  PrimitiveSink
PrimitiveSink.putInt ( int p1 ) [abstract]  :  PrimitiveSink
PrimitiveSink.putLong ( long p1 ) [abstract]  :  PrimitiveSink
PrimitiveSink.putShort ( short p1 ) [abstract]  :  PrimitiveSink
PrimitiveSink.putString ( CharSequence p1 ) [abstract]  :  PrimitiveSink
PrimitiveSink.putString ( CharSequence p1, Charset p2 ) [abstract]  :  PrimitiveSink

cdk-1.5.3.jar, Queues.class
package com.google.common.collect
Queues.drain ( BlockingQueue q, Collection buffer, int numElements, long timeout, TimeUnit unit ) [static]  :  int
Queues.drainUninterruptibly ( BlockingQueue q, Collection buffer, int numElements, long timeout, TimeUnit unit ) [static]  :  int
Queues.newArrayBlockingQueue ( int capacity ) [static]  :  ArrayBlockingQueue
Queues.newArrayDeque ( ) [static]  :  ArrayDeque
Queues.newArrayDeque ( Iterable elements ) [static]  :  ArrayDeque
Queues.newConcurrentLinkedQueue ( ) [static]  :  ConcurrentLinkedQueue
Queues.newConcurrentLinkedQueue ( Iterable elements ) [static]  :  ConcurrentLinkedQueue
Queues.newLinkedBlockingDeque ( ) [static]  :  LinkedBlockingDeque
Queues.newLinkedBlockingDeque ( int capacity ) [static]  :  LinkedBlockingDeque
Queues.newLinkedBlockingDeque ( Iterable elements ) [static]  :  LinkedBlockingDeque
Queues.newLinkedBlockingQueue ( ) [static]  :  LinkedBlockingQueue
Queues.newLinkedBlockingQueue ( int capacity ) [static]  :  LinkedBlockingQueue
Queues.newLinkedBlockingQueue ( Iterable elements ) [static]  :  LinkedBlockingQueue
Queues.newPriorityBlockingQueue ( ) [static]  :  PriorityBlockingQueue
Queues.newPriorityBlockingQueue ( Iterable elements ) [static]  :  PriorityBlockingQueue
Queues.newPriorityQueue ( ) [static]  :  PriorityQueue
Queues.newPriorityQueue ( Iterable elements ) [static]  :  PriorityQueue
Queues.newSynchronousQueue ( ) [static]  :  SynchronousQueue
Queues.synchronizedQueue ( Queue queue ) [static]  :  Queue

cdk-1.5.3.jar, Range.class
package com.google.common.collect
Range.all ( ) [static]  :  Range
Range.apply ( Comparable input )  :  boolean
Range.apply ( Object x0 )  :  boolean
Range.asSet ( DiscreteDomain domain )  :  ContiguousSet *DEPRECATED*
Range.atLeast ( Comparable endpoint ) [static]  :  Range
Range.atMost ( Comparable endpoint ) [static]  :  Range
Range.canonical ( DiscreteDomain domain )  :  Range
Range.closed ( Comparable lower, Comparable upper ) [static]  :  Range
Range.closedOpen ( Comparable lower, Comparable upper ) [static]  :  Range
Range.contains ( Comparable value )  :  boolean
Range.containsAll ( Iterable values )  :  boolean
Range.downTo ( Comparable endpoint, BoundType boundType ) [static]  :  Range
Range.encloseAll ( Iterable values ) [static]  :  Range
Range.encloses ( Range other )  :  boolean
Range.equals ( Object object )  :  boolean
Range.greaterThan ( Comparable endpoint ) [static]  :  Range
Range.hashCode ( )  :  int
Range.hasLowerBound ( )  :  boolean
Range.hasUpperBound ( )  :  boolean
Range.intersection ( Range connectedRange )  :  Range
Range.isConnected ( Range other )  :  boolean
Range.isEmpty ( )  :  boolean
Range.lessThan ( Comparable endpoint ) [static]  :  Range
Range.lowerBoundType ( )  :  BoundType
Range.lowerEndpoint ( )  :  Comparable
Range.open ( Comparable lower, Comparable upper ) [static]  :  Range
Range.openClosed ( Comparable lower, Comparable upper ) [static]  :  Range
Range.range ( Comparable lower, BoundType lowerType, Comparable upper, BoundType upperType ) [static]  :  Range
Range.singleton ( Comparable value ) [static]  :  Range
Range.span ( Range other )  :  Range
Range.toString ( )  :  String
Range.upperBoundType ( )  :  BoundType
Range.upperEndpoint ( )  :  Comparable
Range.upTo ( Comparable endpoint, BoundType boundType ) [static]  :  Range

cdk-1.5.3.jar, RangeMap.class
package com.google.common.collect
RangeMap.asMapOfRanges ( ) [abstract]  :  Map
RangeMap.clear ( ) [abstract]  :  void
RangeMap.equals ( Object p1 ) [abstract]  :  boolean
RangeMap.get ( Comparable p1 ) [abstract]  :  Object
RangeMap.getEntry ( Comparable p1 ) [abstract]  :  Map.Entry
RangeMap.hashCode ( ) [abstract]  :  int
RangeMap.put ( Range p1, Object p2 ) [abstract]  :  void
RangeMap.putAll ( RangeMap p1 ) [abstract]  :  void
RangeMap.remove ( Range p1 ) [abstract]  :  void
RangeMap.span ( ) [abstract]  :  Range
RangeMap.subRangeMap ( Range p1 ) [abstract]  :  RangeMap
RangeMap.toString ( ) [abstract]  :  String

cdk-1.5.3.jar, Ranges.class
package com.google.common.collect
Ranges.all ( ) [static]  :  Range
Ranges.atLeast ( Comparable endpoint ) [static]  :  Range
Ranges.atMost ( Comparable endpoint ) [static]  :  Range
Ranges.closed ( Comparable lower, Comparable upper ) [static]  :  Range
Ranges.closedOpen ( Comparable lower, Comparable upper ) [static]  :  Range
Ranges.downTo ( Comparable endpoint, BoundType boundType ) [static]  :  Range
Ranges.encloseAll ( Iterable values ) [static]  :  Range
Ranges.greaterThan ( Comparable endpoint ) [static]  :  Range
Ranges.lessThan ( Comparable endpoint ) [static]  :  Range
Ranges.open ( Comparable lower, Comparable upper ) [static]  :  Range
Ranges.openClosed ( Comparable lower, Comparable upper ) [static]  :  Range
Ranges.range ( Comparable lower, BoundType lowerType, Comparable upper, BoundType upperType ) [static]  :  Range
Ranges.singleton ( Comparable value ) [static]  :  Range
Ranges.upTo ( Comparable endpoint, BoundType boundType ) [static]  :  Range

cdk-1.5.3.jar, RangeSet.class
package com.google.common.collect
RangeSet.add ( Range p1 ) [abstract]  :  void
RangeSet.addAll ( RangeSet p1 ) [abstract]  :  void
RangeSet.asRanges ( ) [abstract]  :  Set
RangeSet.clear ( ) [abstract]  :  void
RangeSet.complement ( ) [abstract]  :  RangeSet
RangeSet.contains ( Comparable p1 ) [abstract]  :  boolean
RangeSet.encloses ( Range p1 ) [abstract]  :  boolean
RangeSet.enclosesAll ( RangeSet p1 ) [abstract]  :  boolean
RangeSet.equals ( Object p1 ) [abstract]  :  boolean
RangeSet.hashCode ( ) [abstract]  :  int
RangeSet.isEmpty ( ) [abstract]  :  boolean
RangeSet.rangeContaining ( Comparable p1 ) [abstract]  :  Range
RangeSet.remove ( Range p1 ) [abstract]  :  void
RangeSet.removeAll ( RangeSet p1 ) [abstract]  :  void
RangeSet.span ( ) [abstract]  :  Range
RangeSet.subRangeSet ( Range p1 ) [abstract]  :  RangeSet
RangeSet.toString ( ) [abstract]  :  String

cdk-1.5.3.jar, RateLimiter.class
package com.google.common.util.concurrent
RateLimiter.acquire ( )  :  void
RateLimiter.acquire ( int permits )  :  void
RateLimiter.create ( double permitsPerSecond ) [static]  :  RateLimiter
RateLimiter.create ( double permitsPerSecond, long warmupPeriod, TimeUnit unit ) [static]  :  RateLimiter
RateLimiter.getRate ( )  :  double
RateLimiter.setRate ( double permitsPerSecond )  :  void
RateLimiter.toString ( )  :  String
RateLimiter.tryAcquire ( )  :  boolean
RateLimiter.tryAcquire ( int permits )  :  boolean
RateLimiter.tryAcquire ( int permits, long timeout, TimeUnit unit )  :  boolean
RateLimiter.tryAcquire ( long timeout, TimeUnit unit )  :  boolean

cdk-1.5.3.jar, Reflection.class
package com.google.common.reflect
Reflection.getPackageName ( Class clazz ) [static]  :  String
Reflection.getPackageName ( String classFullName ) [static]  :  String
Reflection.initialize ( Class[ ] classes ) [static]  :  void
Reflection.newProxy ( Class interfaceType, InvocationHandler handler ) [static]  :  Object

cdk-1.5.3.jar, RelevantCycles.class
package org.openscience.cdk.graph
RelevantCycles.paths ( )  :  int[ ][ ]
RelevantCycles.RelevantCycles ( int[ ][ ] graph )
RelevantCycles.size ( )  :  int

cdk-1.5.3.jar, RemovalCause.class
package com.google.common.cache
RemovalCause.valueOf ( String name ) [static]  :  RemovalCause
RemovalCause.values ( ) [static]  :  RemovalCause[ ]

cdk-1.5.3.jar, RemovalListener.class
package com.google.common.cache
RemovalListener.onRemoval ( RemovalNotification p1 ) [abstract]  :  void

cdk-1.5.3.jar, RemovalListeners.class
package com.google.common.cache
RemovalListeners.asynchronous ( RemovalListener listener, Executor executor ) [static]  :  RemovalListener

cdk-1.5.3.jar, RemovalNotification.class
package com.google.common.cache
RemovalNotification.equals ( Object object )  :  boolean
RemovalNotification.getCause ( )  :  RemovalCause
RemovalNotification.getKey ( )  :  Object
RemovalNotification.getValue ( )  :  Object
RemovalNotification.hashCode ( )  :  int
RemovalNotification.setValue ( Object value )  :  Object
RemovalNotification.toString ( )  :  String
RemovalNotification.wasEvicted ( )  :  boolean

cdk-1.5.3.jar, ResourceInfo.class
package com.google.common.reflect
ClassPath.ResourceInfo.equals ( Object obj )  :  boolean
ClassPath.ResourceInfo.getResourceName ( )  :  String
ClassPath.ResourceInfo.hashCode ( )  :  int
ClassPath.ResourceInfo.toString ( )  :  String
ClassPath.ResourceInfo.url ( )  :  URL

cdk-1.5.3.jar, Resources.class
package com.google.common.io
Resources.asByteSource ( URL url ) [static]  :  ByteSource
Resources.asCharSource ( URL url, Charset charset ) [static]  :  CharSource
Resources.copy ( URL from, OutputStream to ) [static]  :  void
Resources.getResource ( Class contextClass, String resourceName ) [static]  :  URL
Resources.getResource ( String resourceName ) [static]  :  URL
Resources.newInputStreamSupplier ( URL url ) [static]  :  InputSupplier
Resources.newReaderSupplier ( URL url, Charset charset ) [static]  :  InputSupplier
Resources.readLines ( URL url, Charset charset ) [static]  :  List
Resources.readLines ( URL url, Charset charset, LineProcessor callback ) [static]  :  Object
Resources.toByteArray ( URL url ) [static]  :  byte[ ]
Resources.toString ( URL url, Charset charset ) [static]  :  String

cdk-1.5.3.jar, RowSortedTable.class
package com.google.common.collect
RowSortedTable.rowKeySet ( ) [abstract]  :  SortedSet
RowSortedTable.rowMap ( ) [abstract]  :  SortedMap

cdk-1.5.3.jar, Schedule.class
package com.google.common.util.concurrent
AbstractScheduledService.CustomScheduler.Schedule.AbstractScheduledService.CustomScheduler.Schedule ( long delay, TimeUnit unit )

cdk-1.5.3.jar, Scheduler.class
package com.google.common.util.concurrent
AbstractScheduledService.Scheduler.newFixedDelaySchedule ( long initialDelay, long delay, TimeUnit unit ) [static]  :  AbstractScheduledService.Scheduler
AbstractScheduledService.Scheduler.newFixedRateSchedule ( long initialDelay, long period, TimeUnit unit ) [static]  :  AbstractScheduledService.Scheduler

cdk-1.5.3.jar, SDFWriter.class
package org.openscience.cdk.io
SDFWriter.SDFWriter ( OutputStream output, Set propertiesToWrite )
SDFWriter.SDFWriter ( Set propertiesToWrite )
SDFWriter.SDFWriter ( Writer out, Set propertiesToWrite )

cdk-1.5.3.jar, Service.class
package com.google.common.util.concurrent
Service.addListener ( Service.Listener p1, Executor p2 ) [abstract]  :  void
Service.failureCause ( ) [abstract]  :  Throwable
Service.isRunning ( ) [abstract]  :  boolean
Service.start ( ) [abstract]  :  ListenableFuture
Service.startAndWait ( ) [abstract]  :  Service.State
Service.state ( ) [abstract]  :  Service.State
Service.stop ( ) [abstract]  :  ListenableFuture
Service.stopAndWait ( ) [abstract]  :  Service.State

cdk-1.5.3.jar, ServiceManager.class
package com.google.common.util.concurrent
ServiceManager.addListener ( ServiceManager.Listener listener, Executor executor )  :  void
ServiceManager.awaitHealthy ( )  :  void
ServiceManager.awaitHealthy ( long timeout, TimeUnit unit )  :  void
ServiceManager.awaitStopped ( )  :  void
ServiceManager.awaitStopped ( long timeout, TimeUnit unit )  :  void
ServiceManager.isHealthy ( )  :  boolean
ServiceManager.ServiceManager ( Iterable services )
ServiceManager.servicesByState ( )  :  ImmutableMultimap
ServiceManager.startAsync ( )  :  ServiceManager
ServiceManager.startupTimes ( )  :  ImmutableMap
ServiceManager.stopAsync ( )  :  ServiceManager
ServiceManager.toString ( )  :  String

cdk-1.5.3.jar, SetMultimap.class
package com.google.common.collect
SetMultimap.asMap ( ) [abstract]  :  Map
SetMultimap.entries ( ) [abstract]  :  Set
SetMultimap.equals ( Object p1 ) [abstract]  :  boolean
SetMultimap.get ( Object p1 ) [abstract]  :  Set
SetMultimap.removeAll ( Object p1 ) [abstract]  :  Set
SetMultimap.replaceValues ( Object p1, Iterable p2 ) [abstract]  :  Set

cdk-1.5.3.jar, Sets.class
package com.google.common.collect
Sets.cartesianProduct ( List sets ) [static]  :  Set
Sets.cartesianProduct ( Set[ ] sets ) [static]  :  Set
Sets.complementOf ( Collection collection ) [static]  :  EnumSet
Sets.complementOf ( Collection collection, Class type ) [static]  :  EnumSet
Sets.difference ( Set set1, Set set2 ) [static]  :  Sets.SetView
Sets.filter ( NavigableSet unfiltered, Predicate predicate ) [static]  :  NavigableSet
Sets.filter ( Set unfiltered, Predicate predicate ) [static]  :  Set
Sets.filter ( SortedSet unfiltered, Predicate predicate ) [static]  :  SortedSet
Sets.immutableEnumSet ( Enum anElement, Enum[ ] otherElements ) [static]  :  ImmutableSet
Sets.immutableEnumSet ( Iterable elements ) [static]  :  ImmutableSet
Sets.intersection ( Set set1, Set set2 ) [static]  :  Sets.SetView
Sets.newCopyOnWriteArraySet ( ) [static]  :  CopyOnWriteArraySet
Sets.newCopyOnWriteArraySet ( Iterable elements ) [static]  :  CopyOnWriteArraySet
Sets.newEnumSet ( Iterable iterable, Class elementType ) [static]  :  EnumSet
Sets.newHashSet ( ) [static]  :  HashSet
Sets.newHashSet ( Iterable elements ) [static]  :  HashSet
Sets.newHashSet ( Iterator elements ) [static]  :  HashSet
Sets.newHashSet ( Object[ ] elements ) [static]  :  HashSet
Sets.newHashSetWithExpectedSize ( int expectedSize ) [static]  :  HashSet
Sets.newIdentityHashSet ( ) [static]  :  Set
Sets.newLinkedHashSet ( ) [static]  :  LinkedHashSet
Sets.newLinkedHashSet ( Iterable elements ) [static]  :  LinkedHashSet
Sets.newLinkedHashSetWithExpectedSize ( int expectedSize ) [static]  :  LinkedHashSet
Sets.newSetFromMap ( Map map ) [static]  :  Set
Sets.newTreeSet ( ) [static]  :  TreeSet
Sets.newTreeSet ( Comparator comparator ) [static]  :  TreeSet
Sets.newTreeSet ( Iterable elements ) [static]  :  TreeSet
Sets.powerSet ( Set set ) [static]  :  Set
Sets.symmetricDifference ( Set set1, Set set2 ) [static]  :  Sets.SetView
Sets.synchronizedNavigableSet ( NavigableSet navigableSet ) [static]  :  NavigableSet
Sets.union ( Set set1, Set set2 ) [static]  :  Sets.SetView
Sets.unmodifiableNavigableSet ( NavigableSet set ) [static]  :  NavigableSet

cdk-1.5.3.jar, SettableFuture.class
package com.google.common.util.concurrent
SettableFuture.create ( ) [static]  :  SettableFuture
SettableFuture.set ( Object value )  :  boolean
SettableFuture.setException ( Throwable throwable )  :  boolean

cdk-1.5.3.jar, SetView.class
package com.google.common.collect
Sets.SetView.copyInto ( Set set )  :  Set
Sets.SetView.immutableCopy ( )  :  ImmutableSet

cdk-1.5.3.jar, Shorts.class
package com.google.common.primitives
Shorts.asList ( short[ ] backingArray ) [static]  :  List
Shorts.checkedCast ( long value ) [static]  :  short
Shorts.compare ( short a, short b ) [static]  :  int
Shorts.concat ( short[ ][ ] arrays ) [static]  :  short[ ]
Shorts.contains ( short[ ] array, short target ) [static]  :  boolean
Shorts.ensureCapacity ( short[ ] array, int minLength, int padding ) [static]  :  short[ ]
Shorts.fromByteArray ( byte[ ] bytes ) [static]  :  short
Shorts.fromBytes ( byte b1, byte b2 ) [static]  :  short
Shorts.hashCode ( short value ) [static]  :  int
Shorts.indexOf ( short[ ] array, short target ) [static]  :  int
Shorts.indexOf ( short[ ] array, short[ ] target ) [static]  :  int
Shorts.join ( String separator, short[ ] array ) [static]  :  String
Shorts.lastIndexOf ( short[ ] array, short target ) [static]  :  int
Shorts.lexicographicalComparator ( ) [static]  :  Comparator
Shorts.max ( short[ ] array ) [static]  :  short
Shorts.min ( short[ ] array ) [static]  :  short
Shorts.saturatedCast ( long value ) [static]  :  short
Shorts.toArray ( Collection collection ) [static]  :  short[ ]
Shorts.toByteArray ( short value ) [static]  :  byte[ ]

cdk-1.5.3.jar, SignedBytes.class
package com.google.common.primitives
SignedBytes.checkedCast ( long value ) [static]  :  byte
SignedBytes.compare ( byte a, byte b ) [static]  :  int
SignedBytes.join ( String separator, byte[ ] array ) [static]  :  String
SignedBytes.lexicographicalComparator ( ) [static]  :  Comparator
SignedBytes.max ( byte[ ] array ) [static]  :  byte
SignedBytes.min ( byte[ ] array ) [static]  :  byte
SignedBytes.saturatedCast ( long value ) [static]  :  byte

cdk-1.5.3.jar, SimpleForwardingCache.class
package com.google.common.cache
ForwardingCache.SimpleForwardingCache.delegate ( )  :  Cache
ForwardingCache.SimpleForwardingCache.delegate ( )  :  Object
ForwardingCache.SimpleForwardingCache.ForwardingCache.SimpleForwardingCache ( Cache delegate )

cdk-1.5.3.jar, SimpleForwardingCheckedFuture.class
package com.google.common.util.concurrent
ForwardingCheckedFuture.SimpleForwardingCheckedFuture.delegate ( )  :  CheckedFuture
ForwardingCheckedFuture.SimpleForwardingCheckedFuture.delegate ( )  :  Future
ForwardingCheckedFuture.SimpleForwardingCheckedFuture.delegate ( )  :  ListenableFuture
ForwardingCheckedFuture.SimpleForwardingCheckedFuture.delegate ( )  :  Object
ForwardingCheckedFuture.SimpleForwardingCheckedFuture.ForwardingCheckedFuture.SimpleForwardingCheckedFuture ( CheckedFuture delegate )

cdk-1.5.3.jar, SimpleForwardingFuture.class
package com.google.common.util.concurrent
ForwardingFuture.SimpleForwardingFuture.delegate ( )  :  Future
ForwardingFuture.SimpleForwardingFuture.delegate ( )  :  Object
ForwardingFuture.SimpleForwardingFuture.ForwardingFuture.SimpleForwardingFuture ( Future delegate )

cdk-1.5.3.jar, SimpleForwardingListenableFuture.class
package com.google.common.util.concurrent
ForwardingListenableFuture.SimpleForwardingListenableFuture.delegate ( )  :  Future
ForwardingListenableFuture.SimpleForwardingListenableFuture.delegate ( )  :  ListenableFuture
ForwardingListenableFuture.SimpleForwardingListenableFuture.delegate ( )  :  Object
ForwardingListenableFuture.SimpleForwardingListenableFuture.ForwardingListenableFuture.SimpleForwardingListenableFuture ( ListenableFuture delegate )

cdk-1.5.3.jar, SimpleForwardingLoadingCache.class
package com.google.common.cache
ForwardingLoadingCache.SimpleForwardingLoadingCache.delegate ( )  :  Cache
ForwardingLoadingCache.SimpleForwardingLoadingCache.delegate ( )  :  LoadingCache
ForwardingLoadingCache.SimpleForwardingLoadingCache.delegate ( )  :  Object
ForwardingLoadingCache.SimpleForwardingLoadingCache.ForwardingLoadingCache.SimpleForwardingLoadingCache ( LoadingCache delegate )

cdk-1.5.3.jar, SimpleStatsCounter.class
package com.google.common.cache
AbstractCache.SimpleStatsCounter.AbstractCache.SimpleStatsCounter ( )
AbstractCache.SimpleStatsCounter.incrementBy ( AbstractCache.StatsCounter other )  :  void
AbstractCache.SimpleStatsCounter.recordEviction ( )  :  void
AbstractCache.SimpleStatsCounter.recordHits ( int count )  :  void
AbstractCache.SimpleStatsCounter.recordLoadException ( long loadTime )  :  void
AbstractCache.SimpleStatsCounter.recordLoadSuccess ( long loadTime )  :  void
AbstractCache.SimpleStatsCounter.recordMisses ( int count )  :  void
AbstractCache.SimpleStatsCounter.snapshot ( )  :  CacheStats

cdk-1.5.3.jar, SimpleTimeLimiter.class
package com.google.common.util.concurrent
SimpleTimeLimiter.callWithTimeout ( Callable callable, long timeoutDuration, TimeUnit timeoutUnit, boolean amInterruptible )  :  Object
SimpleTimeLimiter.newProxy ( Object target, Class interfaceType, long timeoutDuration, TimeUnit timeoutUnit )  :  Object
SimpleTimeLimiter.SimpleTimeLimiter ( )
SimpleTimeLimiter.SimpleTimeLimiter ( ExecutorService executor )

cdk-1.5.3.jar, SortedMapDifference.class
package com.google.common.collect
SortedMapDifference.entriesDiffering ( ) [abstract]  :  SortedMap
SortedMapDifference.entriesInCommon ( ) [abstract]  :  SortedMap
SortedMapDifference.entriesOnlyOnLeft ( ) [abstract]  :  SortedMap
SortedMapDifference.entriesOnlyOnRight ( ) [abstract]  :  SortedMap

cdk-1.5.3.jar, SortedMultiset.class
package com.google.common.collect
SortedMultiset.comparator ( ) [abstract]  :  Comparator
SortedMultiset.descendingMultiset ( ) [abstract]  :  SortedMultiset
SortedMultiset.elementSet ( ) [abstract]  :  NavigableSet
SortedMultiset.firstEntry ( ) [abstract]  :  Multiset.Entry
SortedMultiset.headMultiset ( Object p1, BoundType p2 ) [abstract]  :  SortedMultiset
SortedMultiset.iterator ( ) [abstract]  :  Iterator
SortedMultiset.lastEntry ( ) [abstract]  :  Multiset.Entry
SortedMultiset.pollFirstEntry ( ) [abstract]  :  Multiset.Entry
SortedMultiset.pollLastEntry ( ) [abstract]  :  Multiset.Entry
SortedMultiset.subMultiset ( Object p1, BoundType p2, Object p3, BoundType p4 ) [abstract]  :  SortedMultiset
SortedMultiset.tailMultiset ( Object p1, BoundType p2 ) [abstract]  :  SortedMultiset

cdk-1.5.3.jar, SortedSetMultimap.class
package com.google.common.collect
SortedSetMultimap.asMap ( ) [abstract]  :  Map
SortedSetMultimap.get ( Object p1 ) [abstract]  :  SortedSet
SortedSetMultimap.removeAll ( Object p1 ) [abstract]  :  SortedSet
SortedSetMultimap.replaceValues ( Object p1, Iterable p2 ) [abstract]  :  SortedSet
SortedSetMultimap.valueComparator ( ) [abstract]  :  Comparator

cdk-1.5.3.jar, Splitter.class
package com.google.common.base
Splitter.fixedLength ( int length ) [static]  :  Splitter
Splitter.limit ( int limit )  :  Splitter
Splitter.omitEmptyStrings ( )  :  Splitter
Splitter.on ( char separator ) [static]  :  Splitter
Splitter.on ( CharMatcher separatorMatcher ) [static]  :  Splitter
Splitter.on ( Pattern separatorPattern ) [static]  :  Splitter
Splitter.on ( String separator ) [static]  :  Splitter
Splitter.onPattern ( String separatorPattern ) [static]  :  Splitter
Splitter.split ( CharSequence sequence )  :  Iterable
Splitter.trimResults ( )  :  Splitter
Splitter.trimResults ( CharMatcher trimmer )  :  Splitter
Splitter.withKeyValueSeparator ( char separator )  :  Splitter.MapSplitter
Splitter.withKeyValueSeparator ( Splitter keyValueSplitter )  :  Splitter.MapSplitter
Splitter.withKeyValueSeparator ( String separator )  :  Splitter.MapSplitter

cdk-1.5.3.jar, StandardDescendingMap.class
package com.google.common.collect
ForwardingNavigableMap.StandardDescendingMap.entryIterator ( )  :  Iterator
ForwardingNavigableMap.StandardDescendingMap.ForwardingNavigableMap.StandardDescendingMap ( ForwardingNavigableMap p1 )

cdk-1.5.3.jar, StandardDescendingSet.class
package com.google.common.collect
ForwardingNavigableSet.StandardDescendingSet.ForwardingNavigableSet.StandardDescendingSet ( ForwardingNavigableSet p1 )

cdk-1.5.3.jar, StandardElementSet.class
package com.google.common.collect
ForwardingMultiset.StandardElementSet.ForwardingMultiset.StandardElementSet ( ForwardingMultiset p1 )

cdk-1.5.3.jar, StandardEntrySet.class
package com.google.common.collect
ForwardingMap.StandardEntrySet.ForwardingMap.StandardEntrySet ( ForwardingMap p1 )

cdk-1.5.3.jar, StandardKeySet.class
package com.google.common.collect
ForwardingMap.StandardKeySet.ForwardingMap.StandardKeySet ( ForwardingMap p1 )

cdk-1.5.3.jar, StandardNavigableKeySet.class
package com.google.common.collect
ForwardingNavigableMap.StandardNavigableKeySet.ForwardingNavigableMap.StandardNavigableKeySet ( ForwardingNavigableMap p1 )

cdk-1.5.3.jar, StandardValues.class
package com.google.common.collect
ForwardingMap.StandardValues.ForwardingMap.StandardValues ( ForwardingMap p1 )

cdk-1.5.3.jar, State.class
package com.google.common.util.concurrent
Service.State.valueOf ( String name ) [static]  :  Service.State
Service.State.values ( ) [static]  :  Service.State[ ]

cdk-1.5.3.jar, StatsCounter.class
package com.google.common.cache
AbstractCache.StatsCounter.recordEviction ( ) [abstract]  :  void
AbstractCache.StatsCounter.recordHits ( int p1 ) [abstract]  :  void
AbstractCache.StatsCounter.recordLoadException ( long p1 ) [abstract]  :  void
AbstractCache.StatsCounter.recordLoadSuccess ( long p1 ) [abstract]  :  void
AbstractCache.StatsCounter.recordMisses ( int p1 ) [abstract]  :  void
AbstractCache.StatsCounter.snapshot ( ) [abstract]  :  CacheStats

cdk-1.5.3.jar, StereoEncoderFactory.class
package org.openscience.cdk.hash.stereo
StereoEncoderFactory.create ( IAtomContainer p1, int[ ][ ] p2 ) [abstract]  :  StereoEncoder

cdk-1.5.3.jar, Stopwatch.class
package com.google.common.base
Stopwatch.elapsed ( TimeUnit desiredUnit )  :  long
Stopwatch.elapsedMillis ( )  :  long *DEPRECATED*
Stopwatch.elapsedTime ( TimeUnit desiredUnit )  :  long *DEPRECATED*
Stopwatch.isRunning ( )  :  boolean
Stopwatch.reset ( )  :  Stopwatch
Stopwatch.start ( )  :  Stopwatch
Stopwatch.stop ( )  :  Stopwatch
Stopwatch.Stopwatch ( )
Stopwatch.Stopwatch ( Ticker ticker )
Stopwatch.toString ( )  :  String
Stopwatch.toString ( int significantDigits )  :  String *DEPRECATED*

cdk-1.5.3.jar, Strings.class
package com.google.common.base
Strings.commonPrefix ( CharSequence a, CharSequence b ) [static]  :  String
Strings.commonSuffix ( CharSequence a, CharSequence b ) [static]  :  String
Strings.emptyToNull ( String string ) [static]  :  String
Strings.isNullOrEmpty ( String string ) [static]  :  boolean
Strings.nullToEmpty ( String string ) [static]  :  String
Strings.padEnd ( String string, int minLength, char padChar ) [static]  :  String
Strings.padStart ( String string, int minLength, char padChar ) [static]  :  String
Strings.repeat ( String string, int count ) [static]  :  String

cdk-1.5.3.jar, Striped.class
package com.google.common.util.concurrent
Striped.bulkGet ( Iterable keys )  :  Iterable
Striped.get ( Object p1 ) [abstract]  :  Object
Striped.getAt ( int p1 ) [abstract]  :  Object
Striped.lazyWeakLock ( int stripes ) [static]  :  Striped
Striped.lazyWeakReadWriteLock ( int stripes ) [static]  :  Striped
Striped.lazyWeakSemaphore ( int stripes, int permits ) [static]  :  Striped
Striped.lock ( int stripes ) [static]  :  Striped
Striped.readWriteLock ( int stripes ) [static]  :  Striped
Striped.semaphore ( int stripes, int permits ) [static]  :  Striped
Striped.size ( ) [abstract]  :  int

cdk-1.5.3.jar, Supplier.class
package com.google.common.base
Supplier.get ( ) [abstract]  :  Object

cdk-1.5.3.jar, Suppliers.class
package com.google.common.base
Suppliers.compose ( Function function, Supplier supplier ) [static]  :  Supplier
Suppliers.memoize ( Supplier delegate ) [static]  :  Supplier
Suppliers.memoizeWithExpiration ( Supplier delegate, long duration, TimeUnit unit ) [static]  :  Supplier
Suppliers.ofInstance ( Object instance ) [static]  :  Supplier
Suppliers.supplierFunction ( ) [static]  :  Function
Suppliers.synchronizedSupplier ( Supplier delegate ) [static]  :  Supplier

cdk-1.5.3.jar, Table.class
package com.google.common.collect
Table.cellSet ( ) [abstract]  :  Set
Table.clear ( ) [abstract]  :  void
Table.column ( Object p1 ) [abstract]  :  Map
Table.columnKeySet ( ) [abstract]  :  Set
Table.columnMap ( ) [abstract]  :  Map
Table.contains ( Object p1, Object p2 ) [abstract]  :  boolean
Table.containsColumn ( Object p1 ) [abstract]  :  boolean
Table.containsRow ( Object p1 ) [abstract]  :  boolean
Table.containsValue ( Object p1 ) [abstract]  :  boolean
Table.equals ( Object p1 ) [abstract]  :  boolean
Table.get ( Object p1, Object p2 ) [abstract]  :  Object
Table.hashCode ( ) [abstract]  :  int
Table.isEmpty ( ) [abstract]  :  boolean
Table.put ( Object p1, Object p2, Object p3 ) [abstract]  :  Object
Table.putAll ( Table p1 ) [abstract]  :  void
Table.remove ( Object p1, Object p2 ) [abstract]  :  Object
Table.row ( Object p1 ) [abstract]  :  Map
Table.rowKeySet ( ) [abstract]  :  Set
Table.rowMap ( ) [abstract]  :  Map
Table.size ( ) [abstract]  :  int
Table.values ( ) [abstract]  :  Collection

cdk-1.5.3.jar, Tables.class
package com.google.common.collect
Tables.immutableCell ( Object rowKey, Object columnKey, Object value ) [static]  :  Table.Cell
Tables.newCustomTable ( Map backingMap, Supplier factory ) [static]  :  Table
Tables.transformValues ( Table fromTable, Function function ) [static]  :  Table
Tables.transpose ( Table table ) [static]  :  Table
Tables.unmodifiableRowSortedTable ( RowSortedTable table ) [static]  :  RowSortedTable
Tables.unmodifiableTable ( Table table ) [static]  :  Table

cdk-1.5.3.jar, TeredoInfo.class
package com.google.common.net
InetAddresses.TeredoInfo.getClient ( )  :  Inet4Address
InetAddresses.TeredoInfo.getFlags ( )  :  int
InetAddresses.TeredoInfo.getPort ( )  :  int
InetAddresses.TeredoInfo.getServer ( )  :  Inet4Address
InetAddresses.TeredoInfo.InetAddresses.TeredoInfo ( Inet4Address server, Inet4Address client, int port, int flags )

cdk-1.5.3.jar, ThreadFactoryBuilder.class
package com.google.common.util.concurrent
ThreadFactoryBuilder.build ( )  :  ThreadFactory
ThreadFactoryBuilder.setDaemon ( boolean daemon )  :  ThreadFactoryBuilder
ThreadFactoryBuilder.setNameFormat ( String nameFormat )  :  ThreadFactoryBuilder
ThreadFactoryBuilder.setPriority ( int priority )  :  ThreadFactoryBuilder
ThreadFactoryBuilder.setThreadFactory ( ThreadFactory backingThreadFactory )  :  ThreadFactoryBuilder
ThreadFactoryBuilder.setUncaughtExceptionHandler ( Thread.UncaughtExceptionHandler uncaughtExceptionHandler )  :  ThreadFactoryBuilder
ThreadFactoryBuilder.ThreadFactoryBuilder ( )

cdk-1.5.3.jar, Threshold.class
package org.openscience.cdk.ringsearch
AllRingsFinder.Threshold.valueOf ( String name ) [static]  :  AllRingsFinder.Threshold
AllRingsFinder.Threshold.values ( ) [static]  :  AllRingsFinder.Threshold[ ]

cdk-1.5.3.jar, Throwables.class
package com.google.common.base
Throwables.getCausalChain ( Throwable throwable ) [static]  :  List
Throwables.getRootCause ( Throwable throwable ) [static]  :  Throwable
Throwables.getStackTraceAsString ( Throwable throwable ) [static]  :  String
Throwables.propagate ( Throwable throwable ) [static]  :  RuntimeException
Throwables.propagateIfInstanceOf ( Throwable throwable, Class declaredType ) [static]  :  void
Throwables.propagateIfPossible ( Throwable throwable ) [static]  :  void
Throwables.propagateIfPossible ( Throwable throwable, Class declaredType ) [static]  :  void
Throwables.propagateIfPossible ( Throwable throwable, Class declaredType1, Class declaredType2 ) [static]  :  void

cdk-1.5.3.jar, Ticker.class
package com.google.common.base
Ticker.read ( ) [abstract]  :  long
Ticker.systemTicker ( ) [static]  :  Ticker
Ticker.Ticker ( )

cdk-1.5.3.jar, TimeLimiter.class
package com.google.common.util.concurrent
TimeLimiter.callWithTimeout ( Callable p1, long p2, TimeUnit p3, boolean p4 ) [abstract]  :  Object
TimeLimiter.newProxy ( Object p1, Class p2, long p3, TimeUnit p4 ) [abstract]  :  Object

cdk-1.5.3.jar, ToStringHelper.class
package com.google.common.base
Objects.ToStringHelper.add ( String name, boolean value )  :  Objects.ToStringHelper
Objects.ToStringHelper.add ( String name, char value )  :  Objects.ToStringHelper
Objects.ToStringHelper.add ( String name, double value )  :  Objects.ToStringHelper
Objects.ToStringHelper.add ( String name, float value )  :  Objects.ToStringHelper
Objects.ToStringHelper.add ( String name, int value )  :  Objects.ToStringHelper
Objects.ToStringHelper.add ( String name, long value )  :  Objects.ToStringHelper
Objects.ToStringHelper.add ( String name, Object value )  :  Objects.ToStringHelper
Objects.ToStringHelper.addValue ( boolean value )  :  Objects.ToStringHelper
Objects.ToStringHelper.addValue ( char value )  :  Objects.ToStringHelper
Objects.ToStringHelper.addValue ( double value )  :  Objects.ToStringHelper
Objects.ToStringHelper.addValue ( float value )  :  Objects.ToStringHelper
Objects.ToStringHelper.addValue ( int value )  :  Objects.ToStringHelper
Objects.ToStringHelper.addValue ( long value )  :  Objects.ToStringHelper
Objects.ToStringHelper.addValue ( Object value )  :  Objects.ToStringHelper
Objects.ToStringHelper.omitNullValues ( )  :  Objects.ToStringHelper
Objects.ToStringHelper.toString ( )  :  String

cdk-1.5.3.jar, TreeBasedTable.class
package com.google.common.collect
TreeBasedTable.cellSet ( )  :  Set
TreeBasedTable.clear ( )  :  void
TreeBasedTable.column ( Object x0 )  :  Map
TreeBasedTable.columnComparator ( )  :  Comparator
TreeBasedTable.columnKeySet ( )  :  Set
TreeBasedTable.columnMap ( )  :  Map
TreeBasedTable.contains ( Object rowKey, Object columnKey )  :  boolean
TreeBasedTable.containsColumn ( Object columnKey )  :  boolean
TreeBasedTable.containsRow ( Object rowKey )  :  boolean
TreeBasedTable.containsValue ( Object value )  :  boolean
TreeBasedTable.create ( ) [static]  :  TreeBasedTable
TreeBasedTable.create ( Comparator rowComparator, Comparator columnComparator ) [static]  :  TreeBasedTable
TreeBasedTable.create ( TreeBasedTable table ) [static]  :  TreeBasedTable
TreeBasedTable.equals ( Object obj )  :  boolean
TreeBasedTable.get ( Object rowKey, Object columnKey )  :  Object
TreeBasedTable.hashCode ( )  :  int
TreeBasedTable.isEmpty ( )  :  boolean
TreeBasedTable.put ( Object x0, Object x1, Object x2 )  :  Object
TreeBasedTable.putAll ( Table x0 )  :  void
TreeBasedTable.remove ( Object rowKey, Object columnKey )  :  Object
TreeBasedTable.row ( Object rowKey )  :  SortedMap
TreeBasedTable.row ( Object x0 )  :  Map
TreeBasedTable.rowComparator ( )  :  Comparator
TreeBasedTable.rowKeySet ( )  :  Set
TreeBasedTable.rowKeySet ( )  :  SortedSet
TreeBasedTable.rowMap ( )  :  Map
TreeBasedTable.rowMap ( )  :  SortedMap
TreeBasedTable.size ( )  :  int
TreeBasedTable.toString ( )  :  String
TreeBasedTable.values ( )  :  Collection

cdk-1.5.3.jar, TreeMultimap.class
package com.google.common.collect
TreeMultimap.asMap ( )  :  Map
TreeMultimap.asMap ( )  :  NavigableMap
TreeMultimap.asMap ( )  :  SortedMap
TreeMultimap.clear ( )  :  void
TreeMultimap.containsEntry ( Object x0, Object x1 )  :  boolean
TreeMultimap.containsKey ( Object x0 )  :  boolean
TreeMultimap.containsValue ( Object x0 )  :  boolean
TreeMultimap.create ( ) [static]  :  TreeMultimap
TreeMultimap.create ( Comparator keyComparator, Comparator valueComparator ) [static]  :  TreeMultimap
TreeMultimap.create ( Multimap multimap ) [static]  :  TreeMultimap
TreeMultimap.entries ( )  :  Set
TreeMultimap.equals ( Object x0 )  :  boolean
TreeMultimap.get ( Object key )  :  NavigableSet
TreeMultimap.get ( Object x0 )  :  Collection
TreeMultimap.get ( Object x0 )  :  Set
TreeMultimap.get ( Object x0 )  :  SortedSet
TreeMultimap.hashCode ( )  :  int
TreeMultimap.isEmpty ( )  :  boolean
TreeMultimap.keyComparator ( )  :  Comparator
TreeMultimap.keys ( )  :  Multiset
TreeMultimap.keySet ( )  :  NavigableSet
TreeMultimap.keySet ( )  :  Set
TreeMultimap.keySet ( )  :  SortedSet
TreeMultimap.put ( Object x0, Object x1 )  :  boolean
TreeMultimap.putAll ( Multimap x0 )  :  boolean
TreeMultimap.putAll ( Object x0, Iterable x1 )  :  boolean
TreeMultimap.remove ( Object x0, Object x1 )  :  boolean
TreeMultimap.removeAll ( Object x0 )  :  SortedSet
TreeMultimap.replaceValues ( Object x0, Iterable x1 )  :  SortedSet
TreeMultimap.size ( )  :  int
TreeMultimap.toString ( )  :  String
TreeMultimap.valueComparator ( )  :  Comparator
TreeMultimap.values ( )  :  Collection

cdk-1.5.3.jar, TreeMultiset.class
package com.google.common.collect
TreeMultiset.add ( Object element, int occurrences )  :  int
TreeMultiset.add ( Object x0 )  :  boolean
TreeMultiset.addAll ( Collection x0 )  :  boolean
TreeMultiset.clear ( )  :  void
TreeMultiset.comparator ( )  :  Comparator
TreeMultiset.contains ( Object x0 )  :  boolean
TreeMultiset.count ( Object element )  :  int
TreeMultiset.create ( ) [static]  :  TreeMultiset
TreeMultiset.create ( Comparator comparator ) [static]  :  TreeMultiset
TreeMultiset.create ( Iterable elements ) [static]  :  TreeMultiset
TreeMultiset.descendingMultiset ( )  :  SortedMultiset
TreeMultiset.elementSet ( )  :  NavigableSet
TreeMultiset.entrySet ( )  :  Set
TreeMultiset.equals ( Object x0 )  :  boolean
TreeMultiset.firstEntry ( )  :  Multiset.Entry
TreeMultiset.hashCode ( )  :  int
TreeMultiset.headMultiset ( Object upperBound, BoundType boundType )  :  SortedMultiset
TreeMultiset.isEmpty ( )  :  boolean
TreeMultiset.iterator ( )  :  Iterator
TreeMultiset.lastEntry ( )  :  Multiset.Entry
TreeMultiset.pollFirstEntry ( )  :  Multiset.Entry
TreeMultiset.pollLastEntry ( )  :  Multiset.Entry
TreeMultiset.remove ( Object element, int occurrences )  :  int
TreeMultiset.remove ( Object x0 )  :  boolean
TreeMultiset.removeAll ( Collection x0 )  :  boolean
TreeMultiset.retainAll ( Collection x0 )  :  boolean
TreeMultiset.setCount ( Object element, int count )  :  int
TreeMultiset.setCount ( Object element, int oldCount, int newCount )  :  boolean
TreeMultiset.size ( )  :  int
TreeMultiset.subMultiset ( Object x0, BoundType x1, Object x2, BoundType x3 )  :  SortedMultiset
TreeMultiset.tailMultiset ( Object lowerBound, BoundType boundType )  :  SortedMultiset
TreeMultiset.toString ( )  :  String

cdk-1.5.3.jar, TreeRangeMap.class
package com.google.common.collect
TreeRangeMap.asMapOfRanges ( )  :  Map
TreeRangeMap.clear ( )  :  void
TreeRangeMap.create ( ) [static]  :  TreeRangeMap
TreeRangeMap.equals ( Object o )  :  boolean
TreeRangeMap.get ( Comparable key )  :  Object
TreeRangeMap.getEntry ( Comparable key )  :  Map.Entry
TreeRangeMap.hashCode ( )  :  int
TreeRangeMap.put ( Range range, Object value )  :  void
TreeRangeMap.putAll ( RangeMap rangeMap )  :  void
TreeRangeMap.remove ( Range rangeToRemove )  :  void
TreeRangeMap.span ( )  :  Range
TreeRangeMap.subRangeMap ( Range subRange )  :  RangeMap
TreeRangeMap.toString ( )  :  String

cdk-1.5.3.jar, TreeRangeSet.class
package com.google.common.collect
TreeRangeSet.add ( Range rangeToAdd )  :  void
TreeRangeSet.addAll ( RangeSet x0 )  :  void
TreeRangeSet.asRanges ( )  :  Set
TreeRangeSet.clear ( )  :  void
TreeRangeSet.complement ( )  :  RangeSet
TreeRangeSet.contains ( Comparable x0 )  :  boolean
TreeRangeSet.create ( ) [static]  :  TreeRangeSet
TreeRangeSet.create ( RangeSet rangeSet ) [static]  :  TreeRangeSet
TreeRangeSet.encloses ( Range range )  :  boolean
TreeRangeSet.enclosesAll ( RangeSet x0 )  :  boolean
TreeRangeSet.equals ( Object x0 )  :  boolean
TreeRangeSet.isEmpty ( )  :  boolean
TreeRangeSet.rangeContaining ( Comparable value )  :  Range
TreeRangeSet.remove ( Range rangeToRemove )  :  void
TreeRangeSet.removeAll ( RangeSet x0 )  :  void
TreeRangeSet.span ( )  :  Range
TreeRangeSet.subRangeSet ( Range view )  :  RangeSet

cdk-1.5.3.jar, TypeParameter.class
package com.google.common.reflect
TypeParameter.equals ( Object o )  :  boolean
TypeParameter.hashCode ( )  :  int
TypeParameter.toString ( )  :  String
TypeParameter.TypeParameter ( )

cdk-1.5.3.jar, TypeSet.class
package com.google.common.reflect
TypeToken.TypeSet.classes ( )  :  TypeToken.TypeSet
TypeToken.TypeSet.delegate ( )  :  Collection
TypeToken.TypeSet.delegate ( )  :  Object
TypeToken.TypeSet.delegate ( )  :  Set
TypeToken.TypeSet.interfaces ( )  :  TypeToken.TypeSet
TypeToken.TypeSet.rawTypes ( )  :  Set

cdk-1.5.3.jar, TypeToInstanceMap.class
package com.google.common.reflect
TypeToInstanceMap.getInstance ( Class p1 ) [abstract]  :  Object
TypeToInstanceMap.getInstance ( TypeToken p1 ) [abstract]  :  Object
TypeToInstanceMap.putInstance ( Class p1, Object p2 ) [abstract]  :  Object
TypeToInstanceMap.putInstance ( TypeToken p1, Object p2 ) [abstract]  :  Object

cdk-1.5.3.jar, TypeToken.class
package com.google.common.reflect
TypeToken.constructor ( Constructor constructor )  :  Invokable
TypeToken.equals ( Object o )  :  boolean
TypeToken.getComponentType ( )  :  TypeToken
TypeToken.getRawType ( )  :  Class
TypeToken.getSubtype ( Class subclass )  :  TypeToken
TypeToken.getSupertype ( Class superclass )  :  TypeToken
TypeToken.getType ( )  :  Type
TypeToken.getTypes ( )  :  TypeToken.TypeSet
TypeToken.hashCode ( )  :  int
TypeToken.isArray ( )  :  boolean
TypeToken.isAssignableFrom ( Type type )  :  boolean
TypeToken.isAssignableFrom ( TypeToken type )  :  boolean
TypeToken.method ( Method method )  :  Invokable
TypeToken.of ( Class type ) [static]  :  TypeToken
TypeToken.of ( Type type ) [static]  :  TypeToken
TypeToken.resolveType ( Type type )  :  TypeToken
TypeToken.toString ( )  :  String
TypeToken.TypeToken ( )
TypeToken.TypeToken ( Class declaringClass )
TypeToken.where ( TypeParameter typeParam, Class typeArg )  :  TypeToken
TypeToken.where ( TypeParameter typeParam, TypeToken typeArg )  :  TypeToken
TypeToken.writeReplace ( )  :  Object

cdk-1.5.3.jar, UncaughtExceptionHandlers.class
package com.google.common.util.concurrent
UncaughtExceptionHandlers.systemExit ( ) [static]  :  Thread.UncaughtExceptionHandler

cdk-1.5.3.jar, UncheckedExecutionException.class
package com.google.common.util.concurrent
UncheckedExecutionException.UncheckedExecutionException ( )
UncheckedExecutionException.UncheckedExecutionException ( String message )
UncheckedExecutionException.UncheckedExecutionException ( String message, Throwable cause )
UncheckedExecutionException.UncheckedExecutionException ( Throwable cause )

cdk-1.5.3.jar, UncheckedTimeoutException.class
package com.google.common.util.concurrent
UncheckedTimeoutException.UncheckedTimeoutException ( )
UncheckedTimeoutException.UncheckedTimeoutException ( String message )
UncheckedTimeoutException.UncheckedTimeoutException ( String message, Throwable cause )
UncheckedTimeoutException.UncheckedTimeoutException ( Throwable cause )

cdk-1.5.3.jar, Uninterruptibles.class
package com.google.common.util.concurrent
Uninterruptibles.awaitUninterruptibly ( CountDownLatch latch ) [static]  :  void
Uninterruptibles.awaitUninterruptibly ( CountDownLatch latch, long timeout, TimeUnit unit ) [static]  :  boolean
Uninterruptibles.getUninterruptibly ( Future future ) [static]  :  Object
Uninterruptibles.getUninterruptibly ( Future future, long timeout, TimeUnit unit ) [static]  :  Object
Uninterruptibles.joinUninterruptibly ( Thread toJoin ) [static]  :  void
Uninterruptibles.joinUninterruptibly ( Thread toJoin, long timeout, TimeUnit unit ) [static]  :  void
Uninterruptibles.putUninterruptibly ( BlockingQueue queue, Object element ) [static]  :  void
Uninterruptibles.sleepUninterruptibly ( long sleepFor, TimeUnit unit ) [static]  :  void
Uninterruptibles.takeUninterruptibly ( BlockingQueue queue ) [static]  :  Object

cdk-1.5.3.jar, UnmodifiableIterator.class
package com.google.common.collect
UnmodifiableIterator.remove ( )  :  void *DEPRECATED*
UnmodifiableIterator.UnmodifiableIterator ( )

cdk-1.5.3.jar, UnmodifiableListIterator.class
package com.google.common.collect
UnmodifiableListIterator.add ( Object e )  :  void *DEPRECATED*
UnmodifiableListIterator.set ( Object e )  :  void *DEPRECATED*
UnmodifiableListIterator.UnmodifiableListIterator ( )

cdk-1.5.3.jar, UnsignedBytes.class
package com.google.common.primitives
UnsignedBytes.checkedCast ( long value ) [static]  :  byte
UnsignedBytes.compare ( byte a, byte b ) [static]  :  int
UnsignedBytes.join ( String separator, byte[ ] array ) [static]  :  String
UnsignedBytes.lexicographicalComparator ( ) [static]  :  Comparator
UnsignedBytes.max ( byte[ ] array ) [static]  :  byte
UnsignedBytes.min ( byte[ ] array ) [static]  :  byte
UnsignedBytes.parseUnsignedByte ( String string ) [static]  :  byte
UnsignedBytes.parseUnsignedByte ( String string, int radix ) [static]  :  byte
UnsignedBytes.saturatedCast ( long value ) [static]  :  byte
UnsignedBytes.toInt ( byte value ) [static]  :  int
UnsignedBytes.toString ( byte x ) [static]  :  String
UnsignedBytes.toString ( byte x, int radix ) [static]  :  String

cdk-1.5.3.jar, UnsignedInteger.class
package com.google.common.primitives
UnsignedInteger.add ( UnsignedInteger val )  :  UnsignedInteger *DEPRECATED*
UnsignedInteger.asUnsigned ( int value ) [static]  :  UnsignedInteger *DEPRECATED*
UnsignedInteger.bigIntegerValue ( )  :  BigInteger
UnsignedInteger.compareTo ( Object x0 )  :  int
UnsignedInteger.compareTo ( UnsignedInteger other )  :  int
UnsignedInteger.divide ( UnsignedInteger val )  :  UnsignedInteger *DEPRECATED*
UnsignedInteger.dividedBy ( UnsignedInteger val )  :  UnsignedInteger
UnsignedInteger.doubleValue ( )  :  double
UnsignedInteger.equals ( Object obj )  :  boolean
UnsignedInteger.floatValue ( )  :  float
UnsignedInteger.fromIntBits ( int bits ) [static]  :  UnsignedInteger
UnsignedInteger.hashCode ( )  :  int
UnsignedInteger.intValue ( )  :  int
UnsignedInteger.longValue ( )  :  long
UnsignedInteger.minus ( UnsignedInteger val )  :  UnsignedInteger
UnsignedInteger.mod ( UnsignedInteger val )  :  UnsignedInteger
UnsignedInteger.multiply ( UnsignedInteger val )  :  UnsignedInteger *DEPRECATED*
UnsignedInteger.plus ( UnsignedInteger val )  :  UnsignedInteger
UnsignedInteger.remainder ( UnsignedInteger val )  :  UnsignedInteger *DEPRECATED*
UnsignedInteger.subtract ( UnsignedInteger val )  :  UnsignedInteger *DEPRECATED*
UnsignedInteger.times ( UnsignedInteger val )  :  UnsignedInteger
UnsignedInteger.toString ( )  :  String
UnsignedInteger.toString ( int radix )  :  String
UnsignedInteger.valueOf ( BigInteger value ) [static]  :  UnsignedInteger
UnsignedInteger.valueOf ( long value ) [static]  :  UnsignedInteger
UnsignedInteger.valueOf ( String string ) [static]  :  UnsignedInteger
UnsignedInteger.valueOf ( String string, int radix ) [static]  :  UnsignedInteger

cdk-1.5.3.jar, UnsignedInts.class
package com.google.common.primitives
UnsignedInts.compare ( int a, int b ) [static]  :  int
UnsignedInts.decode ( String stringValue ) [static]  :  int
UnsignedInts.divide ( int dividend, int divisor ) [static]  :  int
UnsignedInts.join ( String separator, int[ ] array ) [static]  :  String
UnsignedInts.lexicographicalComparator ( ) [static]  :  Comparator
UnsignedInts.max ( int[ ] array ) [static]  :  int
UnsignedInts.min ( int[ ] array ) [static]  :  int
UnsignedInts.parseUnsignedInt ( String s ) [static]  :  int
UnsignedInts.parseUnsignedInt ( String string, int radix ) [static]  :  int
UnsignedInts.remainder ( int dividend, int divisor ) [static]  :  int
UnsignedInts.toLong ( int value ) [static]  :  long
UnsignedInts.toString ( int x ) [static]  :  String
UnsignedInts.toString ( int x, int radix ) [static]  :  String

cdk-1.5.3.jar, UnsignedLong.class
package com.google.common.primitives
UnsignedLong.add ( UnsignedLong val )  :  UnsignedLong *DEPRECATED*
UnsignedLong.asUnsigned ( long value ) [static]  :  UnsignedLong *DEPRECATED*
UnsignedLong.bigIntegerValue ( )  :  BigInteger
UnsignedLong.compareTo ( Object x0 )  :  int
UnsignedLong.compareTo ( UnsignedLong o )  :  int
UnsignedLong.divide ( UnsignedLong val )  :  UnsignedLong *DEPRECATED*
UnsignedLong.dividedBy ( UnsignedLong val )  :  UnsignedLong
UnsignedLong.doubleValue ( )  :  double
UnsignedLong.equals ( Object obj )  :  boolean
UnsignedLong.floatValue ( )  :  float
UnsignedLong.fromLongBits ( long bits ) [static]  :  UnsignedLong
UnsignedLong.hashCode ( )  :  int
UnsignedLong.intValue ( )  :  int
UnsignedLong.longValue ( )  :  long
UnsignedLong.minus ( UnsignedLong val )  :  UnsignedLong
UnsignedLong.mod ( UnsignedLong val )  :  UnsignedLong
UnsignedLong.multiply ( UnsignedLong val )  :  UnsignedLong *DEPRECATED*
UnsignedLong.plus ( UnsignedLong val )  :  UnsignedLong
UnsignedLong.remainder ( UnsignedLong val )  :  UnsignedLong *DEPRECATED*
UnsignedLong.subtract ( UnsignedLong val )  :  UnsignedLong *DEPRECATED*
UnsignedLong.times ( UnsignedLong val )  :  UnsignedLong
UnsignedLong.toString ( )  :  String
UnsignedLong.toString ( int radix )  :  String
UnsignedLong.valueOf ( BigInteger value ) [static]  :  UnsignedLong
UnsignedLong.valueOf ( long value ) [static]  :  UnsignedLong
UnsignedLong.valueOf ( String string ) [static]  :  UnsignedLong
UnsignedLong.valueOf ( String string, int radix ) [static]  :  UnsignedLong

cdk-1.5.3.jar, UnsignedLongs.class
package com.google.common.primitives
UnsignedLongs.compare ( long a, long b ) [static]  :  int
UnsignedLongs.decode ( String stringValue ) [static]  :  long
UnsignedLongs.divide ( long dividend, long divisor ) [static]  :  long
UnsignedLongs.join ( String separator, long[ ] array ) [static]  :  String
UnsignedLongs.lexicographicalComparator ( ) [static]  :  Comparator
UnsignedLongs.max ( long[ ] array ) [static]  :  long
UnsignedLongs.min ( long[ ] array ) [static]  :  long
UnsignedLongs.parseUnsignedLong ( String s ) [static]  :  long
UnsignedLongs.parseUnsignedLong ( String s, int radix ) [static]  :  long
UnsignedLongs.remainder ( long dividend, long divisor ) [static]  :  long
UnsignedLongs.toString ( long x ) [static]  :  String
UnsignedLongs.toString ( long x, int radix ) [static]  :  String

cdk-1.5.3.jar, ValueDifference.class
package com.google.common.collect
MapDifference.ValueDifference.equals ( Object p1 ) [abstract]  :  boolean
MapDifference.ValueDifference.hashCode ( ) [abstract]  :  int
MapDifference.ValueDifference.leftValue ( ) [abstract]  :  Object
MapDifference.ValueDifference.rightValue ( ) [abstract]  :  Object

cdk-1.5.3.jar, Weigher.class
package com.google.common.cache
Weigher.weigh ( Object p1, Object p2 ) [abstract]  :  int

cdk-1.5.3.jar, WithExplicitOrdering.class
package com.google.common.util.concurrent
CycleDetectingLockFactory.WithExplicitOrdering.newReentrantLock ( Enum rank )  :  ReentrantLock
CycleDetectingLockFactory.WithExplicitOrdering.newReentrantLock ( Enum rank, boolean fair )  :  ReentrantLock
CycleDetectingLockFactory.WithExplicitOrdering.newReentrantReadWriteLock ( Enum rank )  :  ReentrantReadWriteLock
CycleDetectingLockFactory.WithExplicitOrdering.newReentrantReadWriteLock ( Enum rank, boolean fair )  :  ReentrantReadWriteLock

cdk-1.5.3.jar, Wrapper.class
package com.google.common.base
Equivalence.Wrapper.equals ( Object obj )  :  boolean
Equivalence.Wrapper.get ( )  :  Object
Equivalence.Wrapper.hashCode ( )  :  int
Equivalence.Wrapper.toString ( )  :  String

to the top

Removed Methods (365)


cdk-1.5.2.jar, AcidicGroupCountDescriptor.class
package org.openscience.cdk.qsar.descriptors.molecular
AcidicGroupCountDescriptor.AcidicGroupCountDescriptor ( IChemObjectBuilder builder )

cdk-1.5.2.jar, AllEquivalentCyclicSet.class
package org.openscience.cdk.hash.equivalent
AllEquivalentCyclicSet.AllEquivalentCyclicSet ( )
AllEquivalentCyclicSet.find ( long[ ] invariants, IAtomContainer container, int[ ][ ] graph )  :  Set

cdk-1.5.2.jar, AllRingsFinder.class
package org.openscience.cdk.ringsearch
AllRingsFinder.findAllRings ( IAtomContainer atomContainer, Integer maxRingSize )  :  IRingSet
AllRingsFinder.findAllRingsInIsolatedRingSystem ( IAtomContainer atomContainer, Integer maxRingSize )  :  IRingSet

cdk-1.5.2.jar, AminoAcids.class
package org.openscience.cdk.templates
AminoAcids.getHashMapByThreeLetterCode ( ) [static]  :  HashMap

cdk-1.5.2.jar, Atom.class
package signature.chemistry
Molecule.Atom.equals ( Molecule.Atom other )  :  boolean
Molecule.Atom.Molecule.Atom ( Molecule index, int symbol, String p3 )
Molecule.Atom.Molecule.Atom ( Molecule other, Molecule.Atom p2 )
Molecule.Atom.toString ( )  :  String

cdk-1.5.2.jar, AtomEncoder.class
package org.openscience.cdk.hash.seed
AtomEncoder.encode ( IAtom p1, IAtomContainer p2 ) [abstract]  :  int

cdk-1.5.2.jar, AtomPermutor.class
package signature.chemistry
AtomPermutor.AtomPermutor ( Molecule molecule )
AtomPermutor.next ( )  :  Molecule
AtomPermutor.next ( )  :  Object
AtomPermutor.remove ( )  :  void

cdk-1.5.2.jar, AtomSignature.class
package signature.chemistry
AtomSignature.AtomSignature ( Molecule molecule, int atomNumber )
AtomSignature.AtomSignature ( Molecule molecule, int atomNumber, int height )
AtomSignature.AtomSignature ( Molecule molecule, int atomNumber, int height, AbstractVertexSignature.InvariantType invariantType )
AtomSignature.getConnected ( int vertexIndex )  :  int[ ]
AtomSignature.getEdgeLabel ( int vertexIndex, int otherVertexIndex )  :  String
AtomSignature.getIntLabel ( int vertexIndex )  :  int
AtomSignature.getVertexSymbol ( int vertexIndex )  :  String

cdk-1.5.2.jar, BasicAtomEncoder.class
package org.openscience.cdk.hash.seed
BasicAtomEncoder.valueOf ( String name ) [static]  :  BasicAtomEncoder
BasicAtomEncoder.values ( ) [static]  :  BasicAtomEncoder[ ]

cdk-1.5.2.jar, BasicAtomHashGenerator.class
package org.openscience.cdk.hash
BasicAtomHashGenerator.BasicAtomHashGenerator ( AtomHashGenerator seedGenerator, Pseudorandom pseudorandom, StereoEncoderFactory factory, int depth )

cdk-1.5.2.jar, BasicGroupCountDescriptor.class
package org.openscience.cdk.qsar.descriptors.molecular
BasicGroupCountDescriptor.BasicGroupCountDescriptor ( IChemObjectBuilder builder )

cdk-1.5.2.jar, BasicPermutationParity.class
package org.openscience.cdk.hash.stereo.parity
BasicPermutationParity.BasicPermutationParity ( int[ ] indices )
BasicPermutationParity.parity ( long[ ] current )  :  int

cdk-1.5.2.jar, Bond.class
package signature.chemistry
Molecule.Bond.compareTo ( Molecule.Bond o )  :  int
Molecule.Bond.compareTo ( Object p1 )  :  int
Molecule.Bond.equals ( Object o )  :  boolean
Molecule.Bond.getConnected ( int i )  :  int
Molecule.Bond.hasBoth ( int atomIndexA, int atomIndexB )  :  boolean
Molecule.Bond.Molecule.Bond ( Molecule a, Molecule.Atom b, Molecule.Atom order, int p4 )
Molecule.Bond.Molecule.Bond ( Molecule other, Molecule.Bond p2 )
Molecule.Bond.toString ( )  :  String

cdk-1.5.2.jar, CanonicalLabellingTest.class
package signature.simple
CanonicalLabellingTest.CanonicalLabellingTest ( )
CanonicalLabellingTest.fiveCycleTest ( )  :  void
CanonicalLabellingTest.fourCycleTest ( )  :  void
CanonicalLabellingTest.getLabels ( SimpleGraph graph )  :  int[ ]
CanonicalLabellingTest.isIdentity ( int[ ] permutation )  :  boolean
CanonicalLabellingTest.permuteTest ( SimpleGraph graph )  :  void
CanonicalLabellingTest.testSimpleGraphLabelling ( )  :  void
CanonicalLabellingTest.threeFourFusedCycle ( )  :  void
CanonicalLabellingTest.threeThreeFusedCycle ( )  :  void

cdk-1.5.2.jar, ChiralCenterFinder.class
package signature.chemistry
ChiralCenterFinder.ChiralCenterFinder ( )
ChiralCenterFinder.findTetrahedralChiralCenters ( Molecule molecule ) [static]  :  List

cdk-1.5.2.jar, ChiralityTest.class
package signature.chemistry
ChiralityTest.ChiralityTest ( )
ChiralityTest.dichlorocyclopropaneTest ( )  :  void
ChiralityTest.dihydroxyCyclohexane ( )  :  void
ChiralityTest.spiranTest ( )  :  void

cdk-1.5.2.jar, ColoredTreePanel.class
package signature.display
ColoredTreePanel.clear ( )  :  void
ColoredTreePanel.ColoredTreePanel ( ColoredTree tree, int width, int height )
ColoredTreePanel.ColoredTreePanel ( int width, int height )
ColoredTreePanel.paint ( Graphics g )  :  void
ColoredTreePanel.setDrawKey ( boolean drawKey )  :  void
ColoredTreePanel.setTree ( ColoredTree tree )  :  void

cdk-1.5.2.jar, CombinedPermutationParity.class
package org.openscience.cdk.hash.stereo.parity
CombinedPermutationParity.CombinedPermutationParity ( PermutationParity left, PermutationParity right )
CombinedPermutationParity.parity ( long[ ] current )  :  int

cdk-1.5.2.jar, ConjugatedAtomEncoder.class
package org.openscience.cdk.hash.seed
ConjugatedAtomEncoder.ConjugatedAtomEncoder ( List encoders )
ConjugatedAtomEncoder.create ( AtomEncoder encoder, AtomEncoder[ ] encoders ) [static]  :  AtomEncoder
ConjugatedAtomEncoder.encode ( IAtom atom, IAtomContainer container )  :  int

cdk-1.5.2.jar, DescriptorEngine.class
package org.openscience.cdk.qsar
DescriptorEngine.DescriptorEngine ( int type, IChemObjectBuilder builder )
DescriptorEngine.DescriptorEngine ( int type, String[ ] jarFileNames, IChemObjectBuilder builder )

cdk-1.5.2.jar, DisplayableColoredTree.class
package signature.display
DisplayableColoredTree.DisplayableColoredTree ( ColoredTree tree, int width, int height )
DisplayableColoredTree.DisplayableColoredTree ( int width, int height )
DisplayableColoredTree.makeFromColoredTree ( ColoredTree tree )  :  void
DisplayableColoredTree.paint ( Graphics g )  :  void
DisplayableColoredTree.paint ( Graphics g, DisplayableColoredTree.DrawNode node )  :  void
DisplayableColoredTree.paintKey ( Graphics g )  :  void
DisplayableColoredTree.setDrawKey ( boolean drawKey )  :  void

cdk-1.5.2.jar, DoubleBond2DParity.class
package org.openscience.cdk.hash.stereo.parity
DoubleBond2DParity.DoubleBond2DParity ( Point2d left, Point2d right, Point2d leftSubstituent, Point2d rightSubstituent )
DoubleBond2DParity.DoubleBond2DParity ( Point2d left, Point2d right, Point2d leftSubstituent1, Point2d leftSubstituent2, Point2d rightSubstituent1, Point2d rightSubstituent2 )
DoubleBond2DParity.parity ( )  :  int

cdk-1.5.2.jar, DoubleBond3DParity.class
package org.openscience.cdk.hash.stereo.parity
DoubleBond3DParity.DoubleBond3DParity ( Point3d left, Point3d right, Point3d leftSubstituent, Point3d rightSubstituent )
DoubleBond3DParity.parity ( )  :  int

cdk-1.5.2.jar, DrawNode.class
package signature.display
DisplayableColoredTree.DrawNode.countLeaves ( )  :  int
DisplayableColoredTree.DrawNode.DisplayableColoredTree.DrawNode ( DisplayableColoredTree label, String parent, DisplayableColoredTree.DrawNode d, int color, int edgeLabel, String p6 )
DisplayableColoredTree.DrawNode.DisplayableColoredTree.DrawNode ( DisplayableColoredTree label, String parent, DisplayableColoredTree.DrawNode d, int color, int p5 )
DisplayableColoredTree.DrawNode.isLeaf ( )  :  boolean
DisplayableColoredTree.DrawNode.toString ( )  :  String

cdk-1.5.2.jar, Edge.class
package signature.simple
SimpleGraph.Edge.compareTo ( Object p1 )  :  int
SimpleGraph.Edge.compareTo ( SimpleGraph.Edge other )  :  int
SimpleGraph.Edge.SimpleGraph.Edge ( SimpleGraph a, int b, int p3 )
SimpleGraph.Edge.toString ( )  :  String

cdk-1.5.2.jar, EquivalentSetFinder.class
package org.openscience.cdk.hash.equivalent
EquivalentSetFinder.find ( long[ ] p1, IAtomContainer p2, int[ ][ ] p3 ) [abstract]  :  Set

cdk-1.5.2.jar, GeometricDoubleBondEncoderFactory.class
package org.openscience.cdk.hash.stereo.factory
GeometricDoubleBondEncoderFactory.create ( IAtomContainer container, int[ ][ ] graph )  :  StereoEncoder
GeometricDoubleBondEncoderFactory.GeometricDoubleBondEncoderFactory ( )

cdk-1.5.2.jar, GeometricParity.class
package org.openscience.cdk.hash.stereo.parity
GeometricParity.parity ( ) [abstract]  :  int

cdk-1.5.2.jar, GeometricTetrahedralEncoderFactory.class
package org.openscience.cdk.hash.stereo.factory
GeometricTetrahedralEncoderFactory.create ( IAtomContainer container, int[ ][ ] graph )  :  StereoEncoder
GeometricTetrahedralEncoderFactory.GeometricTetrahedralEncoderFactory ( )

cdk-1.5.2.jar, GeometryEncoder.class
package org.openscience.cdk.hash.stereo
GeometryEncoder.GeometryEncoder ( int centre, PermutationParity permutation, GeometricParity geometric )
GeometryEncoder.GeometryEncoder ( int[ ] centres, PermutationParity permutation, GeometricParity geometric )

cdk-1.5.2.jar, HashGeneratorMaker.class
package org.openscience.cdk.hash
HashGeneratorMaker.encode ( AtomEncoder encoder )  :  HashGeneratorMaker
HashGeneratorMaker.perturbWith ( EquivalentSetFinder equivSetFinder )  :  HashGeneratorMaker

cdk-1.5.2.jar, HeightTest.class
package signature
HeightTest.completeGraphTest ( )  :  void
HeightTest.HeightTest ( )
HeightTest.main ( String[ ] args ) [static]  :  void
HeightTest.makeCompleteGraph ( int n )  :  SimpleGraph
HeightTest.makeTorus ( int width, int height )  :  SimpleGraph
HeightTest.regularGraphTest ( SimpleGraph graph, int diameter )  :  void
HeightTest.torusTest ( )  :  void

cdk-1.5.2.jar, LargeMoleculeTest.class
package signature.chemistry
LargeMoleculeTest.addRing ( int atomToAttachTo, int ringSize, Molecule molecule )  :  void
LargeMoleculeTest.buckyballTest ( )  :  void
LargeMoleculeTest.buckyballWithoutMultipleBonds ( )  :  void
LargeMoleculeTest.dodecahedraneTest ( )  :  void
LargeMoleculeTest.drawTrees ( MoleculeQuotientGraph mqg, String directoryPath )  :  void
LargeMoleculeTest.faulonsBuckySignatures ( )  :  void
LargeMoleculeTest.LargeMoleculeTest ( )
LargeMoleculeTest.main ( String[ ] args ) [static]  :  void
LargeMoleculeTest.makeChain ( int length )  :  Molecule
LargeMoleculeTest.makeMinimalMultiRing ( int ringCount, int ringSize )  :  Molecule
LargeMoleculeTest.makeTetrakisTriphenylPhosphoranylRhodium ( )  :  Molecule
LargeMoleculeTest.readSigs ( String filename )  :  List
LargeMoleculeTest.readSigs2 ( String filename )  :  List
LargeMoleculeTest.testLongChains ( )  :  void
LargeMoleculeTest.testMinimalMol ( )  :  void
LargeMoleculeTest.ttprTest ( )  :  void

cdk-1.5.2.jar, MinimumEquivalentCyclicSet.class
package org.openscience.cdk.hash.equivalent
MinimumEquivalentCyclicSet.find ( long[ ] invariants, IAtomContainer container, int[ ][ ] graph )  :  Set
MinimumEquivalentCyclicSet.MinimumEquivalentCyclicSet ( )

cdk-1.5.2.jar, MinimumEquivalentCyclicSetUnion.class
package org.openscience.cdk.hash.equivalent
MinimumEquivalentCyclicSetUnion.find ( long[ ] invariants, IAtomContainer container, int[ ][ ] graph )  :  Set
MinimumEquivalentCyclicSetUnion.MinimumEquivalentCyclicSetUnion ( )

cdk-1.5.2.jar, Molecule.class
package signature.chemistry
Molecule.addAtom ( int i, String symbol )  :  void
Molecule.addAtom ( String symbol )  :  void
Molecule.addBond ( int atomNumberA, int atomNumberB, int order )  :  void
Molecule.addMultipleAtoms ( int count, String symbol )  :  void
Molecule.addMultipleSingleBonds ( int i, int[ ] js )  :  void
Molecule.addSingleBond ( int atomNumberA, int atomNumberB )  :  void
Molecule.bonds ( )  :  List
Molecule.bondsOrdered ( )  :  boolean
Molecule.getAtomCount ( )  :  int
Molecule.getBondCount ( )  :  int
Molecule.getBondOrder ( int atomIndex, int otherAtomIndex )  :  int
Molecule.getBondOrder ( int bondIndex )  :  int
Molecule.getConnected ( int atomIndex )  :  int[ ]
Molecule.getFirstInBond ( int bondIndex )  :  int
Molecule.getSecondInBond ( int bondIndex )  :  int
Molecule.getSymbolFor ( int atomIndex )  :  String
Molecule.getTotalOrder ( int atomIndex )  :  int
Molecule.identical ( Molecule other )  :  boolean
Molecule.isConnected ( int i, int j )  :  boolean
Molecule.Molecule ( )
Molecule.Molecule ( Molecule other )
Molecule.Molecule ( Molecule other, int[ ] permutation )
Molecule.Molecule ( String atomSymbol, int count )
Molecule.toEdgeString ( )  :  String
Molecule.toString ( )  :  String

cdk-1.5.2.jar, MoleculeBuilder.class
package signature.chemistry
MoleculeBuilder.fromTree ( ColoredTree tree )  :  Molecule
MoleculeBuilder.getMolecule ( )  :  Molecule
MoleculeBuilder.makeEdge ( int vertexIndex1, int vertexIndex2, String symbolA, String symbolB, String edgeLabel )  :  void
MoleculeBuilder.makeGraph ( )  :  void
MoleculeBuilder.makeVertex ( String label )  :  void
MoleculeBuilder.MoleculeBuilder ( )

cdk-1.5.2.jar, MoleculeFactory.class
package signature.chemistry
MoleculeFactory.fiveCycle ( ) [static]  :  Molecule
MoleculeFactory.fiveStar ( ) [static]  :  Molecule
MoleculeFactory.fourCycle ( ) [static]  :  Molecule
MoleculeFactory.fourStar ( ) [static]  :  Molecule
MoleculeFactory.methane ( ) [static]  :  Molecule
MoleculeFactory.methylatedCyclobutane ( ) [static]  :  Molecule
MoleculeFactory.MoleculeFactory ( )
MoleculeFactory.propellane ( ) [static]  :  Molecule
MoleculeFactory.pseudopropellane ( ) [static]  :  Molecule
MoleculeFactory.sixCage ( ) [static]  :  Molecule
MoleculeFactory.sixCycle ( ) [static]  :  Molecule
MoleculeFactory.threeCycle ( ) [static]  :  Molecule
MoleculeFactory.threeStar ( ) [static]  :  Molecule

cdk-1.5.2.jar, MoleculeQuotientGraph.class
package signature.chemistry
MoleculeQuotientGraph.isConnected ( int i, int j )  :  boolean
MoleculeQuotientGraph.MoleculeQuotientGraph ( Molecule molecule )
MoleculeQuotientGraph.MoleculeQuotientGraph ( Molecule molecule, List sigStrings )

cdk-1.5.2.jar, MoleculeReader.class
package signature.chemistry
MoleculeReader.MoleculeReader ( )
MoleculeReader.readMolfile ( String filename ) [static]  :  Molecule
MoleculeReader.readSDFFile ( String filename ) [static]  :  List
MoleculeReader.readSDFfromStream ( InputStream stream ) [static]  :  List

cdk-1.5.2.jar, MoleculeSignature.class
package signature.chemistry
MoleculeSignature.getMolecularSignature ( )  :  String
MoleculeSignature.getVertexCount ( )  :  int
MoleculeSignature.isCanonicallyLabelled ( Molecule molecule ) [static]  :  boolean
MoleculeSignature.MoleculeSignature ( Molecule molecule )
MoleculeSignature.MoleculeSignature ( Molecule molecule, AbstractVertexSignature.InvariantType invariantType )
MoleculeSignature.signatureForVertex ( int vertexIndex )  :  AbstractVertexSignature
MoleculeSignature.signatureStringForVertex ( int vertexIndex )  :  String
MoleculeSignature.signatureStringForVertex ( int vertexIndex, int height )  :  String

cdk-1.5.2.jar, MoleculeSignatureTest.class
package signature.chemistry
MoleculeSignatureTest.minimalTest ( )  :  void
MoleculeSignatureTest.MoleculeSignatureTest ( )
MoleculeSignatureTest.testCage ( )  :  void
MoleculeSignatureTest.testCanonicalIsUnique ( )  :  void
MoleculeSignatureTest.testCanonicalIsUnique ( Molecule molecule )  :  void
MoleculeSignatureTest.testCanonicalLabelling ( )  :  void
MoleculeSignatureTest.testCarbonChainUnique ( )  :  void
MoleculeSignatureTest.testCarbonHydrogenCanonicalChain ( )  :  void
MoleculeSignatureTest.testColoredTreeCreation ( )  :  void
MoleculeSignatureTest.testFiveCycle ( )  :  void
MoleculeSignatureTest.testFiveStarCanonicalUnique ( )  :  void
MoleculeSignatureTest.testFourStarCanonicalUnique ( )  :  void
MoleculeSignatureTest.testHexagonCanonicalIsUnique ( )  :  void
MoleculeSignatureTest.testLargeExample ( )  :  void
MoleculeSignatureTest.testMethaneIsCanonicallyUnique ( )  :  void
MoleculeSignatureTest.testMethaneSignatures ( )  :  void
MoleculeSignatureTest.testMetheneFragmentIsCanonicallyUnique ( )  :  void
MoleculeSignatureTest.testMetheneFragmentSignatures ( )  :  void
MoleculeSignatureTest.testMethylCyclobutaneCanonicalIsUnique ( )  :  void
MoleculeSignatureTest.testMethyneFragmentSignatures ( )  :  void
MoleculeSignatureTest.testOddCycleReadin ( )  :  void
MoleculeSignatureTest.testPentagonCanonicalIsUnique ( )  :  void
MoleculeSignatureTest.testPropellaneCanonicalIsUnique ( )  :  void
MoleculeSignatureTest.testPseudopropellaneCanonicalIsUnique ( )  :  void
MoleculeSignatureTest.testRoundtrip ( )  :  void
MoleculeSignatureTest.testSDF ( )  :  void
MoleculeSignatureTest.testSixcageCanonicalIsUnique ( )  :  void
MoleculeSignatureTest.testSquareCanonicalIsUnique ( )  :  void
MoleculeSignatureTest.testThreeStarCanonicalUnique ( )  :  void
MoleculeSignatureTest.testTriangleCanonicalIsUnique ( )  :  void

cdk-1.5.2.jar, MoleculeWriter.class
package signature.chemistry
MoleculeWriter.MoleculeWriter ( )
MoleculeWriter.writeMolfile ( String filename, Molecule molecule ) [static]  :  void
MoleculeWriter.writeToStream ( OutputStream stream, Molecule molecule ) [static]  :  void

cdk-1.5.2.jar, MultipleBondTest.class
package signature.chemistry
MultipleBondTest.benzeneTest ( )  :  void
MultipleBondTest.cocoTest ( )  :  void
MultipleBondTest.cyclobut_1_ene ( )  :  void
MultipleBondTest.cyclobut_2_ene ( )  :  void
MultipleBondTest.multipleBondedFragmentTest ( )  :  void
MultipleBondTest.MultipleBondTest ( )

cdk-1.5.2.jar, NumberLabelsTest.class
package signature.chemistry
NumberLabelsTest.choTest ( )  :  void
NumberLabelsTest.NumberLabelsTest ( )

cdk-1.5.2.jar, ParsingTest.class
package signature
ParsingTest.basicParseTest ( )  :  void
ParsingTest.edgeLabelMultipleChildrenParseTest ( )  :  void
ParsingTest.edgeLabelMultipleLevelsParseTest ( )  :  void
ParsingTest.edgeLabelParseTest ( )  :  void
ParsingTest.multipleChildrenParseTest ( )  :  void
ParsingTest.multipleLevelsParseTest ( )  :  void
ParsingTest.ParsingTest ( )

cdk-1.5.2.jar, Path.class
package org.openscience.cdk.ringsearch
Path.getIntersectionSize ( Path other )  :  int
Path.join ( Path path1, Path path2, IAtom atom ) [static]  :  Path
Path.Path ( )
Path.Path ( IAtom atom1, IAtom atom2 )
Path.toString ( IAtomContainer ac )  :  String

cdk-1.5.2.jar, PermutationParity.class
package org.openscience.cdk.hash.stereo.parity
PermutationParity.parity ( long[ ] p1 ) [abstract]  :  int

cdk-1.5.2.jar, PermutationTest.class
package signature
PermutationTest.doubleBondChainTest ( )  :  void
PermutationTest.PermutationTest ( )
PermutationTest.permuteCNOMolecule ( )  :  void
PermutationTest.permuteCompletely ( Molecule molecule )  :  void
PermutationTest.permuteOCCCSC ( )  :  void
PermutationTest.permuteOCCOCO ( )  :  void
PermutationTest.printIdentity ( Molecule molecule, String signature )  :  void
PermutationTest.testSpecificPermutation ( Molecule molecule, int[ ] permutation )  :  void
PermutationTest.toSignatureString ( Molecule molecule )  :  String

cdk-1.5.2.jar, PerturbedAtomHashGenerator.class
package org.openscience.cdk.hash
PerturbedAtomHashGenerator.PerturbedAtomHashGenerator ( AtomHashGenerator seedGenerator, Pseudorandom pseudorandom, StereoEncoderFactory factory, EquivalentSetFinder finder, int depth )

cdk-1.5.2.jar, ReconstructionTest.class
package signature.simple
ReconstructionTest.bowtieaneTest ( )  :  void
ReconstructionTest.petersensGraphTest ( )  :  void
ReconstructionTest.reconstruct ( SimpleGraph graph )  :  void
ReconstructionTest.ReconstructionTest ( )

cdk-1.5.2.jar, SDFToSignatures.class
package signature.chemistry
SDFToSignatures.main ( String[ ] args ) [static]  :  void
SDFToSignatures.SDFToSignatures ( )

cdk-1.5.2.jar, SeedGenerator.class
package org.openscience.cdk.hash
SeedGenerator.SeedGenerator ( AtomEncoder encoder )

cdk-1.5.2.jar, SignatureViewer.class
package signature.display
SignatureViewer.actionPerformed ( ActionEvent e )  :  void
SignatureViewer.main ( String[ ] args ) [static]  :  void
SignatureViewer.SignatureViewer ( )

cdk-1.5.2.jar, SimpleGraph.class
package signature.simple
SimpleGraph.degree ( int vertexIndex )  :  int
SimpleGraph.getConnected ( int vertexIndex )  :  int[ ]
SimpleGraph.getVertexCount ( )  :  int
SimpleGraph.isConnected ( int i, int j )  :  boolean
SimpleGraph.makeEdge ( int a, int b )  :  void
SimpleGraph.SimpleGraph ( )
SimpleGraph.SimpleGraph ( SimpleGraph graph, int[ ] permutation )
SimpleGraph.SimpleGraph ( String graphString )
SimpleGraph.toString ( )  :  String

cdk-1.5.2.jar, SimpleGraphBuilder.class
package signature.simple
SimpleGraphBuilder.fromTree ( ColoredTree tree )  :  SimpleGraph
SimpleGraphBuilder.makeEdge ( int vertexIndex1, int vertexIndex2, String a, String b, String edgeLabel )  :  void
SimpleGraphBuilder.makeGraph ( )  :  void
SimpleGraphBuilder.makeVertex ( String label )  :  void
SimpleGraphBuilder.SimpleGraphBuilder ( )

cdk-1.5.2.jar, SimpleGraphFactory.class
package signature.simple
SimpleGraphFactory.make26Fullerene ( ) [static]  :  SimpleGraph
SimpleGraphFactory.makeAdamantane ( ) [static]  :  SimpleGraph
SimpleGraphFactory.makeBowtieane ( ) [static]  :  SimpleGraph
SimpleGraphFactory.makeCuneane ( ) [static]  :  SimpleGraph
SimpleGraphFactory.makeDiSpiroOctane ( ) [static]  :  SimpleGraph
SimpleGraphFactory.makeDoubleBridgedPentagon ( ) [static]  :  SimpleGraph
SimpleGraphFactory.makeFourRegularExample ( ) [static]  :  SimpleGraph
SimpleGraphFactory.makeNapthalene ( ) [static]  :  SimpleGraph
SimpleGraphFactory.makePappusGraph ( ) [static]  :  SimpleGraph
SimpleGraphFactory.makePetersensGraph ( ) [static]  :  SimpleGraph
SimpleGraphFactory.makePrism ( int size ) [static]  :  SimpleGraph
SimpleGraphFactory.makeSandwich ( int size ) [static]  :  SimpleGraph
SimpleGraphFactory.makeSpiroPentagons ( ) [static]  :  SimpleGraph
SimpleGraphFactory.makeSquareQuotientGraph ( ) [static]  :  SimpleGraph
SimpleGraphFactory.makeThreeFourFiveTwisted ( ) [static]  :  SimpleGraph
SimpleGraphFactory.makeTietzesGraph ( ) [static]  :  SimpleGraph
SimpleGraphFactory.makeTricycloPropaIndene ( ) [static]  :  SimpleGraph
SimpleGraphFactory.makeTruncatedTetrahedron ( ) [static]  :  SimpleGraph
SimpleGraphFactory.makeTwistane ( ) [static]  :  SimpleGraph
SimpleGraphFactory.SimpleGraphFactory ( )

cdk-1.5.2.jar, SimpleGraphPermutor.class
package signature.simple
SimpleGraphPermutor.next ( )  :  Object
SimpleGraphPermutor.next ( )  :  SimpleGraph
SimpleGraphPermutor.remove ( )  :  void
SimpleGraphPermutor.SimpleGraphPermutor ( SimpleGraph graph )

cdk-1.5.2.jar, SimpleGraphSignature.class
package signature.simple
SimpleGraphSignature.getVertexCount ( )  :  int
SimpleGraphSignature.signatureForVertex ( int vertexIndex )  :  AbstractVertexSignature
SimpleGraphSignature.signatureStringForVertex ( int vertexIndex )  :  String
SimpleGraphSignature.signatureStringForVertex ( int vertexIndex, int height )  :  String
SimpleGraphSignature.SimpleGraphSignature ( SimpleGraph graph )
SimpleGraphSignature.toCanonicalString ( )  :  String

cdk-1.5.2.jar, SimpleGraphTest.class
package signature.simple
SimpleGraphTest.signatureFromString ( String string )  :  SimpleGraphSignature
SimpleGraphTest.signatureHeightTest ( )  :  void
SimpleGraphTest.SimpleGraphTest ( )
SimpleGraphTest.testChain ( )  :  void
SimpleGraphTest.testColoredTreeRoundtrip ( )  :  void
SimpleGraphTest.testVertexCount ( )  :  void

cdk-1.5.2.jar, SimpleQuotientGraph.class
package signature.simple
SimpleQuotientGraph.isConnected ( int i, int j )  :  boolean
SimpleQuotientGraph.SimpleQuotientGraph ( SimpleGraph graph )
SimpleQuotientGraph.SimpleQuotientGraph ( SimpleGraph graph, int height )

cdk-1.5.2.jar, SimpleQuotientGraphTest.class
package signature.simple
SimpleQuotientGraphTest.adamantaneTest ( )  :  void
SimpleQuotientGraphTest.bowtieaneQuotientGraphTest ( )  :  void
SimpleQuotientGraphTest.check3Regularity ( SimpleGraph graph )  :  void
SimpleQuotientGraphTest.check4Regularity ( SimpleGraph graph )  :  void
SimpleQuotientGraphTest.checkParameters ( SimpleQuotientGraph qGraph, int expectedVertexCount, int expectedEdgeCount, int expectedLoopEdgeCount )  :  void
SimpleQuotientGraphTest.cubeTest ( )  :  void
SimpleQuotientGraphTest.cuneaneTest ( )  :  void
SimpleQuotientGraphTest.diSpiroOctaneQuotientGraphTest ( )  :  void
SimpleQuotientGraphTest.doubleBridgedPentagonTest ( )  :  void
SimpleQuotientGraphTest.draw ( SimpleQuotientGraph quotientGraph )  :  void
SimpleQuotientGraphTest.fourRegularExampleTest ( )  :  void
SimpleQuotientGraphTest.fullerene26Test ( )  :  void
SimpleQuotientGraphTest.hexagonalSandwichTest ( )  :  void
SimpleQuotientGraphTest.napthaleneTest ( )  :  void
SimpleQuotientGraphTest.pappusGraphTest ( )  :  void
SimpleQuotientGraphTest.pentagonalPrismTest ( )  :  void
SimpleQuotientGraphTest.pentagonalSandwichTest ( )  :  void
SimpleQuotientGraphTest.petersensGraphTest ( )  :  void
SimpleQuotientGraphTest.SimpleQuotientGraphTest ( )
SimpleQuotientGraphTest.spiroPentagonTest ( )  :  void
SimpleQuotientGraphTest.squareQuotientGraphTest ( )  :  void
SimpleQuotientGraphTest.squareSandwichTest ( )  :  void
SimpleQuotientGraphTest.threeFourFiveTwistedGraphTest ( )  :  void
SimpleQuotientGraphTest.tietzesGraphTest ( )  :  void
SimpleQuotientGraphTest.triangleSandwichTest ( )  :  void
SimpleQuotientGraphTest.triangularPrismTest ( )  :  void
SimpleQuotientGraphTest.tricycloPropaIndeneQuotientGraphTest ( )  :  void
SimpleQuotientGraphTest.truncatedTetrahedronTest ( )  :  void
SimpleQuotientGraphTest.twistaneTest ( )  :  void

cdk-1.5.2.jar, SimpleVertexSignature.class
package signature.simple
SimpleVertexSignature.getConnected ( int vertexIndex )  :  int[ ]
SimpleVertexSignature.getEdgeLabel ( int vertexIndex, int otherVertexIndex )  :  String
SimpleVertexSignature.getIntLabel ( int vertexIndex )  :  int
SimpleVertexSignature.getVertexSymbol ( int vertexIndex )  :  String
SimpleVertexSignature.SimpleVertexSignature ( int rootVertexIndex, int height, SimpleGraph graph )
SimpleVertexSignature.SimpleVertexSignature ( int rootVertexIndex, SimpleGraph graph )

cdk-1.5.2.jar, StereoEncoderFactory.class
package org.openscience.cdk.hash.stereo.factory
StereoEncoderFactory.create ( IAtomContainer p1, int[ ][ ] p2 ) [abstract]  :  StereoEncoder

cdk-1.5.2.jar, TestColoredTreePanel.class
package signature.display
TestColoredTreePanel.dummyTest ( )  :  void
TestColoredTreePanel.main ( String[ ] args ) [static]  :  void
TestColoredTreePanel.makeColoredTree ( String signatureString ) [static]  :  ColoredTree
TestColoredTreePanel.TestColoredTreePanel ( )

cdk-1.5.2.jar, TestMultipleTrees.class
package signature.display
TestMultipleTrees.dummyTest ( )  :  void
TestMultipleTrees.main ( String[ ] args ) [static]  :  void
TestMultipleTrees.makePanel ( JFrame f, String signature, int w, int h ) [static]  :  void
TestMultipleTrees.TestMultipleTrees ( )

cdk-1.5.2.jar, Tetrahedral2DParity.class
package org.openscience.cdk.hash.stereo.parity
Tetrahedral2DParity.parity ( )  :  int
Tetrahedral2DParity.Tetrahedral2DParity ( Point2d[ ] coordinates, int[ ] elevations )

cdk-1.5.2.jar, Tetrahedral3DParity.class
package org.openscience.cdk.hash.stereo.parity
Tetrahedral3DParity.parity ( )  :  int
Tetrahedral3DParity.Tetrahedral3DParity ( Point3d[ ] coordinates )

cdk-1.5.2.jar, TreeDrawer.class
package signature.display
TreeDrawer.makeImage ( ColoredTree coloredTree, File file, int w, int h ) [static]  :  void
TreeDrawer.makeTreeImages ( List signatureStrings, String directoryPath, int w, int h ) [static]  :  void
TreeDrawer.TreeDrawer ( )

cdk-1.5.2.jar, TreeLayout.class
package signature.display
DisplayableColoredTree.TreeLayout.DisplayableColoredTree.TreeLayout ( DisplayableColoredTree p1 )
DisplayableColoredTree.TreeLayout.layout ( DisplayableColoredTree.DrawNode node )  :  int
DisplayableColoredTree.TreeLayout.layoutTree ( DisplayableColoredTree.DrawNode root, int width, int height )  :  void

cdk-1.5.2.jar, WriterTest.class
package signature.chemistry
WriterTest.minimalTest ( )  :  void
WriterTest.WriterTest ( )

cdk-1.5.2.jar, Xorshift.class
package org.openscience.cdk.hash
Xorshift.Xorshift ( )

to the top

Problems with Data Types, High Severity (76)


cdk-1.5.2.jar
package org.openscience.cdk.hash
[+] BasicMoleculeHashGenerator (1)
[+] HashGeneratorMaker (1)
[+] Pseudorandom (1)
[+] Xorshift (1)

package org.openscience.cdk.hash.equivalent
[+] AllEquivalentCyclicSet (1)
[+] EquivalentSetFinder (1)
[+] MinimumEquivalentCyclicSet (1)
[+] MinimumEquivalentCyclicSetUnion (1)

package org.openscience.cdk.hash.seed
[+] AtomEncoder (1)
[+] BasicAtomEncoder (1)
[+] ConjugatedAtomEncoder (1)

package org.openscience.cdk.hash.stereo.factory
[+] GeometricDoubleBondEncoderFactory (1)
[+] GeometricTetrahedralEncoderFactory (1)
[+] StereoEncoderFactory (1)

package org.openscience.cdk.hash.stereo.parity
[+] BasicPermutationParity (1)
[+] CombinedPermutationParity (1)
[+] DoubleBond2DParity (1)
[+] DoubleBond3DParity (1)
[+] GeometricParity (1)
[+] PermutationParity (1)
[+] Tetrahedral2DParity (1)
[+] Tetrahedral3DParity (1)

package org.openscience.cdk.layout
[+] HydrogenPlacer (3)

package org.openscience.cdk.qsar
[+] DescriptorEngine (4)
[+] IDescriptor (1)

package org.openscience.cdk.ringsearch
[+] AllRingsFinder (2)
[+] Path (1)

package signature
[+] AbstractVertexSignature (1)
[+] HeightTest (1)
[+] ParsingTest (1)
[+] PermutationTest (1)

package signature.chemistry
[+] AtomPermutor (1)
[+] AtomSignature (1)
[+] ChiralCenterFinder (1)
[+] ChiralityTest (1)
[+] LargeMoleculeTest (1)
[+] Molecule (1)
[+] Molecule.Atom (1)
[+] Molecule.Bond (1)
[+] MoleculeBuilder (1)
[+] MoleculeFactory (1)
[+] MoleculeQuotientGraph (1)
[+] MoleculeReader (1)
[+] MoleculeSignature (1)
[+] MoleculeSignatureTest (1)
[+] MoleculeWriter (1)
[+] MultipleBondTest (1)
[+] NumberLabelsTest (1)
[+] SDFToSignatures (1)
[+] WriterTest (1)

package signature.display
[+] ColoredTreePanel (1)
[+] DisplayableColoredTree (1)
[+] DisplayableColoredTree.DrawNode (1)
[+] DisplayableColoredTree.TreeLayout (1)
[+] SignatureViewer (1)
[+] TestColoredTreePanel (1)
[+] TestMultipleTrees (1)
[+] TreeDrawer (1)

package signature.simple
[+] CanonicalLabellingTest (1)
[+] ReconstructionTest (1)
[+] SimpleGraph (1)
[+] SimpleGraph.Edge (1)
[+] SimpleGraphBuilder (1)
[+] SimpleGraphFactory (1)
[+] SimpleGraphPermutor (1)
[+] SimpleGraphSignature (1)
[+] SimpleGraphTest (1)
[+] SimpleQuotientGraph (1)
[+] SimpleQuotientGraphTest (1)
[+] SimpleVertexSignature (1)

to the top

Problems with Methods, High Severity (2)


cdk-1.5.2.jar, Pseudorandom
package org.openscience.cdk.hash
[+] Pseudorandom.next ( long p1 ) [abstract]  :  long (1)

cdk-1.5.2.jar, Xorshift
package org.openscience.cdk.hash
[+] Xorshift.next ( long seed )  :  long (1)

to the top

Problems with Data Types, Low Severity (80)


cdk-1.5.2.jar
package org.openscience.cdk.hash
[+] Xorshift (1)

package org.openscience.cdk.qsar
[+] AbstractAtomicDescriptor (1)
[+] AbstractBondDescriptor (1)

package org.openscience.cdk.qsar.descriptors.atomic
[+] AtomDegreeDescriptor (1)
[+] AtomHybridizationDescriptor (1)
[+] AtomHybridizationVSEPRDescriptor (1)
[+] AtomValenceDescriptor (1)
[+] BondsToAtomDescriptor (1)
[+] CovalentRadiusDescriptor (1)
[+] DistanceToAtomDescriptor (1)
[+] EffectiveAtomPolarizabilityDescriptor (1)
[+] InductiveAtomicHardnessDescriptor (1)
[+] InductiveAtomicSoftnessDescriptor (1)
[+] IsProtonInAromaticSystemDescriptor (1)
[+] IsProtonInConjugatedPiSystemDescriptor (1)
[+] PeriodicTablePositionDescriptor (1)
[+] PiElectronegativityDescriptor (1)
[+] ProtonTotalPartialChargeDescriptor (1)
[+] RDFProtonDescriptor_G3R (1)
[+] RDFProtonDescriptor_GDR (1)
[+] RDFProtonDescriptor_GHR (1)
[+] RDFProtonDescriptor_GHR_topol (1)
[+] RDFProtonDescriptor_GSR (1)
[+] SigmaElectronegativityDescriptor (1)
[+] StabilizationPlusChargeDescriptor (1)
[+] VdWRadiusDescriptor (1)

package org.openscience.cdk.qsar.descriptors.atompair
[+] PiContactDetectionDescriptor (1)

package org.openscience.cdk.qsar.descriptors.bond
[+] AtomicNumberDifferenceDescriptor (1)
[+] BondSigmaElectronegativityDescriptor (1)

package org.openscience.cdk.qsar.descriptors.molecular
[+] AcidicGroupCountDescriptor (1)
[+] ALOGPDescriptor (1)
[+] AminoAcidCountDescriptor (1)
[+] APolDescriptor (1)
[+] AromaticAtomsCountDescriptor (1)
[+] AromaticBondsCountDescriptor (1)
[+] AtomCountDescriptor (1)
[+] AutocorrelationDescriptorCharge (1)
[+] AutocorrelationDescriptorMass (1)
[+] AutocorrelationDescriptorPolarizability (1)
[+] BasicGroupCountDescriptor (1)
[+] BCUTDescriptor (1)
[+] BondCountDescriptor (1)
[+] BPolDescriptor (1)
[+] CarbonTypesDescriptor (1)
[+] ChiChainDescriptor (1)
[+] ChiClusterDescriptor (1)
[+] ChiPathClusterDescriptor (1)
[+] ChiPathDescriptor (1)
[+] CPSADescriptor (1)
[+] EccentricConnectivityIndexDescriptor (1)
[+] FMFDescriptor (1)
[+] FragmentComplexityDescriptor (1)
[+] GravitationalIndexDescriptor (1)
[+] HBondAcceptorCountDescriptor (1)
[+] HBondDonorCountDescriptor (1)
[+] HybridizationRatioDescriptor (1)
[+] IPMolecularLearningDescriptor (1)
[+] KappaShapeIndicesDescriptor (1)
[+] KierHallSmartsDescriptor (1)
[+] LargestChainDescriptor (1)
[+] LargestPiSystemDescriptor (1)
[+] LengthOverBreadthDescriptor (1)
[+] LongestAliphaticChainDescriptor (1)
[+] MannholdLogPDescriptor (1)
[+] MDEDescriptor (1)
[+] MomentOfInertiaDescriptor (1)
[+] PetitjeanNumberDescriptor (1)
[+] PetitjeanShapeIndexDescriptor (1)
[+] RotatableBondsCountDescriptor (1)
[+] RuleOfFiveDescriptor (1)
[+] TPSADescriptor (1)
[+] VABCDescriptor (1)
[+] VAdjMaDescriptor (1)
[+] WeightDescriptor (1)
[+] WeightedPathDescriptor (1)
[+] WHIMDescriptor (1)
[+] WienerNumbersDescriptor (1)
[+] XLogPDescriptor (1)
[+] ZagrebIndexDescriptor (1)

package org.openscience.cdk.qsar.descriptors.protein
[+] TaeAminoAcidDescriptor (1)

to the top

Other Changes in Data Types (2)


cdk-1.5.2.jar
package org.openscience.cdk.config
[+] Elements (2)

to the top

Java ARchives (1)


cdk-1.5.2.jar

to the top