Skip navigation links
Oracle® Fusion Middleware Java API Reference for Oracle Coherence
14c (14.1.1.0.0)

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

A

abort(Object) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
Abort an atomic sequence of mutating operations.
abort(Throwable) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore.BatchTask
Abort all changes that have been made to the persistent store by this BatchTask.
abort(Object) - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistentStore
Abort an atomic sequence of mutating operations.
abort(Object) - Method in class com.tangosol.util.NullImplementation.NullPersistentStore
 
abortInternal(Object) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
Abort an atomic sequence of mutating operations.
ABOVE - Static variable in class com.tangosol.util.AbstractSparseArray.Crawler
 
AbstractAggregator<K,V,T,E,R> - Class in com.tangosol.util.aggregator
Abstract base class implementation of InvocableMap.EntryAggregator that supports streaming aggregation.
AbstractAggregator() - Constructor for class com.tangosol.util.aggregator.AbstractAggregator
Deserialization constructor.
AbstractAggregator(ValueExtractor<? super T, ? extends E>) - Constructor for class com.tangosol.util.aggregator.AbstractAggregator
Construct an AbstractAggregator that will aggregate values extracted from a set of InvocableMap.Entry objects.
AbstractAggregator(String) - Constructor for class com.tangosol.util.aggregator.AbstractAggregator
Construct an AbstractAggregator that will aggregate values extracted from a set of InvocableMap.Entry objects.
AbstractAsynchronousAggregator<K,V,P,R> - Class in com.tangosol.util.aggregator
Abstract base class for asynchronous entry aggregators.
AbstractAsynchronousAggregator(InvocableMap.StreamingAggregator<K, V, P, R>, int) - Constructor for class com.tangosol.util.aggregator.AbstractAsynchronousAggregator
Construct an AsynchronousAggregator for a given streaming aggregator.
AbstractAsynchronousProcessor<K,V,R,T> - Class in com.tangosol.util.processor
Abstract base class for asynchronous entry processors.
AbstractAsynchronousProcessor(InvocableMap.EntryProcessor<K, V, R>, int) - Constructor for class com.tangosol.util.processor.AbstractAsynchronousProcessor
Construct AbstractAsynchronousProcessor instance.
AbstractBackingMapManager - Class in com.tangosol.net
Abstract base of the BackingMapManager implementations.
AbstractBackingMapManager() - Constructor for class com.tangosol.net.AbstractBackingMapManager
Default constructor.
AbstractBigDecimalAggregator<T> - Class in com.tangosol.util.aggregator
Abstract aggregator that processes Number values extracted from a set of entries in a Map and returns a result in a form of a BigDecimal value.
AbstractBigDecimalAggregator() - Constructor for class com.tangosol.util.aggregator.AbstractBigDecimalAggregator
Default constructor (necessary for the ExternalizableLite interface).
AbstractBigDecimalAggregator(ValueExtractor<? super T, ? extends Number>) - Constructor for class com.tangosol.util.aggregator.AbstractBigDecimalAggregator
Construct an AbstractBigDecimalAggregator object.
AbstractBigDecimalAggregator(String) - Constructor for class com.tangosol.util.aggregator.AbstractBigDecimalAggregator
Construct an AbstractBigDecimalAggregator object.
AbstractBinaryEntryBundler - Class in com.tangosol.net.cache
An abstract BinaryEntry-based bundler that serves as a base for BinaryEntryStore operation bundling.
AbstractBinaryEntryBundler() - Constructor for class com.tangosol.net.cache.AbstractBinaryEntryBundler
 
AbstractBinaryEntryBundler.Bundle - Class in com.tangosol.net.cache
 
AbstractBinaryStore - Class in com.tangosol.io
Abstract implementation of the BinaryStore interface.
AbstractBinaryStore() - Constructor for class com.tangosol.io.AbstractBinaryStore
 
AbstractBufferInput() - Constructor for class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
Default constructor.
AbstractBufferManager - Class in com.tangosol.io.nio
Provides a basic implementation of ByteBufferManager.
AbstractBufferManager(int, int) - Constructor for class com.tangosol.io.nio.AbstractBufferManager
Construct a AbstractBufferManager that supports a buffer of a certain initial and maximum size.
AbstractBufferOutput() - Constructor for class com.tangosol.io.AbstractWriteBuffer.AbstractBufferOutput
Construct an AbstractBufferOutput that will begin writing at the start of the containing WriteBuffer.
AbstractBufferOutput(int) - Constructor for class com.tangosol.io.AbstractWriteBuffer.AbstractBufferOutput
Construct an AbstractBufferOutput that will begin writing at the specified offset within the containing WriteBuffer.
AbstractBundler - Class in com.tangosol.net.cache
An abstract base for processors that implement bundling strategy.
AbstractBundler() - Constructor for class com.tangosol.net.cache.AbstractBundler
Construct the bundler.
AbstractBundler.Bundle - Class in com.tangosol.net.cache
Bundle represents a unit of optimized execution.
AbstractBundler.Statistics - Class in com.tangosol.net.cache
Statistics class contains the latest bundler statistics.
AbstractByteArrayReadBuffer - Class in com.tangosol.io
The AbstractByteArrayReadBuffer abstract class is intended to serve as a base class for the following: the pre-existing Binary class a new byte[] based class that does not attempt to add the immutability aspect provided by the Binary class a new ByteBuffer based class that will work with Java NIO This implementation is not intended to be thread safe.
AbstractByteArrayReadBuffer() - Constructor for class com.tangosol.io.AbstractByteArrayReadBuffer
Default constructor; intended for deserialization use by subclasses.
AbstractByteArrayReadBuffer(byte[], int, int) - Constructor for class com.tangosol.io.AbstractByteArrayReadBuffer
Construct an AbstractByteArrayReadBuffer on a portion of a byte array.
AbstractByteArrayReadBuffer.ByteArrayBufferInput - Class in com.tangosol.io
This is a simple implementation of the BufferInput interface on top of a byte array.
AbstractByteSequence - Class in com.tangosol.util
A simple base class for ByteSequence implementations.
AbstractByteSequence() - Constructor for class com.tangosol.util.AbstractByteSequence
 
AbstractByteSequence.AggregateByteSequence - Class in com.tangosol.util
A naive ByteSequence that glues two ByteSequence instances together.
AbstractByteSequence.PartialByteSequence - Class in com.tangosol.util
A naive ByteSequence that represents a portion of another ByteSequence.
AbstractCacheLoader<K,V> - Class in com.tangosol.net.cache
An abstract base class for the JCache CacheLoader.
AbstractCacheLoader() - Constructor for class com.tangosol.net.cache.AbstractCacheLoader
 
AbstractCacheStore<K,V> - Class in com.tangosol.net.cache
An abstract base class for the JCache CacheLoader.
AbstractCacheStore() - Constructor for class com.tangosol.net.cache.AbstractCacheStore
 
AbstractCachingScheme<D extends ServiceDependencies> - Class in com.tangosol.coherence.config.scheme
An AbstractCachingScheme is a base implementation for an CachingScheme.
AbstractCachingScheme() - Constructor for class com.tangosol.coherence.config.scheme.AbstractCachingScheme
 
AbstractCodec() - Constructor for class com.tangosol.io.pof.reflect.Codecs.AbstractCodec
 
AbstractCoherenceBasedCache<K,V,C extends CoherenceBasedConfiguration<K,V>> - Class in com.tangosol.coherence.jcache
The base implementation of a CoherenceBasedCache.
AbstractCoherenceBasedCache(CoherenceBasedCacheManager, String, C) - Constructor for class com.tangosol.coherence.jcache.AbstractCoherenceBasedCache
AbstractCoherenceBasedCompleteConfiguration<K,V> - Class in com.tangosol.coherence.jcache
A base implementation of a CoherenceBasedCompleteConfiguration.
AbstractCoherenceBasedCompleteConfiguration() - Constructor for class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
AbstractCoherenceBasedCompleteConfiguration(CompleteConfiguration<K, V>) - Constructor for class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
Constructs an AbstractCoherenceBasedCompleteConfiguration based on another CompleteConfiguration.
AbstractCoherenceQueryWalker - Class in com.tangosol.coherence.dslquery.internal
AbstractCoherenceTermWalker is a visitor class that provides a framework for walking Term Trees by providing classification methods based on the Abstract Syntax Tree vocabulary for the Coherence Query expression Language.
AbstractCoherenceQueryWalker(List, ParameterResolver, CoherenceQueryLanguage) - Constructor for class com.tangosol.coherence.dslquery.internal.AbstractCoherenceQueryWalker
Creates a AbstractCoherenceQueryWalker with the specified bind variables.
AbstractComparableAggregator<T,R> - Class in com.tangosol.util.aggregator
Abstract aggregator that processes values extracted from a set of entries in a Map, with knowledge of how to compare those values.
AbstractComparableAggregator() - Constructor for class com.tangosol.util.aggregator.AbstractComparableAggregator
Default constructor (necessary for the ExternalizableLite interface).
AbstractComparableAggregator(ValueExtractor<? super T, ? extends E>) - Constructor for class com.tangosol.util.aggregator.AbstractComparableAggregator
Construct an AbstractComparableAggregator object.
AbstractComparableAggregator(ValueExtractor<? super T, ? extends R>, Comparator<? super R>) - Constructor for class com.tangosol.util.aggregator.AbstractComparableAggregator
Construct an AbstractComparableAggregator object.
AbstractComparableAggregator(String) - Constructor for class com.tangosol.util.aggregator.AbstractComparableAggregator
Construct an AbstractComparableAggregator object.
AbstractCompositeExtractor<T,E> - Class in com.tangosol.util.extractor
Abstract super class for ValueExtractor implementations that are based on an underlying array of ValueExtractor objects.
AbstractCompositeExtractor() - Constructor for class com.tangosol.util.extractor.AbstractCompositeExtractor
Default constructor
AbstractCompositeExtractor(ValueExtractor[]) - Constructor for class com.tangosol.util.extractor.AbstractCompositeExtractor
Construct a AbstractCompositeExtractor based on the specified ValueExtractor array.
AbstractCompositeScheme<T> - Class in com.tangosol.coherence.config.scheme
The AbstractCompositeScheme manages a scheme that is used to build a composite cache consisting of a front map and a back cache/map.
AbstractCompositeScheme() - Constructor for class com.tangosol.coherence.config.scheme.AbstractCompositeScheme
 
AbstractConverterEntry(Map.Entry<FK, FV>) - Constructor for class com.tangosol.util.ConverterCollections.AbstractConverterEntry
Constructor.
AbstractDelegateBinaryLongMap(BinaryLongMap, MultiBinaryLongMap.LongStorage, int) - Constructor for class com.tangosol.util.MultiBinaryLongMap.AbstractDelegateBinaryLongMap
Construct an AbstractDelegateBinaryLongMap based on the specified key tree, long storage, and storage index.
AbstractDoubleAggregator<T> - Class in com.tangosol.util.aggregator
Abstract aggregator that processes numeric values extracted from a set of entries in a Map.
AbstractDoubleAggregator() - Constructor for class com.tangosol.util.aggregator.AbstractDoubleAggregator
Default constructor (necessary for the ExternalizableLite interface).
AbstractDoubleAggregator(ValueExtractor<? super T, ? extends Number>) - Constructor for class com.tangosol.util.aggregator.AbstractDoubleAggregator
Construct an AbstractDoubleAggregator object.
AbstractDoubleAggregator(String) - Constructor for class com.tangosol.util.aggregator.AbstractDoubleAggregator
Construct an AbstractDoubleAggregator object.
AbstractEmptyElementProcessor<T> - Class in com.tangosol.coherence.config.xml.processor
A ConditionalElementProcessor that provides defined behaviors for processing empty XmlElements.
AbstractEmptyElementProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.AbstractEmptyElementProcessor
Constructs an AbstractEmptyElementProcessor that will attempt to process empty XmlElements.
AbstractEmptyElementProcessor(AbstractEmptyElementProcessor.EmptyElementBehavior) - Constructor for class com.tangosol.coherence.config.xml.processor.AbstractEmptyElementProcessor
Constructs an AbstractEmptyElementProcessor with the specified behavior for processing empty XmlElements (with a default value of null).
AbstractEmptyElementProcessor(T) - Constructor for class com.tangosol.coherence.config.xml.processor.AbstractEmptyElementProcessor
Constructs an AbstractEmptyElementProcessor that will return the specified default value when it encounters an empty XmlElement.
AbstractEmptyElementProcessor.EmptyElementBehavior - Enum in com.tangosol.coherence.config.xml.processor
The behavior of the ConditionalElementProcessor when it encounters an empty XmlElement.
AbstractEntryBundler - Class in com.tangosol.net.cache
An abstract entry-based bundler serves as a base for NamedCache.put() and CacheStore.store() operation bundling.
AbstractEntryBundler() - Constructor for class com.tangosol.net.cache.AbstractEntryBundler
 
AbstractEntryBundler.Bundle - Class in com.tangosol.net.cache
 
AbstractEvictionPolicy - Class in com.tangosol.net.cache
An abstract base class for custom cache eviction policies.
AbstractEvictionPolicy() - Constructor for class com.tangosol.net.cache.AbstractEvictionPolicy
 
AbstractEvolvable - Class in com.tangosol.io
An abstract base class for implementing Evolvable objects.
AbstractEvolvable() - Constructor for class com.tangosol.io.AbstractEvolvable
 
AbstractEvolvableProcessor<K,V,R> - Class in com.tangosol.util.processor
An Evolvable AbstractProcessor that is a partial EntryProcessor implementation that provides the default implementation of the AbstractEvolvableProcessor.processAll(java.util.Set<? extends com.tangosol.util.InvocableMap.Entry<K, V>>) method.
AbstractEvolvableProcessor() - Constructor for class com.tangosol.util.processor.AbstractEvolvableProcessor
 
AbstractExtractor<T,E> - Class in com.tangosol.util.extractor
Abstract base for ValueExtractor implementations.
AbstractExtractor() - Constructor for class com.tangosol.util.extractor.AbstractExtractor
 
AbstractFederatedInterceptor<K,V> - Class in com.tangosol.coherence.federation.events
An abstract implementation of an EventInterceptor for FederatedChangeEvents applicable to remote participants.
AbstractFederatedInterceptor() - Constructor for class com.tangosol.coherence.federation.events.AbstractFederatedInterceptor
 
AbstractHttpSessionCollection - Class in com.tangosol.coherence.servlet
An abstract base class from which implementations of HttpSessionCollection can be more easily built.
AbstractHttpSessionCollection() - Constructor for class com.tangosol.coherence.servlet.AbstractHttpSessionCollection
Default constructor (required).
AbstractHttpSessionCollection.ApplicationScopeController - Class in com.tangosol.coherence.servlet
A simple implementation of the AttributeScopeController interface that scopes all attributes to the application by prepending the name of the application to all attribute names.
AbstractHttpSessionCollection.DistributedController - Class in com.tangosol.coherence.servlet
A simple implementation of the SessionDistributionController interface that forces all sessions (and thus their attributes) to be managed in a distributed manner.
AbstractHttpSessionCollection.GlobalScopeController - Class in com.tangosol.coherence.servlet
A simple implementation of the AttributeScopeController interface that does not scope attributes.
AbstractHttpSessionCollection.HybridController - Class in com.tangosol.coherence.servlet
A simple implementation of the SessionDistributionController interface that forces all sessions and serializable attributes to be managed in a distributed manner.
AbstractHttpSessionCollection.LocalController - Class in com.tangosol.coherence.servlet
A simple implementation of the SessionDistributionController interface that forces all sessions (and thus their attributes) to be managed locally.
AbstractHttpSessionModel - Class in com.tangosol.coherence.servlet
An abstract base class from which implementations of HttpSessionModel can be more easily built.
AbstractHttpSessionModel() - Constructor for class com.tangosol.coherence.servlet.AbstractHttpSessionModel
Default constructor for deserialization.
AbstractHttpSessionModel(AbstractHttpSessionCollection, HttpSession, String) - Constructor for class com.tangosol.coherence.servlet.AbstractHttpSessionModel
Session creation constructor.
AbstractInvocable - Class in com.tangosol.net
An abstract base for Invocable and PriorityTask implementations.
AbstractInvocable() - Constructor for class com.tangosol.net.AbstractInvocable
 
AbstractJCacheStatistics - Class in com.tangosol.coherence.jcache.common
Shared implementation between implementations of JCacheStatistics.
AbstractJCacheStatistics() - Constructor for class com.tangosol.coherence.jcache.common.AbstractJCacheStatistics
 
AbstractJournalRM - Class in com.tangosol.io.journal
The AbstractJournalRM represents a Journal Resource Manager that manages storage for journaled data, and acts as a shared resource for any number of journals that share a common configuration.
AbstractJournalRM(Cluster, AbstractJournalRM.Dependencies) - Constructor for class com.tangosol.io.journal.AbstractJournalRM
Construct an AbstractJournalRM.
AbstractJournalRM.CollectorDaemon - Class in com.tangosol.io.journal
The CollectorDaemon evaluates the JournalFile objects to see which ones should be evacuated, it evacuates those that should be, and it deletes those that have been successfully evacuated.
AbstractJournalRM.CollectorDaemon.CollectionCoordinator - Class in com.tangosol.io.journal
A CollectionCoordinator is responsible for shaping an evacuation as well as managing any reserved files created to ensure the journal continues to operate.
AbstractJournalRM.CollectorDaemon.InvokeGCJournalFile - Class in com.tangosol.io.journal
A AbstractJournalRM.JournalFile implementation returned when the journal has consumed all known capacity.
AbstractJournalRM.DefaultDependencies - Class in com.tangosol.io.journal
The DefaultDependencies class provides a default implementation of Dependencies.
AbstractJournalRM.Dependencies - Interface in com.tangosol.io.journal
The Dependencies interface provides AbstractJournalRM with its external dependencies.
AbstractJournalRM.JournalFile - Class in com.tangosol.io.journal
A JournalFile object is created for each file used to store the journal contents.
AbstractJournalRM.JournalImpl - Class in com.tangosol.io.journal
A Journal implementation managed by this Journal Resource Manager.
AbstractJournalScheme<T extends CompactSerializationCache> - Class in com.tangosol.coherence.config.scheme
The AbstractJournalScheme contains functionality common to all Journal schemes.
AbstractJournalScheme() - Constructor for class com.tangosol.coherence.config.scheme.AbstractJournalScheme
 
AbstractKeyBasedMap<K,V> - Class in com.tangosol.util
AbstractKeyBasedMap is a base class for Map implementations.
AbstractKeyBasedMap() - Constructor for class com.tangosol.util.AbstractKeyBasedMap
 
AbstractKeyBasedMap.DeferredCacheEvent<K,V> - Class in com.tangosol.util
A DeferredCacheEvent is a CacheEvent object that defers the loading of the old value.
AbstractKeyBasedMap.EntrySet - Class in com.tangosol.util
A set of entries backed by this map.
AbstractKeyBasedMap.EntrySet.Entry - Class in com.tangosol.util
A Map Entry implementation that defers its value acquisition from the containing map (via Map.get(Object)) if the Entry is constructed with a null value.
AbstractKeyBasedMap.EntrySet.EntrySetIterator - Class in com.tangosol.util
An Iterator over the EntrySet that is backed by the Map.
AbstractKeyBasedMap.KeySet - Class in com.tangosol.util
A set of keys backed by this map.
AbstractKeyBasedMap.ValuesCollection - Class in com.tangosol.util
A Collection of values backed by this map.
AbstractKeyBasedMap.ValuesCollection.ValuesIterator - Class in com.tangosol.util
An Iterator over the values Collection that is backed by the AbstractKeyBasedMap.
AbstractKeyBundler - Class in com.tangosol.net.cache
An abstract key-based bundler serves as a base for NamedCache get() and remove() operation bundling as well as the CacheStore load() and erase() operation bundling.
AbstractKeyBundler() - Constructor for class com.tangosol.net.cache.AbstractKeyBundler
 
AbstractKeyBundler.Bundle - Class in com.tangosol.net.cache
Bundle represents a unit of optimized execution.
AbstractKeySetBasedMap<K,V> - Class in com.tangosol.util
AbstractKeySetBasedMap is an extension to the AbstractKeyBasedMap that has a full awareness of the set of keys upon which the Map is based.
AbstractKeySetBasedMap() - Constructor for class com.tangosol.util.AbstractKeySetBasedMap
 
AbstractKeySetBasedMap.EntrySet - Class in com.tangosol.util
A set of entries backed by this map.
AbstractKeySetBasedMap.KeyIterator - Class in com.tangosol.util
An iterator over the keys from the internal key Set that implements element removal via the Map's removeBlind method.
AbstractKeySetBasedMap.KeySet - Class in com.tangosol.util
A set of keys backed by this map.
AbstractKeySetBasedMap.ValuesCollection - Class in com.tangosol.util
A Collection of values backed by this map.
AbstractLocalCachingScheme<T> - Class in com.tangosol.coherence.config.scheme
The AbstractLocalCachingScheme is provides common functionality for local caching schemes, including local-scheme, external-scheme, etc.
AbstractLocalCachingScheme() - Constructor for class com.tangosol.coherence.config.scheme.AbstractLocalCachingScheme
 
AbstractLongAggregator<T> - Class in com.tangosol.util.aggregator
Abstract aggregator that processes numeric values extracted from a set of entries in a Map.
AbstractLongAggregator() - Constructor for class com.tangosol.util.aggregator.AbstractLongAggregator
Default constructor (necessary for the ExternalizableLite interface).
AbstractLongAggregator(ValueExtractor<? super T, ? extends Number>) - Constructor for class com.tangosol.util.aggregator.AbstractLongAggregator
Construct an AbstractLongAggregator object.
AbstractLongAggregator(String) - Constructor for class com.tangosol.util.aggregator.AbstractLongAggregator
Construct an AbstractLongAggregator object.
AbstractLongArray<V> - Class in com.tangosol.util
An implementation of portions of the LongArray interface.
AbstractLongArray() - Constructor for class com.tangosol.util.AbstractLongArray
 
AbstractMapListener - Class in com.tangosol.util
A base class that simplifies the implementation of a MapListener, particularly inner classes that only implement one or two of the three event methods.
AbstractMapListener() - Constructor for class com.tangosol.util.AbstractMapListener
 
AbstractMarshaller<T> - Class in com.tangosol.coherence.rest.io
Abstract base class for built-in marshallers.
AbstractMarshaller(Class<T>) - Constructor for class com.tangosol.coherence.rest.io.AbstractMarshaller
Construct a marshaller instance.
AbstractNamespaceHandler - Class in com.tangosol.config.xml
An AbstractNamespaceHandler provides a base implementation of a NamespaceHandler with support for implicit and explicit registration of ElementProcessors and AttributeProcessors for those xml attributes and elements occurring in the associated xml namespace.
AbstractNamespaceHandler() - Constructor for class com.tangosol.config.xml.AbstractNamespaceHandler
AbstractNioManagerBuilder<T> - Class in com.tangosol.coherence.config.builder.storemanager
The AbstractNioManagerBuilder class is an abstract class used to build an NIO file manager or an NIO memory manager.
AbstractNioManagerBuilder() - Constructor for class com.tangosol.coherence.config.builder.storemanager.AbstractNioManagerBuilder
 
AbstractOPToken(String, String, String) - Constructor for class com.tangosol.coherence.dslquery.queryplus.AbstractQueryPlusStatementBuilder.AbstractOPToken
Construct an AbstractOpToken.
AbstractPartitionedIterator<T> - Class in com.tangosol.net.partition
Abstract base class for partitioned iterators.
AbstractPartitionedIterator(Filter, NamedCache, PartitionSet) - Constructor for class com.tangosol.net.partition.AbstractPartitionedIterator
Create AbstractPartitionedIterator instance.
AbstractPartitionedIterator(Filter, NamedCache, PartitionSet, boolean, boolean) - Constructor for class com.tangosol.net.partition.AbstractPartitionedIterator
Create AbstractPartitionedIterator instance.
AbstractPersistenceEnvironment - Class in com.tangosol.persistence
Abstract implementation of a ReadBuffer-based PersistentEnvironment.
AbstractPersistenceEnvironment(File, File, File) - Constructor for class com.tangosol.persistence.AbstractPersistenceEnvironment
Create a new AbstractPersistenceEnvironment that manages a singleton AbstractPersistenceManager with the specified data directory and that creates, opens, and deletes snapshots under the specified snapshot directory.
AbstractPersistenceEnvironment.DefaultFailureContinuation - Class in com.tangosol.persistence
Continuation implementation that accepts a Throwable and throws a PersistenceException.
AbstractPersistenceManager<PS extends AbstractPersistenceManager.AbstractPersistentStore> - Class in com.tangosol.persistence
Abstract implementation of a ReadBuffer-based PersistentManager.
AbstractPersistenceManager(File, File, String) - Constructor for class com.tangosol.persistence.AbstractPersistenceManager
Create a new AbstractPersistenceManager.
AbstractPersistenceManager.AbstractPersistenceSnapshotTools - Class in com.tangosol.persistence
Abstract implementation of PersistenceTools which can be extended to support local snapshot operations for specific implementations.
AbstractPersistenceManager.AbstractPersistentStore - Class in com.tangosol.persistence
Abstract implementation of a ReadBuffer-based PersistentStore.
AbstractPersistenceManager.AbstractPersistentStore.BatchTask - Class in com.tangosol.persistence
Runnable implementation that is used to perform and commit a sequence of mutating persistent store operations asynchronously.
AbstractPersistenceManager.AbstractPersistentStore.BatchTask.EraseOperation - Class in com.tangosol.persistence
An erase() Operation.
AbstractPersistenceManager.AbstractPersistentStore.BatchTask.Operation - Class in com.tangosol.persistence
Base class for Runnable implementations that encapsulate a persistent store operation.
AbstractPersistenceManager.AbstractPersistentStore.BatchTask.StoreOperation - Class in com.tangosol.persistence
A store() Operation.
AbstractPersistenceManager.AbstractPersistentStore.DeleteExtentTask - Class in com.tangosol.persistence
A Task implementation that deletes an extent from the associated store.
AbstractPersistenceManager.AbstractPersistentStore.OpenTask - Class in com.tangosol.persistence
An OpenTask opens the store (parent of this inner class) with the provided store and notifies the Collector when complete.
AbstractPersistenceManager.Task - Class in com.tangosol.persistence
Runnable extension that adds the ability to notify the task that it has been canceled.
AbstractPersistenceSnapshotTools(File, OfflinePersistenceInfo) - Constructor for class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistenceSnapshotTools
Construct an abstract implementation for a given snapshot directory.
AbstractPersistenceTools - Class in com.tangosol.persistence
Abstract implementation of PersistenceTools which can be extended for either local or archived snapshot operations.
AbstractPersistenceTools(OfflinePersistenceInfo) - Constructor for class com.tangosol.persistence.AbstractPersistenceTools
Constructs an abstract implementation of PersistenceTools that can be utilized for both local or archived snapshot operations.
AbstractPersistenceTools.StatsVisitor - Class in com.tangosol.persistence
An implementation of a CachePersistenceHelper.Visitor to collect details statistics from the snapshot we are analysing.
AbstractPersistentStore(String) - Constructor for class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
Create a new AbstractPersistentStore with the given identifier.
AbstractPofHandler - Class in com.tangosol.io.pof
An abstract implementation of PofHandler that delegates to a PofHandler.
AbstractPofHandler(PofHandler) - Constructor for class com.tangosol.io.pof.AbstractPofHandler
Construct a delegating PofHandler.
AbstractPofPath - Class in com.tangosol.io.pof.reflect
Abstract base class for static, path-based implementations of PofNavigator interface.
AbstractPofPath() - Constructor for class com.tangosol.io.pof.reflect.AbstractPofPath
 
AbstractPofValue - Class in com.tangosol.io.pof.reflect
An abstract base class that implements common functionality for all PofValue types.
AbstractPofValue(PofValue, ReadBuffer, PofContext, int, int) - Constructor for class com.tangosol.io.pof.reflect.AbstractPofValue
Construct a PofValue instance wrapping the supplied buffer.
AbstractPriorityTask - Class in com.tangosol.net
An abstract base for PriorityTask implementations.
AbstractPriorityTask() - Constructor for class com.tangosol.net.AbstractPriorityTask
 
AbstractProcessor<K,V,R> - Class in com.tangosol.util.processor
An AbstractProcessor is a partial EntryProcessor implementation that provides the default implementation of the AbstractProcessor.processAll(java.util.Set<? extends com.tangosol.util.InvocableMap.Entry<K, V>>) method.
AbstractProcessor() - Constructor for class com.tangosol.util.processor.AbstractProcessor
 
AbstractQueryEngine - Class in com.tangosol.coherence.rest.query
Abstract base class for QueryEngine implementations.
AbstractQueryEngine() - Constructor for class com.tangosol.coherence.rest.query.AbstractQueryEngine
 
AbstractQueryEngine.ParsedQuery - Class in com.tangosol.coherence.rest.query
Immutable helper class that wraps both final query string and a map of parameter types, keyed by parameter name.
AbstractQueryPlusStatementBuilder - Class in com.tangosol.coherence.dslquery.queryplus
This is the base class for command builders that are specific to the QueryPlus tool rather than general CohQL statements.
AbstractQueryPlusStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.queryplus.AbstractQueryPlusStatementBuilder
Construct a AbstractQueryPlusStatementBuilder.
AbstractQueryPlusStatementBuilder.AbstractOPToken - Class in com.tangosol.coherence.dslquery.queryplus
An OPToken implementation that holds the name of the functor associated to an OPToken.
AbstractQueryPlusStatementBuilder.AbstractStatement - Class in com.tangosol.coherence.dslquery.queryplus
An abstract base class that allows sub classes to implement the applicable methods on Statement.
AbstractQueryRecorderFilter<T> - Class in com.tangosol.util.filter
Abstract base class implementation of QueryRecorderFilter.
AbstractQueryRecorderFilter() - Constructor for class com.tangosol.util.filter.AbstractQueryRecorderFilter
 
AbstractReadBuffer - Class in com.tangosol.io
Abstract base implementation of the ReadBuffer interface.
AbstractReadBuffer() - Constructor for class com.tangosol.io.AbstractReadBuffer
 
AbstractReadBuffer.AbstractBufferInput - Class in com.tangosol.io
This is an implementation of the BufferInput interface that delegates its work back to its ReadBuffer.
AbstractReapTask - Class in com.tangosol.coherence.servlet
Base class for reaping tasks.
AbstractReapTask(SessionHelper, SessionReaperStatistics, Iterator) - Constructor for class com.tangosol.coherence.servlet.AbstractReapTask
Construct an AbstractReapTask.
AbstractRecordableStep(Filter) - Constructor for class com.tangosol.util.SimpleQueryRecord.PartialResult.AbstractRecordableStep
Construct an AbstractRecordableStep.
AbstractSafeLongArray<V> - Class in com.tangosol.util
An abstract base class for thread-safe LongArrays which are protected by lock(s).
AbstractSafeLongArray() - Constructor for class com.tangosol.util.AbstractSafeLongArray
 
AbstractSafeLongArray.SafeIterator - Class in com.tangosol.util
A lock based LongArray Iterator.
AbstractScheme - Class in com.tangosol.coherence.config.scheme
The AbstractScheme is the base implementation of a Scheme.
AbstractScheme() - Constructor for class com.tangosol.coherence.config.scheme.AbstractScheme
 
AbstractScript - Class in com.tangosol.util
AbstractScriptBase is the base class for script based processing.
AbstractScript() - Constructor for class com.tangosol.util.AbstractScript
Default constructor for ExternalizableLite.
AbstractScript(String, String, Object...) - Constructor for class com.tangosol.util.AbstractScript
Create a AbstractScriptBase.
AbstractSerializationCache - Class in com.tangosol.net.cache
An abstract base class for serialization-based caches.
AbstractSerializationCache(BinaryStore) - Constructor for class com.tangosol.net.cache.AbstractSerializationCache
Construct a serialization cache on top of a BinaryStore.
AbstractSerializationCache(BinaryStore, ClassLoader) - Constructor for class com.tangosol.net.cache.AbstractSerializationCache
Construct a serialization cache on top of a BinaryStore, using the passed ClassLoader for deserialization.
AbstractSerializationCache(BinaryStore, boolean) - Constructor for class com.tangosol.net.cache.AbstractSerializationCache
Construct a serialization cache on top of a BinaryStore, optionally storing only Binary keys and values.
AbstractServiceLoadBalancer<S extends Service,T extends ServiceLoad> - Class in com.tangosol.net
An abstract base for ServiceLoadBalancer implementations.
AbstractServiceLoadBalancer() - Constructor for class com.tangosol.net.AbstractServiceLoadBalancer
 
AbstractServiceScheme<D extends ServiceDependencies> - Class in com.tangosol.coherence.config.scheme
The AbstractServiceScheme provides functionality common to all schemes that use services.
AbstractServiceScheme() - Constructor for class com.tangosol.coherence.config.scheme.AbstractServiceScheme
 
AbstractSnapshotArchiver - Class in com.tangosol.persistence
An abstract implementation of a SnapshotArchiver which must be extended to create a specific implementation.
AbstractSnapshotArchiver(String, String) - Constructor for class com.tangosol.persistence.AbstractSnapshotArchiver
Create a new AbstractSnapshotArchiver which is used to archive and retrieve snapshot parts to/from a common archive location.
AbstractSnapshotStatement - Class in com.tangosol.coherence.dslquery.statement.persistence
Abstract implementation of an AbstractStatement providing functionality useful for generic snapshot statements.
AbstractSnapshotStatement(String, String) - Constructor for class com.tangosol.coherence.dslquery.statement.persistence.AbstractSnapshotStatement
Create a AbstractSnapshotStatement that will prove base functionality for other snapshot commands.
AbstractSparseArray<V> - Class in com.tangosol.util
A data structure resembling an array indexed by long values, stored as an AVL tree.
AbstractSparseArray() - Constructor for class com.tangosol.util.AbstractSparseArray
Default constructor.
AbstractSparseArray.Crawler - Class in com.tangosol.util
A tree node iterator.
AbstractSparseArray.Node<V> - Class in com.tangosol.util
An AVL tree node.
AbstractSQLSnapshotOPToken - Class in com.tangosol.coherence.dslquery.token.persistence
An abstract implementation of a snapshot operation which can be extended to support different persistence operations.
AbstractSQLSnapshotOPToken(String) - Constructor for class com.tangosol.coherence.dslquery.token.persistence.AbstractSQLSnapshotOPToken
Construct a new AbstractSQLSnapshotOPToken.
AbstractSQLSnapshotOPToken(String, String) - Constructor for class com.tangosol.coherence.dslquery.token.persistence.AbstractSQLSnapshotOPToken
Construct a new AbstractSQLSnapshotOPToken.
AbstractStableIterator - Class in com.tangosol.util
Deprecated.
As of Coherence 12.1.2, replaced by AbstractStableIterator
AbstractStableIterator() - Constructor for class com.tangosol.util.AbstractStableIterator
Deprecated.
 
AbstractStatement() - Constructor for class com.tangosol.coherence.dslquery.queryplus.AbstractQueryPlusStatementBuilder.AbstractStatement
 
AbstractStatement - Class in com.tangosol.coherence.dslquery.statement
A base class for Statement implementations.
AbstractStatement() - Constructor for class com.tangosol.coherence.dslquery.statement.AbstractStatement
 
AbstractStatementBuilder<T extends Statement> - Class in com.tangosol.coherence.dslquery.statement
A base class for StatementBuilder implementations.
AbstractStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.statement.AbstractStatementBuilder
 
AbstractStoreManager - Class in com.tangosol.io.nio
A base implementation of BinaryStoreManager interface that uses BinaryMap objects built on a ByteBufferManager to provide BinaryStore objects.
AbstractStoreManager(int, int) - Constructor for class com.tangosol.io.nio.AbstractStoreManager
Construct a AbstractStoreManager that uses BinaryMap objests built on the ByteBufferManager(s) with certain initial and maximum size.
AbstractStoreManagerBuilder<T> - Class in com.tangosol.coherence.config.builder.storemanager
The AbstractStoreManagerBuilder class builds an instance of a BinaryStoreManager.
AbstractStoreManagerBuilder() - Constructor for class com.tangosol.coherence.config.builder.storemanager.AbstractStoreManagerBuilder
 
AbstractUpdater<K,V,U> - Class in com.tangosol.util.extractor
Abstract base for ValueUpdater implementations.
AbstractUpdater() - Constructor for class com.tangosol.util.extractor.AbstractUpdater
 
AbstractWork() - Constructor for class com.tangosol.coherence.commonj.WorkManager.AbstractWork
Default constructor (necessary for a lite serialization).
AbstractWork(long, int) - Constructor for class com.tangosol.coherence.commonj.WorkManager.AbstractWork
Construct the AbstractWork to be executed on behalf of the specified member (a Work originator).
AbstractWrapperCollection() - Constructor for class com.tangosol.util.WrapperCollections.AbstractWrapperCollection
Default constructor
AbstractWrapperCollection(Collection<E>) - Constructor for class com.tangosol.util.WrapperCollections.AbstractWrapperCollection
Create an AbstractWrapperCollection which delegates to the specified Collection.
AbstractWrapperEntry(Map.Entry<K, V>) - Constructor for class com.tangosol.util.WrapperCollections.AbstractWrapperEntry
Create an AbstractWrapperEntry which delegates to the specified Entry.
AbstractWrapperIterator(Iterator<E>) - Constructor for class com.tangosol.util.WrapperCollections.AbstractWrapperIterator
Create an AbstractWrapperIterator which delegates to the specified Iterator.
AbstractWrapperList() - Constructor for class com.tangosol.util.WrapperCollections.AbstractWrapperList
Default constructor.
AbstractWrapperList(List<E>) - Constructor for class com.tangosol.util.WrapperCollections.AbstractWrapperList
Create an AbstractWrapperList which delegates to the specified List.
AbstractWrapperListIterator(ListIterator<E>) - Constructor for class com.tangosol.util.WrapperCollections.AbstractWrapperListIterator
Create an AbstractWrapperListIterator which delegates to the specified ListIterator.
AbstractWrapperLongArray() - Constructor for class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
 
AbstractWrapperMap() - Constructor for class com.tangosol.util.WrapperCollections.AbstractWrapperMap
Default constructor
AbstractWrapperMap(Map<K, V>) - Constructor for class com.tangosol.util.WrapperCollections.AbstractWrapperMap
Create an AbstractWrapperMap which delegates to the specified Map.
AbstractWrapperSet() - Constructor for class com.tangosol.util.WrapperCollections.AbstractWrapperSet
Default constructor.
AbstractWrapperSet(Set<E>) - Constructor for class com.tangosol.util.WrapperCollections.AbstractWrapperSet
Create an AbstractWrapperSet which delegates to the specified Set.
AbstractWrapperSortedMap() - Constructor for class com.tangosol.util.WrapperCollections.AbstractWrapperSortedMap
Construct instance which wraps an instance of a SortedMap.
AbstractWrapperSortedMap(SortedMap<K, V>) - Constructor for class com.tangosol.util.WrapperCollections.AbstractWrapperSortedMap
Create an AbstractWrapperMap which delegates to the specified Map.
AbstractWrapperSortedSet() - Constructor for class com.tangosol.util.WrapperCollections.AbstractWrapperSortedSet
Default constructor
AbstractWrapperSortedSet(SortedSet<E>) - Constructor for class com.tangosol.util.WrapperCollections.AbstractWrapperSortedSet
Create an AbstractWrapperSortedSet which delegates to the specified SortedSet.
AbstractWriteBuffer - Class in com.tangosol.io
The AbstractWriteBuffer is a partial implementation of the WriteBuffer interface intended to be used as a base class for easily creating concrete WriteBuffer implementations.
AbstractWriteBuffer() - Constructor for class com.tangosol.io.AbstractWriteBuffer
 
AbstractWriteBuffer.AbstractBufferOutput - Class in com.tangosol.io
AbstractBufferOutput is a concrete implementation of BufferOutput for the non-concrete AbstractWriteBuffer implementation.
accelerateEntryRipe(Binary) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.WriteQueue
Move the ripe time for the queued entry up to accelerate the store operation.
accept(TermWalker) - Method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
 
accept(TermWalker) - Method in class com.tangosol.coherence.dsltools.termtrees.NodeTerm
 
accept(TermWalker) - Method in class com.tangosol.coherence.dsltools.termtrees.Term
Do a dispatch back to the given walker.
accept() - Method in class com.tangosol.net.CompositeAddressProvider
This method should be called by the client immediately after it determines that it can successfully use an address returned by the SocketAddressProvider.getNextAddress() method.
accept() - Method in class com.tangosol.net.CompositeAddressProvider.SingleProvider
This method should be called by the client immediately after it determines that it can successfully use an address returned by the SocketAddressProvider.getNextAddress() method.
accept() - Method in class com.tangosol.net.CompositeSocketAddressProvider
This method should be called by the client immediately after it determines that it can successfully use an address returned by the SocketAddressProvider.getNextAddress() method.
accept() - Method in class com.tangosol.net.ConfigurableAddressProvider
This method should be called by the client immediately after it determines that it can successfully use an address returned by the SocketAddressProvider.getNextAddress() method.
accept() - Method in class com.tangosol.net.RefreshableAddressProvider
This method should be called by the client immediately after it determines that it can successfully use an address returned by the SocketAddressProvider.getNextAddress() method.
accept() - Method in interface com.tangosol.net.SocketAddressProvider
This method should be called by the client immediately after it determines that it can successfully use an address returned by the SocketAddressProvider.getNextAddress() method.
accept(File) - Method in class com.tangosol.persistence.ArchiverHelper.DirectoryFileFilter
Deprecated.
Accept the given file only if it is a directory.
accept() - Method in class com.tangosol.util.NullImplementation.NullAddressProvider
This method should be called by the client immediately after it determines that it can successfully use an address returned by the SocketAddressProvider.getNextAddress() method.
acceptAtom(String, AtomicTerm) - Method in class com.tangosol.coherence.dslquery.internal.AbstractCoherenceQueryWalker
 
acceptAtom(String, AtomicTerm) - Method in interface com.tangosol.coherence.dsltools.termtrees.TermWalker
The receiver has been dispatched to from the given atom.
acceptBinaryOperator(String, Term, Term) - Method in class com.tangosol.coherence.dslquery.FilterBuilder
This method will take a Binary Operator and the left and right Terms for the operator and result in the creation of a Filter or a ValueExtractor.
acceptBinaryOperator(String, Term, Term) - Method in class com.tangosol.coherence.dslquery.internal.AbstractCoherenceQueryWalker
The receiver has classified a binary operation node.
acceptBinaryOperator(String, Term, Term) - Method in class com.tangosol.coherence.dslquery.internal.SelectListMaker
The receiver has classified a binary operation node
acceptBinaryOperator(String, Term, Term) - Method in class com.tangosol.coherence.dslquery.internal.UpdateSetListMaker
 
acceptCall(String, NodeTerm) - Method in class com.tangosol.coherence.dslquery.internal.AbstractCoherenceQueryWalker
The receiver has classified a call node.
acceptCall(String, NodeTerm) - Method in class com.tangosol.coherence.dslquery.internal.SelectListMaker
The receiver has classified a call node
acceptCall(String, NodeTerm) - Method in class com.tangosol.coherence.dslquery.internal.UpdateSetListMaker
 
acceptIdentifier(String) - Method in class com.tangosol.coherence.dslquery.FilterBuilder
 
acceptIdentifier(String) - Method in class com.tangosol.coherence.dslquery.internal.AbstractCoherenceQueryWalker
The receiver has classified an identifier node.
acceptIdentifier(String) - Method in class com.tangosol.coherence.dslquery.internal.ConstructorQueryWalker
The receiver has classified an identifier node.
acceptIdentifier(String) - Method in class com.tangosol.coherence.dslquery.internal.SelectListMaker
 
acceptIdentifier(String) - Method in class com.tangosol.coherence.dslquery.internal.UpdateSetListMaker
 
acceptIdentifierInternal(String) - Method in class com.tangosol.coherence.dslquery.internal.AbstractCoherenceQueryWalker
Return true if the identifier specified is a well known identifier ('null', 'true' or 'false'), with a side-affect of m_oResult being set appropriately.
acceptKeyedBinding(String) - Method in class com.tangosol.coherence.dslquery.internal.AbstractCoherenceQueryWalker
The receiver has classified a bind slot.
acceptList(NodeTerm) - Method in class com.tangosol.coherence.dslquery.FilterBuilder
 
acceptList(NodeTerm) - Method in class com.tangosol.coherence.dslquery.internal.AbstractCoherenceQueryWalker
The receiver has classified a list node.
acceptList(NodeTerm) - Method in class com.tangosol.coherence.dslquery.internal.UpdateSetListMaker
 
acceptLiteral(AtomicTerm) - Method in class com.tangosol.coherence.dslquery.internal.AbstractCoherenceQueryWalker
The receiver has classified a literal node.
acceptNode(String, NodeTerm) - Method in class com.tangosol.coherence.dslquery.internal.AbstractCoherenceQueryWalker
 
acceptNode(String, NodeTerm) - Method in class com.tangosol.coherence.dslquery.internal.UpdateSetListMaker
 
acceptNode(String, NodeTerm) - Method in interface com.tangosol.coherence.dsltools.termtrees.TermWalker
The receiver has been dispatched to from the given node.
acceptNumericBinding(int) - Method in class com.tangosol.coherence.dslquery.internal.AbstractCoherenceQueryWalker
The receiver has classified a bind slot.
AcceptorDependenciesProcessor - Class in com.tangosol.coherence.config.xml.processor
An ElementProcessor that will parse an <acceptor-config> and produce an AcceptorDependencies.
AcceptorDependenciesProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.AcceptorDependenciesProcessor
 
acceptPath(NodeTerm) - Method in class com.tangosol.coherence.dslquery.FilterBuilder
 
acceptPath(NodeTerm) - Method in class com.tangosol.coherence.dslquery.internal.AbstractCoherenceQueryWalker
The receiver has classified a path node.
acceptPath(NodeTerm) - Method in class com.tangosol.coherence.dslquery.internal.ConstructorQueryWalker
The receiver has classified a path node.
acceptPath(NodeTerm) - Method in class com.tangosol.coherence.dslquery.internal.SelectListMaker
 
acceptPath(NodeTerm) - Method in class com.tangosol.coherence.dslquery.internal.UpdateSetListMaker
 
acceptPathAsChainedExtractor(String, NodeTerm) - Method in class com.tangosol.coherence.dslquery.internal.AbstractCoherenceQueryWalker
Process the specified path term as a ChainedExtractor.
accepts(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.AbstractEmptyElementProcessor
Determines if the specified XmlElement should be processed.
accepts(ProcessingContext, XmlElement) - Method in interface com.tangosol.config.xml.ConditionalElementProcessor
Determines if the specified XmlElement should be processed.
acceptTarget() - Method in class com.tangosol.coherence.dslquery.internal.UpdateSetListMaker
Do the Tree Walk for the set target AST
acceptTerm(String, Term) - Method in class com.tangosol.coherence.dslquery.internal.AbstractCoherenceQueryWalker
 
acceptTerm(String, Term) - Method in interface com.tangosol.coherence.dsltools.termtrees.TermWalker
The receiver has been dispatched to from the given atom.
acceptUnaryOperator(String, Term) - Method in class com.tangosol.coherence.dslquery.FilterBuilder
 
acceptUnaryOperator(String, Term) - Method in class com.tangosol.coherence.dslquery.internal.AbstractCoherenceQueryWalker
The receiver has classified a unary operation node.
acceptUnaryOperator(String, Term) - Method in class com.tangosol.coherence.dslquery.internal.UpdateSetListMaker
 
AccessController - Interface in com.tangosol.net.security
The AccessController interface is used by the cluster services to verify whether or not a caller has sufficient rights to access protected clustered resources.
accessed(long, ExpiryPolicy) - Method in class com.tangosol.coherence.jcache.common.JCacheEntryMetaInf
Update the JCacheEntryMetaInf based on the associated entry being accessed at the specified time.
accessInternalValue(long, ExpiryPolicy) - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheValue
Access value
accumulate(InvocableMap.Entry) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics.PartitionedCacheStatisticsAggregator
 
accumulate(InvocableMap.Entry) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics.PartitionedCacheStatisticsClear
 
accumulate(Streamer<? extends InvocableMap.Entry<? extends K, ? extends V>>) - Method in class com.tangosol.util.aggregator.AbstractAggregator
 
accumulate(InvocableMap.Entry<? extends K, ? extends V>) - Method in class com.tangosol.util.aggregator.AbstractAggregator
 
accumulate(InvocableMap.Entry) - Method in class com.tangosol.util.aggregator.CompositeAggregator
 
accumulate(Streamer<? extends InvocableMap.Entry<? extends K, ? extends V>>) - Method in class com.tangosol.util.aggregator.Count
 
accumulate(InvocableMap.Entry<? extends K, ? extends V>) - Method in class com.tangosol.util.aggregator.Count
 
accumulate(Streamer<? extends InvocableMap.Entry<? extends K, ? extends V>>) - Method in class com.tangosol.util.aggregator.DistinctValues
 
accumulate(InvocableMap.Entry<? extends K, ? extends V>) - Method in class com.tangosol.util.aggregator.GroupAggregator
 
accumulate(InvocableMap.Entry<? extends K, ? extends V>) - Method in class com.tangosol.util.aggregator.PriorityAggregator
 
accumulate(Streamer<? extends InvocableMap.Entry<? extends K, ? extends V>>) - Method in class com.tangosol.util.aggregator.QueryRecorder
 
accumulate(InvocableMap.Entry<? extends K, ? extends V>) - Method in class com.tangosol.util.aggregator.QueryRecorder
 
accumulate(InvocableMap.Entry<? extends K, ? extends V>) - Method in class com.tangosol.util.aggregator.ScriptAggregator
 
accumulate(InvocableMap.Entry<? extends K, ? extends V>) - Method in class com.tangosol.util.aggregator.TopNAggregator
 
accumulate(Streamer<? extends InvocableMap.Entry<? extends K, ? extends V>>) - Method in interface com.tangosol.util.InvocableMap.StreamingAggregator
Accumulate multiple entries into the result.
accumulate(InvocableMap.Entry<? extends K, ? extends V>) - Method in interface com.tangosol.util.InvocableMap.StreamingAggregator
Accumulate one entry into the result.
acquireReadLock() - Method in class com.tangosol.util.AbstractSafeLongArray
Acquire the read lock.
acquireReadLock() - Method in class com.tangosol.util.ReadHeavyLongArray
 
acquireReadLock() - Method in class com.tangosol.util.SafeLongArray
 
acquireWriteLock() - Method in class com.tangosol.util.AbstractSafeLongArray
Acquire the write lock.
acquireWriteLock() - Method in class com.tangosol.util.ReadHeavyLongArray
 
acquireWriteLock() - Method in class com.tangosol.util.SafeLongArray
 
Action - Interface in com.tangosol.net
An Action represents a controllable action or behavior that a Service might perform.
ACTION_DEFAULT - Static variable in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder
The value of the hostname-verifier action to use the default verifier.
ACTION_IGNORE - Static variable in class com.tangosol.util.filter.FilterTrigger
Evaluation failure results in restoring the original Entry's value.
ACTION_IGNORE_LOGICAL - Static variable in class com.tangosol.util.filter.FilterTrigger
Evaluation failure results in restoring the original Entry's value using the non-synthetic API.
ACTION_REMOVE - Static variable in class com.tangosol.util.filter.FilterTrigger
Evaluation failure results in a removal of the entry.
ACTION_REMOVE_LOGICAL - Static variable in class com.tangosol.util.filter.FilterTrigger
Evaluation failure results in a non-synthetic removal of the entry.
ACTION_ROLLBACK - Static variable in class com.tangosol.util.filter.FilterTrigger
Evaluation failure results in an IllegalArgumentException thrown by the trigger.
actionable(AbstractJournalRM.JournalFile) - Method in class com.tangosol.io.journal.AbstractJournalRM.CollectorDaemon.CollectionCoordinator
Inform the CollectionCoordinator of an item that could be actioned if the CollectorDaemon was to execute.
ActionPolicy - Interface in com.tangosol.net
ActionPolicy defines which aspects of a Service's behavior are currently allowed.
ActionPolicyBuilder - Class in com.tangosol.coherence.config.builder
The abstract ActionPolicyBuilder is a base class builder for building ActionPolicy's instances and defers cache configuration validation until the instance is realized.
ActionPolicyBuilder() - Constructor for class com.tangosol.coherence.config.builder.ActionPolicyBuilder
 
ActionPolicyBuilder.ActionPolicyParameterizedBuilder - Class in com.tangosol.coherence.config.builder
ActionPolicyBuilder wrapper for a ParameterizedBuilder.
ActionPolicyBuilder.NullImplementationBuilder - Class in com.tangosol.coherence.config.builder
ActionPolicy Null Implementation
ActionPolicyBuilder.QuorumRule - Class in com.tangosol.coherence.config.builder
Intermediate QuorumRule with enough information to report a ConfigurationException at instantiation time.
ActionPolicyParameterizedBuilder(ParameterizedBuilder<ActionPolicy>) - Constructor for class com.tangosol.coherence.config.builder.ActionPolicyBuilder.ActionPolicyParameterizedBuilder
activate() - Method in class com.tangosol.application.ContainerAdapter
Initialize and start the application that is hosted by this ContainerAdapter.
activate(String, HttpSession) - Method in class com.tangosol.coherence.servlet.AbstractHttpSessionCollection
Move the session into an active state, if it is not already.
activate(HttpSession) - Method in class com.tangosol.coherence.servlet.AbstractHttpSessionModel
Activate the session model.
activate(String, HttpSession) - Method in interface com.tangosol.coherence.servlet.HttpSessionCollection
Move the session into an active state, if it is not already.
activate() - Method in interface com.tangosol.net.ConfigurableCacheFactory
Activate prepares the factory to be used within a container and should be called before any other factory method.
activate() - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
Deprecated.
Activate prepares the factory to be used within a container and should be called before any other factory method.
activate() - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
Activate prepares the factory to be used within a container and should be called before any other factory method.
ActiveActiveProcessor - Class in com.tangosol.coherence.config.xml.processor
An ActivePassiveProcessor is responsible for processing <active-active> XmlElements to produce a TopologyBuilder.ActiveActiveTopologyBuilder.
ActiveActiveProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.ActiveActiveProcessor
 
ActivePassiveProcessor - Class in com.tangosol.coherence.config.xml.processor
An ActivePassiveProcessor is responsible for processing <active-passive> XmlElements to produce a TopologyBuilder.ActivePassiveTopologyBuilder.
ActivePassiveProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.ActivePassiveProcessor
 
ADAPTER_INIT_PARAMS - Static variable in class com.tangosol.run.xml.XmlBean.BeanInfo
Parameters for finding the default adapter constructor.
add(V) - Method in interface com.oracle.coherence.common.base.Collector
Notify the collector of a item of interest.
add(String, int) - Method in class com.tangosol.coherence.config.builder.ListBasedAddressProviderBuilder
Add an address and port.
add(String) - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.NameListDependencies
 
add(Parameter) - Method in interface com.tangosol.coherence.config.ParameterList
Adds a Parameter to the end of the ParameterList or replaces an existing Parameter in the ParameterList.
add(Parameter) - Method in class com.tangosol.coherence.config.ResolvableParameterList
Adds a Parameter to the end of the ParameterList or replaces an existing Parameter in the ParameterList.
add(Parameter) - Method in class com.tangosol.coherence.config.SimpleParameterList
Adds a Parameter to the end of the ParameterList or replaces an existing Parameter in the ParameterList.
add(Object) - Method in class com.tangosol.coherence.config.SimpleParameterList
Adds the specified object to the end of the ParameterList as an anonymous Parameter.
add(JCacheStatistics) - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
 
add(JCacheStatistics) - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
add JCacheStatistics stats to this instance.
add(JCacheStatistics) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
 
add(Comparator) - Method in class com.tangosol.coherence.rest.util.ComparatorBuilder
Append specified comparator to the end of list of comparators owned by this builder.
add(PropertySpec) - Method in class com.tangosol.coherence.rest.util.PropertySet
Add a property to this property set.
add(BinaryEntry) - Method in class com.tangosol.net.cache.AbstractBinaryEntryBundler.Bundle
Add the specified binary entry to the Bundle.
add(Object, Object) - Method in class com.tangosol.net.cache.AbstractEntryBundler.Bundle
Add the specified entry to the Bundle.
add(Object) - Method in class com.tangosol.net.cache.AbstractKeyBundler.Bundle
Add the specified key to the Bundle.
add(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.ReadQueue
Add a key to the queue.
add(ReadWriteBackingMap.Entry, long) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.WriteQueue
Add an entry to the queue.
add(Object) - Method in class com.tangosol.net.CompositeAddressProvider
Ensures that this collection contains the specified element (optional operation).
add(Guardable, long, float) - Method in class com.tangosol.net.GuardSupport
Add the specified guardable to the set of Guardables managed by this manager, subject to the specified service parameters.
add(Object) - Method in class com.tangosol.net.LoadBalancer.Queue
Add an object to the end of the queue.
add(int) - Method in class com.tangosol.net.partition.PartitionSet
Add the specified partition to the set.
add(PartitionSet) - Method in class com.tangosol.net.partition.PartitionSet
Add the specified PartitionSet to this set.
add(Object) - Method in class com.tangosol.run.xml.SimpleElement.ElementList
Appends the specified element to the end of this list.
add(int, Object) - Method in class com.tangosol.run.xml.SimpleElement.ElementList
Inserts the specified element at the specified position in this list.
add(V) - Method in class com.tangosol.util.AbstractLongArray
Add the passed element value to the LongArray and return the index at which the element value was stored.
add(V) - Method in class com.tangosol.util.AbstractSafeLongArray
 
add(E) - Method in class com.tangosol.util.aggregator.TopNAggregator.PartialResult
 
add(E) - Method in class com.tangosol.util.ChainedCollection
 
add(Object) - Method in class com.tangosol.util.ChainedMap.EntrySet
Ensures that this collection contains the specified element (optional operation).
add(E) - Method in class com.tangosol.util.ChainedSet
 
add(Object) - Method in class com.tangosol.util.CircularArrayList
add(int, Object) - Method in class com.tangosol.util.CircularArrayList
Insert the element at the specified position in this list.
add(T) - Method in class com.tangosol.util.ConverterCollections.ConverterCollection
add(Map.Entry<TK, TV>) - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet
add(int, T) - Method in class com.tangosol.util.ConverterCollections.ConverterList
add(T) - Method in class com.tangosol.util.ConverterCollections.ConverterListIterator
add(T) - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray
 
add(V) - Method in class com.tangosol.util.CopyOnWriteLongArray
Add the passed element value to the LongArray and return the index at which the element value was stored.
add(Object) - Method in class com.tangosol.util.DeltaSet
Ensures that this Collection contains the specified element.
add(Object) - Method in class com.tangosol.util.ImmutableMultiList.MultiIterator
 
add(Object) - Method in class com.tangosol.util.InflatableCollection
add(int, Object) - Method in class com.tangosol.util.InflatableList
add(EventListener) - Method in class com.tangosol.util.Listeners
Add a listener.
add(E) - Method in class com.tangosol.util.LiteSet
Ensures that this Set contains the specified element.
add(V) - Method in interface com.tangosol.util.LongArray
Add the passed element value to the LongArray and return the index at which the element value was stored.
add(Object) - Method in class com.tangosol.util.MapSet
Ensures that this Set contains the specified element.
add(V) - Method in class com.tangosol.util.NullImplementation.NullCollector
Notify the collector of a item of interest.
add(Object) - Method in class com.tangosol.util.NullImplementation.NullSet
Ensures that this Collection contains the specified element.
add(E) - Method in class com.tangosol.util.OpenHashSet
add(Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedCollection
Ensures that this Collection contains the specified element.
add(Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet
Ensures that this Collection contains the specified element.
add(int, Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedList
Inserts the specified element at the specified position in this list (optional operation).
add(Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedListIterator
Inserts the specified element into the list.
add(Object) - Method in class com.tangosol.util.SafeLinkedList
Appends the specified element to the end of this List.
add(int, Object) - Method in class com.tangosol.util.SafeLinkedList
Inserts the specified element at the specified position in this List.
add(Object) - Method in class com.tangosol.util.SimpleLongArray
Add the passed element value to the LongArray and return the index at which the element value was stored.
add(E) - Method in class com.tangosol.util.SortedBag
add(E) - Method in class com.tangosol.util.SortedBag.ViewBag
add(String) - Method in class com.tangosol.util.StringTable
Add the passed string to the table.
add(T) - Method in class com.tangosol.util.SubList
add(int, T) - Method in class com.tangosol.util.SubList
add(E) - Method in class com.tangosol.util.SubSet
add(Comparable) - Method in class com.tangosol.util.Tree
Add the passed key to the tree.
add(E) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperCollection
add(int, E) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperList
add(E) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperListIterator
add(V) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
 
add(E) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperCollection
addAddress(InetSocketAddress) - Method in class com.tangosol.net.CompositeAddressProvider
Add an address.
addAddress(SocketAddress) - Method in class com.tangosol.net.CompositeSocketAddressProvider
addAliases(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.BaseOperator
Add any aliases of this operator to the specified token table.
addAll(Set) - Method in class com.tangosol.net.cache.AbstractBinaryEntryBundler.Bundle
Add the specified set of binary entries to the Bundle.
addAll(Map) - Method in class com.tangosol.net.cache.AbstractEntryBundler.Bundle
Add the specified collection of entries to the Bundle.
addAll(Collection) - Method in class com.tangosol.net.cache.AbstractKeyBundler.Bundle
Add the specified collection of keys to the Bundle.
addAll(Collection) - Method in class com.tangosol.run.xml.SimpleElement.ElementList
Overrides the ArrayList implementation to force this throw the single object add() method.
addAll(int, Collection) - Method in class com.tangosol.run.xml.SimpleElement.ElementList
Overrides the ArrayList implementation to force this throw the single object add() method.
addAll(Iterator<E>) - Method in class com.tangosol.util.aggregator.TopNAggregator.PartialResult
Add all specified values to this PartialResult.
addAll(Collection<? extends E>) - Method in class com.tangosol.util.ChainedCollection
 
addAll(Collection<? extends E>) - Method in class com.tangosol.util.ChainedSet
 
addAll(Collection) - Method in class com.tangosol.util.CircularArrayList
Appends all of the elements in the specified Collection to the end of this list, in the order that they are returned by the specified Collection's Iterator.
addAll(int, Collection) - Method in class com.tangosol.util.CircularArrayList
Inserts all of the elements in the specified Collection into this list, starting at the specified position.
addAll(Collection<? extends T>) - Method in class com.tangosol.util.ConverterCollections.ConverterCollection
addAll(Collection<? extends Map.Entry<TK, TV>>) - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet
addAll(int, Collection<? extends T>) - Method in class com.tangosol.util.ConverterCollections.ConverterList
addAll(int, Collection) - Method in class com.tangosol.util.InflatableList
addAll(Listeners) - Method in class com.tangosol.util.Listeners
Add all listeners from another Listeners object.
addAll(Collection<? extends E>) - Method in class com.tangosol.util.LiteSet
Adds all of the elements in the specified Collection to this Set if they are not already present.
addAll(Collection) - Method in class com.tangosol.util.MapSet
Adds all of the elements in the specified Collection to this Set if they're not already present.
addAll(Collection) - Method in class com.tangosol.util.RestrictedCollections.RestrictedCollection
Adds all of the elements in the specified Collection to this Collection (optional operation).
addAll(Collection) - Method in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet
Adds all of the elements in the specified Collection to this Collection (optional operation).
addAll(int, Collection) - Method in class com.tangosol.util.RestrictedCollections.RestrictedList
Inserts all of the elements in the specified collection into this list at the specified position (optional operation).
addAll(int, Collection) - Method in class com.tangosol.util.SafeLinkedList
Inserts all of the elements in the specified collection at the specified location in this List.
addAll(Collection) - Method in class com.tangosol.util.SafeLinkedList
Appends all of the elements in the specified collection to the end of this List, in the order that they are returned by the specified collection's iterator.
addAll(StringTable) - Method in class com.tangosol.util.StringTable
Adds all of the nodes in the specified StringTable to this StringTable if they are not already present.
addAll(Collection<? extends T>) - Method in class com.tangosol.util.SubList
addAll(int, Collection<? extends T>) - Method in class com.tangosol.util.SubList
addAll(Collection<? extends E>) - Method in class com.tangosol.util.SubSet
addAll(Tree) - Method in class com.tangosol.util.Tree
Adds all of the nodes in the specified Tree to this Tree if they are not already present.
addAll(Collection<? extends E>) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperCollection
addAll(int, Collection<? extends E>) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperList
addAll(Collection<? extends E>) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperCollection
addAlterSessionStatement() - Method in class com.tangosol.coherence.dslquery.QueryPlus
Add the QueryPlus ALTER SESSION statements
addAttribute(String) - Method in class com.tangosol.run.xml.SimpleElement
Provides a means to add a new attribute value.
addAttribute(String) - Method in interface com.tangosol.run.xml.XmlElement
Provides a means to add a new attribute value.
addAuthorizedHostsToFilter(String, String) - Method in class com.tangosol.coherence.config.builder.InetAddressRangeFilterBuilder
Add an authorized host range to the filter.
addBuffer() - Method in class com.tangosol.io.MultiBufferWriteBuffer
Once the current buffer is full, allocate a new one and make it the current buffer.
addCacheEntryListenerConfiguration(CacheEntryListenerConfiguration<K, V>) - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
 
addCacheEntryListenerConfiguration(CacheEntryListenerConfiguration<K, V>) - Method in interface com.tangosol.coherence.jcache.CoherenceBasedCompleteConfiguration
Add a configuration for a CacheEntryListener.
addCacheMappingRegistry(SchemeMappingRegistry) - Method in class com.tangosol.coherence.config.CacheConfig
Add cache scheme mappings to the SchemeMappingRegistry.
addConfig(BundleManager.BundleConfig) - Method in class com.tangosol.coherence.config.scheme.BundleManager
Add the BundleConfig to the list of bundle configurations.
addCookie(Class<T>, String, T) - Method in class com.tangosol.config.xml.DefaultProcessingContext
Adds the specified named and typed cookie to the ProcessingContext.
addCookie(Class<T>, T) - Method in class com.tangosol.config.xml.DefaultProcessingContext
Adds the specified cookie to the ProcessingContext.
addCookie(Class<T>, String, T) - Method in interface com.tangosol.config.xml.ProcessingContext
Adds the specified named and typed cookie to the ProcessingContext.
addCookie(Class<T>, T) - Method in interface com.tangosol.config.xml.ProcessingContext
Adds the specified cookie to the ProcessingContext.
addDefaultDefinition(String, String) - Method in class com.tangosol.coherence.config.xml.preprocessor.CacheDefaultsPreprocessor
Adds a requirement that the specified "default" element must be added to (if not already defined) in the element specified by the defined parent path.
addDefaultsDefinition(String, XmlElement) - Method in class com.tangosol.coherence.config.xml.preprocessor.OperationalDefaultsPreprocessor
Defines that elements matching the specified path must contain the child elements defined by the default element.
addElement(String) - Method in class com.tangosol.run.xml.SimpleElement
Create a new element and add it as a child element to this element.
addElement(String) - Method in interface com.tangosol.run.xml.XmlElement
Create a new element and add it as a child element to this element.
addElement(Object) - Method in class com.tangosol.util.Dequeue
Adds an element to the dequeue.
addElementPreprocessor(DocumentElementPreprocessor.ElementPreprocessor) - Method in class com.tangosol.config.xml.DocumentElementPreprocessor
addElements(XmlElement, Iterator) - Static method in class com.tangosol.run.xml.XmlHelper
Add the elements from the iterator to the passed XML.
addEnteredThread() - Method in class com.tangosol.coherence.servlet.AbstractHttpSessionModel
Add the currently running thread to the list of threads that have entered this session model.
addEnumeration(Enumeration) - Method in class com.tangosol.util.ChainedEnumerator
Add the Enumeration to the end of the chain.
addEvent(Class<? extends CacheEntryListener>, CacheEntryEvent<K, V>) - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheEventEventDispatcher
Requests that the specified event be prepared for dispatching to the specified type of listeners.
addEventInterceptor(EventInterceptor<E>) - Method in interface com.tangosol.net.events.EventDispatcher
Add an EventInterceptor to this dispatcher to be used to process Events.
addEventInterceptor(String, EventInterceptor<E>) - Method in interface com.tangosol.net.events.EventDispatcher
Add a uniquely identified EventInterceptor to this dispatcher to be used to process Events.
addEventInterceptor(String, EventInterceptor<E>, Set<T>, boolean) - Method in interface com.tangosol.net.events.EventDispatcher
Add a uniquely identified EventInterceptor to this dispatcher to be used to process Events.
addForwardEntry(Object, Object) - Method in class com.tangosol.util.SimpleMapIndex
Add a new mapping to the forward index map.
addFunction(String, ParameterizedBuilder) - Method in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
Map the specified CohQL ParameterizedBuilder to the specified function name.
addHttpSessionAttributeListener(HttpSessionAttributeListener) - Method in class com.tangosol.coherence.servlet.AbstractHttpSessionCollection
Sign up the specified listener to receive HttpSessionBindingEvent objects.
addHttpSessionAttributeListener(HttpSessionAttributeListener) - Method in interface com.tangosol.coherence.servlet.HttpSessionCollection
Sign up the specified listener to receive HttpSessionBindingEvent objects.
addHttpSessionListener(HttpSessionListener) - Method in class com.tangosol.coherence.servlet.AbstractHttpSessionCollection
Sign up the specified listener to receive HttpSessionEvent objects.
addHttpSessionListener(HttpSessionListener) - Method in interface com.tangosol.coherence.servlet.HttpSessionCollection
Sign up the specified listener to receive HttpSessionEvent objects.
addIgnoreAttributeName(String) - Method in class com.tangosol.coherence.servlet.SessionHelper
Register a name to ignore events for.
addIndex(ValueExtractor<? super T, ? extends E>, boolean, Comparator<? super E>) - Method in class com.tangosol.net.cache.ContinuousQueryCache
If ContinuousQueryCache.isCacheValues() is true, the index will be created locally as well as on the NamedCache this ContinuousQueryCache wraps, otherwise, the index will be created on the wrapped NamedCache only.
addIndex(ValueExtractor<? super T, ? extends E>, boolean, Comparator<? super E>) - Method in class com.tangosol.net.cache.NearCache
Add an index to this QueryMap.
addIndex(ValueExtractor<? super T, ? extends E>, boolean, Comparator<? super E>) - Method in class com.tangosol.net.cache.WrapperNamedCache
Add an index to this QueryMap.
addIndex(ValueExtractor<? super T, ? extends E>, boolean, Comparator<? super E>) - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
Add an index to this QueryMap.
addIndex(ValueExtractor<? super T, ? extends E>, boolean, Comparator<? super E>) - Method in class com.tangosol.util.ConverterCollections.ConverterQueryMap
Add an index to this QueryMap.
addIndex(ValueExtractor, boolean, Comparator, ObservableMap, Map) - Static method in class com.tangosol.util.InvocableMapHelper
Add an index to the given map of indexes, keyed by the given extractor.
addIndex() - Method in class com.tangosol.util.MultiBinaryLongMap.LongStorage
Add an additional index value to each slot.
addIndex(ValueExtractor<? super T, ? extends E>, boolean, Comparator<? super E>) - Method in interface com.tangosol.util.QueryMap
Add an index to this QueryMap.
addInternalValueDecoration(Object, int, Object) - Method in interface com.tangosol.net.BackingMapManagerContext
Decorate a specified value in the internal form with a specified decoration in the "normal" Object form.
addInternalValueDecoration(Object, int, Object) - Method in class com.tangosol.util.NullImplementation.NullBackingMapManagerContext
Decorate a specified value in the internal form with a specified decoration in the "normal" Object form.
addInverseCollectionMapping(Map, Object, Object) - Method in class com.tangosol.util.SimpleMapIndex
Add new mappings from the elements of the given value to the given key in the supplied index.
addInverseMapping(Object, Object) - Method in class com.tangosol.util.SimpleMapIndex
Add a new mapping from the given indexed value to the given key in the inverse index.
addInverseMapping(Map, Object, Object) - Method in class com.tangosol.util.SimpleMapIndex
Add a new mapping from the given indexed value to the given key in the supplied index.
addIterator(Iterator) - Method in class com.tangosol.util.ChainedEnumerator
Add the Iterator to the end of the chain.
AdditionOperator - Class in com.tangosol.coherence.dslquery.operator
A BaseOperator implementation representing the addition (+) operator.
AdditionOperator() - Constructor for class com.tangosol.coherence.dslquery.operator.AdditionOperator
Construct an AdditionOperator.
addLifecycleListener(LifecycleListener) - Method in class com.tangosol.net.DefaultCacheServer
Add a LifecycleListener that will be notified of lifecycle events for this DefaultCacheServer.
addListener(boolean, String) - Method in class com.tangosol.coherence.rest.CacheResource
Register SSE event listener for this cache.
addListener(boolean) - Method in class com.tangosol.coherence.rest.EntryResource
Register SSE event listener for this entry.
addListener(boolean, UriInfo) - Method in class com.tangosol.coherence.rest.NamedQueryResource
Register SSE event listener for this named query.
AddListener() - Constructor for class com.tangosol.net.cache.ContinuousQueryCache.AddListener
 
addListener(FiniteStateMachineListener<S>) - Method in interface com.tangosol.util.fsm.FiniteStateMachine
addListener(FiniteStateMachineListener<S>) - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine
addListener(MapListener, Filter, boolean) - Method in class com.tangosol.util.MapListenerSupport
Add a map listener that receives events based on a filter evaluation.
addListener(MapListener, Object, boolean) - Method in class com.tangosol.util.MapListenerSupport
Add a map listener for a specific key.
addListener(MapListener, Set, boolean) - Method in class com.tangosol.util.MapListenerSupport
Add a map listener for a set of keys.
addListener(MultiBinaryLongMap.BinaryLongMapListener) - Method in class com.tangosol.util.MultiBinaryLongMap
Add the specified listener to listen to changes that occur to the MultiBinaryLongMap's primary BinaryLongMap.
addListener(MultiBinaryLongMap.BinaryLongMapListener) - Method in class com.tangosol.util.MultiBinaryLongMap.PrimaryBinaryLongMap
Add the specified listener to the collection of listeners that this DelegatingPrimaryBinaryLongMap dispatches notifications to.
addListenerState(Map, Object, MapListener, boolean) - Static method in class com.tangosol.util.MapListenerSupport
Add a state information (lite or standard) associated with specified key and listener.
addListenerWithCheck(MapListener, Filter, boolean) - Method in class com.tangosol.util.MapListenerSupport
Add a map listener that receives events based on a filter evaluation.
addListenerWithCheck(MapListener, Object, boolean) - Method in class com.tangosol.util.MapListenerSupport
Add a map listener for a specific key.
addListenerWithCheck(MapListener, Set, boolean) - Method in class com.tangosol.util.MapListenerSupport
Add a map listener for a set of keys.
addLocalClass(Class) - Method in class com.tangosol.coherence.servlet.AbstractHttpSessionCollection.HybridController
Add a class which should never be distributed in the coherence cache.
addLookupCallback(NameService.LookupCallback) - Method in interface com.tangosol.net.NameService
Register a NameService.LookupCallback to be used to perform lookups on names that are not bound to the NameService's directory.
addMap(int, Map) - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.MapArray
Add a new mapping between a partition ID and its backing map.
addMapListener(MapListener) - Method in class com.tangosol.net.cache.AbstractSerializationCache
Add a standard map listener that will receive all events (inserts, updates, deletes) that occur against the map, with the key, old-value and new-value included.
addMapListener(MapListener, Object, boolean) - Method in class com.tangosol.net.cache.AbstractSerializationCache
Add a map listener for a specific key.
addMapListener(MapListener, Filter, boolean) - Method in class com.tangosol.net.cache.AbstractSerializationCache
Add a map listener that receives events based on a filter evaluation.
addMapListener(MapListener) - Method in class com.tangosol.net.cache.CompactSerializationCache
Add a standard map listener that will receive all events (inserts, updates, deletes) that occur against the map, with the key, old-value and new-value included.
addMapListener(MapListener, Object, boolean) - Method in class com.tangosol.net.cache.CompactSerializationCache
Add a map listener for a specific key.
addMapListener(MapListener, Filter, boolean) - Method in class com.tangosol.net.cache.CompactSerializationCache
Add a map listener that receives events based on a filter evaluation.
addMapListener(MapListener<? super K, ? super V_FRONT>) - Method in class com.tangosol.net.cache.ContinuousQueryCache
 
addMapListener(MapListener<? super K, ? super V_FRONT>, K, boolean) - Method in class com.tangosol.net.cache.ContinuousQueryCache
 
addMapListener(MapListener<? super K, ? super V_FRONT>, Filter, boolean) - Method in class com.tangosol.net.cache.ContinuousQueryCache
 
addMapListener(MapListener<? super K, ? super V>) - Method in class com.tangosol.net.cache.NearCache
Add a standard map listener.
addMapListener(MapListener<? super K, ? super V>, K, boolean) - Method in class com.tangosol.net.cache.NearCache
Add a map listener for a specific key.
addMapListener(MapListener<? super K, ? super V>, Filter, boolean) - Method in class com.tangosol.net.cache.NearCache
Add a map listener that receives events based on a filter evaluation.
addMapListener(MapListener) - Method in class com.tangosol.net.cache.OldCache
Deprecated.
Add a standard map listener that will receive all events (inserts, updates, deletes) that occur against the map, with the key, old-value and new-value included.
addMapListener(MapListener, Object, boolean) - Method in class com.tangosol.net.cache.OldCache
Deprecated.
Add a map listener for a specific key.
addMapListener(MapListener, Filter, boolean) - Method in class com.tangosol.net.cache.OldCache
Deprecated.
Add a map listener that receives events based on a filter evaluation.
addMapListener(MapListener) - Method in class com.tangosol.net.cache.OverflowMap
Add a standard map listener that will receive all events (inserts, updates, deletes) that occur against the map, with the key, old-value and new-value included.
addMapListener(MapListener, Object, boolean) - Method in class com.tangosol.net.cache.OverflowMap
Add a map listener for a specific key.
addMapListener(MapListener, Filter, boolean) - Method in class com.tangosol.net.cache.OverflowMap
Add a map listener that receives events based on a filter evaluation.
addMapListener(MapListener) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
Add a standard map listener that will receive all events (inserts, updates, deletes) that occur against the map, with the key, old-value and new-value included.
addMapListener(MapListener, Object, boolean) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
Add a map listener for a specific key.
addMapListener(MapListener, Filter, boolean) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
Add a map listener that receives events based on a filter evaluation.
addMapListener(MapListener, Object, boolean) - Method in class com.tangosol.net.partition.ObservableSplittingBackingMap
Add a map listener for a specific key.
addMapListener(MapListener, Filter, boolean) - Method in class com.tangosol.net.partition.ObservableSplittingBackingMap
Add a map listener that receives events based on a filter evaluation.
addMapListener(MapListener<? super TK, ? super TV>) - Method in class com.tangosol.util.ConverterCollections.ConverterObservableMap
Add a standard map listener that will receive all events (inserts, updates, deletes) that occur against the map, with the key, old-value and new-value included.
addMapListener(MapListener<? super TK, ? super TV>, TK, boolean) - Method in class com.tangosol.util.ConverterCollections.ConverterObservableMap
Add a map listener for a specific key.
addMapListener(MapListener<? super TK, ? super TV>, Filter, boolean) - Method in class com.tangosol.util.ConverterCollections.ConverterObservableMap
Add a map listener that receives events based on a filter evaluation.
addMapListener(MapListener) - Method in class com.tangosol.util.NullImplementation.NullObservableMap
Add a standard map listener that will receive all events (inserts, updates, deletes) that occur against the map, with the key, old-value and new-value included.
addMapListener(MapListener, Object, boolean) - Method in class com.tangosol.util.NullImplementation.NullObservableMap
Add a map listener for a specific key.
addMapListener(MapListener, Filter, boolean) - Method in class com.tangosol.util.NullImplementation.NullObservableMap
Add a map listener that receives events based on a filter evaluation.
addMapListener(MapListener) - Method in class com.tangosol.util.ObservableHashMap
 
addMapListener(MapListener<? super K, ? super V>, K, boolean) - Method in class com.tangosol.util.ObservableHashMap
 
addMapListener(MapListener<? super K, ? super V>, Filter, boolean) - Method in class com.tangosol.util.ObservableHashMap
 
addMapListener(MapListener<? super K, ? super V>) - Method in interface com.tangosol.util.ObservableMap
Add a standard map listener that will receive all events (inserts, updates, deletes) that occur against the map, with the key, old-value and new-value included.
addMapListener(MapListener<? super K, ? super V>, K, boolean) - Method in interface com.tangosol.util.ObservableMap
Add a map listener for a specific key.
addMapListener(MapListener<? super K, ? super V>, Filter, boolean) - Method in interface com.tangosol.util.ObservableMap
Add a map listener that receives events based on a filter evaluation.
addMapListener(MapListener<? super K, ? super V>) - Method in class com.tangosol.util.WrapperObservableMap
Add a standard map listener that will receive all events (inserts, updates, deletes) that occur against the map, with the key, old-value and new-value included.
addMapListener(MapListener<? super K, ? super V>, K, boolean) - Method in class com.tangosol.util.WrapperObservableMap
Add a map listener for a specific key.
addMapListener(MapListener<? super K, ? super V>, Filter, boolean) - Method in class com.tangosol.util.WrapperObservableMap
Add a map listener that receives events based on a filter evaluation.
addMBeanAttributes(ObjectName, Map<String, Object>, MBeanServer, Filter<MBeanAttributeInfo>) - Method in class com.tangosol.net.management.MBeanAccessor.GetAttributes
Add attributes of an MBean to a Map.
addMemberListener(MemberListener) - Method in interface com.tangosol.net.Service
Add a Member listener.
addMemberListener(MemberListener) - Method in class com.tangosol.net.WrapperService
Add a Member listener.
addNamedProviderType(String, SocketProviderFactory.Dependencies.ProviderType) - Method in class com.tangosol.net.SocketProviderFactory.DefaultDependencies
Add SocketProviderFactory.Dependencies.ProviderType for sId identifier to this SocketProviderFactory's Dependency mapping.
addNamedQuery(NamedQuery) - Method in class com.tangosol.coherence.rest.config.QueryConfig
Add named query to this config.
addNamedSSLDependencies(String, SSLSocketProvider.Dependencies) - Method in class com.tangosol.net.SocketProviderFactory.DefaultDependencies
Add SSLSocketProvider.Dependencies for sId identifier to this SocketProviderFactory's Dependency mapping.
addNamedSSLDependenciesBuilder(String, SSLSocketProviderDependenciesBuilder) - Method in class com.tangosol.net.SocketProviderFactory.DefaultDependencies
 
addNamedTCPDatagramDependencies(String, TcpDatagramSocketProvider.Dependencies) - Method in class com.tangosol.net.SocketProviderFactory.DefaultDependencies
Add TcpDatagramSocketProvider.Dependencies for sId identifier to this SocketProviderFactory's Dependency mapping.
addNotificationListener(NotificationListener, NotificationFilter, Object) - Method in class com.tangosol.net.management.AnnotatedStandardEmitterMBean.SilentEmitter
 
addNotificationListener(String, NotificationListener, NotificationFilter, Object) - Method in interface com.tangosol.net.management.MBeanServerProxy
Adds a listener to a registered MBean.
addNotificationListener(String, NotificationListener, NotificationFilter, Object) - Method in class com.tangosol.net.management.WrapperMBeanServerProxy
 
addOperator(BaseOperator) - Method in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
Add the custom operator to the CohQL language.
addOPToken(OPToken) - Method in class com.tangosol.coherence.dsltools.precedence.PeekOPToken
Add the specified OPToken to the Map of tokens that will be called depending on the next token parsed from the token stream.
addOPToken(String, OPToken) - Method in class com.tangosol.coherence.dsltools.precedence.PeekOPToken
Add the specified OPToken to the Map of tokens that will be called depending on the next token parsed from the token stream.
addPartitionListener(PartitionListener) - Method in interface com.tangosol.net.PartitionedService
Add a PartitionListener to this service.
addProvider(AddressProvider) - Method in class com.tangosol.net.CompositeAddressProvider
Add an AddressProvider.
addProvider(SocketAddressProvider) - Method in class com.tangosol.net.CompositeSocketAddressProvider
addQuorumRule(String, int, int) - Method in class com.tangosol.coherence.config.builder.PartitionedCacheQuorumPolicyBuilder
 
addRegistrySchemeMapping(SchemeMappingRegistry) - Method in class com.tangosol.coherence.config.CacheConfig
Add topic scheme mappings to scheme SchemeMappingRegistry if no mapping already exists for the same patter.
address - Variable in class com.tangosol.net.LoadBalancer.AddressPort
The address.
AddressHolder(String, int) - Constructor for class com.tangosol.net.ConfigurableAddressProvider.AddressHolder
Construct an AddressHolder for the specified host and port.
AddressIterator(List) - Constructor for class com.tangosol.net.CompositeAddressProvider.AddressIterator
 
AddressPort(InetAddress, int) - Constructor for class com.tangosol.net.LoadBalancer.AddressPort
Construct an AddressPort object.
AddressProvider - Interface in com.tangosol.net
The AddressProvider is a subclass interface of SocketAddressProvider which returns InetSocketAddress from AddressProvider.getNextAddress().
AddressProviderBuilder - Interface in com.tangosol.coherence.config.builder
AddressProviderBuilder interface
AddressProviderBuilderProcessor - Class in com.tangosol.coherence.config.xml.processor
An ElementProcessor that will parse and produce a ParameterizedBuilder<AddressProvider> based on an address-provider configuration element, that of which is defined as such (with support for foreign-namespaces) <!
AddressProviderBuilderProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.AddressProviderBuilderProcessor
 
AddressProviderFactory - Interface in com.tangosol.net
A factory for AddressProvider objects.
addSafeListener(Map, Object, MapListener) - Static method in class com.tangosol.util.MapListenerSupport
Ensure that the specified map has a Listeners object associated with the specified key and add the specified listener to it.
addSafeListener(Map, Filter, MapListener) - Static method in class com.tangosol.util.MapListenerSupport
Ensure that the specified map has a Listeners object associated with the specified Filter and add the specified listener to it.
addServiceListener(ServiceListener) - Method in class com.tangosol.net.WrapperService
Register a ServiceListener that will receive events pertaining to the lifecycle of this Service.
addServiceListener(ServiceListener) - Method in interface com.tangosol.util.Service
Register a ServiceListener that will receive events pertaining to the lifecycle of this Service.
addStateEntryAction(S, StateEntryAction<S>) - Method in class com.tangosol.util.fsm.SimpleModel
Adds/overrides the StateEntryAction for the specified state in the Model.
addStateExitAction(S, StateExitAction<S>) - Method in class com.tangosol.util.fsm.SimpleModel
Adds/overrides the StateExitAction for the specified state in the Model.
addStatement(String, StatementBuilder<?>) - Method in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
Register the given StatementBuilder to the specified functor name.
addStatement(AbstractQueryPlusStatementBuilder) - Method in class com.tangosol.coherence.dslquery.QueryPlus
Add a new QueryPlus statement.
addToken(String, OPToken) - Method in class com.tangosol.coherence.dsltools.precedence.TokenTable
Add a token t under the given name
addToken(String, OPToken, String) - Method in class com.tangosol.coherence.dsltools.precedence.TokenTable
Add a token t under the given name with given ast name
addToken(String, OPToken, String, String) - Method in class com.tangosol.coherence.dsltools.precedence.TokenTable
Add a token t under the given name with given led and nud names
addToken(OPToken) - Method in class com.tangosol.coherence.dsltools.precedence.TokenTable
Add a token t under the id stored in the token
addToken(OPToken, String) - Method in class com.tangosol.coherence.dsltools.precedence.TokenTable
Add a token t with given ast name
addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.AdditionOperator
 
addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.AndOperator
 
addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.BaseOperator
Add this operator to the given TokenTable.
addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.BetweenOperator
 
addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.ContainsAllOperator
 
addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.ContainsAnyOperator
 
addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.ContainsOperator
 
addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.DivisionOperator
Add this operator to the given TokenTable.
addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.EqualsOperator
 
addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.GreaterEqualsOperator
 
addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.GreaterOperator
 
addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.InOperator
 
addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.LessEqualsOperator
 
addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.LessOperator
 
addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.LikeOperator
 
addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.MultiplicationOperator
Add this operator to the given TokenTable.
addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.NotEqualsOperator
 
addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.OrOperator
 
addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.SubtractionOperator
Add this operator to the given TokenTable.
addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.XorOperator
 
addTransition(Transition<S>) - Method in class com.tangosol.util.fsm.SimpleModel
Adds the specified Transition to the Model.
addValue(Binary, long) - Method in class com.tangosol.util.MultiBinaryLongMap.PrimaryBinaryLongMap.DelegatingPrimaryBinaryLongMap
Add the specified key to the BinaryLongMap, and associate the specified value with it in the primary BLM.
addWait(Collection) - Method in class com.tangosol.coherence.commonj.WorkManager.WorkHolder
Add a collection to a wait list.
adjust(int) - Method in class com.tangosol.io.MultiBufferWriteBuffer.MultiBufferOutput
Adjust the offset of this BufferOutput based on a write that by-passed this BufferOutput's own super-class implementation that is responsible for maintaining the offset.
adjust() - Method in class com.tangosol.net.cache.AbstractBundler
Adjust this Bundler's parameters according to the available statistical information.
adjustDepth(int) - Method in class com.tangosol.io.pof.LoggingPofHandler
Adjust the complex data structure depth.
adjustDoubleBalance(AbstractSparseArray.Node<V>, AbstractSparseArray.Node<V>, int) - Method in class com.tangosol.util.AbstractSparseArray
Adjust the balance factor of a node and its descendants prior to a a double rotation.
adjustIndirectStorageSize(long) - Method in class com.tangosol.net.partition.PartitionStatistics
Adjust the non-PartitionAwareBackingMap storage size of the partition by the specified amount.
ADJUSTMENT_FREQUENCY - Static variable in class com.tangosol.net.cache.AbstractBundler
Frequency of the adjustment attempts.
adjustOffsetInternal(int) - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
Adjust the internal stream offset.
adjustOffsetInternal(int) - Method in class com.tangosol.io.nio.ByteBufferReadBuffer.ByteBufferInput
Adjust the internal stream offset.
adjustOpenBlockOffset(int, int) - Method in class com.tangosol.io.nio.BinaryMap
When an open block changes position in the buffer, this method is invoked to adjust the cache of open blocks.
adjustPoolSize() - Method in interface com.tangosol.net.ThreadPoolSizingStrategy
Analyze the thread usage of the thread pool.
adjustSize(int) - Method in class com.tangosol.net.cache.OverflowMap
Adjust the number of entries in the OverflowMap.
adjustUnits(int) - Method in class com.tangosol.net.cache.OldCache
Deprecated.
Adjust current size.
adjustUnits(int) - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
Adjust the number of units for each map with the pool of units provided.
adjustWaitTime(long, long) - Method in class com.tangosol.util.ThreadGateLite
Calculate the time remaining from the total time allotted for an operation.
adopt(Map) - Method in class com.tangosol.run.xml.XmlBean
Helper to adopt a Map of XmlBean objects.
adopt(Collection) - Method in class com.tangosol.run.xml.XmlBean
Helper to adopt a Collection of XmlBean objects.
adopt(Iterator) - Method in class com.tangosol.run.xml.XmlBean
Helper to adopt a collection of XmlBean objects.
adopt(Object[]) - Method in class com.tangosol.run.xml.XmlBean
Helper to adopt a collection of XmlBean objects.
adopt(XmlBean) - Method in class com.tangosol.run.xml.XmlBean
When an XmlBean adds a contained XmlBean, it should invoke this method to relate the contained XmlBean with this XmlBean.
adopt(AbstractSparseArray.Node<V>, boolean) - Method in class com.tangosol.util.AbstractSparseArray.Node
Adopt a child node
advance() - Method in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
Advance to the next character.
advance(String) - Method in class com.tangosol.coherence.dsltools.precedence.OPScanner
Advance to the next token and expect it to match the given string.
advance(String, boolean) - Method in class com.tangosol.coherence.dsltools.precedence.OPScanner
Advance to the next token and expect it to match the given string.
advance() - Method in class com.tangosol.coherence.dsltools.precedence.OPScanner
Advance to the next token.
advance() - Method in class com.tangosol.io.MultiBufferWriteBuffer.MultiBufferOutput
Advance past the end of the current underlying BufferOutput by switching to the BufferOutput of the next underlying WriteBuffer, creating one if necessary.
advance(boolean) - Method in class com.tangosol.io.pof.PofDeltaCompressor.ChangeTracker
Update the tracker to indicate that the most recently scanned region was the same or different.
advance() - Method in class com.tangosol.net.cache.OverflowMap.EntrySet.EntrySetIterator
Advance to the next object.
advance() - Method in class com.tangosol.net.cache.OverflowMap.InternalKeySet.InternalKeySetIterator
Advance to the next object.
advance() - Method in class com.tangosol.net.cache.SimpleOverflowMap.KeyIterator
Advance to the next key.
advance() - Method in class com.tangosol.net.CompositeAddressProvider.AddressIterator
Advance to the next object.
advance() - Method in class com.tangosol.net.partition.AbstractPartitionedIterator
 
advance() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.PartitionedIterator
Advance to the next object.
advance() - Method in class com.tangosol.util.AbstractKeySetBasedMap.KeyIterator
Advance to the next object.
advance() - Method in class com.tangosol.util.SafeHashMap.EntrySet.EntrySetIterator
Advance to the next object.
advance() - Method in class com.tangosol.util.SegmentedHashMap.EntrySet.EntrySetIterator
Advance to the next object in the iteration.
advanceCurrentPage(SerializationPagedCache.WrapperBinaryStore) - Method in class com.tangosol.net.cache.SerializationPagedCache.PagedBinaryStore
Advance the current page, using the passed BinaryStore as the store for the new current page, and returning the oldest active page, if the maximum number of active pages is exceeded by the advancing of the current page.
advancePage() - Method in class com.tangosol.net.cache.SerializationPagedCache
Advance to a new current page, and deactivate the oldest page is the maximum number of active pages has been reached.
advanceTo(int) - Method in class com.tangosol.io.pof.PofBufferReader
Advance through the POF stream until the specified property is found.
advanceTo(int) - Method in class com.tangosol.io.pof.PofBufferReader.UserTypeReader
Advance through the POF stream until the specified property is found.
advanceToStmt(OPScanner) - Method in class com.tangosol.coherence.dslquery.token.SQLExplainOPToken
Advance the scanner past any tokens preceding the statement.
advanceToStmt(OPScanner) - Method in class com.tangosol.coherence.dslquery.token.SQLTraceOPToken
 
advanceWhenMatching(String) - Method in class com.tangosol.coherence.dsltools.precedence.OPScanner
Test to see if the current BaseToken's string matches the given string and advance if true. * The token table's ignoringCase flag is consulted to see if case matters.
after(long, TimeUnit) - Static method in class com.oracle.coherence.common.base.Timeout
Specify a new timeout.
after(long) - Static method in class com.oracle.coherence.common.base.Timeout
Specify a new timeout.
aggregate(String, String) - Method in class com.tangosol.coherence.rest.CacheResource
Perform an aggregating operation against the entries that satisfy the specified criteria.
aggregate(String) - Method in class com.tangosol.coherence.rest.EntrySetResource
Perform an aggregating operation against the entries.
aggregate(UriInfo, String) - Method in class com.tangosol.coherence.rest.NamedQueryResource
Perform an aggregating operation against the entries that belong to the named query.
aggregate(InvocableMap.EntryAggregator<? super K, ? super V, R>) - Method in interface com.tangosol.net.AsyncNamedCache
Perform an aggregating operation asynchronously against all the entries.
aggregate(Collection<? extends K>, InvocableMap.EntryAggregator<? super K, ? super V, R>) - Method in interface com.tangosol.net.AsyncNamedCache
Perform an aggregating operation asynchronously against the entries specified by the passed keys.
aggregate(Filter<?>, InvocableMap.EntryAggregator<? super K, ? super V, R>) - Method in interface com.tangosol.net.AsyncNamedCache
Perform an aggregating operation asynchronously against the set of entries that are selected by the given Filter.
aggregate(Collection<? extends K>, InvocableMap.EntryAggregator<? super K, ? super V_FRONT, R>) - Method in class com.tangosol.net.cache.ContinuousQueryCache
 
aggregate(Filter, InvocableMap.EntryAggregator<? super K, ? super V_FRONT, R>) - Method in class com.tangosol.net.cache.ContinuousQueryCache
 
aggregate(Collection<? extends K>, InvocableMap.EntryAggregator<? super K, ? super V, R>) - Method in class com.tangosol.net.cache.NearCache
Perform an aggregating operation against the entries specified by the passed keys.
aggregate(Filter, InvocableMap.EntryAggregator<? super K, ? super V, R>) - Method in class com.tangosol.net.cache.NearCache
Perform an aggregating operation against the set of entries that are selected by the given Filter.
aggregate(Collection<? extends K>, InvocableMap.EntryAggregator<? super K, ? super V, R>) - Method in class com.tangosol.net.cache.WrapperNamedCache
Perform an aggregating operation against the entries specified by the passed keys.
aggregate(Filter, InvocableMap.EntryAggregator<? super K, ? super V, R>) - Method in class com.tangosol.net.cache.WrapperNamedCache
Perform an aggregating operation against the set of entries that are selected by the given Filter.
aggregate(MBeanAccessor.QueryBuilder.ParsedQuery, String, String, String) - Method in class com.tangosol.net.management.MBeanAccessor
Process the request for MBean attributes.
aggregate(Set<? extends InvocableMap.Entry<? extends K, ? extends V>>) - Method in class com.tangosol.util.aggregator.AbstractAsynchronousAggregator
Not supported.
aggregate(Set) - Method in class com.tangosol.util.aggregator.CompositeAggregator
Process a set of InvocableMap Entry objects using each of the underlying agregators in order to produce an array of aggregated results.
aggregate(Set<? extends InvocableMap.Entry<? extends K, ? extends V>>) - Method in class com.tangosol.util.aggregator.PriorityAggregator
Process a set of InvocableMap.Entry objects in order to produce an aggregated result.
aggregate(Set<? extends InvocableMap.Entry<? extends K, ? extends V>>) - Method in class com.tangosol.util.aggregator.QueryRecorder
Process a set of InvocableMap.Entry objects in order to produce an aggregated result.
aggregate(Collection<? extends TK>, InvocableMap.EntryAggregator<? super TK, ? super TV, R>) - Method in class com.tangosol.util.ConverterCollections.ConverterInvocableMap
Perform an aggregating operation against the entries specified by the passed keys.
aggregate(Filter, InvocableMap.EntryAggregator<? super TK, ? super TV, R>) - Method in class com.tangosol.util.ConverterCollections.ConverterInvocableMap
Perform an aggregating operation against the set of entries that are selected by the given Filter.
aggregate(Collection<? extends TK>, InvocableMap.EntryAggregator<? super TK, ? super TV, R>) - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
Perform an aggregating operation against the entries specified by the passed keys.
aggregate(Filter, InvocableMap.EntryAggregator<? super TK, ? super TV, R>) - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
Perform an aggregating operation against the set of entries that are selected by the given Filter.
aggregate(InvocableMap.EntryAggregator<? super K, ? super V, R>) - Method in interface com.tangosol.util.InvocableMap
Perform an aggregating operation against all the entries.
aggregate(Collection<? extends K>, InvocableMap.EntryAggregator<? super K, ? super V, R>) - Method in interface com.tangosol.util.InvocableMap
Perform an aggregating operation against the entries specified by the passed keys.
aggregate(Filter, InvocableMap.EntryAggregator<? super K, ? super V, R>) - Method in interface com.tangosol.util.InvocableMap
Perform an aggregating operation against the set of entries that are selected by the given Filter.
aggregate(Set<? extends InvocableMap.Entry<? extends K, ? extends V>>) - Method in interface com.tangosol.util.InvocableMap.EntryAggregator
Process a set of InvocableMap.Entry objects in order to produce an aggregated result.
aggregate(Set<? extends InvocableMap.Entry<? extends K, ? extends V>>) - Method in interface com.tangosol.util.InvocableMap.StreamingAggregator
 
AggregateByteSequence(ByteSequence, ByteSequence) - Constructor for class com.tangosol.util.AbstractByteSequence.AggregateByteSequence
Construct an AggregateByteSequence from two ByteSequence objects.
aggregatePartialResults(Collection<P>) - Method in interface com.tangosol.util.InvocableMap.ParallelAwareAggregator.PartialResultAggregator
Deprecated.
Aggregate the results of the parallel aggregations, producing a partial result logically representing the partial aggregation.
aggregateResults(Collection<P>) - Method in interface com.tangosol.util.InvocableMap.ParallelAwareAggregator
Deprecated.
Aggregate the results of the partial aggregations into a final result.
AggregatingCacheStatistics() - Constructor for class com.tangosol.net.partition.PartitionSplittingBackingMap.AggregatingCacheStatistics
 
AGGREGATOR_REQUEST_REGEX - Static variable in class com.tangosol.coherence.rest.util.aggregator.AggregatorRegistry
Regex pattern that defines the aggregator request syntax.
AggregatorConfig - Class in com.tangosol.coherence.rest.config
The AggregatorConfig class encapsulates information related to a Coherence REST EntryAggregator configuration.
AggregatorConfig(String, Class) - Constructor for class com.tangosol.coherence.rest.config.AggregatorConfig
Construct a AggregatorConfig.
AggregatorFactory<K,V,R> - Interface in com.tangosol.coherence.rest.util.aggregator
A factory for aggregators.
AggregatorRegistry - Class in com.tangosol.coherence.rest.util.aggregator
A registry for AggregatorFactory instances.
AggregatorRegistry() - Constructor for class com.tangosol.coherence.rest.util.aggregator.AggregatorRegistry
Construct an AggregatorRegistry.
AggregatorRegistry(Collection<AggregatorConfig>) - Constructor for class com.tangosol.coherence.rest.util.aggregator.AggregatorRegistry
Construct an AggregatorRegistry that includes built-in aggregators in addition to the specified aggregators.
Aggregators - Class in com.tangosol.util
Simple Aggregator DSL.
Aggregators() - Constructor for class com.tangosol.util.Aggregators
 
alias(String, String) - Method in class com.tangosol.coherence.dsltools.precedence.TokenTable
Add a token alias under the given name for a token already installed
ALL - Static variable in class com.tangosol.net.ClusterPermission
All actions.
all(Filter<? super T>...) - Static method in class com.tangosol.util.Filters
Return a composite filter representing logical AND of all specified filters.
ALL_ALLOWED - Static variable in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumRule
A QuorumRule that permits all actions.
ALL_INCLUSIVE - Static variable in interface com.tangosol.util.Streamer
Characteristic value signifying that this Streamer includes all the values from the underlying data set.
AllFilter - Class in com.tangosol.util.filter
Filter which returns the logical "and" of a filter array.
AllFilter() - Constructor for class com.tangosol.util.filter.AllFilter
Default constructor (necessary for the ExternalizableLite interface).
AllFilter(Filter[]) - Constructor for class com.tangosol.util.filter.AllFilter
Construct an "all" filter.
allMatch(DoublePredicate) - Method in interface com.tangosol.util.stream.RemoteDoubleStream
Returns whether all elements of this stream match the provided predicate.
allMatch(Remote.DoublePredicate) - Method in interface com.tangosol.util.stream.RemoteDoubleStream
Returns whether all elements of this stream match the provided predicate.
allMatch(IntPredicate) - Method in interface com.tangosol.util.stream.RemoteIntStream
Returns whether all elements of this stream match the provided predicate.
allMatch(Remote.IntPredicate) - Method in interface com.tangosol.util.stream.RemoteIntStream
Returns whether all elements of this stream match the provided predicate.
allMatch(LongPredicate) - Method in interface com.tangosol.util.stream.RemoteLongStream
Returns whether all elements of this stream match the provided predicate.
allMatch(Remote.LongPredicate) - Method in interface com.tangosol.util.stream.RemoteLongStream
Returns whether all elements of this stream match the provided predicate.
allMatch(Predicate<? super T>) - Method in interface com.tangosol.util.stream.RemoteStream
Returns whether all elements of this stream match the provided predicate.
allMatch(Remote.Predicate<? super T>) - Method in interface com.tangosol.util.stream.RemoteStream
Returns whether all elements of this stream match the provided predicate.
allocate(int) - Method in class com.tangosol.io.ByteArrayWriteBuffer.Allocator
Allocate a new ByteArrayWriteBuffer.
allocate(byte[]) - Method in class com.tangosol.io.journal.FlashJournalRM.BufferPool
Allocate a buffer from the buffer pool.
allocate() - Method in class com.tangosol.io.journal.RamJournalRM.BufferPool
Allocate a WriteBuffer from the buffer pool.
allocate(int) - Method in interface com.tangosol.io.MultiBufferWriteBuffer.WriteBufferPool
Allocate a WriteBuffer for use by the MultiBufferWriteBuffer.
allocate(int) - Method in class com.tangosol.io.nio.BinaryMap.Block
Allocate this free block (or at least a specified number of bytes of this block) as an Entry block.
allocate(int) - Method in class com.tangosol.util.ExternalizableHelper.Stats
Allocate a WriteBuffer for use by the MultiBufferWriteBuffer.
allocateBlock(int) - Method in class com.tangosol.io.nio.BinaryMap
Allocate a free Block object of at least a certain size.
allocateBuffer() - Method in class com.tangosol.io.journal.FlashJournalRM.JournalFile
Allocate a Buffer to use with this JournalFile.
allocateBuffer() - Method in class com.tangosol.io.nio.AbstractBufferManager
Allocate a new buffer, copying old data if there is any.
allocateBuffer() - Method in class com.tangosol.io.nio.DirectBufferManager
Deprecated.
Allocate a new buffer, copying old data if there is any.
allocateBuffer() - Method in class com.tangosol.io.nio.MappedBufferManager
Allocate a new buffer, copying old data if there is any.
allocateSnapshotPartitions(Map<Integer, Object[]>, int) - Static method in class com.tangosol.persistence.ArchiverHelper
Deprecated.
Given a Map of member Id's and the stores each member can see for a given snapshot, allocate the stores evenly as so to allow the archival process to run in parallel across the greatest number of members.
Allocator(int) - Constructor for class com.tangosol.io.ByteArrayWriteBuffer.Allocator
Construct an Allocator for ByteArrayWriteBuffers of a given size.
ALLOW_INCONSISTENCIES - Static variable in interface com.tangosol.util.InvocableMap.StreamingAggregator
A flag specifying that this aggregator may provide entries that are not consistent with the provided Filter.
always() - Static method in class com.tangosol.util.Filters
Return a filter that always evaluates to true.
AlwaysFilter<T> - Class in com.tangosol.util.filter
Filter which always evaluates to true.
AlwaysFilter() - Constructor for class com.tangosol.util.filter.AlwaysFilter
Construct an AlwaysFilter.
AnalysisContext() - Constructor for class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
Default constructor.
analyze(SimpleAssignmentStrategy.AnalysisContext) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
Analyze the distribution using the specified analysis context.
analyzeDistribution(SimpleAssignmentStrategy.AnalysisContext) - Method in class com.tangosol.net.partition.MirroringAssignmentStrategy
Analyze the distribution and suggest the resulting distribution to distribution manager.
analyzeDistribution() - Method in interface com.tangosol.net.partition.PartitionAssignmentStrategy
Analyze the distribution and return the desired time interval before the next distribution analysis.
analyzeDistribution() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
Analyze the distribution and return the desired time interval before the next distribution analysis.
analyzeDistribution(SimpleAssignmentStrategy.AnalysisContext) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
Analyze the distribution and suggest the resulting distribution to distribution manager.
analyzeDistribution() - Method in class com.tangosol.util.NullImplementation.NullPartitionAssignmentStrategy
Analyze the distribution and return the desired time interval before the next distribution analysis.
analyzeOrphans(Map<Member, PartitionSet>) - Method in interface com.tangosol.net.partition.PartitionAssignmentStrategy
Analyze and suggest the assignment of orphaned partitions (partitions without an active primary or backup owner) subject to the specified constraints.
analyzeOrphans(Map<Member, PartitionSet>) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
Analyze and suggest the assignment of orphaned partitions (partitions without an active primary or backup owner) subject to the specified constraints.
analyzeOrphans(Map<Member, PartitionSet>) - Method in class com.tangosol.util.NullImplementation.NullPartitionAssignmentStrategy
Analyze and suggest the assignment of orphaned partitions (partitions without an active primary or backup owner) subject to the specified constraints.
and(Filter) - Method in interface com.tangosol.util.Filter
Return a composed filter that represents a short-circuiting logical AND of this filter and another.
and(Remote.BiPredicate<? super T, ? super U>) - Method in interface com.tangosol.util.function.Remote.BiPredicate
Returns a composed predicate that represents a short-circuiting logical AND of this predicate and another.
and(Remote.DoublePredicate) - Method in interface com.tangosol.util.function.Remote.DoublePredicate
Returns a composed predicate that represents a short-circuiting logical AND of this predicate and another.
and(Remote.IntPredicate) - Method in interface com.tangosol.util.function.Remote.IntPredicate
Returns a composed predicate that represents a short-circuiting logical AND of this predicate and another.
and(Remote.LongPredicate) - Method in interface com.tangosol.util.function.Remote.LongPredicate
Returns a composed predicate that represents a short-circuiting logical AND of this predicate and another.
and(Remote.Predicate<? super T>) - Method in interface com.tangosol.util.function.Remote.Predicate
Returns a composed predicate that represents a short-circuiting logical AND of this predicate and another.
AndFilter - Class in com.tangosol.util.filter
Filter which returns the logical "and" of two other filters.
AndFilter() - Constructor for class com.tangosol.util.filter.AndFilter
Default constructor (necessary for the ExternalizableLite interface).
AndFilter(Filter, Filter) - Constructor for class com.tangosol.util.filter.AndFilter
Construct an "and" filter.
AndOperator - Class in com.tangosol.coherence.dslquery.operator
An operator representing a logical AND (&&).
AndOperator() - Constructor for class com.tangosol.coherence.dslquery.operator.AndOperator
Constructs an AndOperator.
andThen(ValueExtractor<? super E, ? extends V>) - Method in class com.tangosol.util.extractor.ChainedExtractor
 
andThen(Remote.BiConsumer<? super T, ? super U>) - Method in interface com.tangosol.util.function.Remote.BiConsumer
Returns a composed BiConsumer that performs, in sequence, this operation followed by the after operation.
andThen(Remote.Function<? super R, ? extends V>) - Method in interface com.tangosol.util.function.Remote.BiFunction
Returns a composed function that first applies this function to its input, and then applies the after function to the result.
andThen(Remote.Consumer<? super T>) - Method in interface com.tangosol.util.function.Remote.Consumer
Returns a composed Consumer that performs, in sequence, this operation followed by the after operation.
andThen(Remote.DoubleConsumer) - Method in interface com.tangosol.util.function.Remote.DoubleConsumer
Returns a composed DoubleConsumer that performs, in sequence, this operation followed by the after operation.
andThen(Remote.DoubleUnaryOperator) - Method in interface com.tangosol.util.function.Remote.DoubleUnaryOperator
Returns a composed operator that first applies this operator to its input, and then applies the after operator to the result.
andThen(Remote.Function<? super R, ? extends V>) - Method in interface com.tangosol.util.function.Remote.Function
Returns a composed function that first applies this function to its input, and then applies the after function to the result.
andThen(Remote.IntConsumer) - Method in interface com.tangosol.util.function.Remote.IntConsumer
Returns a composed IntConsumer that performs, in sequence, this operation followed by the after operation.
andThen(Remote.IntUnaryOperator) - Method in interface com.tangosol.util.function.Remote.IntUnaryOperator
Returns a composed operator that first applies this operator to its input, and then applies the after operator to the result.
andThen(Remote.LongConsumer) - Method in interface com.tangosol.util.function.Remote.LongConsumer
Returns a composed LongConsumer that performs, in sequence, this operation followed by the after operation.
andThen(Remote.LongUnaryOperator) - Method in interface com.tangosol.util.function.Remote.LongUnaryOperator
Returns a composed operator that first applies this operator to its input, and then applies the after operator to the result.
andThen(MapEventTransformer<K, U, T>) - Method in interface com.tangosol.util.MapEventTransformer
Returns a composed MapEventTransformer that performs, in sequence, this transformation followed by the after transformation.
andThen(ValueExtractor<? super E, ? extends V>) - Method in interface com.tangosol.util.ValueExtractor
Returns a composed extractor that first applies this extractor to its input, and then applies the after extractor to the result.
AnnotatedStandardEmitterMBean - Class in com.tangosol.net.management
AnnotatedStandardEmitterMBean is an extension of a StandardEmitterMBean that uses the Description and Notification annotations to describe the MBean and any attributes, operations and notifications it declares.
AnnotatedStandardEmitterMBean(T, Class<T>) - Constructor for class com.tangosol.net.management.AnnotatedStandardEmitterMBean
Make a DynamicMBean out of the MBean implementation, using the specified mbeanInterface class.
AnnotatedStandardEmitterMBean.SilentEmitter - Class in com.tangosol.net.management
A silent NotificationEmitter implementation for all NotificationEmitter methods except getNotificationInfo().
AnnotatedStandardMBean - Class in com.tangosol.net.management
AnnotatedStandardMBean is an extension of a StandardMBean that uses the Description annotation for describing the attributes, operations and the bean on the designated MBean interface.
AnnotatedStandardMBean(T, Class<T>) - Constructor for class com.tangosol.net.management.AnnotatedStandardMBean
Make a DynamicMBean out of the MBean implementation, using the specified mbeanInterface class.
AnnotatedStandardMBean(T, Class<T>, boolean) - Constructor for class com.tangosol.net.management.AnnotatedStandardMBean
Make a DynamicMBean out of the MBean implementation, using the specified mbeanInterface class.
AnnotationDrivenModel<S extends Enum<S>> - Class in com.tangosol.util.fsm
An AnnotationDrivenModel is a Model created through extracting information defined by Transitions annotation.
AnnotationDrivenModel(Class<S>, Object) - Constructor for class com.tangosol.util.fsm.AnnotationDrivenModel
Constructs an AnnotationDrivenModel based on the specified annotated class.
ANY - Static variable in interface com.tangosol.net.AsyncNamedCache
A trivial consumer.
any(Filter<? super T>...) - Static method in class com.tangosol.util.Filters
Return a composite filter representing logical OR of all specified filters.
AnyEvent - Class in com.tangosol.util
An AnyEvent is an event used when no specific event implementation fits and it is not worth making one.
AnyEvent(Object, Object) - Constructor for class com.tangosol.util.AnyEvent
Construct a new AnyEvent.
AnyFilter - Class in com.tangosol.util.filter
Filter which returns the logical "or" of a filter array.
AnyFilter() - Constructor for class com.tangosol.util.filter.AnyFilter
Default constructor (necessary for the ExternalizableLite interface).
AnyFilter(Filter[]) - Constructor for class com.tangosol.util.filter.AnyFilter
Construct an "any" filter.
AnyListener - Interface in com.tangosol.util
An AnyEvent is an event used when no specific event implementation fits and it is not worth making one.
anyMatch(DoublePredicate) - Method in interface com.tangosol.util.stream.RemoteDoubleStream
Returns whether any elements of this stream match the provided predicate.
anyMatch(Remote.DoublePredicate) - Method in interface com.tangosol.util.stream.RemoteDoubleStream
Returns whether any elements of this stream match the provided predicate.
anyMatch(IntPredicate) - Method in interface com.tangosol.util.stream.RemoteIntStream
Returns whether any elements of this stream match the provided predicate.
anyMatch(Remote.IntPredicate) - Method in interface com.tangosol.util.stream.RemoteIntStream
Returns whether any elements of this stream match the provided predicate.
anyMatch(LongPredicate) - Method in interface com.tangosol.util.stream.RemoteLongStream
Returns whether any elements of this stream match the provided predicate.
anyMatch(Remote.LongPredicate) - Method in interface com.tangosol.util.stream.RemoteLongStream
Returns whether any elements of this stream match the provided predicate.
anyMatch(Predicate<? super T>) - Method in interface com.tangosol.util.stream.RemoteStream
Returns whether any elements of this stream match the provided predicate.
anyMatch(Remote.Predicate<? super T>) - Method in interface com.tangosol.util.stream.RemoteStream
Returns whether any elements of this stream match the provided predicate.
append(StringBuilder, Object[], String) - Method in class com.tangosol.coherence.dslquery.internal.AbstractCoherenceQueryWalker
Append each of the values in the aoObjects array to the StringBuilder appending the specified separator between each value.
appendDefaultSerializerToUserTypes(XmlElement) - Static method in class com.tangosol.io.pof.ConfigurablePofContext
Process <default-serializer> element from the specified xml configuration and append information about the serializer to each <user-type> element within <user-type-list> unless user type already has a serializer specified.
APPLICATION - Static variable in annotation type com.tangosol.net.management.annotation.MetricsScope
The full descriptor value to use for vendor scoped metrics.
ApplicationScopeController() - Constructor for class com.tangosol.coherence.servlet.AbstractHttpSessionCollection.ApplicationScopeController
 
apply(F) - Method in interface com.oracle.coherence.common.base.Converter
 
apply(MBeanServer) - Method in class com.tangosol.net.management.MBeanAccessor.GetAttributes
 
apply(MBeanServer) - Method in class com.tangosol.net.management.MBeanAccessor.Invoke
 
apply(MBeanServer) - Method in class com.tangosol.net.management.MBeanAccessor.SetAttributes
 
apply(ObjectName) - Method in class com.tangosol.net.management.MBeanHelper.QueryExpFilter
 
apply(ServerSocket) - Method in class com.tangosol.net.SocketOptions
Configure the specified socket.
apply(Socket) - Method in class com.tangosol.net.SocketOptions
Configure the specified socket.
apply(DatagramSocket) - Method in class com.tangosol.net.SocketOptions
Configure the specified socket.
apply(MulticastSocket) - Method in class com.tangosol.net.SocketOptions
Configure the specified socket.
apply(SocketOptions, ServerSocket) - Static method in class com.tangosol.net.SocketOptions
Apply the specified options to a socket.
apply(SocketOptions, Socket) - Static method in class com.tangosol.net.SocketOptions
Apply the specified options to a socket.
apply(SocketOptions, DatagramSocket) - Static method in class com.tangosol.net.SocketOptions
Apply the specified options to a socket.
apply(SocketOptions, MulticastSocket) - Method in class com.tangosol.net.SocketOptions
Apply the specified options to a socket.
apply(T) - Method in interface com.tangosol.util.ValueExtractor
 
applyAsDouble(T) - Method in interface com.tangosol.util.ValueExtractor
 
applyAsInt(T) - Method in interface com.tangosol.util.ValueExtractor
 
applyAsLong(T) - Method in interface com.tangosol.util.ValueExtractor
 
applyChanges() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
Apply all the changes that were made to this value and return a binary representation of the new value.
applyChanges() - Method in interface com.tangosol.io.pof.reflect.PofValue
Apply all the changes that were made to this value and return a binary representation of the new value.
applyDelta(ReadBuffer, ReadBuffer) - Method in class com.tangosol.io.BinaryDeltaCompressor
Apply a delta to an old value in order to create a new value.
applyDelta(ReadBuffer, ReadBuffer) - Method in class com.tangosol.io.DecoratedBinaryDeltaCompressor
Apply a delta to an old value in order to create a new value.
applyDelta(ReadBuffer, ReadBuffer) - Method in class com.tangosol.io.DecorationOnlyDeltaCompressor
Apply a delta to an old value in order to create a new value.
applyDelta(ReadBuffer, ReadBuffer) - Method in interface com.tangosol.io.DeltaCompressor
Apply a delta to an old value in order to create a new value.
applyDelta(ReadBuffer, ReadBuffer) - Method in class com.tangosol.util.ExternalizableHelper.FormatAwareCompressor
Apply a delta to an old value in order to create a new value.
applyDelta(ReadBuffer, ReadBuffer) - Method in class com.tangosol.util.NullImplementation.NullDeltaCompressor
Apply a delta to an old value in order to create a new value.
applyFilter(Filter, int, Map, Set, QueryContext, QueryRecord.PartialResult.TraceStep) - Method in class com.tangosol.util.filter.ArrayFilter
Apply the specified IndexAwareFilter to the specified keySet.
applyIndex(Map, Set, QueryContext, QueryRecord.PartialResult.TraceStep) - Method in class com.tangosol.util.filter.AllFilter
Apply the specified IndexAwareFilter to the specified keySet.
applyIndex(Map, Set) - Method in class com.tangosol.util.filter.AlwaysFilter
Filter remaining keys using a Map of available indexes.
applyIndex(Map, Set, QueryContext, QueryRecord.PartialResult.TraceStep) - Method in class com.tangosol.util.filter.AnyFilter
Apply the specified IndexAwareFilter to the specified keySet.
applyIndex(Map, Set) - Method in class com.tangosol.util.filter.ArrayFilter
Filter remaining keys using a Map of available indexes.
applyIndex(Map, Set, QueryContext, QueryRecord.PartialResult.TraceStep) - Method in class com.tangosol.util.filter.ArrayFilter
Apply the specified IndexAwareFilter to the specified keySet.
applyIndex(Map, Set) - Method in class com.tangosol.util.filter.BetweenFilter
Filter remaining keys using a Map of available indexes.
applyIndex(Map, Set) - Method in class com.tangosol.util.filter.ContainsAllFilter
Filter remaining keys using a Map of available indexes.
applyIndex(Map, Set) - Method in class com.tangosol.util.filter.ContainsAnyFilter
Filter remaining keys using a Map of available indexes.
applyIndex(Map, Set) - Method in class com.tangosol.util.filter.ContainsFilter
Filter remaining keys using a Map of available indexes.
applyIndex(Map, Set) - Method in class com.tangosol.util.filter.EqualsFilter
Filter remaining keys using a Map of available indexes.
applyIndex(Map, Set) - Method in class com.tangosol.util.filter.ExtractorFilter
Filter remaining keys using a Map of available indexes.
applyIndex(Map, Set) - Method in class com.tangosol.util.filter.GreaterEqualsFilter
Filter remaining keys using a Map of available indexes.
applyIndex(Map, Set) - Method in class com.tangosol.util.filter.GreaterFilter
Filter remaining keys using a Map of available indexes.
applyIndex(Map<? extends ValueExtractor<? extends V, ?>, ? extends MapIndex<? extends K, ? extends V, ?>>, Set<? extends K>) - Method in interface com.tangosol.util.filter.IndexAwareFilter
Filter remaining keys using a Map of available indexes.
applyIndex(Map, Set) - Method in class com.tangosol.util.filter.InFilter
Filter remaining keys using a Map of available indexes.
applyIndex(Map, Set) - Method in class com.tangosol.util.filter.InKeySetFilter
Filter remaining keys using a Map of available indexes.
applyIndex(Map, Set) - Method in class com.tangosol.util.filter.KeyFilter
Filter remaining keys using a Map of available indexes.
applyIndex(Map, Set) - Method in class com.tangosol.util.filter.LessEqualsFilter
Filter remaining keys using a Map of available indexes.
applyIndex(Map, Set) - Method in class com.tangosol.util.filter.LessFilter
Filter remaining keys using a Map of available indexes.
applyIndex(Map, Set) - Method in class com.tangosol.util.filter.LikeFilter
Filter remaining keys using a Map of available indexes.
applyIndex(Map, Set) - Method in class com.tangosol.util.filter.LimitFilter
Filter remaining keys using a Map of available indexes.
applyIndex(Map, Set) - Method in class com.tangosol.util.filter.NeverFilter
Filter remaining keys using a Map of available indexes.
applyIndex(Map, Set) - Method in class com.tangosol.util.filter.NotEqualsFilter
Filter remaining keys using a Map of available indexes.
applyIndex(Map, Set) - Method in class com.tangosol.util.filter.NotFilter
Filter remaining keys using a Map of available indexes.
applyIndex(Map, Set) - Method in class com.tangosol.util.filter.PresentFilter
Filter remaining keys using a Map of available indexes.
applyIndex(Map, Set) - Method in class com.tangosol.util.filter.PriorityFilter
Filter remaining keys using a Map of available indexes.
applyIndex(Map, Set, QueryContext, QueryRecord.PartialResult.TraceStep) - Method in class com.tangosol.util.filter.XorFilter
Apply the specified IndexAwareFilter to the specified keySet.
ApplyPatch() - Constructor for class com.tangosol.coherence.servlet.WebPluginInstaller.ApplyPatch
Default constructor.
applySortedIndex(Set, SortedMap<Object, Set>) - Method in class com.tangosol.util.filter.BetweenFilter
Called by the BetweenFilter.applyIndex(java.util.Map, java.util.Set) method if the index corresponding to this filter's value extractor is a sorted index.
archive(Snapshot, PersistenceEnvironment<ReadBuffer>) - Method in class com.tangosol.persistence.AbstractSnapshotArchiver
 
archive(Snapshot, PersistenceEnvironment<ReadBuffer>) - Method in interface com.tangosol.persistence.SnapshotArchiver
Archive the specified snapshot.
ARCHIVE_SNAPSHOT - Static variable in class com.tangosol.coherence.dslquery.internal.PersistenceToolsHelper
JMX operation to archive a snapshot
ARCHIVE_SNAPSHOT_BEGIN - Static variable in interface com.tangosol.persistence.PersistenceManagerMBean
Notification type for the start of archiving a snapshot.
ARCHIVE_SNAPSHOT_END - Static variable in interface com.tangosol.persistence.PersistenceManagerMBean
Notification type for the end of archiving a snapshot.
archivedSnapshotExists(String, String) - Method in class com.tangosol.coherence.dslquery.internal.PersistenceToolsHelper
Validate that an archived snapshot exists for a given service.
archiveInternal(Snapshot, PersistenceManager<ReadBuffer>) - Method in class com.tangosol.persistence.AbstractSnapshotArchiver
Internal implementation to Archive the specified snapshot.
archiveInternal(Snapshot, PersistenceManager<ReadBuffer>) - Method in class com.tangosol.persistence.DirectorySnapshotArchiver
 
ArchiverHelper - Class in com.tangosol.persistence
Deprecated.
this API is intended for internal purposes only and will be removed in a future version of Coherence
ArchiverHelper() - Constructor for class com.tangosol.persistence.ArchiverHelper
Deprecated.
 
ArchiverHelper.DirectoryFileFilter - Class in com.tangosol.persistence
Deprecated.
FileFilter implementation that only includes directories.
archiveSnapshot(String) - Method in interface com.tangosol.persistence.PersistenceManagerMBean
Archive the snapshot to a centralized location.
ArchiveSnapshotStatement(String, String) - Constructor for class com.tangosol.coherence.dslquery.statement.persistence.ArchiveSnapshotStatementBuilder.ArchiveSnapshotStatement
Create a new ArchiveSnapshotStatement for the snapshot and service name.
ArchiveSnapshotStatementBuilder - Class in com.tangosol.coherence.dslquery.statement.persistence
An implementation of a StatementBuilder that parses a CohQL term tree to produce an instance of a ArchiveSnapshotStatementBuilder.ArchiveSnapshotStatement.
ArchiveSnapshotStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.statement.persistence.ArchiveSnapshotStatementBuilder
 
ArchiveSnapshotStatementBuilder.ArchiveSnapshotStatement - Class in com.tangosol.coherence.dslquery.statement.persistence
Implementation of the CohQL "ARCHIVE SNAPSHOT" command.
ArrayAdapter - Class in com.tangosol.run.xml
An ArrayAdapter supports properties of Java array types (not including arrays of primitive types).
ArrayAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.ArrayAdapter
Construct a ArrayAdapter.
ArrayCodec(Class<?>) - Constructor for class com.tangosol.io.pof.reflect.Codecs.ArrayCodec
Construct an ArrayCodec.
arrayContains(ValueExtractor<T, E[]>, E) - Static method in class com.tangosol.util.Filters
Return a filter that tests if the extracted array contains the specified value.
arrayContainsAll(ValueExtractor<T, E[]>, Set<? extends E>) - Static method in class com.tangosol.util.Filters
Return a filter that tests if the extracted array contains all of the specified values.
arrayContainsAll(ValueExtractor<T, E[]>, E...) - Static method in class com.tangosol.util.Filters
Return a filter that tests if the extracted array contains all of the specified values.
arrayContainsAny(ValueExtractor<T, E[]>, Set<? extends E>) - Static method in class com.tangosol.util.Filters
Return a filter that tests if the extracted array contains any of the specified values.
arrayContainsAny(ValueExtractor<T, E[]>, E...) - Static method in class com.tangosol.util.Filters
Return a filter that tests if the extracted array contains any of the specified values.
ArrayFilter - Class in com.tangosol.util.filter
Filter which is a logical operator of a filter array.
ArrayFilter() - Constructor for class com.tangosol.util.filter.ArrayFilter
Default constructor (necessary for the ExternalizableLite interface).
ArrayFilter(Filter[]) - Constructor for class com.tangosol.util.filter.ArrayFilter
Construct a logical filter that applies a binary operator to a filter array.
ArrayFilter.WeightedFilter - Class in com.tangosol.util.filter
A thin wrapper around a Filter allowing for sorting the filters according to their effectiveness.
as(Class<C>) - Method in interface com.tangosol.net.NamedCache
Request a specific type of reference to a NamedCache that this NamedCache may additionally implement or support.
asBinary(ReadBuffer) - Static method in class com.tangosol.util.ExternalizableHelper
Return a Binary representing the contents of the specified ReadBuffer, or null if the buffer is null.
asc(String) - Method in class com.tangosol.coherence.rest.util.ComparatorBuilder
Add comparator to this builder.
asc(ValueExtractor) - Method in class com.tangosol.coherence.rest.util.ComparatorBuilder
Add comparator to this builder.
asDoubleStream() - Method in interface com.tangosol.util.stream.RemoteIntStream
Returns a DoubleStream consisting of the elements of this stream, converted to double.
asDoubleStream() - Method in interface com.tangosol.util.stream.RemoteLongStream
Returns a DoubleStream consisting of the elements of this stream, converted to double.
asGraphViz(Model<S>, boolean) - Static method in class com.tangosol.util.fsm.Render
Produces a GraphViz representation of a Model.
asLimitFilter(int) - Method in interface com.tangosol.util.Filter
Return a limit filter based on this filter.
asLongStream() - Method in interface com.tangosol.util.stream.RemoteIntStream
Returns a LongStream consisting of the elements of this stream, converted to long.
assertCacheName(String, ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.AbstractStatement
Test to see whether the given String is a known cache name.
assertEqual(Class, Class) - Static method in class com.tangosol.io.pof.PofBufferWriter
Assert that a class is equal to another class.
assertIdentity(Object, Service) - Method in class com.tangosol.net.security.DefaultIdentityAsserter
Asserts an identity based on a token-based identity assertion.
assertIdentity(Object, Service) - Method in interface com.tangosol.net.security.IdentityAsserter
Asserts an identity based on a token-based identity assertion.
assertIdentity(Object, Service) - Method in class com.tangosol.net.security.JAASIdentityAsserter
Asserts an identity based on a token-based identity assertion.
AssertionException - Exception in com.tangosol.util
An AssertionException is thrown when an assertion fails.
AssertionException() - Constructor for exception com.tangosol.util.AssertionException
Constructs a AssertionException with no detail message.
AssertionException(String) - Constructor for exception com.tangosol.util.AssertionException
Constructs a AssertionException with the specified detail message.
assertNotDisposed() - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
Throws IllegalStateException if this factory has been disposed via invocation of ExtensibleConfigurableCacheFactory.dispose().
assertNotDisposed() - Method in class com.tangosol.net.SimpleServiceMonitor
Throws IllegalStateException if this monitor has been disposed via invocation of SimpleServiceMonitor.dispose().
assertTypeSafety(String, CacheMapping, boolean) - Method in interface com.tangosol.net.cache.TypeAssertion
Asserts the type compatibility of a named cache given the CacheMapping that defines the cache.
assertTypeSafety(String, CacheMapping) - Method in interface com.tangosol.net.cache.TypeAssertion
Asserts the type compatibility of a named cache given the CacheMapping that defines the cache.
assertTypeSafety(String, CacheMapping, boolean) - Method in class com.tangosol.net.cache.TypeAssertion.WithTypesAssertion
Asserts the type compatibility of a named cache given the CacheMapping that defines the cache.
assertTypeSafety(String, TopicMapping) - Method in interface com.tangosol.net.ValueTypeAssertion
Asserts the type compatibility of a topic given the TopicMapping that defines the topic.
assertTypeSafety(String, TopicMapping) - Method in class com.tangosol.net.ValueTypeAssertion.WithValueTypeAssertion
Asserts the type compatibility of a topic given the TopicMapping that defines the topic.
assign(long) - Method in class com.tangosol.util.WrapperConcurrentMap.Lock
Assign the ownership of this Lock to the calling thread.
assignExternalKey(String) - Method in class com.tangosol.coherence.servlet.SplittableHolder
Generate and set the key that will be used to access the binary value for this attribute holder that is in the external cache.
assignStores(Map<Integer, Object[]>, int) - Static method in class com.tangosol.persistence.GUIDHelper
Return a Map containing assignments of member id to stores based on the given constraints.
Associated<T> - Interface in com.oracle.coherence.common.base
The Associated interface facilitates the creation of a very generic equivalence relation between different objects and allows to group them based on the equality of the "association key" object returned by the Associated.getAssociatedKey() method.
associatedWith(K) - Method in interface com.tangosol.util.Filter
Return a key associated filter based on this filter and a specified key.
associateWithClassLoader(ClassLoader[]) - Method in class com.tangosol.application.ContainerAdapter
Associates the application hosted by this ContainerAdapter with specified ClassLoaders.
Associator - Interface in com.oracle.coherence.common.base
The Associator interface facilitates the creation of a very generic equivalence relation between different objects and allows to group them based on the equality of the "association key" object returned by the Associator.getAssociatedKey(java.lang.Object) method.
async() - Method in interface com.tangosol.net.NamedCache
Return an asynchronous wrapper for this NamedCache.
async(AsyncNamedCache.Option...) - Method in interface com.tangosol.net.NamedCache
Return an asynchronous wrapper for this NamedCache.
AsyncBinaryStore - Class in com.tangosol.io
An AsyncBinaryStore is a BinaryStore wrapper that performs the "O" (output) portion of its I/O asynchronously on a daemon thread.
AsyncBinaryStore(BinaryStore) - Constructor for class com.tangosol.io.AsyncBinaryStore
Construct an AsyncBinaryStore.
AsyncBinaryStore(BinaryStore, int) - Constructor for class com.tangosol.io.AsyncBinaryStore
Construct an AsyncBinaryStore.
AsyncBinaryStore.QueueDaemon - Class in com.tangosol.io
A daemon that processes queued writes.
AsyncBinaryStoreManager - Class in com.tangosol.io
An AsyncBinaryStoreManager is a wrapper BinaryStoreManager that creates wrapper AsyncBinaryStore objects.
AsyncBinaryStoreManager(BinaryStoreManager) - Constructor for class com.tangosol.io.AsyncBinaryStoreManager
Construct an AsyncBinaryStoreManager.
AsyncBinaryStoreManager(BinaryStoreManager, int) - Constructor for class com.tangosol.io.AsyncBinaryStoreManager
Construct an AsyncBinaryStoreManager.
asynchronous(InvocableMap.StreamingAggregator<K, V, P, R>) - Static method in class com.tangosol.util.Aggregators
Return an AsynchronousAggregator for a given streaming aggregator.
asynchronous(InvocableMap.StreamingAggregator<K, V, P, R>, int) - Static method in class com.tangosol.util.Aggregators
Return an AsynchronousAggregator for a given streaming aggregator.
asynchronous(InvocableMap.EntryProcessor<K, V, R>) - Static method in class com.tangosol.util.Processors
Construct an asynchronous processor for a given processor.
asynchronous(InvocableMap.EntryProcessor<K, V, R>, int) - Static method in class com.tangosol.util.Processors
Construct an asynchronous processor for a given processor with unit-of-order id.
AsynchronousAgent<T> - Class in com.tangosol.util
Base class for asynchronous operations that provides a simple implementation of the Future interface.
AsynchronousAgent(int) - Constructor for class com.tangosol.util.AsynchronousAgent
Construct the agent.
AsynchronousAggregator<K,V,P,R> - Class in com.tangosol.util.aggregator
A marker EntryAggregator wrapper class that allows for an asynchronous invocation of the underlying aggregator.
AsynchronousAggregator(InvocableMap.StreamingAggregator<K, V, P, R>) - Constructor for class com.tangosol.util.aggregator.AsynchronousAggregator
Construct an AsynchronousAggregator for a given streaming aggregator.
AsynchronousAggregator(InvocableMap.StreamingAggregator<K, V, P, R>, int) - Constructor for class com.tangosol.util.aggregator.AsynchronousAggregator
Construct an AsynchronousAggregator for a given streaming aggregator.
AsynchronousProcessor<K,V,R> - Class in com.tangosol.util.processor
An EntryProcessor wrapper class that allows for an asynchronous invocation of the underlying processor.
AsynchronousProcessor(InvocableMap.EntryProcessor<K, V, R>) - Constructor for class com.tangosol.util.processor.AsynchronousProcessor
Construct an AsynchronousProcessor for a given processor.
AsynchronousProcessor(InvocableMap.EntryProcessor<K, V, R>, int) - Constructor for class com.tangosol.util.processor.AsynchronousProcessor
Construct an AsynchronousProcessor for a given processor.
AsyncNamedCache<K,V> - Interface in com.tangosol.net
Asynchronous NamedCache.
AsyncNamedCache.Option - Interface in com.tangosol.net
An immutable option for creating and configuring AsyncNamedCaches.
AsyncNamedCache.OrderBy - Class in com.tangosol.net
A configuration option which determines the ordering of async operations.
AsyncStoreManagerBuilder - Class in com.tangosol.coherence.config.builder.storemanager
The AsyncStoreManagerBuilder class builds and instance of an AsyncBinaryStoreManager.
AsyncStoreManagerBuilder() - Constructor for class com.tangosol.coherence.config.builder.storemanager.AsyncStoreManagerBuilder
 
atomicStringValueOf(Term) - Static method in class com.tangosol.coherence.dslquery.statement.AbstractStatementBuilder
Return a String that is the value of the given Term.
AtomicTerm - Class in com.tangosol.coherence.dsltools.termtrees
AtomicTerms is the class used to represent literal Terms such as String and Numbers.
AtomicTerm(String, int) - Constructor for class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
Construct a new AtomicTerm with the given parameters.
attributeAdded(ServletContextAttributeEvent) - Method in class com.tangosol.coherence.servlet.api23.ServletContextAttributeListenerImpl
Notification that a new attribute was added to the servlet context.
AttributeHolder - Class in com.tangosol.coherence.servlet
An immutable object to hold attribute values and related information.
AttributeHolder() - Constructor for class com.tangosol.coherence.servlet.AttributeHolder
Default constructor is required for deserialization purposes.
AttributeHolder(AbstractHttpSessionModel) - Constructor for class com.tangosol.coherence.servlet.AttributeHolder
 
AttributeHolder(String, Object, AbstractHttpSessionModel) - Constructor for class com.tangosol.coherence.servlet.AttributeHolder
Construct an AttributeHolder for a value.
AttributeMap() - Constructor for class com.tangosol.run.xml.SimpleElement.AttributeMap
 
AttributeProcessor<T> - Interface in com.tangosol.config.xml
An AttributeProcessor is responsible for processing XmlAttribute content to return a strongly-typed value.
attributeRemoved(ServletContextAttributeEvent) - Method in class com.tangosol.coherence.servlet.api23.ServletContextAttributeListenerImpl
Notification that an existing attribute has been remved from the servlet context.
attributeReplaced(ServletContextAttributeEvent) - Method in class com.tangosol.coherence.servlet.api23.ServletContextAttributeListenerImpl
Notification that an attribute on the servlet context has been replaced.
AuditingAuthorizer - Class in com.tangosol.net.security
Simple StorageAccessAuthorizer implementation that logs the authorization requests and allows operations to proceed.
AuditingAuthorizer() - Constructor for class com.tangosol.net.security.AuditingAuthorizer
Construct a non-strict AuditingAuthorizer.
AuditingAuthorizer(boolean) - Constructor for class com.tangosol.net.security.AuditingAuthorizer
Construct an AuditingAuthorizer.
authorize(Subject, ClusterPermission) - Method in interface com.tangosol.net.security.Authorizer
Authorize the caller to perform the action specified by the permission.
AuthorizedHostsProcessor - Class in com.tangosol.coherence.config.xml.processor
An ElementProcessor for <authorized-hosts> Configuration Elements.
AuthorizedHostsProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.AuthorizedHostsProcessor
 
Authorizer(String) - Constructor for class com.tangosol.coherence.rest.providers.SecurityFilter.Authorizer
 
Authorizer(String, Principal, String) - Constructor for class com.tangosol.coherence.rest.providers.SecurityFilter.Authorizer
 
Authorizer - Interface in com.tangosol.net.security
This interface represents an environment-specific facility for authorizing callers to perform actions described by the corresponding permission objects.
available() - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
Returns the number of bytes that can be read (or skipped over) from this input stream without causing a blocking I/O condition to occur.
available() - Method in class com.tangosol.io.Base64InputStream
Returns the number of bytes that can be read (or skipped over) from this input stream without blocking by the next caller of a method for this input stream.
available() - Method in class com.tangosol.io.MultiByteArrayInputStream
Returns the number of bytes that can be read (or skipped over) from this input stream without blocking by the next caller of a method for this input stream.
available() - Method in class com.tangosol.io.nio.ByteBufferInputStream
Returns the number of bytes that can be read (or skipped over) from this input stream without blocking by the next caller of a method for this input stream.
available() - Method in class com.tangosol.io.nio.ByteBufferReadBuffer.ByteBufferInput
Returns the number of bytes that can be read (or skipped over) from this input stream without causing a blocking I/O condition to occur.
available() - Method in class com.tangosol.io.pof.PofInputStream
Returns the number of bytes that can be read (or skipped over) from this input stream without causing a blocking I/O condition to occur.
available() - Method in interface com.tangosol.io.ReadBuffer.BufferInput
Returns the number of bytes that can be read (or skipped over) from this input stream without causing a blocking I/O condition to occur.
available() - Method in class com.tangosol.io.WrapperDataInputStream
Returns the number of bytes that can be read (or skipped over) from this input stream without causing a blocking I/O condition to occur.
available() - Method in class com.tangosol.io.WrapperInputStream
Returns the number of bytes that can be read (or skipped over) from this input stream without causing a blocking I/O condition to occur.
available() - Method in class com.tangosol.io.WrapperObjectInputStream
Returns the number of bytes that can be read (or skipped over) from this input stream without causing a blocking I/O condition to occur.
average(ValueExtractor<? super T, ? extends Number>) - Static method in class com.tangosol.util.Aggregators
Return an aggregator that calculates a average of the numeric values extracted from a set of entries in a Map.
average(String) - Static method in class com.tangosol.util.Aggregators
Return an aggregator that calculates a average of the numeric values extracted from a set of entries in a Map.
average() - Method in interface com.tangosol.util.stream.RemoteDoubleStream
Returns an OptionalDouble describing the arithmetic mean of elements of this stream, or an empty optional if this stream is empty.
average() - Method in interface com.tangosol.util.stream.RemoteIntStream
Returns an OptionalDouble describing the arithmetic mean of elements of this stream, or an empty optional if this stream is empty.
average() - Method in interface com.tangosol.util.stream.RemoteLongStream
Returns an OptionalDouble describing the arithmetic mean of elements of this stream, or an empty optional if this stream is empty.
averagingDouble(ValueExtractor<? super U, ? extends Number>) - Static method in class com.tangosol.util.stream.RemoteCollectors
Returns a Collector that produces the arithmetic mean of a double-valued function applied to the input elements.
averagingInt(ValueExtractor<? super U, ? extends Number>) - Static method in class com.tangosol.util.stream.RemoteCollectors
Returns a Collector that produces the arithmetic mean of an integer-valued function applied to the input elements.
averagingLong(ValueExtractor<? super U, ? extends Number>) - Static method in class com.tangosol.util.stream.RemoteCollectors
Returns a Collector that produces the arithmetic mean of a long-valued function applied to the input elements.
await(Condition) - Static method in class com.oracle.coherence.common.base.Blocking
Await for the Condition to be signaled while still respecting the calling thread's timeout.
await(Condition, long) - Static method in class com.oracle.coherence.common.base.Blocking
Await for the Condition to be signaled while still respecting the calling thread's timeout.
await(Condition, long, TimeUnit) - Static method in class com.oracle.coherence.common.base.Blocking
Await for the Condition to be signaled while still respecting the calling thread's timeout.
await(long) - Method in class com.oracle.coherence.common.base.ConcurrentNotifier
 
await() - Method in interface com.oracle.coherence.common.base.Notifier
Wait for a notification.
await(long) - Method in interface com.oracle.coherence.common.base.Notifier
Wait for a notification.
await(long) - Method in class com.oracle.coherence.common.base.SingleWaiterCooperativeNotifier
 
await(long) - Method in class com.oracle.coherence.common.base.SingleWaiterMultiNotifier
 
azzert() - Static method in class com.tangosol.util.Base
Definite assertion failure.
azzert(boolean) - Static method in class com.tangosol.util.Base
Test an assertion.
azzert(boolean, String) - Static method in class com.tangosol.util.Base
Test an assertion, and print the specified message if the assertion fails.
azzertFailed(String) - Static method in class com.tangosol.util.Base
Throw an assertion exception.

B

BACKING_MAP - Static variable in class com.tangosol.net.security.LocalPermission
"BackingMapManagerContext.getBackingMap" permission.
BackingMapBinaryEntry - Class in com.tangosol.net.cache
An implementation of the BinaryEntry interface that is based on specified binary key, binary value and BackingMapManagerContext.
BackingMapBinaryEntry(Binary, Binary, Binary, BackingMapManagerContext) - Constructor for class com.tangosol.net.cache.BackingMapBinaryEntry
Construct a BackingMapBinaryEntry with the specified binary key, values and BackingMapManagerContext.
BackingMapBinaryEntry(Binary, Binary, Binary, long, BackingMapManagerContext) - Constructor for class com.tangosol.net.cache.BackingMapBinaryEntry
Construct a BackingMapBinaryEntry with the specified binary key, values and BackingMapManagerContext.
BackingMapContext - Interface in com.tangosol.net
The BackingMapContext provides an execution context to server side agents such as EntryProcessors and EntryAggregators.
BackingMapManager - Interface in com.tangosol.net
A callback interface used by CacheService implementations.
BackingMapManagerBuilder - Interface in com.tangosol.coherence.config.builder
BackingMapManagerContext - Interface in com.tangosol.net
The BackingMapManager context is used by the CacheService to pass information to the BackingMapManager during the service initialization.
BackingMapScheme - Class in com.tangosol.coherence.config.scheme
The BackingMapScheme class is responsible for building a fully configured instance of a backing map.
BackingMapScheme() - Constructor for class com.tangosol.coherence.config.scheme.BackingMapScheme
 
BackingMapSchemeProcessor - Class in com.tangosol.coherence.config.xml.processor
A BackingMapSchemeProcessor is responsible for processing a backing-map-scheme XmlElement to produce a BackingMapScheme.
BackingMapSchemeProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.BackingMapSchemeProcessor
 
BackMapListener() - Constructor for class com.tangosol.net.cache.OverflowMap.BackMapListener
 
BackServiceListener() - Constructor for class com.tangosol.net.cache.NearCache.BackServiceListener
 
BackupConfig() - Constructor for class com.tangosol.coherence.config.scheme.DistributedScheme.BackupConfig
 
BackupJournalRM - Class in com.tangosol.io.journal
The BackupJournalRM is a "meta" journal resource manager that is intended to be used for storage of "backup" data.
BackupJournalRM(RamJournalRM, double) - Constructor for class com.tangosol.io.journal.BackupJournalRM
Construct a BackupJournalRM based on a RamJournalRM.
BackupJournalRM.FlashConsumer - Class in com.tangosol.io.journal
The FlashConsumer is a "dummy" consumer used to obtain a flash journal instance.
BackupJournalRM.JournalImpl - Class in com.tangosol.io.journal
A Journal implementation managed by this Journal Resource Manager.
BackupJournalRM.RamConsumer - Class in com.tangosol.io.journal
The RamConsumer is a pass-through consumer used to obtain a ram journal instance.
BackupMapConfig - Interface in com.tangosol.coherence.config.scheme
The BackupMapConfig interface exposes the configuration needed to create an instance of a backup map, which is used by the distributed cache to store backup data.
BackupStatement(String, String) - Constructor for class com.tangosol.coherence.dslquery.statement.BackupStatementBuilder.BackupStatement
Construct a BackupStatement that backs the specified cache up to the specified file.
BackupStatementBuilder - Class in com.tangosol.coherence.dslquery.statement
An implementation of a StatementBuilder that parses a CohQL term tree to produce an instance of a BackupStatementBuilder.BackupStatement.
BackupStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.statement.BackupStatementBuilder
 
BackupStatementBuilder.BackupStatement - Class in com.tangosol.coherence.dslquery.statement
Implementation of the CohQL "BACKUP" command.
BackupStrength(int, Set, Set, Set) - Constructor for class com.tangosol.net.partition.SimpleAssignmentStrategy.BackupStrength
Construct a BackupStrength of the specified strength.
balance - Variable in class com.tangosol.util.AbstractSparseArray.Node
The AVL balance factor of the sub-tree.
balancedInsertion(AbstractSparseArray.Node<V>, AbstractSparseArray.Node<V>) - Method in class com.tangosol.util.AbstractSparseArray
Insert a node into a tree and rebalance.
balancePostRemove(AbstractSparseArray.Node<V>, boolean) - Method in class com.tangosol.util.AbstractSparseArray
Rebalance the tree following the removal of a node.
Bar(Thread) - Constructor for class com.tangosol.util.ThreadGateLite.Bar
Construct a Bar for the specified thread.
barEntry(long) - Method in class com.tangosol.util.ThreadGateLite
Bar entry to the thread gate by other threads, but do not wait for the gate to close.
barEntry(long) - Method in class com.tangosol.util.WrapperReentrantGate
Bar entry to the thread gate by other threads, but do not wait for the gate to close.
BASE - Static variable in annotation type com.tangosol.net.management.annotation.MetricsScope
The full descriptor value to use for base scoped metrics.
Base - Class in com.tangosol.util
Base class for providing standard functionality.
Base() - Constructor for class com.tangosol.util.Base
 
Base.LoggingWriter - Class in com.tangosol.util
Inner class for over-riding the destination of log(), out() and err() calls.
Base.StackFrame - Class in com.tangosol.util
A class that provides "stack frame" information from a line of a stack trace.
BASE64_ALPHABET - Static variable in class com.tangosol.io.Base64OutputStream
Base64 encodes into this "alphabet" of 64 characters.
BASE64_LF - Static variable in class com.tangosol.io.Base64OutputStream
The Base64 line feed character.
BASE64_PAD - Static variable in class com.tangosol.io.Base64OutputStream
The Base64 padding character.
Base64InputStream - Class in com.tangosol.io
Reads binary data from a Reader using IETF RFC 2045 Base64 Content Transfer Encoding.
Base64InputStream(Reader) - Constructor for class com.tangosol.io.Base64InputStream
Construct a Base64InputStream on a Reader object.
Base64OutputStream - Class in com.tangosol.io
Writes binary data into a Writer using IETF RFC 2045 Base64 Content Transfer Encoding.
Base64OutputStream(Writer) - Constructor for class com.tangosol.io.Base64OutputStream
Construct a Base64OutputStream on a Writer object.
Base64OutputStream(Writer, boolean) - Constructor for class com.tangosol.io.Base64OutputStream
Construct a Base64OutputStream on a Writer object and specifying a line-break option.
BaseOperator<F extends Filter> - Class in com.tangosol.coherence.dslquery.operator
A base class for CohQL Operator implementations.
BaseOperator(String, boolean, String...) - Constructor for class com.tangosol.coherence.dslquery.operator.BaseOperator
Create an instance of a BaseOperator with the specified symbol, conditional flag and aliases.
BaseRemoteStream<T,S extends BaseStream<T,S>> - Interface in com.tangosol.util.stream
An extension of BaseStream that adds support for the RemotePipeline retrieval.
BaseToken - Class in com.tangosol.coherence.dsltools.base
BaseToken is the abstract base class for all tokens processed by the low level BaseTokenScanner.
BaseToken() - Constructor for class com.tangosol.coherence.dsltools.base.BaseToken
 
BaseTokenScanner - Class in com.tangosol.coherence.dsltools.base
BaseTokenScanner gives clients a streaming api that returns a next BaseToken by processing either a java.lang.String or a java.io.Reader.
BaseTokenScanner(String) - Constructor for class com.tangosol.coherence.dsltools.base.BaseTokenScanner
Construct a new BaseTokenScanner with the given String.
BaseTokenScanner(Reader) - Constructor for class com.tangosol.coherence.dsltools.base.BaseTokenScanner
Construct a new BaseTokenScanner with the given Reader.
BaseTokenScannerException - Exception in com.tangosol.coherence.dsltools.base
BaseTokenScannerExpression is the RuntimeException thrown by the BaseTokenScanner when expectations are not met.
BaseTokenScannerException(String) - Constructor for exception com.tangosol.coherence.dsltools.base.BaseTokenScannerException
Construct a new BaseTokenException with the given string.
BaseTokenScannerException() - Constructor for exception com.tangosol.coherence.dsltools.base.BaseTokenScannerException
Construct a new BaseTokenException.
BaseTokenStream - Class in com.tangosol.coherence.dsltools.base
Since BaseTokens can nest, BaseTokenStream creates for clients a utility interface that allows streaming (atEnd(), next()) over a CompoundBaseToken.
BaseTokenStream(CompoundBaseToken) - Constructor for class com.tangosol.coherence.dsltools.base.BaseTokenStream
Constructor a new BaseTokenStream on the CompoundBaseToken.
BatchTask(Object, Collector<Object>, Object) - Constructor for class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore.BatchTask
Create a new BatchTask.
BdbStoreManagerBuilder - Class in com.tangosol.coherence.config.builder.storemanager
The BdbStoreManagerBuilder class builds an instance of a BerkeleyDBBinaryStoreManager.
BdbStoreManagerBuilder() - Constructor for class com.tangosol.coherence.config.builder.storemanager.BdbStoreManagerBuilder
 
BEAN_ACCESSOR_PREFIXES - Static variable in class com.tangosol.util.extractor.UniversalExtractor
JavaBean accessor prefixes.
BEAN_MODIFIER_PREFIX - Static variable in class com.tangosol.util.extractor.UniversalUpdater
JavaBean property modifier prefix.
BeanInfo(Class, XmlElement) - Constructor for class com.tangosol.run.xml.XmlBean.BeanInfo
Construct a BeanInfo.
begin(int, String) - Method in class com.tangosol.io.pof.LoggingPofHandler
Begin a complex data structure, such as a user type or a collection.
begin() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
Begin a new sequence of mutating operations that should be committed to the store as an atomic unit.
begin(Collector<Object>, Object) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
Begin a new sequence of mutating operations that should be committed to the store asynchronously as an atomic unit.
begin() - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistentStore
Begin a new sequence of mutating operations that should be committed to the store as an atomic unit.
begin(Collector<Object>, Object) - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistentStore
Begin a new sequence of mutating operations that should be committed to the store asynchronously as an atomic unit.
begin() - Method in class com.tangosol.util.NullImplementation.NullPersistentStore
 
begin(Collector<Object>, Object) - Method in class com.tangosol.util.NullImplementation.NullPersistentStore
 
begin() - Method in interface com.tangosol.util.TransactionMap
Start a transaction for this TransactionMap.
beginArray(int, int) - Method in class com.tangosol.io.pof.AbstractPofHandler
Report that an array of values has been encountered in the POF stream.
beginArray(int, int) - Method in class com.tangosol.io.pof.DuplexingPofHandler
Report that an array of values has been encountered in the POF stream.
beginArray(int, int) - Method in class com.tangosol.io.pof.LoggingPofHandler
Report that an array of values has been encountered in the POF stream.
beginArray(int, int) - Method in interface com.tangosol.io.pof.PofHandler
Report that an array of values has been encountered in the POF stream.
beginArray(int, int) - Method in class com.tangosol.io.pof.ValidatingPofHandler
Report that an array of values has been encountered in the POF stream.
beginArray(int, int) - Method in class com.tangosol.io.pof.WritingPofHandler
Report that an array of values has been encountered in the POF stream.
beginArray(int, int) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
Report that an array of values has been encountered in the POF stream.
beginBulkKeyProcess(Object[]) - Method in class com.tangosol.net.cache.SimpleOverflowMap
Begin key-level procecessing for any number of keys.
beginCollection(int, int) - Method in class com.tangosol.io.pof.AbstractPofHandler
Report that a collection of values has been encountered in the POF stream.
beginCollection(int, int) - Method in class com.tangosol.io.pof.DuplexingPofHandler
Report that a collection of values has been encountered in the POF stream.
beginCollection(int, int) - Method in class com.tangosol.io.pof.LoggingPofHandler
Report that a collection of values has been encountered in the POF stream.
beginCollection(int, int) - Method in interface com.tangosol.io.pof.PofHandler
Report that a collection of values has been encountered in the POF stream.
beginCollection(int, int) - Method in class com.tangosol.io.pof.ValidatingPofHandler
Report that a collection of values has been encountered in the POF stream.
beginCollection(int, int) - Method in class com.tangosol.io.pof.WritingPofHandler
Report that a collection of values has been encountered in the POF stream.
beginCollection(int, int) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
Report that a collection of values has been encountered in the POF stream.
beginInternal() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
Begin a sequence of mutating operations that should be committed atomically and return a token that represents the atomic unit.
beginKeyProcess(Object) - Method in class com.tangosol.net.cache.OverflowMap
Block until a key is available for processing, and return the Status object for that key.
beginKeyProcess(Object) - Method in class com.tangosol.net.cache.SimpleOverflowMap
Block until a key is available for processing, and return the Status object for that key.
beginMap(int, int) - Method in class com.tangosol.io.pof.AbstractPofHandler
Report that a map of key/value pairs has been encountered in the POF stream.
beginMap(int, int) - Method in class com.tangosol.io.pof.DuplexingPofHandler
Report that a map of key/value pairs has been encountered in the POF stream.
beginMap(int, int) - Method in class com.tangosol.io.pof.LoggingPofHandler
Report that a map of key/value pairs has been encountered in the POF stream.
beginMap(int, int) - Method in interface com.tangosol.io.pof.PofHandler
Report that a map of key/value pairs has been encountered in the POF stream.
beginMap(int, int) - Method in class com.tangosol.io.pof.ValidatingPofHandler
Report that a map of key/value pairs has been encountered in the POF stream.
beginMap(int, int) - Method in class com.tangosol.io.pof.WritingPofHandler
Report that a map of key/value pairs has been encountered in the POF stream.
beginMap(int, int) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
Report that a map of key/value pairs has been encountered in the POF stream.
beginMapProcess() - Method in class com.tangosol.net.cache.OverflowMap
Block until this thread has exclusive access to perform operations against the OverflowMap.
beginMapProcess() - Method in class com.tangosol.net.cache.SimpleOverflowMap
Block until this thread has exclusive access to perform operations against the OverflowMap.
beginProperty(int) - Method in class com.tangosol.io.pof.PofBufferWriter
Report that a POF property is about to be written to the POF stream.
beginProperty(int) - Method in class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
Report that a POF property is about to be written to the POF stream.
beginSparseArray(int, int) - Method in class com.tangosol.io.pof.AbstractPofHandler
Report that a sparse array of values has been encountered in the POF stream.
beginSparseArray(int, int) - Method in class com.tangosol.io.pof.DuplexingPofHandler
Report that a sparse array of values has been encountered in the POF stream.
beginSparseArray(int, int) - Method in class com.tangosol.io.pof.LoggingPofHandler
Report that a sparse array of values has been encountered in the POF stream.
beginSparseArray(int, int) - Method in interface com.tangosol.io.pof.PofHandler
Report that a sparse array of values has been encountered in the POF stream.
beginSparseArray(int, int) - Method in class com.tangosol.io.pof.ValidatingPofHandler
Report that a sparse array of values has been encountered in the POF stream.
beginSparseArray(int, int) - Method in class com.tangosol.io.pof.WritingPofHandler
Report that a sparse array of values has been encountered in the POF stream.
beginSparseArray(int, int) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
Report that a sparse array of values has been encountered in the POF stream.
beginUniformArray(int, int, int) - Method in class com.tangosol.io.pof.AbstractPofHandler
Report that a uniform array of values has been encountered in the POF stream.
beginUniformArray(int, int, int) - Method in class com.tangosol.io.pof.DuplexingPofHandler
Report that a uniform array of values has been encountered in the POF stream.
beginUniformArray(int, int, int) - Method in class com.tangosol.io.pof.LoggingPofHandler
Report that a uniform array of values has been encountered in the POF stream.
beginUniformArray(int, int, int) - Method in interface com.tangosol.io.pof.PofHandler
Report that a uniform array of values has been encountered in the POF stream.
beginUniformArray(int, int, int) - Method in class com.tangosol.io.pof.ValidatingPofHandler
Report that a uniform array of values has been encountered in the POF stream.
beginUniformArray(int, int, int) - Method in class com.tangosol.io.pof.WritingPofHandler
Report that a uniform array of values has been encountered in the POF stream.
beginUniformArray(int, int, int) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
Report that a uniform array of values has been encountered in the POF stream.
beginUniformCollection(int, int, int) - Method in class com.tangosol.io.pof.AbstractPofHandler
Report that a uniform collection of values has been encountered in the POF stream.
beginUniformCollection(int, int, int) - Method in class com.tangosol.io.pof.DuplexingPofHandler
Report that a uniform collection of values has been encountered in the POF stream.
beginUniformCollection(int, int, int) - Method in class com.tangosol.io.pof.LoggingPofHandler
Report that a uniform collection of values has been encountered in the POF stream.
beginUniformCollection(int, int, int) - Method in interface com.tangosol.io.pof.PofHandler
Report that a uniform collection of values has been encountered in the POF stream.
beginUniformCollection(int, int, int) - Method in class com.tangosol.io.pof.ValidatingPofHandler
Report that a uniform collection of values has been encountered in the POF stream.
beginUniformCollection(int, int, int) - Method in class com.tangosol.io.pof.WritingPofHandler
Report that a uniform collection of values has been encountered in the POF stream.
beginUniformCollection(int, int, int) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
Report that a uniform collection of values has been encountered in the POF stream.
beginUniformKeysMap(int, int, int) - Method in class com.tangosol.io.pof.AbstractPofHandler
Report that a map of key/value pairs (with the keys being of a uniform type) has been encountered in the POF stream.
beginUniformKeysMap(int, int, int) - Method in class com.tangosol.io.pof.DuplexingPofHandler
Report that a map of key/value pairs (with the keys being of a uniform type) has been encountered in the POF stream.
beginUniformKeysMap(int, int, int) - Method in class com.tangosol.io.pof.LoggingPofHandler
Report that a map of key/value pairs (with the keys being of a uniform type) has been encountered in the POF stream.
beginUniformKeysMap(int, int, int) - Method in interface com.tangosol.io.pof.PofHandler
Report that a map of key/value pairs (with the keys being of a uniform type) has been encountered in the POF stream.
beginUniformKeysMap(int, int, int) - Method in class com.tangosol.io.pof.ValidatingPofHandler
Report that a map of key/value pairs (with the keys being of a uniform type) has been encountered in the POF stream.
beginUniformKeysMap(int, int, int) - Method in class com.tangosol.io.pof.WritingPofHandler
Report that a map of key/value pairs (with the keys being of a uniform type) has been encountered in the POF stream.
beginUniformKeysMap(int, int, int) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
Report that a map of key/value pairs (with the keys being of a uniform type) has been encountered in the POF stream.
beginUniformMap(int, int, int, int) - Method in class com.tangosol.io.pof.AbstractPofHandler
Report that a map of key/value pairs (with the keys being of a uniform type and the values being of a uniform type) has been encountered in the POF stream.
beginUniformMap(int, int, int, int) - Method in class com.tangosol.io.pof.DuplexingPofHandler
Report that a map of key/value pairs (with the keys being of a uniform type and the values being of a uniform type) has been encountered in the POF stream.
beginUniformMap(int, int, int, int) - Method in class com.tangosol.io.pof.LoggingPofHandler
Report that a map of key/value pairs (with the keys being of a uniform type and the values being of a uniform type) has been encountered in the POF stream.
beginUniformMap(int, int, int, int) - Method in interface com.tangosol.io.pof.PofHandler
Report that a map of key/value pairs (with the keys being of a uniform type and the values being of a uniform type) has been encountered in the POF stream.
beginUniformMap(int, int, int, int) - Method in class com.tangosol.io.pof.ValidatingPofHandler
Report that a map of key/value pairs (with the keys being of a uniform type and the values being of a uniform type) has been encountered in the POF stream.
beginUniformMap(int, int, int, int) - Method in class com.tangosol.io.pof.WritingPofHandler
Report that a map of key/value pairs (with the keys being of a uniform type and the values being of a uniform type) has been encountered in the POF stream.
beginUniformMap(int, int, int, int) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
Report that a map of key/value pairs (with the keys being of a uniform type and the values being of a uniform type) has been encountered in the POF stream.
beginUniformSparseArray(int, int, int) - Method in class com.tangosol.io.pof.AbstractPofHandler
Report that a uniform sparse array of values has been encountered in the POF stream.
beginUniformSparseArray(int, int, int) - Method in class com.tangosol.io.pof.DuplexingPofHandler
Report that a uniform sparse array of values has been encountered in the POF stream.
beginUniformSparseArray(int, int, int) - Method in class com.tangosol.io.pof.LoggingPofHandler
Report that a uniform sparse array of values has been encountered in the POF stream.
beginUniformSparseArray(int, int, int) - Method in interface com.tangosol.io.pof.PofHandler
Report that a uniform sparse array of values has been encountered in the POF stream.
beginUniformSparseArray(int, int, int) - Method in class com.tangosol.io.pof.ValidatingPofHandler
Report that a uniform sparse array of values has been encountered in the POF stream.
beginUniformSparseArray(int, int, int) - Method in class com.tangosol.io.pof.WritingPofHandler
Report that a uniform sparse array of values has been encountered in the POF stream.
beginUniformSparseArray(int, int, int) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
Report that a uniform sparse array of values has been encountered in the POF stream.
beginUserType(int, int, int) - Method in class com.tangosol.io.pof.AbstractPofHandler
Report that a value of a "user type" has been encountered in the POF stream.
beginUserType(int, int, int) - Method in class com.tangosol.io.pof.DuplexingPofHandler
Report that a value of a "user type" has been encountered in the POF stream.
beginUserType(int, int, int) - Method in class com.tangosol.io.pof.LoggingPofHandler
Report that a value of a "user type" has been encountered in the POF stream.
beginUserType(int, int, int) - Method in interface com.tangosol.io.pof.PofHandler
Report that a value of a "user type" has been encountered in the POF stream.
beginUserType(int, int, int) - Method in class com.tangosol.io.pof.ValidatingPofHandler
Report that a value of a "user type" has been encountered in the POF stream.
beginUserType(int, int, int) - Method in class com.tangosol.io.pof.WritingPofHandler
Report that a value of a "user type" has been encountered in the POF stream.
beginUserType(int, int, int, int) - Method in class com.tangosol.io.pof.WritingPofHandler
Report that a value of a "user type" has been encountered in the POF stream.
beginUserType(int, int, int) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
Report that a value of a "user type" has been encountered in the POF stream.
BerkeleyDBBinaryStore - Class in com.tangosol.io.bdb
An implementation of the BinaryStore interface using Sleepycat Berkeley DB Java Edition.
BerkeleyDBBinaryStore(String, DatabaseFactory) - Constructor for class com.tangosol.io.bdb.BerkeleyDBBinaryStore
Create a new Berkeley DB BinaryStore using the supplied DatabaseFactory.
BerkeleyDBBinaryStore.DatabaseHolder - Class in com.tangosol.io.bdb
The DatabaseHolder class is used as a wrapper around a Berkeley DB Database object.
BerkeleyDBBinaryStoreManager - Class in com.tangosol.io.bdb
An implementation of the BinaryStoreManager interface using Sleepycat Berkeley DB Java Edition.
BerkeleyDBBinaryStoreManager() - Constructor for class com.tangosol.io.bdb.BerkeleyDBBinaryStoreManager
Default constructor.
BerkeleyDBBinaryStoreManager(File, String) - Constructor for class com.tangosol.io.bdb.BerkeleyDBBinaryStoreManager
Construct a Berkeley DB BinaryStoreManager for the specified directory.
between(ValueExtractor<T, ? extends E>, E, E) - Static method in class com.tangosol.util.Filters
Return a filter that tests if the extracted value is between the specified values (inclusive).
BetweenFilter<T,E extends Comparable<? super E>> - Class in com.tangosol.util.filter
Filter which compares the result of a method invocation with a value for "Between" condition.
BetweenFilter() - Constructor for class com.tangosol.util.filter.BetweenFilter
Default constructor (necessary for serialization).
BetweenFilter(ValueExtractor<? super T, ? extends E>, E, E) - Constructor for class com.tangosol.util.filter.BetweenFilter
Construct a BetweenFilter for testing "Between" condition.
BetweenFilter(String, E, E) - Constructor for class com.tangosol.util.filter.BetweenFilter
Construct a BetweenFilter for testing "Between" condition.
BetweenFilter(String, E, E, boolean, boolean) - Constructor for class com.tangosol.util.filter.BetweenFilter
Construct a BetweenFilter for testing "Between" condition.
BetweenFilter(ValueExtractor<? super T, ? extends E>, E, E, boolean, boolean) - Constructor for class com.tangosol.util.filter.BetweenFilter
Construct a BetweenFilter for testing "Between" condition.
BetweenOperator - Class in com.tangosol.coherence.dslquery.operator
An operator representing the "between" conditional operator.
BetweenOperator() - Constructor for class com.tangosol.coherence.dslquery.operator.BetweenOperator
Construct a BetweenOperator.
BetweenOPToken - Class in com.tangosol.coherence.dsltools.precedence
BetweenOPToken is used to parse a SQl like between statment.
BetweenOPToken(String, int) - Constructor for class com.tangosol.coherence.dsltools.precedence.BetweenOPToken
Construct a new BetweenOPToken with the given parameters.
BetweenOPToken(String, int, String) - Constructor for class com.tangosol.coherence.dsltools.precedence.BetweenOPToken
Construct a new BetweenOPToken with the given parameters.
biConsumer(Remote.BiConsumer<T, U>) - Static method in class com.tangosol.util.function.Remote
Capture serializable BiConsumer.
biFunction(Remote.BiFunction<T, U, R>) - Static method in class com.tangosol.util.function.Remote
Capture serializable BiFunction.
BIG_DECIMAL_AVERAGE_FUNCTION_BUILDER - Static variable in class com.tangosol.coherence.dslquery.function.FunctionBuilders
This builder will realize instances of the BigDecimalAverage aggregator.
BIG_DECIMAL_MAX_FUNCTION_BUILDER - Static variable in class com.tangosol.coherence.dslquery.function.FunctionBuilders
This builder will realize instances of the BigDecimalMax aggregator.
BIG_DECIMAL_MIN_FUNCTION_BUILDER - Static variable in class com.tangosol.coherence.dslquery.function.FunctionBuilders
This builder will realize instances of the BigDecimalMin aggregator.
BIG_DECIMAL_SUM_FUNCTION_BUILDER - Static variable in class com.tangosol.coherence.dslquery.function.FunctionBuilders
This builder will realize instances of the BigDecimalSum aggregator.
BIGDECIMAL_ZERO - Static variable in class com.tangosol.io.pof.PofHelper
The default BigDecimal value.
BigDecimalAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.SimpleAdapter.BigDecimalAdapter
Construct a SimpleAdapter.
BigDecimalAverage<T> - Class in com.tangosol.util.aggregator
Calculates an average for values of any numeric type extracted from a set of entries in a Map in a form of a BigDecimal value.
BigDecimalAverage() - Constructor for class com.tangosol.util.aggregator.BigDecimalAverage
Default constructor (necessary for the ExternalizableLite interface).
BigDecimalAverage(ValueExtractor<? super T, ? extends Number>) - Constructor for class com.tangosol.util.aggregator.BigDecimalAverage
Construct a BigDecimalAverage aggregator.
BigDecimalAverage(String) - Constructor for class com.tangosol.util.aggregator.BigDecimalAverage
Construct an BigDecimalAverage object.
bigDecimalAverage(ValueExtractor<? super T, ? extends Number>) - Static method in class com.tangosol.util.Aggregators
Return an aggregator that calculates a average of the numeric values extracted from a set of entries in a Map.
bigDecimalAverage(String) - Static method in class com.tangosol.util.Aggregators
Return an aggregator that calculates a average of the numeric values extracted from a set of entries in a Map.
BigDecimalMax<T> - Class in com.tangosol.util.aggregator
Calculates a maximum of numeric values extracted from a set of entries in a Map in a form of a BigDecimal value.
BigDecimalMax() - Constructor for class com.tangosol.util.aggregator.BigDecimalMax
Default constructor (necessary for the ExternalizableLite interface).
BigDecimalMax(ValueExtractor<? super T, ? extends Number>) - Constructor for class com.tangosol.util.aggregator.BigDecimalMax
Construct a BigDecimalMax aggregator.
BigDecimalMax(String) - Constructor for class com.tangosol.util.aggregator.BigDecimalMax
Construct a BigDecimalMax aggregator.
bigDecimalMax(ValueExtractor<? super T, ? extends Number>) - Static method in class com.tangosol.util.Aggregators
Return an aggregator that calculates a maximum of the numeric values extracted from a set of entries in a Map.
bigDecimalMax(String) - Static method in class com.tangosol.util.Aggregators
Return an aggregator that calculates a maximum of the numeric values extracted from a set of entries in a Map.
BigDecimalMin<T> - Class in com.tangosol.util.aggregator
Calculates a minimum of numeric values extracted from a set of entries in a Map in a form of a BigDecimal value.
BigDecimalMin() - Constructor for class com.tangosol.util.aggregator.BigDecimalMin
Default constructor (necessary for the ExternalizableLite interface).
BigDecimalMin(ValueExtractor<? super T, ? extends Number>) - Constructor for class com.tangosol.util.aggregator.BigDecimalMin
Construct a BigDecimalMin aggregator.
BigDecimalMin(String) - Constructor for class com.tangosol.util.aggregator.BigDecimalMin
Construct a BigDecimalMin aggregator.
bigDecimalMin(ValueExtractor<? super T, ? extends Number>) - Static method in class com.tangosol.util.Aggregators
Return an aggregator that calculates a minimum of the numeric values extracted from a set of entries in a Map.
bigDecimalMin(String) - Static method in class com.tangosol.util.Aggregators
Return an aggregator that calculates a minimum of the numeric values extracted from a set of entries in a Map.
BigDecimalSum<T> - Class in com.tangosol.util.aggregator
Calculates an sum for values of any numberic type extracted from a set of entries in a Map in a form of a BigDecimal value.
BigDecimalSum() - Constructor for class com.tangosol.util.aggregator.BigDecimalSum
Default constructor (necessary for the ExternalizableLite interface).
BigDecimalSum(ValueExtractor<? super T, ? extends Number>) - Constructor for class com.tangosol.util.aggregator.BigDecimalSum
Construct a BigDecimalSum aggregator.
BigDecimalSum(String) - Constructor for class com.tangosol.util.aggregator.BigDecimalSum
Construct an BigDecimalSum object.
bigDecimalSum(ValueExtractor<? super T, ? extends Number>) - Static method in class com.tangosol.util.Aggregators
Return an aggregator that calculates a sum of the numeric values extracted from a set of entries in a Map.
bigDecimalSum(String) - Static method in class com.tangosol.util.Aggregators
Return an aggregator that calculates a sum of the numeric values extracted from a set of entries in a Map.
BIGGEST_MODULO - Static variable in class com.tangosol.util.SafeHashMap
Biggest possible modulo.
BIGGEST_MODULO - Static variable in class com.tangosol.util.SegmentedHashMap
Biggest possible modulo.
BIGINTEGER_MAX_LONG - Static variable in class com.tangosol.io.pof.PofHelper
The BigInteger representation of Long.MAX_VALUE.
BIGINTEGER_MIN_LONG - Static variable in class com.tangosol.io.pof.PofHelper
The BigInteger representation of Long.MIN_VALUE.
BigIntegerAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.SimpleAdapter.BigIntegerAdapter
Construct a SimpleAdapter.
bin(String) - Static method in class com.tangosol.io.nio.BinaryMap
Internal debugging support: Turn a String into a Binary.
BIN_DECO_ONLY - Static variable in class com.tangosol.io.DecorationOnlyDeltaCompressor
A place-holder Binary value used by the compressor to indicate a decoration-only update.
BIN_STORE_PENDING - Static variable in class com.tangosol.net.cache.ReadWriteBackingMap
The binary form of the decoration indicating that the CacheStore on the primary member has not yet written the value.
Binary - Class in com.tangosol.util
A thread-safe immutable binary object.
Binary() - Constructor for class com.tangosol.util.Binary
Default constructor for a binary object.
Binary(byte[]) - Constructor for class com.tangosol.util.Binary
Construct a binary object from a byte array.
Binary(byte[], int, int) - Constructor for class com.tangosol.util.Binary
Construct a binary object from a portion of a byte array.
Binary(Binary) - Constructor for class com.tangosol.util.Binary
Construct a Binary object from a Binary object.
Binary(ByteArrayOutputStream) - Constructor for class com.tangosol.util.Binary
Construct a Binary object from the contents of a ByteArrayOutputStream.
Binary(DataInput) - Constructor for class com.tangosol.util.Binary
Construct a binary object from a DataInput interface.
BINARY_EMPTY - Static variable in class com.tangosol.io.pof.PofHelper
An empty Binary value.
BINARY_OPERATOR_NODE - Static variable in class com.tangosol.coherence.dsltools.precedence.OPToken
The AST node name for a Binary Operator node.
BinaryDeltaCompressor - Class in com.tangosol.io
A DeltaCompressor implementation that works with opaque (binary) values.
BinaryDeltaCompressor() - Constructor for class com.tangosol.io.BinaryDeltaCompressor
Default constructor.
BinaryEntry<K,V> - Interface in com.tangosol.util
Map.Entry that internally stores both key and value in a Binary format and uses an underlying Serializer to convert it to and from an Object view.
BinaryEntryStore<K,V> - Interface in com.tangosol.net.cache
BinaryEntryStore is analogous to the CacheStore, but operates on BinaryEntry objects.
BinaryEntryStoreWrapper(BinaryEntryStore) - Constructor for class com.tangosol.net.cache.ReadWriteBackingMap.BinaryEntryStoreWrapper
Construct a BinaryEntryStoreWrapper.
BinaryLongMap - Interface in com.tangosol.util
A BinaryLongMap is an interface representing a mapping from Binary values to long values.
BinaryLongMap.Entry - Interface in com.tangosol.util
Represents an Entry stored in a BinaryLongMap.
BinaryLongMap.EntryVisitor - Interface in com.tangosol.util
Represent a visitor to be applied to one or more entries in the BinaryLongMap.
BinaryLongMap.SimpleMapImpl - Class in com.tangosol.util
A java.util.Map<Binary, Long> implementation.
BinaryMap - Class in com.tangosol.io.nio
Implements the Map interface to store Binary objects using Java's NIO buffers.
BinaryMap(ByteBuffer) - Constructor for class com.tangosol.io.nio.BinaryMap
Construct a BinaryMap on a specific buffer with the default modulo growth and shrinkage (load factor) settings.
BinaryMap(ByteBuffer, double, double, boolean) - Constructor for class com.tangosol.io.nio.BinaryMap
Construct a BinaryMap on a specific buffer with the specified modulo growth and shrinkage (load factor) settings.
BinaryMap(ByteBufferManager) - Constructor for class com.tangosol.io.nio.BinaryMap
Construct a BinaryMap using a buffer from the specified ByteBufferManager, and using the default modulo growth and shrinkage (load factor) settings.
BinaryMap(ByteBufferManager, double, double, boolean) - Constructor for class com.tangosol.io.nio.BinaryMap
Construct a BinaryMap using a buffer from the specified ByteBufferManager, and using the specified modulo growth and shrinkage (load factor) settings.
BinaryMap() - Constructor for class com.tangosol.io.nio.BinaryMap
Construct a BinaryMap.
BinaryMap.Block - Class in com.tangosol.io.nio
A Block is the unit of storage within a Buffer.
BinaryMap.Entry - Class in com.tangosol.io.nio
A map entry (key-value pair).
BinaryMap.EntrySet - Class in com.tangosol.io.nio
A set of entries backed by this map.
BinaryMap.KeySet - Class in com.tangosol.io.nio
A set of entries backed by this map.
BinaryMap.ValuesCollection - Class in com.tangosol.io.nio
A collection of values backed by this map.
BinaryMapStore - Class in com.tangosol.io.nio
An implementation of BinaryStore backed by a BinaryMap.
BinaryMapStore(BinaryMap) - Constructor for class com.tangosol.io.nio.BinaryMapStore
Construct a BinaryMapStore object, which is an implementation of the BinaryStore interface backed by a BinaryMap.
BinaryMarshaller - Class in com.tangosol.coherence.rest.io
A pass-through marshaller that simply converts HTTP entities into a Binary and vice versa.
BinaryMarshaller() - Constructor for class com.tangosol.coherence.rest.io.BinaryMarshaller
 
BinaryMemoryCalculator - Class in com.tangosol.net.cache
A UnitCalculator implementation that weighs a cache entry based upon the amount of physical memory (in bytes) required to store the entry.
BinaryMemoryCalculator() - Constructor for class com.tangosol.net.cache.BinaryMemoryCalculator
 
binaryOperator(Remote.BinaryOperator<T>) - Static method in class com.tangosol.util.function.Remote
Capture serializable BinaryOperator.
BinaryRadixTree - Class in com.tangosol.util
A BinaryRadixTree is a memory-optimized radix tree (aka a Patricia trie) that is intended to efficiently store a mapping from Binary values to long values.
BinaryRadixTree() - Constructor for class com.tangosol.util.BinaryRadixTree
Construct an empty BinaryRadixTree.
BinaryStore - Interface in com.tangosol.io
A simple mapping of CacheStore operations for Binary objects into a Java interface.
BinaryStore.KeySetAware - Interface in com.tangosol.io
If a BinaryStore is aware of which keys that it stores, then it should implement this optional interface in order to allow that information to be efficiently communicated to an intelligent consumer of the BinaryStore interface.
BinaryStore.SizeAware - Interface in com.tangosol.io
If a BinaryStore is aware of the number of keys that it stores, then it should implement this optional interface in order to allow that information to be efficiently communicated to an intelligent consumer of the BinaryStore interface.
BinaryStoreCacheStore<K,V> - Class in com.tangosol.net.cache
A CacheStore that sits directly on top of a BinaryStore.
BinaryStoreCacheStore(BinaryStore) - Constructor for class com.tangosol.net.cache.BinaryStoreCacheStore
Create a CacheStore that delegates to a BinaryStore.
BinaryStoreCacheStore(BinaryStore, ClassLoader) - Constructor for class com.tangosol.net.cache.BinaryStoreCacheStore
Create a CacheStore that delegates to a BinaryStore, using the passed ClassLoader for deserialization.
BinaryStoreCacheStore(BinaryStore, boolean) - Constructor for class com.tangosol.net.cache.BinaryStoreCacheStore
Create a CacheStore that delegates to a BinaryStore, optionally storing only Binary keys and values.
BinaryStoreManager - Interface in com.tangosol.io
A manager that is capable of creating and destroying BinaryStore objects.
BinaryStoreManagerBuilder - Interface in com.tangosol.coherence.config.builder.storemanager
A BinaryStoreManagerBuilder is responsible for realizing BinaryStoreManagers.
BinaryStoreManagerBuilderCustomization - Interface in com.tangosol.coherence.config.builder.storemanager
A BinaryStoreManagerBuilderCustomization class is one that allows or potentially requires, a BinaryStoreManagerBuilder for the purposes of realizing a BinaryStoreManager.
BinaryWriteBuffer - Class in com.tangosol.util
a WriteBuffer implementation whose primary purpose is to be used to create Binary objects.
BinaryWriteBuffer(int) - Constructor for class com.tangosol.util.BinaryWriteBuffer
Construct an BinaryWriteBuffer with a certain initial capacity.
BinaryWriteBuffer(int, int) - Constructor for class com.tangosol.util.BinaryWriteBuffer
Construct an BinaryWriteBuffer with a certain initial capacity and a certain maximum capacity.
bind(AttributeHolder, AttributeHolder) - Method in class com.tangosol.coherence.servlet.AbstractHttpSessionModel
Bind the specified session attribute, replacing the specified attribute if it exists.
bind(FlowControl) - Method in class com.tangosol.net.cache.ContinuousQueryCache.ConverterAsynchronousProcessor
 
bind(String, Object) - Method in interface com.tangosol.net.NameService
Binds a name to an object.
bind(ObservableSplittingBackingCache) - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache.CapacityAwareMap
Bind to the given ObservableSplittingBackingMap instance.
bind(SocketAddress) - Method in class com.tangosol.net.TcpDatagramSocket
bind(int, InetAddress) - Method in class com.tangosol.net.TcpDatagramSocket.Impl
bind(SocketAddress) - Method in class com.tangosol.net.TcpDatagramSocket.Impl
Bind the socket to the specified address.
bind(FlowControl) - Method in class com.tangosol.util.AsynchronousAgent
Bind this agent with the specified underlying FlowControl object.
BINDING_NODE - Static variable in class com.tangosol.coherence.dsltools.precedence.OPToken
The AST node name for a Binding Node.
bindService(String) - Method in class com.tangosol.net.partition.MirroringAssignmentStrategy
Bind this assignment strategy to the specified partitioned service, and return the bound service.
biPredicate(Remote.BiPredicate<T, U>) - Static method in class com.tangosol.util.function.Remote
Capture serializable BiPredicate.
BitHelper - Class in com.tangosol.util
A collection of methods for bit-based operations.
BitHelper() - Constructor for class com.tangosol.util.BitHelper
 
BlindCompactSerializationCache - Class in com.tangosol.net.cache
BlindCompactSerializationCache is a CompactSerializationCache extension enforcing CompactSerializationCache to operate under a blind mode.
BlindCompactSerializationCache(BinaryStoreManager, ClassLoader) - Constructor for class com.tangosol.net.cache.BlindCompactSerializationCache
Construct a BlindCompactSerializationCache using the specified BinaryStoreManager and classloader.
BlindCompactSerializationCache(BinaryStoreManager, boolean) - Constructor for class com.tangosol.net.cache.BlindCompactSerializationCache
Construct a BlindCompactSerializationCache using the specified BinaryStoreManager, optionally storing only Binary keys and values
BlindCompactSerializationCache(BinaryStoreManager, ClassLoader, boolean) - Constructor for class com.tangosol.net.cache.BlindCompactSerializationCache
Construct a BlindCompactSerializationCache using the specified BinaryStoreManager.
Block() - Constructor for class com.tangosol.io.nio.BinaryMap.Block
Construct a Block.
BLOCK_BUF - Static variable in class com.tangosol.coherence.servlet.WebPluginInstaller.ApplyPatch
The buffer to use for buffered I/O.
BLOCK_SIZE - Static variable in class com.tangosol.coherence.servlet.WebPluginInstaller.ApplyPatch
The size (in bytes) to perform buffered I/O on.
Blocking - Class in com.oracle.coherence.common.base
Blocking provides a set of helper methods related to blocking a thread.
Blocking() - Constructor for class com.oracle.coherence.common.base.Blocking
 
BOOLEAN_ARRAY_EMPTY - Static variable in class com.tangosol.io.pof.PofHelper
An empty array of bytes.
BooleanAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.SimpleAdapter.BooleanAdapter
Construct a SimpleAdapter.
BooleanArrayAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.PrimitiveArrayAdapter.BooleanArrayAdapter
Construct a BooleanArrayAdapter.
BOOLEANLITERAL - Static variable in class com.tangosol.coherence.dsltools.base.LiteralBaseToken
The numberic code for a boolean literal
BOOLEANLITERAL - Static variable in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
The numberic code for a boolean literal
booleanSupplier(Remote.BooleanSupplier) - Static method in class com.tangosol.util.function.Remote
Capture serializable BooleanSupplier.
boxed() - Method in interface com.tangosol.util.stream.RemoteDoubleStream
Returns a Stream consisting of the elements of this stream, boxed to Double.
boxed() - Method in interface com.tangosol.util.stream.RemoteIntStream
Returns a Stream consisting of the elements of this stream, each boxed to an Integer.
boxed() - Method in interface com.tangosol.util.stream.RemoteLongStream
Returns a Stream consisting of the elements of this stream, each boxed to a Long.
breakLines(String, int, String) - Static method in class com.tangosol.util.Base
Breaks the specified string into a multi-line string.
breakLines(String, int, String, boolean) - Static method in class com.tangosol.util.Base
Breaks the specified string into a multi-line string.
BroadKeyPartitioningStrategy - Class in com.tangosol.net.partition
The BroadKeyPartitioningStrategy is a strategy that could be used in cases when the standard key association-based strategy produces very uneven partition distribution - some partitions having significantly larger amount of data than others.
BroadKeyPartitioningStrategy(int) - Constructor for class com.tangosol.net.partition.BroadKeyPartitioningStrategy
Construct the BroadKeyPartitioningStrategy based on the specified span.
BUCKET_COUNTS - Static variable in class com.tangosol.io.nio.BinaryMap
These are potential bucket counts.
Buffer(int) - Constructor for class com.tangosol.io.journal.FlashJournalRM.Buffer
Instantiate a buffer.
buffercopy(ByteBuffer, int, int, int, byte[]) - Static method in class com.tangosol.io.nio.BinaryMap
Copy from one part of the buffer to another.
BufferPool(int, int) - Constructor for class com.tangosol.io.journal.FlashJournalRM.BufferPool
Instantiate a buffer pool to provide buffers to the journal appending process.
BufferPool() - Constructor for class com.tangosol.io.journal.RamJournalRM.BufferPool
Instantiate a buffer pool to provide buffers to the journal appending process.
BufferTypeProcessor - Class in com.tangosol.coherence.config.xml.processor
An ElementProcessor for the <buffer-type> Cache Configuration element.
BufferTypeProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.BufferTypeProcessor
 
build() - Method in class com.tangosol.coherence.rest.util.ComparatorBuilder
Build comparator.
build() - Method in class com.tangosol.net.management.MBeanAccessor.QueryBuilder
Build and return the MBean query.
build() - Method in class com.tangosol.net.ViewBuilder
Construct a view of the NamedCache provided to this builder.
builder(int) - Static method in class com.tangosol.net.ConfigurableLocalAddressProvider
Return a builder which will produce Providers for all local addresses and the specified port
Builder<T> - Interface in com.tangosol.util
A Builder provides a mechanism for realizing a specific class of object as required.
BuilderCustomization<T> - Interface in com.tangosol.coherence.config.builder
A class that implements BuilderCustomization is one that allows an alternate builder, as a ParameterizedBuilder, to be provided so that the said class may use it for realizing objects.
BuilderHelper - Class in com.tangosol.util
Provides a collection of helper methods for working with Builders.
BuilderHelper() - Constructor for class com.tangosol.util.BuilderHelper
 
BuilderRegistration(String, Class<?>, ParameterizedBuilder<?>) - Constructor for class com.tangosol.coherence.config.builder.SimpleParameterizedBuilderRegistry.BuilderRegistration
buildExtractor(List<ValueExtractor>) - Method in class com.tangosol.coherence.dslquery.internal.AbstractCoherenceQueryWalker
Create a single ValueExtractor from the List of ValueExtractors.
buildFactory(String, ClassLoader) - Method in class com.tangosol.application.ContainerAdapter.ContainerCacheFactoryBuilder
Construct and configure a ConfigurableCacheFactory for the specified cache config URI and ClassLoader.
buildFactory() - Method in class com.tangosol.application.ContainerAdapter.DefaultContext
Build the ExtensibleConfigurableCacheFactory to be used by this context.
buildFactory(String, ClassLoader) - Method in class com.tangosol.net.ScopedCacheFactoryBuilder
Construct and configure a ConfigurableCacheFactory for the specified cache config URI and ClassLoader.
buildPlan() - Method in class com.tangosol.util.filter.LikeFilter
Build a plan for processing the LIKE functionality.
bundle(Set) - Method in class com.tangosol.net.cache.AbstractBinaryEntryBundler
The bundle operation to be performed against a collected set of binary entries by the concrete AbstractEntryBundler implementations.
Bundle() - Constructor for class com.tangosol.net.cache.AbstractBinaryEntryBundler.Bundle
Default constructor.
Bundle() - Constructor for class com.tangosol.net.cache.AbstractBundler.Bundle
Default constructor.
bundle(Map) - Method in class com.tangosol.net.cache.AbstractEntryBundler
The bundle operation to be performed against a collected map of entries by the concrete AbstractEntryBundler implementations.
Bundle() - Constructor for class com.tangosol.net.cache.AbstractEntryBundler.Bundle
Default constructor.
bundle(Collection) - Method in class com.tangosol.net.cache.AbstractKeyBundler
The bundle operation to be performed against a collected set of keys by the concrete AbstractKeyBundler implementations.
Bundle() - Constructor for class com.tangosol.net.cache.AbstractKeyBundler.Bundle
Default constructor.
bundle(Collection) - Method in class com.tangosol.net.cache.BundlingNamedCache.GetBundler
A pass through the the underlying getAll operation.
bundle(Map) - Method in class com.tangosol.net.cache.BundlingNamedCache.PutBundler
A pass through the the underlying putAll() operation.
bundle(Collection) - Method in class com.tangosol.net.cache.BundlingNamedCache.RemoveBundler
A pass through the the underlying keySet().removeAll() operation.
BundleConfig() - Constructor for class com.tangosol.coherence.config.scheme.BundleManager.BundleConfig
 
BundleManager - Class in com.tangosol.coherence.config.scheme
The BundleManager class is responsible for configuring caches to use bundling.
BundleManager() - Constructor for class com.tangosol.coherence.config.scheme.BundleManager
 
BundleManager.BundleConfig - Class in com.tangosol.coherence.config.scheme
The BundleConfig class contains the configuration for a Bundle.
BundlingNamedCache - Class in com.tangosol.net.cache
Bundling NamedCache implementation.
BundlingNamedCache(NamedCache) - Constructor for class com.tangosol.net.cache.BundlingNamedCache
Construct a BundlingNamedCache based on the specified NamedCache.
BundlingNamedCache.GetBundler - Class in com.tangosol.net.cache
 
BundlingNamedCache.PutBundler - Class in com.tangosol.net.cache
 
BundlingNamedCache.RemoveBundler - Class in com.tangosol.net.cache
 
BundlingScheme - Interface in com.tangosol.coherence.config.scheme
BundlingSchemes define how the bundling (batching) of operations will occur and the BundleManager used to configure said bundling.
by(Filter<? super V>) - Static method in class com.tangosol.net.topic.Subscriber.Filtered
Return a Filtered option with the specified filter.
BY_MEMBER - Static variable in interface com.tangosol.util.InvocableMap.StreamingAggregator
A flag specifying that it might be beneficial to execute this aggregator member-by-member.
BY_PARTITION - Static variable in interface com.tangosol.util.InvocableMap.StreamingAggregator
A flag specifying that it might be beneficial to execute this aggregator partition-by-partition.
BYTE_ARRAY_EMPTY - Static variable in class com.tangosol.io.pof.PofHelper
An empty array of bytes.
ByteAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.SimpleAdapter.ByteAdapter
Construct a SimpleAdapter.
ByteArrayAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.PrimitiveArrayAdapter.ByteArrayAdapter
Construct a ByteArrayAdapter.
ByteArrayBufferInput() - Constructor for class com.tangosol.io.AbstractByteArrayReadBuffer.ByteArrayBufferInput
Default constructor.
ByteArrayBufferOutput() - Constructor for class com.tangosol.io.ByteArrayWriteBuffer.ByteArrayBufferOutput
Construct an ByteArrayBufferOutput that will begin writing at the start of the containing WriteBuffer.
ByteArrayBufferOutput(int) - Constructor for class com.tangosol.io.ByteArrayWriteBuffer.ByteArrayBufferOutput
Construct an ByteArrayBufferOutput that will begin writing at the specified offset within the containing WriteBuffer.
ByteArrayReadBuffer - Class in com.tangosol.io
A ReadBuffer on top of a byte array.
ByteArrayReadBuffer() - Constructor for class com.tangosol.io.ByteArrayReadBuffer
Default constructor provided for subclasses.
ByteArrayReadBuffer(byte[]) - Constructor for class com.tangosol.io.ByteArrayReadBuffer
Construct a ByteArrayReadBuffer object from a byte array.
ByteArrayReadBuffer(byte[], int, int) - Constructor for class com.tangosol.io.ByteArrayReadBuffer
Construct a ByteArrayReadBuffer object from a portion of a byte array.
ByteArrayReadBuffer(byte[], int, int, boolean, boolean, boolean) - Constructor for class com.tangosol.io.ByteArrayReadBuffer
Construct a ByteArrayReadBuffer object from a portion of a byte array.
ByteArrayWriteBuffer - Class in com.tangosol.io
ByteArrayWriteBuffer is an implementation of WriteBuffer on a byte array.
ByteArrayWriteBuffer() - Constructor for class com.tangosol.io.ByteArrayWriteBuffer
Default constructor; intended only for use by subclasses.
ByteArrayWriteBuffer(byte[]) - Constructor for class com.tangosol.io.ByteArrayWriteBuffer
Construct a ByteArrayWriteBuffer on a byte array.
ByteArrayWriteBuffer(int) - Constructor for class com.tangosol.io.ByteArrayWriteBuffer
Construct an ByteArrayWriteBuffer with a certain initial capacity.
ByteArrayWriteBuffer(int, int) - Constructor for class com.tangosol.io.ByteArrayWriteBuffer
Construct an ByteArrayWriteBuffer with a certain initial capacity and a certain maximum capacity.
ByteArrayWriteBuffer(WriteBuffer, int, int) - Constructor for class com.tangosol.io.ByteArrayWriteBuffer
Create a new ByteArrayWriteBuffer based on a region of an already existing WriteBuffer.
ByteArrayWriteBuffer.Allocator - Class in com.tangosol.io
Allocator is a WriteBufferPool implementation which allocates a new ByteArrayWriteBuffer on each request to the pool, and does not retain the returned buffer.
ByteArrayWriteBuffer.ByteArrayBufferOutput - Class in com.tangosol.io
ByteArrayBufferOutput is an implementation of BufferOutput optimized for writing to the buffer's underlying byte array.
byteAt(int) - Method in class com.tangosol.io.AbstractByteArrayReadBuffer
Returns the byte at the specified offset.
byteAt(int) - Method in class com.tangosol.io.MultiBufferReadBuffer
Returns the byte at the specified offset.
byteAt(int) - Method in class com.tangosol.io.nio.ByteBufferReadBuffer
Returns the byte at the specified offset.
byteAt(int) - Method in interface com.tangosol.io.ReadBuffer
Returns the byte at the specified offset.
byteAt(int) - Method in class com.tangosol.util.AbstractByteSequence.AggregateByteSequence
Determine the n-th byte of the byte sequence.
byteAt(int) - Method in class com.tangosol.util.AbstractByteSequence.PartialByteSequence
Determine the n-th byte of the byte sequence.
byteAt(int) - Method in interface com.tangosol.util.ByteSequence
Determine the n-th byte of the byte sequence.
ByteBufferInput(ByteBuffer) - Constructor for class com.tangosol.io.nio.ByteBufferReadBuffer.ByteBufferInput
Default constructor.
ByteBufferInputStream - Class in com.tangosol.io.nio
An InputStream implementation on top of a Java NIO ByteBuffer.
ByteBufferInputStream(ByteBuffer) - Constructor for class com.tangosol.io.nio.ByteBufferInputStream
Construct a ByteBufferInputStream on a ByteBuffer object.
ByteBufferManager - Interface in com.tangosol.io.nio
An interface for managing a ByteBuffer.
ByteBufferOutput(int) - Constructor for class com.tangosol.io.nio.ByteBufferWriteBuffer.ByteBufferOutput
Construct a ByteBufferOutput on top of an NIO ByteBuffer.
ByteBufferOutputStream - Class in com.tangosol.io.nio
An OutputStream implementation on top of a Java NIO ByteBuffer.
ByteBufferOutputStream(ByteBuffer) - Constructor for class com.tangosol.io.nio.ByteBufferOutputStream
Construct a ByteBufferOutputStream on a ByteBuffer object.
ByteBufferReadBuffer - Class in com.tangosol.io.nio
A ReadBuffer implementation on top of a Java NIO ByteBuffer.
ByteBufferReadBuffer(ByteBuffer) - Constructor for class com.tangosol.io.nio.ByteBufferReadBuffer
Construct a ByteBufferReadBuffer on an NIO ByteBuffer.
ByteBufferReadBuffer.ByteBufferInput - Class in com.tangosol.io.nio
This is a simple implementation of the BufferInput interface on top of a ByteBuffer.
ByteBufferWriteBuffer - Class in com.tangosol.io.nio
A WriteBuffer implementation on top of a Java NIO ByteBuffer.
ByteBufferWriteBuffer(ByteBuffer) - Constructor for class com.tangosol.io.nio.ByteBufferWriteBuffer
Construct a ByteBufferWriteBuffer on an NIO ByteBuffer.
ByteBufferWriteBuffer(ByteBufferWriteBuffer) - Constructor for class com.tangosol.io.nio.ByteBufferWriteBuffer
Perform a shallow clone of the supplied ByteBufferWriteBuffer.
ByteBufferWriteBuffer.ByteBufferOutput - Class in com.tangosol.io.nio
This is a simple implementation of the BufferOutput interface on top of a ByteBuffer.
Bytes - Class in com.tangosol.coherence.config.unit
Bytes is a specialized MemorySize whose default constructor assumes that the specified units (when a magnitude is not specified) are always bytes.
Bytes(int) - Constructor for class com.tangosol.coherence.config.unit.Bytes
Constructs a Bytes representing a MemorySize measured in bytes.
Bytes(MemorySize) - Constructor for class com.tangosol.coherence.config.unit.Bytes
Constructs a Bytes based on another MemorySize.
Bytes(String) - Constructor for class com.tangosol.coherence.config.unit.Bytes
Constructs a Bytes representing a MemorySize measured in bytes.
ByteSequence - Interface in com.tangosol.util
Represents a sequence of bytes.

C

CACHE_CONFIGURATION_PATH - Static variable in class com.tangosol.coherence.servlet.SessionHelper
The name of the resource that will be used to configure the session management module's own ConfigurableCacheFactory.
CACHE_NAME - Static variable in class com.tangosol.net.DefaultConfigurableCacheFactory
Deprecated.
The name of the replaceable parameter representing the cache name.
CACHE_NAME - Static variable in class com.tangosol.net.ExtensibleConfigurableCacheFactory
The name of the replaceable parameter representing the cache name.
CACHE_REF - Static variable in class com.tangosol.net.DefaultConfigurableCacheFactory
Deprecated.
The name of the replaceable parameter representing a cache reference.
CACHE_REF - Static variable in class com.tangosol.net.ExtensibleConfigurableCacheFactory
The name of the replaceable parameter representing a cache reference.
CACHE_TYPE - Static variable in interface com.tangosol.net.management.Registry
String representing the "type" part of ObjectName for the CacheMBean.
CACHE_URI_DEFAULT - Static variable in class com.tangosol.application.ContainerAdapter
Internally used "default" URI identifier.
CacheAdapter - Class in com.tangosol.run.jca
CacheAdapter encapsulates the operations neccessary to communicate with Coherence™ resource adapter (coherence-tx.rar).
CacheAdapter() - Constructor for class com.tangosol.run.jca.CacheAdapter
Construct the adapter using a default InitialContext, standard JNDI name, "optimistic" concurrency, "committed" isolation level an no timeout.
CacheAdapter(Context, String, int, int, int) - Constructor for class com.tangosol.run.jca.CacheAdapter
Construct the adapter using the specified Context and JNDI name
CacheAdapter.CacheConnectionSpec - Class in com.tangosol.run.jca
CacheConnectionSpec is an implementation of ConnectionSpec interface used to pass the connection info to the adapter.
CacheCollator - Class in com.tangosol.util
Implements a collator which caches its keys.
CacheCollator(Collator) - Constructor for class com.tangosol.util.CacheCollator
Construct this collator to cache the results of another collator.
CacheConfig - Class in com.tangosol.coherence.config
A CacheConfig is the top-level container for Coherence Cache Configuration, that of which is used at runtime to establish caches and services.
CacheConfig(ParameterResolver) - Constructor for class com.tangosol.coherence.config.CacheConfig
Construct a CacheConfig.
CacheConfigNamespaceHandler - Class in com.tangosol.coherence.config.xml
The CacheConfigNamespaceHandler is responsible for capturing and creating Coherence Cache Configurations when processing a Coherence Configuration file.
CacheConfigNamespaceHandler() - Constructor for class com.tangosol.coherence.config.xml.CacheConfigNamespaceHandler
Standard Constructor.
CacheConnectionSpec(String, String, String, String, int, int, int) - Constructor for class com.tangosol.run.jca.CacheAdapter.CacheConnectionSpec
Construct a ConnectionSpec based on the specified parameters.
CacheDefaultsPreprocessor - Class in com.tangosol.coherence.config.xml.preprocessor
A CacheDefaultsPreprocessor is an DocumentElementPreprocessor.ElementPreprocessor that introduces (via cloning) default xml content for xml elements where the said content is missing.
CacheDefaultsPreprocessor(String) - Constructor for class com.tangosol.coherence.config.xml.preprocessor.CacheDefaultsPreprocessor
Constructs a CacheDefaultsPreprocessor with a specific path to where default element content can be located.
CacheDelegator - Interface in com.tangosol.coherence.servlet
An interface for a class that will perform all cluster cache related operations
CacheEvent<K,V> - Class in com.tangosol.net.cache
An extension of the MapEvent which allows to differentiate between client driven (natural) events and cache internal (synthetic) events.
CacheEvent(ObservableMap<K, V>, int, K, V, V, boolean) - Constructor for class com.tangosol.net.cache.CacheEvent
Constructs a new CacheEvent.
CacheEvent(ObservableMap<K, V>, int, K, V, V, boolean, boolean) - Constructor for class com.tangosol.net.cache.CacheEvent
Constructs a new CacheEvent.
CacheEvent(ObservableMap<K, V>, int, K, V, V, boolean, CacheEvent.TransformationState) - Constructor for class com.tangosol.net.cache.CacheEvent
Constructs a new CacheEvent.
CacheEvent(ObservableMap<K, V>, int, K, V, V, boolean, CacheEvent.TransformationState, boolean) - Constructor for class com.tangosol.net.cache.CacheEvent
Constructs a new CacheEvent.
CacheEvent(ObservableMap<K, V>, int, K, V, V, boolean, CacheEvent.TransformationState, boolean, boolean) - Constructor for class com.tangosol.net.cache.CacheEvent
Constructs a new CacheEvent.
CacheEvent.TransformationState - Enum in com.tangosol.net.cache
TransformationState describes how a CacheEvent has been or should be transformed.
CacheEventFilter<K,V> - Class in com.tangosol.util.filter
An extension of the MapEventFilter which allows selection of client driven (natural) events, cache internal (synthetic) events, or both.
CacheEventFilter() - Constructor for class com.tangosol.util.filter.CacheEventFilter
Default constructor (necessary for the ExternalizableLite interface).
CacheEventFilter(int, int) - Constructor for class com.tangosol.util.filter.CacheEventFilter
Construct a CacheEventFilter that evaluates MapEvent objects based on the specified combination of event types.
CacheEventFilter(Filter<V>, int) - Constructor for class com.tangosol.util.filter.CacheEventFilter
Construct a CacheEventFilter that evaluates MapEvent objects that would affect the results of a keySet filter issued by a previous call to QueryMap.keySet(com.tangosol.util.Filter).
CacheEventFilter(int, Filter<V>, int) - Constructor for class com.tangosol.util.filter.CacheEventFilter
Construct a CacheEventFilter that evaluates MapEvent objects based on the specified combination of event types.
CacheFactory - Class in com.tangosol.net
Factory for the Coherence™ cache product.
CacheFactory() - Constructor for class com.tangosol.net.CacheFactory
 
CacheFactoryBuilder - Interface in com.tangosol.net
CacheFactoryBuilder provides the means for building and managing configurable cache factories across class loaders in a pluggable fashion.
CacheFactoryLogHandler - Class in com.tangosol.coherence.servlet
 
CacheFactoryLogHandler() - Constructor for class com.tangosol.coherence.servlet.CacheFactoryLogHandler
 
CacheInfo(String, String, Map) - Constructor for class com.tangosol.net.DefaultConfigurableCacheFactory.CacheInfo
Deprecated.
Construct a CacheInfo object.
CacheLifecycleEvent - Interface in com.tangosol.net.events.partition.cache
A CacheLifecycleEvent allows subscribers to capture events pertaining to the lifecycle of a cache.
CacheLifecycleEvent.Type - Enum in com.tangosol.net.events.partition.cache
The emitted event types for a CacheLifecycleEvent.
CacheLoader<K,V> - Interface in com.tangosol.net.cache
A JCache CacheLoader.
CacheLoaderCacheStore<K,V> - Class in com.tangosol.net.cache
A read-only CacheStore that wraps a CacheLoader.
CacheLoaderCacheStore(CacheLoader<K, V>) - Constructor for class com.tangosol.net.cache.CacheLoaderCacheStore
The CacheLoader to delegate to.
CacheLoaderCacheStore(CacheLoader) - Constructor for class com.tangosol.net.cache.ReadWriteBackingMap.CacheLoaderCacheStore
Construct a CacheLoaderCacheStore.
CacheLoaderCacheStore.Iterable<K,V> - Class in com.tangosol.net.cache
An extension to the CacheLoaderCacheStore that implements the IterableCacheLoader interface.
CacheMap<K,V> - Interface in com.tangosol.net.cache
A CacheMap is a Map that supports caching.
CacheMapping - Class in com.tangosol.coherence.config
A CacheMapping captures configuration information for a pattern-match-based mapping from a proposed NamedCache name to a caching scheme.
CacheMapping(String, String) - Constructor for class com.tangosol.coherence.config.CacheMapping
Construct a CacheMapping for caches that will use rawtypes by default.
CacheMappingProcessor - Class in com.tangosol.coherence.config.xml.processor
An CacheMappingProcessor is responsible for processing <cache-mapping> XmlElements to produce a CacheMapping.
CacheMappingProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.CacheMappingProcessor
 
CacheMappingRegistry - Class in com.tangosol.coherence.config
Deprecated.
As Coherence 14.1.1, use ResourceMappingRegistry.
CacheMappingRegistry() - Constructor for class com.tangosol.coherence.config.CacheMappingRegistry
Deprecated.
CacheMappingRegistry(ResourceMappingRegistry) - Constructor for class com.tangosol.coherence.config.CacheMappingRegistry
Deprecated.
CacheMappingRegistry delegates to ResourceMappingRegistry.
CACHENAME_LOCAL_ATTRIBUTES - Static variable in class com.tangosol.coherence.servlet.AbstractHttpSessionCollection
The name of the local cache that stores the session attributes that are not distributed (if there is a distribution controller or attributes are allowed to become local when serialization fails).
CACHENAME_LOCAL_SESSIONS - Static variable in class com.tangosol.coherence.servlet.AbstractHttpSessionCollection
The name of the local cache that stores the sessions that are not yet distributed (if there is a distribution controller).
CACHENAME_OVERFLOW - Static variable in class com.tangosol.coherence.servlet.SplitHttpSessionCollection
The name of the clustered cache that stores the attributes that are too large to store as part of the session objects.
CACHENAME_SESSIONS - Static variable in class com.tangosol.coherence.servlet.AbstractHttpSessionCollection
The name of the clustered cache that stores the sessions.
CachePersistenceHelper - Class in com.tangosol.persistence
Static helper methods used in the persistence of a partitioned cache.
CachePersistenceHelper() - Constructor for class com.tangosol.persistence.CachePersistenceHelper
 
CachePersistenceHelper.Visitor - Interface in com.tangosol.persistence
The Visitor interface allows the "iteration" of the persisted contents (and metadata) of a cache service in the style of the Visitor Pattern.
CacheProvider - Interface in com.tangosol.net
Deprecated.
CacheRefExpression(Expression<?>, ClassLoader, ResourceMappingRegistry) - Constructor for class com.tangosol.coherence.config.xml.processor.InitParamProcessor.CacheRefExpression
Constructs a CacheRefExpression.
CacheRefExpression(Expression<?>, ClassLoader, CacheMappingRegistry) - Constructor for class com.tangosol.coherence.config.xml.processor.InitParamProcessor.CacheRefExpression
Deprecated.
As of Coherence 14.1.1, use #CacheRefExpression(Expression, ClassLoader, ResourceMappingRegistry).
CacheResource - Class in com.tangosol.coherence.rest
RESTful wrapper around a Coherence NamedCache.
CacheResource(NamedCache, Class, Class, KeyConverter, QueryConfig, int) - Constructor for class com.tangosol.coherence.rest.CacheResource
Construct a new CacheResource.
CacheService - Interface in com.tangosol.net
A CacheService is a clustered service providing a collection of named Maps that hold resources shared among members of a cluster.
CacheService.CacheAction - Interface in com.tangosol.net
CacheAction represents a type of action taken by a CacheService.
CacheServiceProxyProcessor - Class in com.tangosol.coherence.config.xml.processor
An ElementProcessor that will parse cache-service-proxy configuration element tp produce a DefaultCacheServiceProxyDependencies object.
CacheServiceProxyProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.CacheServiceProxyProcessor
 
CacheStatistics - Interface in com.tangosol.net.cache
An interface for exposing Cache statistics.
CacheStatisticsExtractor() - Constructor for class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics.CacheStatisticsExtractor
CacheStatisticsExtractor(JCacheIdentifier) - Constructor for class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics.CacheStatisticsExtractor
Constructs PartitionedJCacheStatistics.CacheStatisticsExtractor to get JCacheStatistics associated with id.
CacheStore<K,V> - Interface in com.tangosol.net.cache
A JCache cache store.
CacheStoreMap - Class in com.tangosol.net.cache
A backing Map implementation that delegates all operations to a CacheStore.
CacheStoreMap(BackingMapManagerContext, IterableCacheLoader) - Constructor for class com.tangosol.net.cache.CacheStoreMap
Construct a read-only CacheStoreMap.
CacheStoreMap(BackingMapManagerContext, CacheStore) - Constructor for class com.tangosol.net.cache.CacheStoreMap
Construct a read/write CacheStoreMap.
CacheStoreMap(BackingMapManagerContext, CacheStore, boolean) - Constructor for class com.tangosol.net.cache.CacheStoreMap
Construct a read/write CacheStoreMap.
CacheStoreMap.ReadWriteMap - Class in com.tangosol.net.cache
A Map implementation that delegates straight through to a CacheStore.
CacheStoreScheme - Class in com.tangosol.coherence.config.scheme
The CacheStoreScheme class is responsible for building a fully configured instance of a CacheStore, CacheLoader or remote NamedCache.
CacheStoreScheme() - Constructor for class com.tangosol.coherence.config.scheme.CacheStoreScheme
 
CacheStoreWrapper(CacheStore) - Constructor for class com.tangosol.net.cache.ReadWriteBackingMap.CacheStoreWrapper
Construct a CacheStoreWrapper.
CacheStoreWrapper(CacheStore) - Constructor for class com.tangosol.net.cache.VersionedBackingMap.CacheStoreWrapper
Deprecated.
Construct a wrapped CacheStore.
CachingMap<K,V> - Class in com.tangosol.net.cache
Map implementation that wraps two maps - a front map (assumed to be "inexpensive" and probably "incomplete") and a back map (assumed to be "complete" and "correct", but more "expensive") - using a read-through/write-through approach.
CachingMap(Map<K, V>, Map<K, V>) - Constructor for class com.tangosol.net.cache.CachingMap
Construct a CachingMap using two specified maps: FrontMap (aka "cache", "near" or "shallow") and BackMap (aka "actual", "real" or "deep").
CachingMap(Map<K, V>, Map<K, V>, int) - Constructor for class com.tangosol.net.cache.CachingMap
Construct a CachingMap using two specified maps: FrontMap (aka "cache", "near" or "shallow") and BackMap (aka "actual", "real" or "deep") and using the specified front map invalidation strategy.
CachingMap.DeactivationListener - Class in com.tangosol.net.cache
DeactivationListener for the back NamedCache.
CachingMap.FrontMapListener - Class in com.tangosol.net.cache
MapListener for front map responsible for deregistering back map listeners upon front map eviction.
CachingMap.PrimingListener - Class in com.tangosol.net.cache
MapListener for back map responsible for keeping the front map coherent with the back map.
CachingMap.SimpleListener - Class in com.tangosol.net.cache
MapListener for back map responsible for keeping the front map coherent with the back map.
CachingScheme - Interface in com.tangosol.coherence.config.scheme
The CachingScheme is a multi-builder for cache-based infrastructure.
CachingSchemeMappingProcessor - Class in com.tangosol.coherence.config.xml.processor
An CachingSchemeMappingProcessor is responsible for processing <caching-scheme-mapping> XmlElements to update the ResourceMappingRegistry with CacheMappings.
CachingSchemeMappingProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.CachingSchemeMappingProcessor
 
CachingSchemesProcessor - Class in com.tangosol.coherence.config.xml.processor
A CachingSchemesProcessor is an ElementProcessor for the <caching-schemes%gt; element of Coherence Cache Configuration files.
CachingSchemesProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.CachingSchemesProcessor
 
calcDecimalSize(BigDecimal) - Static method in class com.tangosol.io.pof.PofHelper
Determine the minimum size (in bytes) of the IEEE754 decimal type that would be capable of holding the passed value.
calcFirstSlotIndex(int) - Static method in class com.tangosol.util.MultiBinaryLongMap.LongStorage
Given a segment index, determine the slot index of the first slot that is stored in the segment.
calcSegmentIndex(int) - Static method in class com.tangosol.util.MultiBinaryLongMap.LongStorage
Give a slot index, determine what segment index the slot will be found in.
calcSegmentSize(int) - Static method in class com.tangosol.util.MultiBinaryLongMap.LongStorage
Given an array segment index, determine the size of the array in slots.
calculateAnalysisDelay() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
Calculate whether the analysis should be delayed.
calculateBasePartitionHash(PartitionedService, Object) - Static method in class com.tangosol.net.partition.DefaultKeyPartitioningStrategy
Determine the partition-hash of the given key.
calculateBucket(int) - Method in class com.tangosol.io.nio.BinaryMap
Calculate the bucket for the specified hash code.
calculateCurrentLoadFactor() - Method in class com.tangosol.io.journal.AbstractJournalRM
Calculate current load factor for compaction (GC).
calculateCurrentLoadFactor() - Method in class com.tangosol.io.journal.AbstractJournalRM.CollectorDaemon.CollectionCoordinator
Calculate current load factor for compaction (GC).
calculateCurrentLoadFactor() - Method in class com.tangosol.io.journal.FlashJournalRM
Calculate current load factor for compaction (GC).
calculateEffectiveness(Map, Set) - Method in class com.tangosol.util.filter.AllFilter
Given a Map of available indexes, determine if this IndexAwareFilter can use any of the indexes to assist in its processing, and if so, determine how effective the use of that index would be.
calculateEffectiveness(Map, Set) - Method in class com.tangosol.util.filter.AlwaysFilter
Given a Map of available indexes, determine if this IndexAwareFilter can use any of the indexes to assist in its processing, and if so, determine how effective the use of that index would be.
calculateEffectiveness(Map, Set) - Method in class com.tangosol.util.filter.AnyFilter
Given a Map of available indexes, determine if this IndexAwareFilter can use any of the indexes to assist in its processing, and if so, determine how effective the use of that index would be.
calculateEffectiveness(Map, Set) - Method in class com.tangosol.util.filter.BetweenFilter
Given a Map of available indexes, determine if this IndexAwareFilter can use any of the indexes to assist in its processing, and if so, determine how effective the use of that index would be.
calculateEffectiveness(Map, Set) - Method in class com.tangosol.util.filter.ContainsAllFilter
Given a Map of available indexes, determine if this IndexAwareFilter can use any of the indexes to assist in its processing, and if so, determine how effective the use of that index would be.
calculateEffectiveness(Map, Set) - Method in class com.tangosol.util.filter.ContainsAnyFilter
Given a Map of available indexes, determine if this IndexAwareFilter can use any of the indexes to assist in its processing, and if so, determine how effective the use of that index would be.
calculateEffectiveness(Map, Set) - Method in class com.tangosol.util.filter.ContainsFilter
Given a Map of available indexes, determine if this IndexAwareFilter can use any of the indexes to assist in its processing, and if so, determine how effective the use of that index would be.
calculateEffectiveness(Map, Set) - Method in class com.tangosol.util.filter.EqualsFilter
Given a Map of available indexes, determine if this IndexAwareFilter can use any of the indexes to assist in its processing, and if so, determine how effective the use of that index would be.
calculateEffectiveness(Map, Set) - Method in class com.tangosol.util.filter.ExtractorFilter
Given a Map of available indexes, determine if this IndexAwareFilter can use any of the indexes to assist in its processing, and if so, determine how effective the use of that index would be.
calculateEffectiveness(Map, Set) - Method in class com.tangosol.util.filter.GreaterEqualsFilter
Given a Map of available indexes, determine if this IndexAwareFilter can use any of the indexes to assist in its processing, and if so, determine how effective the use of that index would be.
calculateEffectiveness(Map, Set) - Method in class com.tangosol.util.filter.GreaterFilter
Given a Map of available indexes, determine if this IndexAwareFilter can use any of the indexes to assist in its processing, and if so, determine how effective the use of that index would be.
calculateEffectiveness(Map<? extends ValueExtractor<? extends V, ?>, ? extends MapIndex<? extends K, ? extends V, ?>>, Set<? extends K>) - Method in interface com.tangosol.util.filter.IndexAwareFilter
Given a Map of available indexes, determine if this IndexAwareFilter can use any of the indexes to assist in its processing, and if so, determine how effective the use of that index would be.
calculateEffectiveness(Map, Set) - Method in class com.tangosol.util.filter.InFilter
Given a Map of available indexes, determine if this IndexAwareFilter can use any of the indexes to assist in its processing, and if so, determine how effective the use of that index would be.
calculateEffectiveness(Map, Set) - Method in class com.tangosol.util.filter.InKeySetFilter
Given a Map of available indexes, determine if this IndexAwareFilter can use any of the indexes to assist in its processing, and if so, determine how effective the use of that index would be.
calculateEffectiveness(Map, Set) - Method in class com.tangosol.util.filter.KeyFilter
Given a Map of available indexes, determine if this IndexAwareFilter can use any of the indexes to assist in its processing, and if so, determine how effective the use of that index would be.
calculateEffectiveness(Map, Set) - Method in class com.tangosol.util.filter.LessEqualsFilter
Given a Map of available indexes, determine if this IndexAwareFilter can use any of the indexes to assist in its processing, and if so, determine how effective the use of that index would be.
calculateEffectiveness(Map, Set) - Method in class com.tangosol.util.filter.LessFilter
Given a Map of available indexes, determine if this IndexAwareFilter can use any of the indexes to assist in its processing, and if so, determine how effective the use of that index would be.
calculateEffectiveness(Map, Set) - Method in class com.tangosol.util.filter.LikeFilter
Given a Map of available indexes, determine if this IndexAwareFilter can use any of the indexes to assist in its processing, and if so, determine how effective the use of that index would be.
calculateEffectiveness(Map, Set) - Method in class com.tangosol.util.filter.LimitFilter
Given a Map of available indexes, determine if this IndexAwareFilter can use any of the indexes to assist in its processing, and if so, determine how effective the use of that index would be.
calculateEffectiveness(Map, Set) - Method in class com.tangosol.util.filter.NeverFilter
Given a Map of available indexes, determine if this IndexAwareFilter can use any of the indexes to assist in its processing, and if so, determine how effective the use of that index would be.
calculateEffectiveness(Map, Set) - Method in class com.tangosol.util.filter.NotEqualsFilter
Given a Map of available indexes, determine if this IndexAwareFilter can use any of the indexes to assist in its processing, and if so, determine how effective the use of that index would be.
calculateEffectiveness(Map, Set) - Method in class com.tangosol.util.filter.NotFilter
Given a Map of available indexes, determine if this IndexAwareFilter can use any of the indexes to assist in its processing, and if so, determine how effective the use of that index would be.
calculateEffectiveness(Map, Set) - Method in class com.tangosol.util.filter.PresentFilter
Given a Map of available indexes, determine if this IndexAwareFilter can use any of the indexes to assist in its processing, and if so, determine how effective the use of that index would be.
calculateEffectiveness(Map, Set) - Method in class com.tangosol.util.filter.PriorityFilter
Given a Map of available indexes, determine if this IndexAwareFilter can use any of the indexes to assist in its processing, and if so, determine how effective the use of that index would be.
calculateEffectiveness(Map, Set) - Method in class com.tangosol.util.filter.XorFilter
Given a Map of available indexes, determine if this IndexAwareFilter can use any of the indexes to assist in its processing, and if so, determine how effective the use of that index would be.
calculateExpiry(long) - Static method in class com.tangosol.net.cache.BackingMapBinaryEntry
Calculate the expiry timestamp based on the expiry delay value.
calculateFairShare(boolean) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
Return the "fair share" (F) load.
calculateIteratorEffectiveness(int) - Static method in class com.tangosol.util.filter.ExtractorFilter
Helper method to calculate effectiveness (or rather ineffectiveness) of a simple iteration against a key set that has to be performed due to an absence of corresponding index.
calculateJMXPartitionStats() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.JMXPartitionStats
Calculate MBean attribute values for partition statistics.
calculateKeyPartition(PartitionedService, Object) - Static method in class com.tangosol.net.partition.DefaultKeyPartitioningStrategy
Determine the partition to which the given key should be assigned for the specified PartitionService, taking into consideration the associations provided by the service's KeyAssociator.
calculateKeyPartitionHash(PartitionedService, Object) - Static method in class com.tangosol.net.partition.DefaultKeyPartitioningStrategy
Determine the partition-hash of the given key.
calculateMatchEffectiveness(Map, Set) - Method in class com.tangosol.util.filter.ComparisonFilter
Helper method to calculate effectiveness for ComparisonFilters that need no more than a single index match in order to retrieve all necessary keys to perform the applyIndex() operation.
calculateMaxFileSize(long) - Method in class com.tangosol.io.journal.AbstractJournalRM.DefaultDependencies
Calculate the maximum size of each file based on the given the journal size.
calculateMaxFileSize(long) - Method in class com.tangosol.io.journal.FlashJournalRM.DefaultDependencies
Calculate the maximum size of each file based on the given the journal size.
calculateMinimumNodeCount(Set<Member>) - Static method in class com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy
Given a set of Member objects, calculate the minimum number of nodes on a single machine.
calculateMinThreshold(int) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy
Calculate the minimum number of storage enabled nodes necessary to proceed with the service recovery.
calculateNaturalPartition(int) - Method in class com.tangosol.util.Binary
Calculate the partition ID to which the specified Binary should be naturally assigned.
calculateObjectName(Cache, MBeanServerRegistrationUtility.ObjectNameType) - Static method in class com.tangosol.coherence.jcache.common.MBeanServerRegistrationUtility
Creates an object name using the scheme "javax.cache:type=Cache<Statistics|Configuration>,CacheManager=<cacheManagerName>,Cache=<cacheName>" MultiTenancy support: "javax.cache:type=Cache<Statistics|Configuration>,CacheManager=<cacheManagerName>,Cache=<cacheName>domainPartition=<domainPartition>"
calculateObjectName(CoherenceBasedCacheManager, JCacheIdentifier, MBeanServerRegistrationUtility.ObjectNameType) - Static method in class com.tangosol.coherence.jcache.common.MBeanServerRegistrationUtility
Creates an object name using the scheme "javax.cache:type=Cache<Statistics|Configuration>,CacheManager=<cacheManagerName>,Cache=<cacheName>" MultiTenancy support: "javax.cache:type=Cache<Statistics|Configuration>,CacheManager=<cacheManagerName>,Cache=<cacheName>domainPartition=<domainPartition>"
calculatePackedLength(int) - Static method in class com.tangosol.util.ExternalizableHelper
Calculate the number of bytes needed to store a packed integer using a variable-length format.
calculatePackedLength(long) - Static method in class com.tangosol.util.ExternalizableHelper
Calculate the number of bytes needed to store a packed long using a variable-length format.
calculatePartition(PartitionedService, int) - Static method in class com.tangosol.net.partition.DefaultKeyPartitioningStrategy
Return the partition associated with the specified hash value in the specified PartitionedService.
calculatePreviousBucket(int) - Method in class com.tangosol.io.nio.BinaryMap
Calculate the old bucket for the specified hash code.
calculateRangeEffectiveness(Map, Set) - Method in class com.tangosol.util.filter.ComparisonFilter
Helper method to calculate effectiveness for ComparisonFilters that need a range of values from an index in order to retrieve all necessary keys to perform the applyIndex() operation.
calculateRequeueDelay(ReadWriteBackingMap.WriteQueue) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
Calculate the requeue delay after a store operation failed.
calculateShallowSize(Class) - Static method in class com.tangosol.net.cache.SimpleMemoryCalculator
Calculate the approximate number of bytes required to store an instance of the given class and its non-static fields in memory.
calculateSize() - Method in interface com.tangosol.util.Sizable
Calculate the memory footprint for this instance.
calculateSizeCode(int) - Static method in class com.tangosol.io.nio.BinaryMap
Determine which "free bucket" a block of a particular size would go into.
calculateTotalLength(Object[][]) - Static method in class com.tangosol.util.ImmutableMultiList
Calculate the total number of element in the array of arrays.
calculateUnits(Object, Object) - Method in class com.tangosol.net.cache.BinaryMemoryCalculator
Calculate the approximate number of bytes required to cache the given Binary key and value.
calculateUnits(Binary, Binary) - Method in class com.tangosol.net.cache.CompactSerializationCache
Calculate the unit cost of the specified cache entry, according to the configured unit-calculator.
calculateUnits(Object, Object) - Method in interface com.tangosol.net.cache.ConfigurableCacheMap.UnitCalculator
Calculate a cache cost for the specified cache entry key and value.
calculateUnits(Object) - Method in class com.tangosol.net.cache.OldCache.Entry
Deprecated.
Calculate a cache cost for the specified object.
calculateUnits(Object, Object) - Method in class com.tangosol.net.cache.OldCache.InternalUnitCalculator
Deprecated.
Calculate a cache cost for the specified cache entry key and value.
calculateUnits(Object, Object) - Method in class com.tangosol.net.cache.SimpleMemoryCalculator
Calculate a cache cost for the specified cache entry key and value.
calculateVersion(Object) - Method in class com.tangosol.run.jca.SimpleValidator
Generate the Comparable version indicator for a given resource value.
calculateWaitTime(long) - Method in class com.tangosol.net.partition.FailoverAccessPolicy
Return the amount of time that a request should be delayed before being allowed to proceed.
calculateWeight(Binary) - Method in class com.tangosol.net.cache.CompactSerializationCache.HybridEvictionPolicy
Calculate the "weight" of the entry associated with the specified key.
calculateWeight(Binary) - Method in class com.tangosol.net.cache.CompactSerializationCache.InternalEvictionPolicy
Calculate the "weight" of the entry associated with the specified key.
calculateWeight(Binary) - Method in class com.tangosol.net.cache.CompactSerializationCache.LFUEvictionPolicy
Calculate the "weight" of the entry associated with the specified key.
calculateWeight(Binary) - Method in class com.tangosol.net.cache.CompactSerializationCache.LRUEvictionPolicy
Calculate the "weight" of the entry associated with the specified key.
calculateWeight(Binary) - Method in class com.tangosol.net.cache.CompactSerializationCache.WrapperEvictionPolicy
Calculate the "weight" of the entry associated with the specified key.
calcUnitFairShare(int) - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
Return the fair share of units for each child maps.
calcUTF(String) - Method in class com.tangosol.io.AbstractWriteBuffer.AbstractBufferOutput
Figure out how many bytes it will take to hold the passed String.
calibrate() - Method in class com.tangosol.io.nio.AbstractBufferManager
Determine the grow and shrink thresholds based on the current capacity.
CALL_NODE - Static variable in class com.tangosol.coherence.dsltools.precedence.OPToken
The AST node name for a Method Call Node.
callable(Remote.Callable<V>) - Static method in class com.tangosol.util.function.Remote
Capture serializable Callable.
cancel(boolean) - Method in class com.tangosol.net.cache.ContinuousQueryCache.ConverterAsynchronousProcessor
 
cancel() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.ReadLatch
Cancel the load operation.
cancel(Throwable) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.ReadLatch
Cancel the load operation due to an exception.
cancel(Throwable) - Method in class com.tangosol.persistence.AbstractPersistenceManager.Task
Cancel execution of the task.
cancel(boolean) - Method in class com.tangosol.util.AsynchronousAgent
 
cancelOutstandingReads(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
Cancel any outstanding asynchronous reads for a key.
cancelPostedWork() - Method in class com.tangosol.coherence.commonj.WorkManager
Cancel all posted work that has not yet completed.
CANONICAL_NAME - Static variable in class com.tangosol.util.extractor.IdentityExtractor
Canonical name for identity extractor.
CanonicallyNamed - Interface in com.oracle.coherence.common.base
CanonicallyNamed provides a way for objects to identify themselves by name.
capacity() - Method in class com.tangosol.util.Dequeue
Determine the current capacity of this dequeue.
CapacityAwareMap(BackingMapManager, String) - Constructor for class com.tangosol.net.partition.ObservableSplittingBackingCache.CapacityAwareMap
Create a CapacityAwareMap.
capitalize(String) - Static method in class com.tangosol.util.Base
Capitalize a string.
cardinality() - Method in class com.tangosol.net.partition.PartitionSet
Returns the number of marked partitions.
castReturnValue(MethodNode) - Static method in class com.tangosol.coherence.rest.util.PartialObject
Cast a return value into an appropriate type.
casValueInternal(Object, Object) - Method in class com.tangosol.util.SegmentedConcurrentMap.LockableEntry
Set the value of this entry to the specified value iff the current value matches the assumed value.
ceiling(long) - Method in class com.tangosol.util.AbstractSafeLongArray
 
ceiling(long) - Method in class com.tangosol.util.AbstractSparseArray
Return the "first" value with an index which is greater than or equal to the specified index.
ceiling(long) - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray
 
ceiling(long) - Method in interface com.tangosol.util.LongArray
Return the "first" value with an index which is greater than or equal to the specified index.
ceiling(Object) - Method in class com.tangosol.util.SafeSortedMap.KeySet
 
ceiling(long) - Method in class com.tangosol.util.SimpleLongArray
 
ceiling(long) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
 
ceilingEntry(Object) - Method in class com.tangosol.util.SafeSortedMap.SubMap
 
ceilingIndex(long) - Method in class com.tangosol.util.AbstractSafeLongArray
 
ceilingIndex(long) - Method in class com.tangosol.util.AbstractSparseArray
Return the "first" index which is greater than or equal to the specified index.
ceilingIndex(long) - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray
 
ceilingIndex(long) - Method in interface com.tangosol.util.LongArray
Return the "first" index which is greater than or equal to the specified index.
ceilingIndex(long) - Method in class com.tangosol.util.SimpleLongArray
 
ceilingIndex(long) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
 
ceilingKey(Object) - Method in class com.tangosol.util.SafeSortedMap.SubMap
 
CentralReplicationProcessor - Class in com.tangosol.coherence.config.xml.processor
An CentralReplicationProcessor is responsible for processing <central-replication> XmlElements to produce a TopologyBuilder.CentralReplicationBuilder.
CentralReplicationProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.CentralReplicationProcessor
 
cEntries - Variable in class com.tangosol.util.SegmentedHashMap.Segment
The number of Entry objects (including synthetics) in this segment.
CFG_KEY_REAPER - Static variable in class com.tangosol.coherence.servlet.SessionHelper
The key in the configuration cache for coordating cluster-wide session reaping.
chainComparators(Comparator, Comparator) - Static method in class com.tangosol.net.partition.SimpleAssignmentStrategy
Helper method to return a Comparator chaining the specified comparators.
chainComparators(Comparator, Comparator, Comparator) - Static method in class com.tangosol.net.partition.SimpleAssignmentStrategy
Helper method to return a Comparator chaining the specified comparators.
chained(String...) - Static method in class com.tangosol.util.Extractors
Returns an extractor that extracts the specified fields where extraction occurs in a chain where the result of each field extraction is the input to the next extractor.
chained(ValueExtractor<?, ?>...) - Static method in class com.tangosol.util.Extractors
Returns an extractor that extracts the specified fields where extraction occurs in a chain where the result of each field extraction is the input to the next extractor.
ChainedCollection<E> - Class in com.tangosol.util
An unmodifiable Collection that provides access to many collections in the given order.
ChainedCollection(Collection<Collection<E>>) - Constructor for class com.tangosol.util.ChainedCollection
Construct a ChainedCollection with the provided Collection of Collection objects.
ChainedCollection(ChainedCollection<E>, Collection<E>) - Constructor for class com.tangosol.util.ChainedCollection
Construct a ChainedCollection from the existing ChainedCollection and an additional Collection object.
ChainedCollection(ChainedCollection<E>, Collection<E>...) - Constructor for class com.tangosol.util.ChainedCollection
Construct a ChainedCollection from the existing ChainedCollection and an array of Collection objects.
ChainedCollection(Collection<E>...) - Constructor for class com.tangosol.util.ChainedCollection
Construct a ChainedCollection with the provided array of Collection objects.
ChainedComparator<T> - Class in com.tangosol.util.comparator
Composite comparator implementation based on a collection of comparators.
ChainedComparator() - Constructor for class com.tangosol.util.comparator.ChainedComparator
Default constructor (for ExternalizableLite and PortableObject).
ChainedComparator(Comparator<T>...) - Constructor for class com.tangosol.util.comparator.ChainedComparator
Construct a ChainedComparator.
ChainedEnumerator - Class in com.tangosol.util
Provide an enumerator which enumerates the contents of multiple enumerators.
ChainedEnumerator() - Constructor for class com.tangosol.util.ChainedEnumerator
Construct an enumerator that will first enumerate multiple enumerators.
ChainedEnumerator(Enumeration) - Constructor for class com.tangosol.util.ChainedEnumerator
Construct an enumerator that will first enumerate the passed Enumeration.
ChainedEnumerator(Iterator) - Constructor for class com.tangosol.util.ChainedEnumerator
Construct an enumerator that will first enumerate the passed Iterator.
ChainedEnumerator(Enumeration, Enumeration) - Constructor for class com.tangosol.util.ChainedEnumerator
Construct an enumerator that will first enumerate the first Enumeration and then will enumerate the second Enumeration as if they were together a single Enumeration.
ChainedEnumerator(Iterator, Iterator) - Constructor for class com.tangosol.util.ChainedEnumerator
Construct an enumerator that will first enumerate the first Iterator and then will enumerate the second Iterator as if they were together a single Iterator.
ChainedEnumerator(Enumeration[]) - Constructor for class com.tangosol.util.ChainedEnumerator
Construct an enumerator that will first enumerate the Enumerations passed in the array as if they were together a single enumerator.
ChainedEnumerator(Iterator[]) - Constructor for class com.tangosol.util.ChainedEnumerator
Construct an enumerator that will first enumerate the Iterators passed in the array as if they were together a single enumerator.
ChainedExtractor<T,E> - Class in com.tangosol.util.extractor
Composite ValueExtractor implementation based on an array of extractors.
ChainedExtractor() - Constructor for class com.tangosol.util.extractor.ChainedExtractor
Default constructor (necessary for the ExternalizableLite interface).
ChainedExtractor(ValueExtractor[]) - Constructor for class com.tangosol.util.extractor.ChainedExtractor
Construct a ChainedExtractor based on a specified ValueExtractor array.
ChainedExtractor(ValueExtractor<? super T, ? extends U>, ValueExtractor<? super U, ? extends E>) - Constructor for class com.tangosol.util.extractor.ChainedExtractor
Construct a ChainedExtractor based on two extractors.
ChainedExtractor(String) - Constructor for class com.tangosol.util.extractor.ChainedExtractor
Construct a ChainedExtractor for a specified method name sequence.
ChainedExtractorBuilder - Class in com.tangosol.coherence.dslquery
An ExtractorBuilder implementation that delegates building ValueExtractors to a chain of ExtractorBuilders and returns the result from the first ExtractorBuilder to return a non-null value from its ChainedExtractorBuilder.realize(String, int, String) method.
ChainedExtractorBuilder(ExtractorBuilder...) - Constructor for class com.tangosol.coherence.dslquery.ChainedExtractorBuilder
Construct a ChainedExtractorBuilder that uses the specified chain of ExtractorBuilders to realize instances of ValueExtractors.
ChainedLock(Lock, Lock) - Constructor for class com.tangosol.util.MultiBinaryLongMap.ChainedLock
Construct a new ChainedLock composed of the specified parent and child locks.
ChainedMap - Class in com.tangosol.util
Chains two maps into one virtual map.
ChainedMap(Map, Map) - Constructor for class com.tangosol.util.ChainedMap
Construct a ChainedMap out of two maps.
ChainedMap.EntrySet - Class in com.tangosol.util
A set of entries backed by this map.
ChainedResourceResolver - Class in com.tangosol.util
A ChainedResourceResolver is a ResourceResolver that chains together one or more other ResourceResolvers, those of which will be queried (in the order in which they are added to the ChainedResourceResolver) when attempting to resolve a resource.
ChainedResourceResolver(ResourceResolver...) - Constructor for class com.tangosol.util.ChainedResourceResolver
ChainedSet<E> - Class in com.tangosol.util
An unmodifiable Set that provides access to many sets in the given order.
ChainedSet(Collection<Set<E>>) - Constructor for class com.tangosol.util.ChainedSet
Construct a ChainedSet with the provided Collection of Set objects.
ChainedSet(ChainedSet<E>, Set<E>) - Constructor for class com.tangosol.util.ChainedSet
Construct a ChainedSet from the existing ChainedSet and an additional Set object.
ChainedSet(ChainedSet<E>, Set<E>...) - Constructor for class com.tangosol.util.ChainedSet
Construct a ChainedSet from the existing ChainedSet and an array of Set objects.
ChainedSet(Set<E>...) - Constructor for class com.tangosol.util.ChainedSet
Construct a ChainedSet with the provided array of Set objects.
ChangeRecord<K,V> - Interface in com.tangosol.coherence.federation
Provides a mechanism to represent and mutate a Cache Entry that was changed in a Federated Cache.
ChangeRecord.Entry<K,V> - Interface in com.tangosol.coherence.federation
Represents the key, value and name of the Participant from which the entry originated.
ChangeRecordUpdater<K,V> - Interface in com.tangosol.coherence.federation
ChangeRecordUpdater allows to update the given ChangeRecord while processing the FederatedChangeEvent.
changeSessionId() - Method in class com.tangosol.coherence.servlet.api23.HttpServletRequestWrapper
Change the session id of the current session associated with this request and return the new session ID.
changeState(int, Daemon.DaemonWorker) - Method in class com.tangosol.io.journal.FlashJournalRM.PreparerDaemon
Change the state of the daemon.
changeState(int) - Method in class com.tangosol.net.cache.ContinuousQueryCache
Change the state of the ContinuousQueryCache.
changeState(int, Daemon.DaemonWorker) - Method in class com.tangosol.util.Daemon
Change the state of the daemon.
ChangeTracker(ReadBuffer.BufferInput, ReadBuffer.BufferInput) - Constructor for class com.tangosol.io.pof.PofDeltaCompressor.ChangeTracker
Construct a ChangeTracker that will produce a delta between the two passed streams.
CHAR_ARRAY_EMPTY - Static variable in class com.tangosol.io.pof.PofHelper
An empty array of chars.
CHAR_BUF_MASK - Static variable in class com.tangosol.io.AbstractWriteBuffer
Bitmask used against a raw offset to determine the offset within the temporary character buffer.
CHAR_BUF_SIZE - Static variable in class com.tangosol.io.AbstractWriteBuffer
Size of the temporary character buffer.
characteristics() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics.PartitionedCacheStatisticsAggregator
 
characteristics() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics.PartitionedCacheStatisticsClear
 
characteristics() - Method in class com.tangosol.util.aggregator.BigDecimalAverage
 
characteristics() - Method in class com.tangosol.util.aggregator.BigDecimalMax
 
characteristics() - Method in class com.tangosol.util.aggregator.BigDecimalMin
 
characteristics() - Method in class com.tangosol.util.aggregator.BigDecimalSum
 
characteristics() - Method in class com.tangosol.util.aggregator.ComparableMax
 
characteristics() - Method in class com.tangosol.util.aggregator.ComparableMin
 
characteristics() - Method in class com.tangosol.util.aggregator.CompositeAggregator
 
characteristics() - Method in class com.tangosol.util.aggregator.Count
 
characteristics() - Method in class com.tangosol.util.aggregator.DistinctValues
 
characteristics() - Method in class com.tangosol.util.aggregator.DoubleAverage
 
characteristics() - Method in class com.tangosol.util.aggregator.DoubleMax
 
characteristics() - Method in class com.tangosol.util.aggregator.DoubleMin
 
characteristics() - Method in class com.tangosol.util.aggregator.DoubleSum
 
characteristics() - Method in class com.tangosol.util.aggregator.GroupAggregator
 
characteristics() - Method in class com.tangosol.util.aggregator.LongMax
 
characteristics() - Method in class com.tangosol.util.aggregator.LongMin
 
characteristics() - Method in class com.tangosol.util.aggregator.LongSum
 
characteristics() - Method in class com.tangosol.util.aggregator.PriorityAggregator
 
characteristics() - Method in class com.tangosol.util.aggregator.QueryRecorder
 
characteristics() - Method in class com.tangosol.util.aggregator.ReducerAggregator
 
characteristics() - Method in class com.tangosol.util.aggregator.ScriptAggregator
 
characteristics() - Method in class com.tangosol.util.aggregator.TopNAggregator
 
characteristics() - Method in interface com.tangosol.util.InvocableMap.StreamingAggregator
A bit mask representing the set of characteristics of this aggregator.
characteristics() - Method in class com.tangosol.util.SimpleStreamer
 
characteristics() - Method in interface com.tangosol.util.Streamer
A bit mask representing the set of characteristics of this Streamer.
CharAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.SimpleAdapter.CharAdapter
Construct a SimpleAdapter.
CharArrayAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.PrimitiveArrayAdapter.CharArrayAdapter
Construct a CharArrayAdapter.
check() - Method in class com.tangosol.io.MultiByteArrayOutputStream
Verify that the stream is still open.
check(String) - Method in class com.tangosol.io.nio.BinaryMap
Debugging support: Validate the buffer's data structures, the hash buckets, free lists, etc.
check() - Method in class com.tangosol.net.GuardSupport
Check the registered Guardable objects for timeout, taking appropriate action and calculate the timestamp when the next check should be performed.
check() - Method in class com.tangosol.util.ThreadLocalObject
Deprecated.
as of Coherence 3.3 this method is a no-op
checkActive() - Method in class com.tangosol.coherence.servlet.AbstractHttpSessionModel
Make sure that the model is 'active', 'usable' and 'valid'.
checkAlias(OPParser, String...) - Method in class com.tangosol.coherence.dslquery.token.SQLOPToken
Check to see if there is an alias and create a Term to hold the alias identifier if one exists
checkAndInvalidate(String) - Method in class com.tangosol.coherence.servlet.AbstractReapTask
Check the specified session to see if it has expired, and in that case invalidate it.
checkBacklog(Continuation) - Method in class com.tangosol.net.cache.ContinuousQueryCache.ConverterAsynchronousProcessor
 
checkBacklog(Continuation<Void>) - Method in interface com.tangosol.net.FlowControl
Check for an excessive backlog and if the underlying communication channel is indeed clogged, call the specified continuation when the backlog is back to normal or the service terminates.
checkBacklog(Continuation<Void>) - Method in class com.tangosol.util.AsynchronousAgent
 
checkBackupBalance(SimpleAssignmentStrategy.AnalysisContext) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
Check that the distribution of backup partitions is balanced.
checkBackupOverloaded(SimpleAssignmentStrategy.AnalysisContext) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
Check if the distribution of backup partitions is balanced.
checkBackupStrong(SimpleAssignmentStrategy.AnalysisContext) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
Check that the backups are strong.
checkBounds(int, int) - Method in class com.tangosol.io.AbstractReadBuffer
Check if the specified read is within bounds.
checkBounds(int, int) - Method in class com.tangosol.io.ByteArrayWriteBuffer
Validate the ranges for the passed bounds and make sure that the underlying array is big enough to handle them.
checkBounds(int, int) - Method in class com.tangosol.io.DelegatingWriteBuffer
Test an offset and length of data to write to see if it can be written to this buffer.
checkBounds(int, int) - Method in class com.tangosol.util.BinaryWriteBuffer
Validate the ranges for the passed bounds and make sure that the underlying array is big enough to handle them.
checkBufferGrow(int) - Method in class com.tangosol.io.nio.BinaryMap
If there is a buffer manager, check if the current buffer should be grown.
checkBufferShrink() - Method in class com.tangosol.io.nio.BinaryMap
If there is a buffer manager, check if the current buffer should be shrunk.
checkCompaction() - Method in class com.tangosol.util.MultiBinaryLongMap.PrimaryBinaryLongMap.DelegatingPrimaryBinaryLongMap
Check to see whether or not the LongStorage slots should be compacted.
checkCompatible(ValidatingConfiguration) - Method in class com.tangosol.coherence.servlet.ConfigurationImpl
 
checkConfigConsistency(ValidatingConfiguration) - Method in class com.tangosol.coherence.servlet.SessionHelper
Check that configuration is consistent with that of existing members.
checkContextPermission(NamedCache) - Static method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
Container aware access check to a cache.
checkDate(int, int, int) - Static method in class com.tangosol.io.pof.PofHelper
Validate date information.
checkDayTimeInterval(int, int, int, int, int) - Static method in class com.tangosol.io.pof.PofHelper
Validate a day-time interval.
checkDecimalRange(BigDecimal, int) - Static method in class com.tangosol.io.pof.PofHelper
Verify that the specified decimal value will fit in the specified number of bits.
checkDestroy() - Method in class com.tangosol.net.cache.SerializationPagedCache.WrapperBinaryStore
Test if the underlying store can be destroyed, and if so, destroy it.
checkElement(XmlElement) - Method in class com.tangosol.run.xml.SimpleElement.ElementList
Validates the passed XmlElement, copying the element into a new valid element if necessary.
checkElementCount(int) - Static method in class com.tangosol.io.pof.PofHelper
Verify that the number of elements is valid.
checkEndangered() - Method in class com.tangosol.net.partition.FailoverAccessPolicy
Check to see if the associated service is endangered.
checkEndangered(SimpleAssignmentStrategy.AnalysisContext) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
Check the distribution to ensure that backups are created for any "endangered" partitions.
checkEntry(Map.Entry) - Method in class com.tangosol.net.cache.ContinuousQueryCache
Check the passed value to verify that it does belong in this ContinuousQueryCache.
checkEntry(Object, Object) - Method in class com.tangosol.net.cache.ContinuousQueryCache
Check the passed value to verify that it does belong in this ContinuousQueryCache.
checkError() - Method in class com.tangosol.io.WriterPrintStream
Flush the stream and check its error state.
checkExpiry(boolean) - Method in class com.tangosol.net.cache.CompactSerializationCache
Check the cache entries for expiration, removing expired entries as necessary.
checkExpiry(Binary) - Method in class com.tangosol.net.cache.CompactSerializationCache
Check the specified key to see if it is expired, removing it if necessary.
checkExpiry() - Method in class com.tangosol.net.cache.SerializationCache
Make sure that the cache does not contain expired items.
checkExplodedDir() - Method in class com.tangosol.net.DefaultCacheServer.GarServer
Check the number of exploded directories is not considerably more than the number of cluster members on this machine.
checkFlush() - Method in class com.tangosol.net.cache.OldCache
Deprecated.
as of Coherence 3.5, use OldCache.evict()
checkForDeadSessions() - Method in class com.tangosol.coherence.servlet.SessionHelper
Discard the HttpSession objects that are no longer alive.
checkKey(Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedMap
Check the passed object to verify that it passes the "key" restriction of this Map.
checkLeaving(SimpleAssignmentStrategy.AnalysisContext) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
Check for any service members that are leaving, and adjust the distribution plan accordingly.
checkMachineQuorum(int, Set<Member>, Set<Member>, Set<Member>, Set<Member>) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.ClusterQuorumPolicy
Check whether the machine quorum for the specified role will be satisfied if the set of suspect members is disconnected from the cluster, given the sets of "healthy" and "announcing" members.
checkModulo() - Method in class com.tangosol.io.nio.BinaryMap
Determine if the modulo should be changed.
checkMutable() - Method in class com.tangosol.run.xml.SimpleDocument
Validates that the document is mutable, otherwise throws an UnsupportedOperationException.
checkMutable() - Method in class com.tangosol.run.xml.SimpleElement
Validates that the element is mutable, otherwise throws an UnsupportedOperationException.
checkMutable() - Method in class com.tangosol.run.xml.XmlBean
Verify that this XmlBean is mutable.
checkMutable() - Method in class com.tangosol.util.InvocableMapHelper.SimpleEntry
Verify that this SimpleEntry is mutable.
checkNotEmpty(String, String) - Static method in class com.tangosol.util.Base
Check that the specified string is neither a null nor an empty string.
checkNotInitialized() - Method in class com.tangosol.io.pof.ConfigurablePofContext
Verify that the ConfigurablePofContext has not already been initialized.
checkNotNull(T, String) - Static method in class com.tangosol.util.Base
Check that the specified object is non-null and return it.
checkObject(Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedCollection
Check the passed object to verify that it passes the restriction of this Collection.
checkObject(Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedListIterator
Check the passed object to verify that it passes the restriction of this ListIterator.
checkObjectInputFilter(Class<?>, ObjectInputStream) - Static method in class com.tangosol.util.ExternalizableHelper
Return true if the provided class is allowed to be deserialized.
checkObjectInputFilter(Class<?>, DataInput) - Static method in class com.tangosol.util.ExternalizableHelper
Return true if the provided class is allowed to be deserialized.
checkObjectInputFilter(Class<?>, int, DataInput) - Static method in class com.tangosol.util.ExternalizableHelper
Return true if the provided class is allowed to be deserialized.
checkPage() - Method in class com.tangosol.net.cache.SerializationPagedCache
Determine if the time has come to set up a new page for storing current cache data.
checkPending(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.WriteQueue
Check for an item known to the WriteBehind queue.
checkPermission(NamedCache) - Static method in class com.tangosol.net.DefaultConfigurableCacheFactory
Deprecated.
Check if the current user is allowed to "join" the cache.
checkPermission(NamedCache) - Static method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
Check if the current user is allowed to "join" the cache.
checkPermission(NamedCollection) - Static method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
Check if the current user is allowed to "join" to the collection.
checkPermission(Service, String) - Static method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
Check if the current user is allowed to "join" the data structure with the specified name.
checkPermission(ClusterPermission, Subject) - Method in interface com.tangosol.net.security.AccessController
Determine whether the cluster access request indicated by the specified permission should be allowed or denied for a given Subject (requestor).
checkPermission(ClusterPermission, Subject) - Method in class com.tangosol.net.security.DefaultController
Determine whether the cluster access request indicated by the specified permission should be allowed or denied for a given Subject (requestor).
checkPermission(Cluster, String, String, String) - Static method in class com.tangosol.net.security.Security
Check if the current user has permission to perform the action against "clustered resources", such as clustered services and caches.
checkPosition(int) - Method in class com.tangosol.io.pof.ValidatingPofHandler
Validate the specified value position in the POF stream.
checkPosition(int) - Method in class com.tangosol.io.pof.ValidatingPofHandler.Complex
Notify the Complex object that a value has been encountered.
checkPosition(int) - Method in class com.tangosol.io.pof.ValidatingPofHandler.ComplexMap
Notify the Complex object that a value has been encountered.
checkPrimaryBalance(SimpleAssignmentStrategy.AnalysisContext) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
Check the distribution to ensure that primary the partition load is balanced.
checkRange(long, long, long, String) - Static method in class com.tangosol.util.Base
Check the range of a value.
checkRange(Object) - Method in class com.tangosol.util.SortedBag.ViewBag
Check that the specified object is within the range of this view.
checkRead(BinaryEntry, Subject, int) - Method in class com.tangosol.net.security.AuditingAuthorizer
 
checkRead(BinaryEntry, Subject, int) - Method in interface com.tangosol.net.security.StorageAccessAuthorizer
Check if the caller represented by the specified Subject is authorized to a read access for the specified entry.
checkReadAny(BackingMapContext, Subject, int) - Method in class com.tangosol.net.security.AuditingAuthorizer
 
checkReadAny(BackingMapContext, Subject, int) - Method in interface com.tangosol.net.security.StorageAccessAuthorizer
Check if the caller represented by the specified Subject is authorized to read any data.
checkReadOnly() - Method in class com.tangosol.net.cache.ContinuousQueryCache
Check the read-only setting to verify that the cache is NOT read-only.
checkRecoveryMembership(PartitionedService.PartitionRecoveryAction) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy
Check if the recovery is allowed for the current membership.
checkReferenceRange(int) - Static method in class com.tangosol.io.pof.PofHelper
Validate a reference identifier to make sure it is in a valid range.
checkRep() - Method in class com.tangosol.util.MultiBinaryLongMap.MaskedLongMapHolder
Debugging function to check the representational invariant.
checkRoleQuorum(int, Set, Set, Set, Set) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.ClusterQuorumPolicy
Check whether the member quorum for the specified role will be satisfied if the set of suspect members is disconnected from the cluster, given the sets of "healthy" and "announcing" members.
checkShrinkFromOther() - Method in class com.tangosol.util.LiteSet
After a mutation operation has reduced the size of an underlying Set, check if the delegation model should be replaced with a more size- efficient storage approach, and switch accordingly.
checkSimpleDistribution(SimpleAssignmentStrategy.AnalysisContext) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
Analyze the distribution for the special two-server case using the specified analysis context.
checkSiteQuorum(int, Set<Member>, Set<Member>, Set<Member>, Set<Member>) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.ClusterQuorumPolicy
Check whether the site quorum for the specified role will be satisfied if the set of suspect members is disconnected from the cluster, given the sets of "healthy" and "announcing" members.
checkSize() - Method in class com.tangosol.net.cache.CompactSerializationCache
Check the current size of the cache to see that it is within the configured high-units, evicting entries according to the configured ConfigurableCacheMap.EvictionPolicy if necessary.
checkSize(boolean) - Method in class com.tangosol.net.cache.CompactSerializationCache
Check the current size of the cache to see that it is within the configured high-units, evicting entries according to the configured ConfigurableCacheMap.EvictionPolicy if necessary.
checkSize() - Method in class com.tangosol.net.cache.SerializationCache
Make sure the size of the cache isn't too big.
checkStrict() - Method in class com.tangosol.net.cache.ReadonlyNamedCache
Enforce the "strict" read-only policy.
checkTime(int, int, int, int) - Static method in class com.tangosol.io.pof.PofHelper
Validate time information.
checkTimeInterval(int, int, int, int) - Static method in class com.tangosol.io.pof.PofHelper
Validate a time interval.
checkTimeZone(int, int) - Static method in class com.tangosol.io.pof.PofHelper
Check the specified timezone offset.
checkTruncation(List<String>, StringBuilder, int) - Static method in class com.tangosol.util.SimpleQueryRecordReporter
Check if the given name will be truncated in the table, and if yes, add the full name to the footer table.
checkType(int) - Static method in class com.tangosol.io.pof.PofHelper
Validate a type identifier.
checkUsable() - Method in class com.tangosol.coherence.servlet.AbstractHttpSessionModel
Make sure that the model is 'usable'.
checkValid() - Method in class com.tangosol.coherence.servlet.AbstractHttpSessionModel
Make sure that the model is 'usable' and 'valid'.
checkValue(Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet
Check the passed object to verify that it passes the "value" restriction of this Map.
checkValue(Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedMap
Check the passed object to verify that it passes the "value" restriction of this Map.
checkWrite(BinaryEntry, Subject, int) - Method in class com.tangosol.net.security.AuditingAuthorizer
 
checkWrite(BinaryEntry, Subject, int) - Method in interface com.tangosol.net.security.StorageAccessAuthorizer
Check if the caller represented by the specified Subject is authorized to a write access for the specified entry.
checkWriteAny(BackingMapContext, Subject, int) - Method in class com.tangosol.net.security.AuditingAuthorizer
 
checkWriteAny(BackingMapContext, Subject, int) - Method in interface com.tangosol.net.security.StorageAccessAuthorizer
Check if the caller represented by the specified Subject is authorized to update any data.
checkYearMonthInterval(int, int) - Static method in class com.tangosol.io.pof.PofHelper
Validate a year-month interval.
children() - Method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
Obtain the childern Terms
children() - Method in class com.tangosol.coherence.dsltools.termtrees.NodeTerm
Obtain the childern Terms
children() - Method in class com.tangosol.coherence.dsltools.termtrees.Term
Obtain the childern Terms
childrenTermEqual(Term) - Method in class com.tangosol.coherence.dsltools.termtrees.Term
Answer whether the receiver's children is equal to the given Terms children.
chooseServer() - Method in class com.tangosol.coherence.commonj.WorkManager
Choose a Member to run a next Work at.
CHUNK_SIZE - Static variable in class com.tangosol.util.ExternalizableHelper
When using the chunking algorithm each chunk is constrained to 64MB by default.
CHUNK_THRESHOLD - Static variable in class com.tangosol.util.ExternalizableHelper
A threshold used to decide whether to perform deserialization using a chunking algorithm; default is greater than 128MB.
CircularArrayList - Class in com.tangosol.util
Resizable-array implementation of the List interface.
CircularArrayList() - Constructor for class com.tangosol.util.CircularArrayList
Create a new CircularArrayList with default settings.
CircularArrayList(int) - Constructor for class com.tangosol.util.CircularArrayList
Create a new CircularArrayList with the specified initial capacity.
CircularArrayList(Collection) - Constructor for class com.tangosol.util.CircularArrayList
Construct a CircularArrayList containing the elements of the specified collection in the order they are returned by the collection's iterator.
CircularIterator() - Constructor for class com.tangosol.net.RefreshableAddressProvider.CircularIterator
 
claimAll(ConfigurableCacheMap) - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
Claim the full entitlement of units for mapRequestor.
claimUnused(ConfigurableCacheMap) - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
Claim as many units as possible from existing maps without causing over-allocated maps to evict.
CLASS_LOADER - Static variable in class com.tangosol.net.DefaultConfigurableCacheFactory
Deprecated.
The name of the replaceable parameter representing the class loader.
CLASS_LOADER - Static variable in class com.tangosol.net.ExtensibleConfigurableCacheFactory
The name of the replaceable parameter representing the class loader.
ClassFilter - Class in com.tangosol.util
Filter which discards all objects that are not of a certain class.
ClassFilter(Class) - Constructor for class com.tangosol.util.ClassFilter
Constructor.
ClassHelper - Class in com.tangosol.util
This abstract class contains dynamic (reflect-based) class, method, and field manipulation methods.
ClassHelper() - Constructor for class com.tangosol.util.ClassHelper
 
classify() - Method in class com.tangosol.coherence.dsltools.precedence.OPScanner
Figure out how to map the current BaseToken to a OPToken and return it.
ClassLoaderAware - Interface in com.tangosol.io
The ClassLoaderAware interface provides the ability to configure a ClassLoader to be used by the implementing object when loading classes or resources.
ClassScheme - Class in com.tangosol.coherence.config.scheme
The ClassScheme class is responsible for building custom CachingSchemes and custom CacheStoreSchemes.
ClassScheme() - Constructor for class com.tangosol.coherence.config.scheme.ClassScheme
 
CLEANUP_FINALIZERS - Static variable in class com.tangosol.io.nio.DirectBufferManager
Deprecated.
Use Runtime.runFinalization() to trigger finalization (default).
CLEANUP_GC - Static variable in class com.tangosol.io.nio.DirectBufferManager
Deprecated.
Use Runtime.gc() to trigger finalization.
CLEANUP_NONE - Static variable in class com.tangosol.io.nio.DirectBufferManager
Deprecated.
Do not perform any buffer cleanup.
cleanupBuffers() - Method in class com.tangosol.io.nio.DirectBufferManager
Deprecated.
Determines if and how to induce the JVM to run finalizers.
cleanUpDeletedSessions(Set<String>) - Method in class com.tangosol.coherence.servlet.AbstractHttpSessionCollection
Clean up the HttpSession objects that are no longer alive.
cleanUpSession(String) - Method in class com.tangosol.coherence.servlet.SessionHelper
Does any addition clean up necessary for the deleted sessions.
clear() - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
 
clear() - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
 
clear() - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
 
clear() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
 
clear() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
 
clear() - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
 
clear() - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
 
clear() - Method in class com.tangosol.io.AbstractWriteBuffer
Set the length of the buffer as indicated by the WriteBuffer.length() method to zero.
clear() - Method in class com.tangosol.io.DelegatingWriteBuffer
Set the length of the buffer as indicated by the WriteBuffer.length() method to zero.
clear() - Method in class com.tangosol.io.nio.BinaryMap.Block
Zero the block.
clear() - Method in class com.tangosol.io.nio.BinaryMap
Removes all mappings from this map.
clear() - Method in class com.tangosol.io.nio.BinaryMap.EntrySet
Removes all of the elements from this set of Keys by clearing the underlying Map.
clear() - Method in class com.tangosol.io.nio.BinaryMap.KeySet
Removes all of the elements from this set of Keys by clearing the underlying Map.
clear() - Method in class com.tangosol.io.nio.BinaryMap.ValuesCollection
Removes all of the elements from this Collection of values by clearing the underlying Map.
clear() - Method in class com.tangosol.io.pof.PofHelper.ReadableEntrySetMap
Removes all mappings from this map.
clear() - Method in interface com.tangosol.io.WriteBuffer
Set the length of the buffer as indicated by the WriteBuffer.length() method to zero.
clear() - Method in interface com.tangosol.net.AsyncNamedCache
Removes all of the mappings from this cache.
clear() - Method in class com.tangosol.net.cache.AbstractSerializationCache
Clear all key/value mappings.
clear() - Method in class com.tangosol.net.cache.CacheStoreMap.ReadWriteMap
Clear is explicitly not implemented.
clear() - Method in class com.tangosol.net.cache.CachingMap
Clears both the front and back maps.
clear() - Method in class com.tangosol.net.cache.CompactSerializationCache
Clear all key/value mappings.
clear() - Method in class com.tangosol.net.cache.ContinuousQueryCache
 
clear() - Method in class com.tangosol.net.cache.LocalCache
Removes all mappings from this map.
clear() - Method in class com.tangosol.net.cache.OldCache
Deprecated.
Removes all mappings from this map.
clear() - Method in class com.tangosol.net.cache.OverflowMap
Clear all key/value mappings.
clear() - Method in class com.tangosol.net.cache.ReadonlyNamedCache
Should not be called.
clear() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
Remove everything from the Map.
clear() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.EntrySet
Removes all of the elements from this set of Keys by clearing the underlying Map.
clear() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.KeySet
Removes all of the elements from this set of Keys by clearing the underlying Map.
clear() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.ReadQueue
Remove all keys from the queue.
clear() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.ValuesCollection
Removes all of the elements from this Collection of values by clearing the underlying Map.
clear() - Method in class com.tangosol.net.cache.SerializationCache
Clear all key/value mappings.
clear() - Method in class com.tangosol.net.cache.SerializationMap
Clear all key/value mappings.
clear() - Method in class com.tangosol.net.cache.SerializationPagedCache
Clear all key/value mappings.
clear() - Method in class com.tangosol.net.cache.SimpleOverflowMap
Clear all key/value mappings.
clear() - Method in class com.tangosol.net.cache.SimpleSerializationMap
Clear all key/value mappings.
clear() - Method in interface com.tangosol.net.NamedCache
Removes all mappings from this map.
clear() - Method in class com.tangosol.net.partition.PartitionSet
Clear the set.
clear() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
Clear all key/value mappings.
clear() - Method in class com.tangosol.run.xml.SimpleElement.AttributeMap
 
clear() - Method in class com.tangosol.run.xml.SimpleElement.ElementList
Removes all of the elements from this list.
clear() - Method in class com.tangosol.util.AbstractKeyBasedMap
Clear all key/value mappings.
clear() - Method in class com.tangosol.util.AbstractKeyBasedMap.EntrySet
Removes all of the elements from this set of Keys by clearing the underlying Map.
clear() - Method in class com.tangosol.util.AbstractKeyBasedMap.KeySet
Removes all of the elements from this set of Keys by clearing the underlying Map.
clear() - Method in class com.tangosol.util.AbstractKeyBasedMap.ValuesCollection
Removes all of the elements from this Collection by clearing the underlying Map.
clear() - Method in class com.tangosol.util.AbstractLongArray
Remove all nodes from the LongArray.
clear() - Method in class com.tangosol.util.AbstractSafeLongArray
 
clear() - Method in class com.tangosol.util.AbstractSparseArray
Remove all nodes from the LongArray.
clear() - Method in interface com.tangosol.util.BinaryLongMap
Initialize the map to an empty state.
clear() - Method in class com.tangosol.util.BinaryLongMap.SimpleMapImpl
Clear all key/value mappings.
clear() - Method in class com.tangosol.util.BinaryRadixTree
Initialize the map to an empty state.
clear() - Method in class com.tangosol.util.ChainedCollection
 
clear() - Method in class com.tangosol.util.ChainedSet
 
clear() - Method in class com.tangosol.util.CircularArrayList
clear() - Method in interface com.tangosol.util.ConcurrentMap
Removes all mappings from this map.
clear() - Method in class com.tangosol.util.ConverterCollections.ConverterCollection
clear() - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet
clear() - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray
 
clear() - Method in class com.tangosol.util.ConverterCollections.ConverterMap
clear() - Method in class com.tangosol.util.CopyOnWriteLongArray
Remove all nodes from the LongArray.
clear() - Method in class com.tangosol.util.CopyOnWriteMap
clear() - Method in class com.tangosol.util.CopyOnWriteMap.EntrySet
clear() - Method in class com.tangosol.util.CopyOnWriteMap.KeySet
clear() - Method in class com.tangosol.util.DeltaSet
Removes all of the elements from this Collection.
clear() - Method in class com.tangosol.util.InflatableCollection
clear() - Method in class com.tangosol.util.LiteSet
Removes all of the elements from this Set.
clear() - Method in interface com.tangosol.util.LongArray
Remove all nodes from the LongArray.
clear() - Method in class com.tangosol.util.MapListenerSupport
Remove all signed up listeners.
clear() - Method in class com.tangosol.util.MapSet
Removes all of the elements from this Set.
clear() - Method in class com.tangosol.util.MultiBinaryLongMap.DelegatingBinaryLongMap
Initialize the map to an empty state.
clear() - Method in class com.tangosol.util.MultiBinaryLongMap.LongStorage
Reset the LongStorage to its initial empty state.
clear() - Method in class com.tangosol.util.MultiBinaryLongMap.MaskedBinaryLongMap
Initialize the map to an empty state.
clear() - Method in class com.tangosol.util.MultiBinaryLongMap.PrimaryBinaryLongMap
Initialize the map to an empty state.
clear() - Method in class com.tangosol.util.MultiBinaryLongMap.PrimaryBinaryLongMap.CompressedPrimaryBinaryLongMap
Initialize the map to an empty state.
clear() - Method in class com.tangosol.util.MultiBinaryLongMap.PrimaryBinaryLongMap.DelegatingPrimaryBinaryLongMap
Initialize the map to an empty state.
clear() - Method in class com.tangosol.util.MultiBinaryLongMap.SafeBinaryLongMap
Initialize the map to an empty state.
clear() - Method in class com.tangosol.util.MultiBinaryLongMap.WrapperBinaryLongMap
Initialize the map to an empty state.
clear() - Method in class com.tangosol.util.NullImplementation.NullSet
Removes all of the elements from this Collection.
clear() - Method in class com.tangosol.util.ObservableHashMap
Remove everything from the cache, notifying any registered listeners.
clear(boolean) - Method in class com.tangosol.util.ObservableHashMap
 
clear() - Method in class com.tangosol.util.OpenHashMap
Clear all key/value mappings.
clear() - Method in class com.tangosol.util.OpenHashSet
clear() - Method in class com.tangosol.util.RestrictedCollections.RestrictedCollection
Removes all of the elements from this Collection.
clear() - Method in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet
Removes all of the elements from this Collection.
clear() - Method in class com.tangosol.util.RestrictedCollections.RestrictedMap
Removes all mappings from this map.
clear() - Method in class com.tangosol.util.SafeHashMap
Removes all mappings from this map.
clear() - Method in class com.tangosol.util.SafeHashMap.EntrySet
Removes all of the elements from this set of Keys by clearing the underlying Map.
clear() - Method in class com.tangosol.util.SafeHashMap.KeySet
Removes all of the elements from this set of Keys by clearing the underlying Map.
clear() - Method in class com.tangosol.util.SafeHashMap.ValuesCollection
Removes all of the elements from this Collection of values by clearing the underlying Map.
clear() - Method in class com.tangosol.util.SafeLinkedList
Removes all of the elements from this List.
clear() - Method in class com.tangosol.util.SafeSortedMap.SubMap
 
clear() - Method in class com.tangosol.util.SafeSortedMap.Values
 
clear() - Method in class com.tangosol.util.SegmentedConcurrentMap
Removes all mappings from this map.
clear() - Method in class com.tangosol.util.SegmentedHashMap
Removes all mappings from this map.
clear() - Method in class com.tangosol.util.SegmentedHashMap.EntrySet
Removes all of the elements from this set of Keys by clearing the underlying Map.
clear() - Method in class com.tangosol.util.SegmentedHashMap.KeySet
Removes all of the elements from this set of Keys by clearing the underlying Map.
clear() - Method in class com.tangosol.util.SegmentedHashMap.ValuesCollection
Removes all of the elements from this Collection of values by clearing the underlying Map.
clear() - Method in class com.tangosol.util.SetMap
 
clear() - Method in class com.tangosol.util.SimpleLongArray
Remove all nodes from the LongArray.
clear() - Method in class com.tangosol.util.StringTable
Remove all strings from the table.
clear() - Method in class com.tangosol.util.SubList
clear() - Method in class com.tangosol.util.SubSet
clear() - Method in class com.tangosol.util.Tree
Remove all nodes from the tree.
clear() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperCollection
clear() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
 
clear() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperMap
clear() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperCollection
clear() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
clear() - Method in class com.tangosol.util.WrapperConcurrentMap
Clear all key/value mappings.
clear() - Method in class com.tangosol.util.WrapperObservableMap
Clear all key/value mappings.
clearBucketOffsets() - Method in class com.tangosol.io.nio.BinaryMap
Clear out all references in the array of hash buckets.
clearBucketOffsets(int) - Method in class com.tangosol.io.nio.BinaryMap
Clear out all references in the array of hash buckets starting with the specified bucket.
clearBuffer() - Method in class com.tangosol.io.nio.BinaryMap
Create one big free block in the buffer.
clearClusterCache() - Method in class com.tangosol.coherence.servlet.AbstractHttpSessionCollection
Clear the cluster cache reference.
clearConverted() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent
Remove any cached conversions of the key or values.
clearCustomFunctions() - Method in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
Remove all custom function mappings that have been registered.
clearCustomOperators() - Method in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
Remove all customisations that have been added to the CohQL language.
clearFreeLists() - Method in class com.tangosol.io.nio.BinaryMap
Clear out all references in the array of free lists.
ClearListener(BinaryLongMap, Journal, AtomicLong) - Constructor for class com.tangosol.io.journal.JournalBinaryStore.ClearListener
Construct a ClearListener for the specified BinaryLongMap and journal.
clearPending() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.WriteQueue
Clear the map of pending entries.
clearStoredConfiguration() - Method in class com.tangosol.coherence.servlet.management.HttpSessionManager
Removes the stored configuration which is used to check configuration consistency.
clearStoredConfiguration() - Method in interface com.tangosol.coherence.servlet.management.HttpSessionManagerMBean
Removes the stored configuration which is used to check configuration consistency.
clearStoredConfiguration() - Method in class com.tangosol.coherence.servlet.SessionHelper
Removes the storeSessd configuration.
clearValue() - Method in class com.tangosol.io.nio.BinaryMap.Block
Zero the value portion of the block.
CLIENT - Static variable in class com.tangosol.coherence.config.xml.processor.ServiceLoadBalancerProcessor
Client option for the service load balancer.
clone() - Method in interface com.oracle.coherence.common.base.Cloneable
Create and return a copy of this object as described by the Object.clone() contract.
clone(T) - Method in interface com.oracle.coherence.common.base.Cloner
Return a copy of the specified object.
clone(T) - Method in class com.oracle.coherence.common.base.NaturalCloner
 
clone() - Method in class com.tangosol.coherence.dsltools.precedence.NestingOPToken
 
clone() - Method in class com.tangosol.io.AbstractReadBuffer
Create a clone of this ReadBuffer object.
clone() - Method in class com.tangosol.io.AbstractWriteBuffer
Create a clone of this WriteBuffer object.
clone() - Method in class com.tangosol.io.ByteArrayReadBuffer
Create a clone of this ReadBuffer object.
clone() - Method in class com.tangosol.io.MultiBufferWriteBuffer
Create a clone of this WriteBuffer object.
clone() - Method in class com.tangosol.io.nio.ByteBufferReadBuffer
Create a clone of this ReadBuffer object.
clone() - Method in class com.tangosol.io.nio.ByteBufferWriteBuffer
Create a clone of this WriteBuffer object.
clone() - Method in interface com.tangosol.io.ReadBuffer
Create a clone of this ReadBuffer object.
clone() - Method in interface com.tangosol.io.WriteBuffer
Create a clone of this WriteBuffer object.
clone() - Method in class com.tangosol.net.partition.Ownership
Create a clone of this Ownership.
clone() - Method in class com.tangosol.net.partition.VersionedOwnership
Create a clone of this Ownership.
clone(Object) - Method in class com.tangosol.run.xml.ArrayAdapter
Make a clone of the passed object.
clone(Object) - Method in class com.tangosol.run.xml.CollectionAdapter
Make a clone of the passed object.
clone(Object) - Method in class com.tangosol.run.xml.MapAdapter
Make a clone of the passed object.
clone(Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.BooleanArrayAdapter
Make a clone of the passed object.
clone(Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.ByteArrayAdapter
Make a clone of the passed object.
clone(Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.CharArrayAdapter
Make a clone of the passed object.
clone(Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter
Make a clone of the passed object.
clone(Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.DoubleArrayAdapter
Make a clone of the passed object.
clone(Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.FloatArrayAdapter
Make a clone of the passed object.
clone(Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.IntArrayAdapter
Make a clone of the passed object.
clone(Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.LongArrayAdapter
Make a clone of the passed object.
clone(Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.ShortArrayAdapter
Make a clone of the passed object.
clone(Object) - Method in class com.tangosol.run.xml.PropertyAdapter
Make a clone of the passed object.
clone(Object) - Method in class com.tangosol.run.xml.SerializableAdapter
Make a clone of the passed object.
clone() - Method in class com.tangosol.run.xml.SimpleDocument
Creates and returns a copy of this XmlDocument.
clone() - Method in class com.tangosol.run.xml.SimpleElement.AttributeMap
 
clone() - Method in class com.tangosol.run.xml.SimpleElement
Creates and returns a copy of this SimpleElement.
clone() - Method in class com.tangosol.run.xml.SimpleValue
Creates and returns a copy of this SimpleValue.
clone() - Method in class com.tangosol.run.xml.XmlBean
Clone the value object.
clone() - Method in interface com.tangosol.run.xml.XmlDocument
Creates and returns a copy of this XmlDocument.
clone() - Method in interface com.tangosol.run.xml.XmlElement
Creates and returns a copy of this XmlElement.
clone(Object) - Method in class com.tangosol.run.xml.XmlSerializableAdapter
Make a clone of the passed object.
clone() - Method in interface com.tangosol.run.xml.XmlValue
Creates and returns a copy of this SimpleValue.
clone() - Method in class com.tangosol.util.AbstractKeyBasedMap
Returns a shallow copy of this AbstractKeyBasedMap instance; the keySet, entrySet and values collections are not cloned or copied to (shared by) the clone.
clone() - Method in class com.tangosol.util.AbstractLongArray
Make a clone of the LongArray.
clone() - Method in class com.tangosol.util.AbstractSafeLongArray
 
clone() - Method in class com.tangosol.util.AbstractSparseArray
Make a clone of the LongArray.
clone() - Method in class com.tangosol.util.AbstractSparseArray.Crawler
Make a shallow copy of the node crawler.
clone() - Method in class com.tangosol.util.AbstractSparseArray.Node
Make a shallow copy of the node and its sub-nodes.
clone() - Method in class com.tangosol.util.Binary
Create a clone of this Binary object.
clone(byte[], int, int) - Static method in class com.tangosol.util.Binary
Create a clone of the specified binary region.
clone() - Method in class com.tangosol.util.CacheCollator
Clone the caching collator.
clone() - Method in class com.tangosol.util.CircularArrayList
Returns a shallow copy of this list instance.
clone() - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray
 
clone() - Method in class com.tangosol.util.CopyOnWriteLongArray
Make a clone of the LongArray.
clone() - Method in class com.tangosol.util.DeltaSet
Clone the delta set.
clone() - Method in class com.tangosol.util.Dequeue
Creates a clone of the dequeue.
clone() - Method in class com.tangosol.util.filter.LimitFilter
Clone this filter.
clone() - Method in class com.tangosol.util.ImmutableArrayList
Create a clone of the ImmutableArrayList.
clone() - Method in class com.tangosol.util.LiteSet
Create a clone of this Set.
clone() - Method in interface com.tangosol.util.LongArray
Make a clone of the LongArray.
clone() - Method in class com.tangosol.util.MapSet
Create a clone of this MapSet.
clone() - Method in class com.tangosol.util.ReadHeavyLongArray
 
clone() - Method in class com.tangosol.util.RecyclingLinkedList
Create a deep clone of the list.
clone() - Method in class com.tangosol.util.SafeHashMap
Create a clone of the SafeHashMap.
clone() - Method in class com.tangosol.util.SafeHashMap.Entry
Clone the Entry.
clone() - Method in class com.tangosol.util.SafeLinkedList
Create a clone of the SafeLinkedList.
clone() - Method in class com.tangosol.util.SafeLinkedList.Node
 
clone() - Method in class com.tangosol.util.SafeLongArray
 
clone() - Method in class com.tangosol.util.SafeSortedMap
 
clone() - Method in class com.tangosol.util.SafeSortedMap.SubMap
 
clone() - Method in class com.tangosol.util.SimpleLongArray
Make a clone of the LongArray.
clone() - Method in class com.tangosol.util.SimpleMapEntry
Clone the Entry.
clone() - Method in class com.tangosol.util.SparseArray
 
clone() - Method in class com.tangosol.util.StringTable
Make a new string table with a copy of the tree and a copy of the collator.
clone() - Method in class com.tangosol.util.SubSet
Clone the subset.
clone() - Method in class com.tangosol.util.Tree
Make a shallow copy of the tree and its nodes.
clone() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
 
Cloneable - Interface in com.oracle.coherence.common.base
This interface is meant to "fix" the usability issues related to the Cloneable method-less interface.
cloneDependencies(AbstractJournalRM.Dependencies) - Method in class com.tangosol.io.journal.AbstractJournalRM
Clone the Dependencies object.
cloneDependencies(AbstractJournalRM.Dependencies) - Method in class com.tangosol.io.journal.FlashJournalRM
Clone the Dependencies object.
cloneDependencies(AbstractJournalRM.Dependencies) - Method in class com.tangosol.io.journal.RamJournalRM
Clone the Dependencies object.
cloneEntryList(SafeHashMap.Entry) - Method in class com.tangosol.util.SafeHashMap
Clone an entire linked list of entries.
Cloner - Interface in com.oracle.coherence.common.base
A Cloner provides an external means for producing copies of objects as prescribed by the Object.clone() contract.
close() - Method in interface com.oracle.coherence.common.base.Disposable
Default implementation invokes Disposable.dispose(), it is not recommended that this be overridden.
close() - Method in interface com.oracle.coherence.common.base.Lockable.Unlockable
Release the acquired exclusive access to this Lockable.
close() - Method in class com.oracle.coherence.common.base.NonBlocking
 
close() - Method in class com.oracle.coherence.common.base.Timeout
As part of closing the Timeout resource any former timeout will be restored.
close() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCache
 
close() - Method in class com.tangosol.coherence.jcache.CoherenceBasedCacheManager
 
close() - Method in class com.tangosol.coherence.jcache.CoherenceBasedCachingProvider
 
close(ClassLoader) - Method in class com.tangosol.coherence.jcache.CoherenceBasedCachingProvider
 
close(URI, ClassLoader) - Method in class com.tangosol.coherence.jcache.CoherenceBasedCachingProvider
 
close() - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
 
close() - Method in class com.tangosol.coherence.rest.events.MapEventOutput
 
close() - Method in class com.tangosol.coherence.servlet.CacheFactoryLogHandler
 
close() - Method in interface com.tangosol.coherence.transaction.Connection
Close the logical connection.
close() - Method in class com.tangosol.config.xml.DefaultProcessingContext
 
close() - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
Close the InputStream and release any system resources associated with it.
close() - Method in class com.tangosol.io.AbstractWriteBuffer.AbstractBufferOutput
Close the OutputStream and release any system resources associated with it.
close() - Method in class com.tangosol.io.AsyncBinaryStore
Close the store.
close() - Method in class com.tangosol.io.Base64InputStream
Close the stream, flushing any accumulated bytes.
close() - Method in class com.tangosol.io.Base64OutputStream
Close the stream, flushing any accumulated bytes.
close() - Method in class com.tangosol.io.bdb.BerkeleyDBBinaryStore
Close the BinaryStore.
close() - Method in class com.tangosol.io.DebugDataOutputStream
Closes this OutputStream and releases any associated system resources.
close() - Method in class com.tangosol.io.journal.AbstractJournalRM
Deprecated.
use the Disposable interface
close() - Method in class com.tangosol.io.journal.BackupJournalRM
Deprecated.
use the Disposable interface
close() - Method in class com.tangosol.io.MultiBufferWriteBuffer.MultiBufferOutput
Close the OutputStream and release any system resources associated with it.
close() - Method in class com.tangosol.io.MultiByteArrayInputStream
Close the stream.
close() - Method in class com.tangosol.io.MultiByteArrayOutputStream
Close the stream, flushing any accumulated bytes.
close() - Method in class com.tangosol.io.nio.BinaryMap.Block
Close the Block object, flushing any pending changes, resetting its contents and recycling the object.
close() - Method in class com.tangosol.io.nio.BinaryMapStore
Deprecated.
use the Disposable interface instead
close() - Method in class com.tangosol.io.nio.ByteBufferInputStream
Close the stream, flushing any accumulated bytes.
close() - Method in class com.tangosol.io.nio.ByteBufferOutputStream
Close the stream, flushing any accumulated bytes.
close() - Method in class com.tangosol.io.nio.MappedBufferManager
Close the underlying resources.
close() - Method in class com.tangosol.io.pof.PofInputStream
Close the InputStream and release any system resources associated with it.
close() - Method in class com.tangosol.io.pof.PofOutputStream
Closes this OutputStream and releases any associated system resources.
close() - Method in interface com.tangosol.io.ReadBuffer.BufferInput
Close the InputStream and release any system resources associated with it.
close() - Method in class com.tangosol.io.SizeEstimatingBufferOutput
 
close() - Method in class com.tangosol.io.Utf8Reader
Close the stream.
close() - Method in class com.tangosol.io.Utf8Writer
Close the stream, flushing it first.
close() - Method in class com.tangosol.io.WrapperBufferOutput
Close the OutputStream and release any system resources associated with it.
close() - Method in class com.tangosol.io.WrapperDataInputStream
Close the InputStream and release any system resources associated with it.
close() - Method in class com.tangosol.io.WrapperDataOutputStream
Closes this OutputStream and releases any associated system resources.
close() - Method in class com.tangosol.io.WrapperInputStream
Close the InputStream and release any system resources associated with it.
close() - Method in class com.tangosol.io.WrapperObjectInputStream
Close the InputStream and release any system resources associated with it.
close() - Method in class com.tangosol.io.WrapperOutputStream
Closes this OutputStream and releases any associated system resources.
close() - Method in interface com.tangosol.io.WriteBuffer.BufferOutput
Close the OutputStream and release any system resources associated with it.
close() - Method in class com.tangosol.io.WriterPrintStream
Close the stream.
close() - Method in class com.tangosol.net.cache.SerializationPagedCache.PagedBinaryStore
Release underlying resources.
close() - Method in class com.tangosol.net.cache.SerializationPagedCache.WrapperBinaryStore
Used to specify that the page is no longer current.
close() - Method in class com.tangosol.net.CoherenceSession
 
close() - Method in class com.tangosol.net.CompressionFilter.DeflaterOutputShell
Deprecated.
Close the input stream.
close() - Method in class com.tangosol.net.CompressionFilter.InflaterInputShell
Deprecated.
Close the input stream.
close() - Method in class com.tangosol.net.DatagramPacketOutputStream
Closes this output stream and releases any system resources associated with this stream.
close() - Method in interface com.tangosol.net.Releasable
 
close() - Method in class com.tangosol.net.TcpDatagramSocket.Impl
close() - Method in interface com.tangosol.net.topic.Publisher
Close this Publisher.
close() - Method in interface com.tangosol.net.topic.Subscriber
Close the Subscriber.
close(String) - Method in class com.tangosol.persistence.AbstractPersistenceManager
Close the associated PersistentStore and release exclusive access to the associated resources.
close(String) - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceManager
Close the associated PersistentStore and release exclusive access to the associated resources.
close() - Method in class com.tangosol.run.jca.CacheAdapter
Close the connection associated with this adapter.
close() - Method in class com.tangosol.util.ExternalizableHelper.ShieldedDataOutputStream
 
close() - Method in class com.tangosol.util.ExternalizableHelper.ShieldedInputStream
 
close() - Method in class com.tangosol.util.ExternalizableHelper.ShieldedObjectOutputStream
 
close() - Method in class com.tangosol.util.ExternalizableHelper.ShieldedOutputStream
 
close() - Method in class com.tangosol.util.NullImplementation.NullOutputStream
Closes this OutputStream and releases any associated system resources.
close(String) - Method in class com.tangosol.util.NullImplementation.NullPersistenceManager
Close the associated PersistentStore and release exclusive access to the associated resources.
close() - Method in class com.tangosol.util.NullImplementation.NullReader
close() - Method in class com.tangosol.util.NullImplementation.NullWriter
close() - Method in class com.tangosol.util.ThreadGateLite
 
close(long) - Method in class com.tangosol.util.ThreadGateLite
Close the gate.
close(long) - Method in class com.tangosol.util.WrapperReentrantGate
Close the gate.
close() - Method in class com.tangosol.util.WrapperReentrantGate
 
closeDb() - Method in class com.tangosol.io.bdb.BerkeleyDBBinaryStore.DatabaseHolder
Close the Database.
closeEnvironment(boolean) - Method in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
Close an Environment.
closeInbound(TcpDatagramSocket.Impl.ConnectionStatus, SocketChannel) - Method in class com.tangosol.net.TcpDatagramSocket.Impl
Close the inbound channel.
closeNested() - Method in class com.tangosol.io.pof.PofBufferReader.UserTypeReader
Notify the UserTypeReader that it is being "closed".
closeNested() - Method in class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
Notify the UserTypeWriter that it is being "closed".
closeOutbound(SocketAddress) - Method in class com.tangosol.net.TcpDatagramSocket.Impl
Close the outbound socket.
closeProcessing() - Method in class com.tangosol.net.cache.OverflowMap.Status
Finish the processing of the entry for which this Status exists and proceed to the commit phase.
closeProcessing() - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
Finish the processing of the entry for which this Status exists and proceed to the commit phase.
closeStatus(OverflowMap.Status) - Method in class com.tangosol.net.cache.OverflowMap
Helper method to close a Status, processing any pending events as part of the process.
Cluster - Interface in com.tangosol.net
The Cluster interface represents a collection of services that operate in a clustered network environment.
CLUSTER - Static variable in class com.tangosol.net.management.MBeanAccessor
The "cluster" key in the ObjectName.
Cluster.MemberTimeoutAction - Interface in com.tangosol.net
MemberTimeoutAction is taken by the cluster service to remove members from the cluster who have exceeded a network timeout (e.g. packet-timeout).
CLUSTER_TYPE - Static variable in interface com.tangosol.net.management.Registry
String representation of the ObjectName for the ClusterMBean.
ClusterDependencies - Interface in com.tangosol.net
The ClusterDependencies interface defines externally provided dependencies for a Cluster.
ClusteredCachingScheme - Interface in com.tangosol.coherence.config.scheme
The ClusteredCachingScheme interface represents schemes that are used for clustered caches.
ClusterException - Exception in com.tangosol.net
Deprecated.
As of release 3.4, replaced by PortableException
ClusterException() - Constructor for exception com.tangosol.net.ClusterException
Deprecated.
Constructs a ClusterException with no detail message.
ClusterException(String) - Constructor for exception com.tangosol.net.ClusterException
Deprecated.
Constructs a ClusterException with the specified detail message.
ClusterException(Throwable) - Constructor for exception com.tangosol.net.ClusterException
Deprecated.
Construct a ClusterException from a Throwable object.
ClusterException(String, Throwable) - Constructor for exception com.tangosol.net.ClusterException
Deprecated.
Construct a ClusterException from a Throwable object and an additional description.
ClusterPermission - Class in com.tangosol.net
This class represents access to a clustered resource such as a Service or NamedCache.
ClusterPermission(String, String) - Constructor for class com.tangosol.net.ClusterPermission
Construct a ClusterPermission object.
ClusterPermission(String, String, String) - Constructor for class com.tangosol.net.ClusterPermission
Construct a ClusterPermission object.
ClusterQuorumPolicy(Map<String, Integer>) - Constructor for class com.tangosol.net.ConfigurableQuorumPolicy.ClusterQuorumPolicy
Construct a ClusterQuorumPolicy with the specified quorum map.
ClusterQuorumPolicyBuilder - Class in com.tangosol.coherence.config.builder
Defer cache configuration validation of a ClusterQuorumPolicyBuilder until realized.
ClusterQuorumPolicyBuilder(Map<String, Integer>, XmlElement) - Constructor for class com.tangosol.coherence.config.builder.ClusterQuorumPolicyBuilder
Constructs ClusterQuorumPolicyBuilder from mapQuorum
CMP_AUTO - Static variable in class com.tangosol.util.comparator.EntryComparator
Indicates that this EntryComparator should choose the comparison style based on the underying comparator type.
CMP_ENTRY - Static variable in class com.tangosol.util.comparator.EntryComparator
Indicates that entries that implement QueryMap.Entry interface will be compared using the compareEntries() method.
CMP_KEY - Static variable in class com.tangosol.util.comparator.EntryComparator
Indicates that this EntryComparator should compare the entries' keys.
CMP_VALUE - Static variable in class com.tangosol.util.comparator.EntryComparator
Indicates that this EntryComparator should compare the entries' values.
CoalescedEvent(Event<S>) - Constructor for class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.CoalescedEvent
CoalescedEvent(Event<S>, NonBlockingFiniteStateMachine.CoalescedEvent.Process) - Constructor for class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.CoalescedEvent
Constructs a NonBlockingFiniteStateMachine.CoalescedEvent of the specified Event type.
CoalescedEvent(Event<S>, NonBlockingFiniteStateMachine.CoalescedEvent.Process, Object) - Constructor for class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.CoalescedEvent
Constructs a NonBlockingFiniteStateMachine.CoalescedEvent with the specified discriminator and Event.
Codec - Interface in com.tangosol.io.pof.reflect
A Codec provides an interception point for any specific code that needs to be executed pre or post (de)serialization.
Codecs - Class in com.tangosol.io.pof.reflect
Codecs is a container for accessing default Codec implementations.
Codecs() - Constructor for class com.tangosol.io.pof.reflect.Codecs
 
Codecs.AbstractCodec - Class in com.tangosol.io.pof.reflect
Abstract Codec implementations that encodes objects by simply delegating to PofWriter.writeObject(int, Object).
Codecs.ArrayCodec - Class in com.tangosol.io.pof.reflect
Implementation of Codec that delegates to PofReader.readObjectArray(int, Object[]) and PofWriter.writeObjectArray(int, Object[]) to deserialize and serialize an object.
Codecs.CollectionCodec - Class in com.tangosol.io.pof.reflect
Implementation of Codec that delegates to PofReader.readCollection(int, Collection) and PofWriter.writeCollection(int, Collection) to deserialize and serialize an object.
Codecs.DefaultCodec - Class in com.tangosol.io.pof.reflect
Implementation of Codec that simply delegates to PofReader.readObject(int) and PofWriter.writeObject(int, Object) to deserialize and serialize an object.
Codecs.LongArrayCodec - Class in com.tangosol.io.pof.reflect
Implementation of Codec that delegates to PofReader.readLongArray(int, LongArray) and PofWriter.writeLongArray(int, LongArray) to deserialize and serialize an object.
Codecs.MapCodec - Class in com.tangosol.io.pof.reflect
Implementation of Codec that delegates to PofReader.readMap(int, Map) and PofWriter.writeMap(int, Map) to deserialize and serialize an object.
CoherenceBasedCache<K,V> - Interface in com.tangosol.coherence.jcache
An Coherence-based implementation of a Cache.
CoherenceBasedCacheManager - Class in com.tangosol.coherence.jcache
The Coherence-based implementation of a CacheManager.
CoherenceBasedCacheManager(CoherenceBasedCachingProvider, ConfigurableCacheFactory, URI, ClassLoader, Properties) - Constructor for class com.tangosol.coherence.jcache.CoherenceBasedCacheManager
Constructs a new CoherenceBasedCacheManager.
CoherenceBasedCachingProvider - Class in com.tangosol.coherence.jcache
The Coherence-based implementation of a CachingProvider.
CoherenceBasedCachingProvider() - Constructor for class com.tangosol.coherence.jcache.CoherenceBasedCachingProvider
CoherenceBasedCompleteConfiguration<K,V> - Interface in com.tangosol.coherence.jcache
An Coherence-based CompleteConfiguration that provides setter methods.
CoherenceBasedConfiguration<K,V> - Interface in com.tangosol.coherence.jcache
A Configuration for a CoherenceBasedCache.
CoherenceCacheEntry<K,V> - Class in com.tangosol.coherence.jcache.common
A Cache.Entry implementation.
CoherenceCacheEntry(Map.Entry<K, V>) - Constructor for class com.tangosol.coherence.jcache.common.CoherenceCacheEntry
Constructs a CoherenceCacheEntry given a Map.Entry.
CoherenceCacheEntry(K, V) - Constructor for class com.tangosol.coherence.jcache.common.CoherenceCacheEntry
Constructs a CoherenceCacheEntry given a key and value
CoherenceCacheEntry(K, V, V) - Constructor for class com.tangosol.coherence.jcache.common.CoherenceCacheEntry
Constructs a CoherenceCacheEntry given a key, value and previous value.
CoherenceCacheEntryEvent<K,V> - Class in com.tangosol.coherence.jcache.common
A minimal implementation of the CacheEntryEvent.
CoherenceCacheEntryEvent(Cache<K, V>, EventType, K, V) - Constructor for class com.tangosol.coherence.jcache.common.CoherenceCacheEntryEvent
Constructs a CoherenceCacheEntryEvent based on a specific key and value.
CoherenceCacheEntryEvent(Cache<K, V>, EventType, K, V, V) - Constructor for class com.tangosol.coherence.jcache.common.CoherenceCacheEntryEvent
Constructs a CoherenceCacheEntryEvent based on a specific key, value and old value.
CoherenceCacheEntryEventFilteringIterable<K,V> - Class in com.tangosol.coherence.jcache.common
An adapter to provide Iterables over Cache Entries, those of which are filtered using a CacheEntryEventFilter.
CoherenceCacheEntryEventFilteringIterable(Iterable<CacheEntryEvent<K, V>>, CacheEntryEventFilter<? super K, ? super V>) - Constructor for class com.tangosol.coherence.jcache.common.CoherenceCacheEntryEventFilteringIterable
CoherenceCacheEntryEventFilteringIterator<K,V> - Class in com.tangosol.coherence.jcache.common
An Iterators to allow filtering of CacheEntryEvents.
CoherenceCacheEntryEventFilteringIterator(Iterator<CacheEntryEvent<K, V>>, CacheEntryEventFilter<? super K, ? super V>) - Constructor for class com.tangosol.coherence.jcache.common.CoherenceCacheEntryEventFilteringIterator
CoherenceCacheEntryListenerRegistration<K,V> - Class in com.tangosol.coherence.jcache.common
A runtime representation of a CacheEntryListener registration, including its CacheEntryListenerConfiguration.
CoherenceCacheEntryListenerRegistration(CacheEntryListenerConfiguration<K, V>) - Constructor for class com.tangosol.coherence.jcache.common.CoherenceCacheEntryListenerRegistration
Constructs a CoherenceCacheEntryListenerRegistration based on a CacheEntryListenerConfiguration.
CoherenceCacheEventEventDispatcher<K,V> - Class in com.tangosol.coherence.jcache.common
Collects and appropriately dispatches CacheEntryEvents to CacheEntryListeners.
CoherenceCacheEventEventDispatcher() - Constructor for class com.tangosol.coherence.jcache.common.CoherenceCacheEventEventDispatcher
CoherenceCacheMXBean<K,V> - Class in com.tangosol.coherence.jcache.common
The Coherence implementation of a CacheMXBean.
CoherenceCacheMXBean(CoherenceBasedCache<K, V>) - Constructor for class com.tangosol.coherence.jcache.common.CoherenceCacheMXBean
Constructs a CoherenceCacheMXBean.
CoherenceConverterAdapter<T> - Class in com.tangosol.coherence.jcache.common
An InternalConverter that uses two Coherence Converters as a means of performing conversions to and from internal representations.
CoherenceConverterAdapter(Converter, Converter) - Constructor for class com.tangosol.coherence.jcache.common.CoherenceConverterAdapter
Constructs a CoherenceConverterAdapter given two Coherence Converters.
CoherenceEntryProcessorResult<T> - Class in com.tangosol.coherence.jcache.common
A Coherence-based EntryProcessorResult.
CoherenceEntryProcessorResult() - Constructor for class com.tangosol.coherence.jcache.common.CoherenceEntryProcessorResult
Constructs a CoherenceEntryProcessorResult (for serialization).
CoherenceEntryProcessorResult(Exception) - Constructor for class com.tangosol.coherence.jcache.common.CoherenceEntryProcessorResult
CoherenceEntryProcessorResult(T) - Constructor for class com.tangosol.coherence.jcache.common.CoherenceEntryProcessorResult
Constructs an CoherenceEntryProcessorResult for a specific value.
CoherenceHttpSessionCollection - Interface in com.tangosol.coherence.servlet
 
CoherenceQueryLanguage - Class in com.tangosol.coherence.dslquery
CoherenceQueryLanguage is a simple language for building Filters and doing simple queries that are similar in style to SQL.
CoherenceQueryLanguage() - Constructor for class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
Construct a CoherenceQueryLanguage instance.
CoherenceQueryLanguageEngine - Class in com.tangosol.coherence.rest.query
Coherence QL-based implementation of QueryEngine.
CoherenceQueryLanguageEngine() - Constructor for class com.tangosol.coherence.rest.query.CoherenceQueryLanguageEngine
 
CoherenceSession - Class in com.tangosol.net
An implementation of a Session allowing applications to use the new operator to create a Session via the default SessionProvider.
CoherenceSession(Session.Option...) - Constructor for class com.tangosol.net.CoherenceSession
Constructs a CoherenceSession based on the specified Options using the default SessionProvider.
CohQLException - Exception in com.tangosol.coherence.dslquery
An exception thrown when errors occur building CohQL queries.
CohQLException(String) - Constructor for exception com.tangosol.coherence.dslquery.CohQLException
Construct a new exception with the specified detail message.
CohQLException(String, Throwable) - Constructor for exception com.tangosol.coherence.dslquery.CohQLException
Construct a new exception with the specified detail message and cause.
collect(Supplier<R>, ObjDoubleConsumer<R>, BiConsumer<R, R>) - Method in interface com.tangosol.util.stream.RemoteDoubleStream
Performs a mutable reduction operation on the elements of this stream.
collect(Remote.Supplier<R>, Remote.ObjDoubleConsumer<R>, Remote.BiConsumer<R, R>) - Method in interface com.tangosol.util.stream.RemoteDoubleStream
Performs a mutable reduction operation on the elements of this stream.
collect(Supplier<R>, ObjIntConsumer<R>, BiConsumer<R, R>) - Method in interface com.tangosol.util.stream.RemoteIntStream
Performs a mutable reduction operation on the elements of this stream.
collect(Remote.Supplier<R>, Remote.ObjIntConsumer<R>, Remote.BiConsumer<R, R>) - Method in interface com.tangosol.util.stream.RemoteIntStream
Performs a mutable reduction operation on the elements of this stream.
collect(Supplier<R>, ObjLongConsumer<R>, BiConsumer<R, R>) - Method in interface com.tangosol.util.stream.RemoteLongStream
Performs a mutable reduction operation on the elements of this stream.
collect(Remote.Supplier<R>, Remote.ObjLongConsumer<R>, Remote.BiConsumer<R, R>) - Method in interface com.tangosol.util.stream.RemoteLongStream
Performs a mutable reduction operation on the elements of this stream.
collect(Supplier<R>, BiConsumer<R, ? super T>, BiConsumer<R, R>) - Method in interface com.tangosol.util.stream.RemoteStream
Performs a mutable reduction operation on the elements of this stream.
collect(Remote.Supplier<R>, Remote.BiConsumer<R, ? super T>, Remote.BiConsumer<R, R>) - Method in interface com.tangosol.util.stream.RemoteStream
Performs a mutable reduction operation on the elements of this stream.
collect(Collector<? super T, A, R>) - Method in interface com.tangosol.util.stream.RemoteStream
Performs a mutable reduction operation on the elements of this stream using a Collector.
collect(RemoteCollector<? super T, A, R>) - Method in interface com.tangosol.util.stream.RemoteStream
Performs a mutable reduction operation on the elements of this stream using a Collector.
collectEndangered(PartitionSet) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
Return a partition set representing the subset of the specified partitions that are "endangered".
collectingAndThen(RemoteCollector<T, A, R>, Remote.Function<R, RR>) - Static method in class com.tangosol.util.stream.RemoteCollectors
Adapts a Collector to perform an additional finishing transformation.
COLLECTION_EMPTY - Static variable in class com.tangosol.io.pof.PofHelper
An empty (and immutable) collection.
CollectionAdapter - Class in com.tangosol.run.xml
A CollectionAdapter supports properties whose types implement the java.util.Collection interface.
CollectionAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.CollectionAdapter
Construct a CollectionAdapter.
CollectionCodec(Class<? extends Collection<Object>>) - Constructor for class com.tangosol.io.pof.reflect.Codecs.CollectionCodec
Construct a CollectionCodec.
CollectionCoordinator() - Constructor for class com.tangosol.io.journal.AbstractJournalRM.CollectorDaemon.CollectionCoordinator
 
CollectionHelper - Class in com.tangosol.util
Deprecated.
As of Coherence 12.1.2
CollectionHelper() - Constructor for class com.tangosol.util.CollectionHelper
Deprecated.
 
CollectionRefExpression(Expression<?>, ClassLoader, ResourceMappingRegistry) - Constructor for class com.tangosol.coherence.config.xml.processor.InitParamProcessor.CollectionRefExpression
Constructs a CollectionRefExpression.
collectListeners(MapEvent) - Method in class com.tangosol.util.MapListenerSupport
Collect all Listeners that should be notified for a given event.
collectMembershipInfo() - Method in class com.tangosol.coherence.commonj.WorkManager
Inform all the members about this node's role (client or server) and collect the information regarding other nodes' roles
CollectMembershipInfo() - Constructor for class com.tangosol.coherence.commonj.WorkManager.CollectMembershipInfo
Default constructor (necessary for a lite serialization).
CollectMembershipInfo(Member) - Constructor for class com.tangosol.coherence.commonj.WorkManager.CollectMembershipInfo
Construct the task for a given member server (could be null for a client).
Collector<V> - Interface in com.oracle.coherence.common.base
A Collector is mechanism for receiving items.
CollectorDaemon() - Constructor for class com.tangosol.io.journal.AbstractJournalRM.CollectorDaemon
Construct a CollectorDaemon.
collectOrphaned(PartitionSet) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
Return a partition set representing the subset of the specified partitions that are "orphaned".
collectRemoved(Object, Object) - Method in class com.tangosol.util.SimpleMapIndex
Given that the old value is known to be a Collection or an array, collect all the enclosed elements that are not part of the new value.
collectScheduledDistributions() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
Collect the scheduled partition distributions, grouped by the primary owner and storage index.
collectServiceSchemes(XmlElement) - Static method in class com.tangosol.net.DefaultConfigurableCacheFactory
Deprecated.
Collect a map keyed by service names with values of corresponding service schemes in the specified cache configuration.
collectServiceSchemes(XmlElement, XmlElement, HashMap) - Static method in class com.tangosol.net.DefaultConfigurableCacheFactory
Deprecated.
Collect the service-schemes referenced by the specified scheme element in the cache configuration and update the specified mapping of service names to the associated service schemes.
collectWeak(PartitionSet) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
Return a partition set representing the subset of the specified partitions that are "weak" or "vulnerable" (as defined by the backup strength).
ColonToken - Class in com.tangosol.coherence.dsltools.termlanguage
Colon is used to make attributes in a list or bag.
ColonToken(String, int) - Constructor for class com.tangosol.coherence.dsltools.termlanguage.ColonToken
Construct a new ColonToken with the given parameters.
com.oracle.coherence.common.base - package com.oracle.coherence.common.base
The base package provides a number of classes to complement those in the java.lang package.
com.tangosol.application - package com.tangosol.application
Contains classes supporting the Coherence Container.
com.tangosol.coherence.commonj - package com.tangosol.coherence.commonj
Contains Coherence-based WorkManager implementation classes.
com.tangosol.coherence.config - package com.tangosol.coherence.config
Defines the Coherence configuration object model for accessing, customizing and or modifying configuration.
com.tangosol.coherence.config.builder - package com.tangosol.coherence.config.builder
Defines the typical runtime configuration builders for the Coherence configuration object model.
com.tangosol.coherence.config.builder.storemanager - package com.tangosol.coherence.config.builder.storemanager
Defines external Store Manager Builder implementations for Coherence caches
com.tangosol.coherence.config.scheme - package com.tangosol.coherence.config.scheme
Defines the Coherence configuration object model classes and interfaces for Caching and Service Schemes.
com.tangosol.coherence.config.unit - package com.tangosol.coherence.config.unit
Defines the standard units of measure for the Coherence configuration object model.
com.tangosol.coherence.config.xml - package com.tangosol.coherence.config.xml
Defines the Xml Document Pre-Processors and Xml Element Processors for converting Coherence Cache Configuration files into Coherence configuration object models.
com.tangosol.coherence.config.xml.preprocessor - package com.tangosol.coherence.config.xml.preprocessor
Defines the Xml document Pre-Processors for Coherence Cache Configuration files.
com.tangosol.coherence.config.xml.processor - package com.tangosol.coherence.config.xml.processor
Defines the Xml document Element and Attribute Processors for Coherence Cache Configuration files.
com.tangosol.coherence.dslquery - package com.tangosol.coherence.dslquery
 
com.tangosol.coherence.dslquery.function - package com.tangosol.coherence.dslquery.function
This package contains builders for the various CohQL functions.
com.tangosol.coherence.dslquery.internal - package com.tangosol.coherence.dslquery.internal
 
com.tangosol.coherence.dslquery.operator - package com.tangosol.coherence.dslquery.operator
This package contains implementations of the com.tangosol.coherence.dslquery.BaseOperator interface.
com.tangosol.coherence.dslquery.queryplus - package com.tangosol.coherence.dslquery.queryplus
This package contains commands that are specific to the QueryPlus tool rather than general CohQL commands.
com.tangosol.coherence.dslquery.statement - package com.tangosol.coherence.dslquery.statement
This package contains StatementBuilder implementations and com.tangosol.coherence.dslquery.CohQLStatement implementations.
com.tangosol.coherence.dslquery.statement.persistence - package com.tangosol.coherence.dslquery.statement.persistence
 
com.tangosol.coherence.dslquery.token - package com.tangosol.coherence.dslquery.token
This package contains implementations of OPToken specifically for parsing CohQL statements.
com.tangosol.coherence.dslquery.token.persistence - package com.tangosol.coherence.dslquery.token.persistence
 
com.tangosol.coherence.dsltools.base - package com.tangosol.coherence.dsltools.base
 
com.tangosol.coherence.dsltools.precedence - package com.tangosol.coherence.dsltools.precedence
 
com.tangosol.coherence.dsltools.termlanguage - package com.tangosol.coherence.dsltools.termlanguage
 
com.tangosol.coherence.dsltools.termtrees - package com.tangosol.coherence.dsltools.termtrees
 
com.tangosol.coherence.federation - package com.tangosol.coherence.federation
Contains Federation conflict resolution interfaces.
com.tangosol.coherence.federation.events - package com.tangosol.coherence.federation.events
Contains abstract classes for processing Federated Caching Live Events.
com.tangosol.coherence.jcache - package com.tangosol.coherence.jcache
Contains classes related to Coherence JCache.
com.tangosol.coherence.jcache.common - package com.tangosol.coherence.jcache.common
Common utilities used by Coherence JCache.
com.tangosol.coherence.jcache.localcache - package com.tangosol.coherence.jcache.localcache
Contains classes related to local cache implementation of Coherence JCache.
com.tangosol.coherence.jcache.partitionedcache - package com.tangosol.coherence.jcache.partitionedcache
Contains classes related to partitioned cache implementation of Coherence JCache.
com.tangosol.coherence.jcache.passthroughcache - package com.tangosol.coherence.jcache.passthroughcache
Contains classes related to pass-through cache implementation of Coherence JCache.
com.tangosol.coherence.jcache.remotecache - package com.tangosol.coherence.jcache.remotecache
Contains classes related to remote cache implementation of Coherence JCache.
com.tangosol.coherence.rest - package com.tangosol.coherence.rest
Contains classes related to the Coherence REST API.
com.tangosol.coherence.rest.config - package com.tangosol.coherence.rest.config
Contains classes related to the Coherence REST configuration.
com.tangosol.coherence.rest.events - package com.tangosol.coherence.rest.events
 
com.tangosol.coherence.rest.io - package com.tangosol.coherence.rest.io
Contains classes related to REST marshalling.
com.tangosol.coherence.rest.providers - package com.tangosol.coherence.rest.providers
 
com.tangosol.coherence.rest.query - package com.tangosol.coherence.rest.query
Contains classes related to the Coherence REST pluggable query engine.
com.tangosol.coherence.rest.server - package com.tangosol.coherence.rest.server
Contains classes related to embedded HTTP server integration.
com.tangosol.coherence.rest.servlet - package com.tangosol.coherence.rest.servlet
Contains classes related to J2EE server integration.
com.tangosol.coherence.rest.util - package com.tangosol.coherence.rest.util
 
com.tangosol.coherence.rest.util.aggregator - package com.tangosol.coherence.rest.util.aggregator
Contains classes related to REST-based aggregation.
com.tangosol.coherence.rest.util.extractor - package com.tangosol.coherence.rest.util.extractor
 
com.tangosol.coherence.rest.util.processor - package com.tangosol.coherence.rest.util.processor
Contains classes related to REST-based entry processing.
com.tangosol.coherence.rest.util.updater - package com.tangosol.coherence.rest.util.updater
 
com.tangosol.coherence.servlet - package com.tangosol.coherence.servlet
Contains classes related to the HTTP Session Replication Module.
com.tangosol.coherence.servlet.api23 - package com.tangosol.coherence.servlet.api23
Contains classes related to the HTTP Session Replication Module that are specific to the Servlet 2.3 specification and higher.
com.tangosol.coherence.servlet.commonj - package com.tangosol.coherence.servlet.commonj
 
com.tangosol.coherence.servlet.commonj.impl - package com.tangosol.coherence.servlet.commonj.impl
 
com.tangosol.coherence.servlet.management - package com.tangosol.coherence.servlet.management
Contains Coherence*Web MBean classes.
com.tangosol.coherence.transaction - package com.tangosol.coherence.transaction
Contains classes related to the Coherence Transaction Framework.
com.tangosol.coherence.transaction.exception - package com.tangosol.coherence.transaction.exception
Contains classes related to the Coherence Transaction Framework.
com.tangosol.config - package com.tangosol.config
Defines commonly required, generic and helper classes, interfaces and annotations used to simplify the configuration of objects, services, caches and components.
com.tangosol.config.annotation - package com.tangosol.config.annotation
Defines annotations typically used for configuring, documenting and injecting values into objects.
com.tangosol.config.xml - package com.tangosol.config.xml
Defines classes and interfaces for processing Xml documents and building object models, like configuration, based on said documents though the use of injection.
com.tangosol.io - package com.tangosol.io
Contains classes providing cache persistence of serialized objects.
com.tangosol.io.bdb - package com.tangosol.io.bdb
Contains Sleepycat Berkeley DB BinaryStore implementation classes.
com.tangosol.io.journal - package com.tangosol.io.journal
Contains classes related to the journaling services.
com.tangosol.io.nio - package com.tangosol.io.nio
Contains classes related to J2SE 1.