- 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
-
- 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
-
- AbstractCoherenceBasedCache(CoherenceBasedCacheManager, String, C) - Constructor for class com.tangosol.coherence.jcache.AbstractCoherenceBasedCache
-
- AbstractCoherenceBasedCompleteConfiguration<K,V> - Class in com.tangosol.coherence.jcache
-
- AbstractCoherenceBasedCompleteConfiguration() - Constructor for class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
-
- AbstractCoherenceBasedCompleteConfiguration(CompleteConfiguration<K, V>) - Constructor for class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
-
- 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.
- 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
-
- AbstractEmptyElementProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.AbstractEmptyElementProcessor
-
- AbstractEmptyElementProcessor(AbstractEmptyElementProcessor.EmptyElementBehavior) - Constructor for class com.tangosol.coherence.config.xml.processor.AbstractEmptyElementProcessor
-
- AbstractEmptyElementProcessor(T) - Constructor for class com.tangosol.coherence.config.xml.processor.AbstractEmptyElementProcessor
-
- AbstractEmptyElementProcessor.EmptyElementBehavior - Enum in com.tangosol.coherence.config.xml.processor
-
- 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
-
- 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
-
- 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
-
- AbstractJournalScheme<T> - Class in com.tangosol.coherence.config.scheme
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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.
- 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
LongArray
s 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
-
- 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
-
- 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
-
- 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
-
- AbstractStatement() - Constructor for class com.tangosol.coherence.dslquery.statement.AbstractStatement
-
- AbstractStatementBuilder<T extends Statement> - Class in com.tangosol.coherence.dslquery.statement
-
- AbstractStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.statement.AbstractStatementBuilder
-
- AbstractStoreManager - Class in com.tangosol.io.nio
-
- 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
-
- 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
-
- accept() - Method in class com.tangosol.net.CompositeAddressProvider.SingleProvider
-
- accept() - Method in class com.tangosol.net.CompositeSocketAddressProvider
-
- accept() - Method in class com.tangosol.net.ConfigurableAddressProvider
-
- accept() - Method in class com.tangosol.net.RefreshableAddressProvider
-
- accept() - Method in interface com.tangosol.net.SocketAddressProvider
-
- 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
-
- 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
Term
s
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
-
- 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.
- 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.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 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.
- ADAPTER_INIT_PARAMS - Static variable in class com.tangosol.run.xml.XmlBean.BeanInfo
-
Parameters for finding the default adapter constructor.
- 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
-
- add(Parameter) - Method in class com.tangosol.coherence.config.ResolvableParameterList
-
- add(Parameter) - Method in class com.tangosol.coherence.config.SimpleParameterList
-
- 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) - 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(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) - 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
-
- 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
-
- addCookie(Class<T>, T) - Method in class com.tangosol.config.xml.DefaultProcessingContext
-
- addCookie(Class<T>, String, T) - Method in interface com.tangosol.config.xml.ProcessingContext
-
- addCookie(Class<T>, T) - Method in interface com.tangosol.config.xml.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.
- 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
-
- addEventInterceptor(String, EventInterceptor<E>) - Method in interface com.tangosol.net.events.EventDispatcher
-
- addEventInterceptor(String, EventInterceptor<E>, Set<T>, boolean) - Method in interface com.tangosol.net.events.EventDispatcher
-
- 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
-
- addIndex(ValueExtractor<? super T, ? extends E>, boolean, Comparator<? super E>) - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
- 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(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.
- 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.
- 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.
- addLookupCallback(NameService.LookupCallback) - Method in interface com.tangosol.net.NameService
-
- 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<? 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- addStateExitAction(S, StateExitAction<S>) - Method in class com.tangosol.util.fsm.SimpleModel
-
- addStatement(String, StatementBuilder<?>) - Method in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
-
- 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
-
- 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
-
- 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
-
- 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
-
- addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.XorOperator
-
- addTransition(Transition<S>) - Method in class com.tangosol.util.fsm.SimpleModel
-
- 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.SafeSortedMap.ViewMap.EntryIterator
-
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.
- 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
-
- 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(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.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(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
-
- 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
-
- AnnotationDrivenModel(Class<S>, Object) - Constructor for class com.tangosol.util.fsm.AnnotationDrivenModel
-
- 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.
- 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, Object>, ? extends MapIndex<? extends RK, ? extends V, Object>>, Set<? extends RK>) - 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.
- applySortedIndex(Set, SortedMap<Object, Set>) - Method in class com.tangosol.util.filter.BetweenFilter
-
- 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
-
- 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
-
- 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
-
- assertNotDisposed() - Method in class com.tangosol.net.SimpleServiceMonitor
-
- 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.
- 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.
- associatedWith(K) - Method in interface com.tangosol.util.Filter
-
Return a key associated filter based on this filter and a specified key.
- 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
-
- AsyncNamedCache.Option - Interface in com.tangosol.net
-
- 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.
- AttributeMap() - Constructor for class com.tangosol.run.xml.SimpleElement.AttributeMap
-
- AttributeProcessor<T> - Interface in com.tangosol.config.xml
-
- 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
-
- 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.
- 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.
- 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.
- 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
-
- 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
-
- CacheDefaultsPreprocessor(String) - Constructor for class com.tangosol.coherence.config.xml.preprocessor.CacheDefaultsPreprocessor
-
- 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.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
-
- 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.
- 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
-
- 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
-
- CacheMappingProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.CacheMappingProcessor
-
- CacheMappingRegistry - Class in com.tangosol.coherence.config
-
- CacheMappingRegistry() - Constructor for class com.tangosol.coherence.config.CacheMappingRegistry
-
Deprecated.
- CacheMappingRegistry(ResourceMappingRegistry) - Constructor for class com.tangosol.coherence.config.CacheMappingRegistry
-
Deprecated.
- 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
-
- CacheResource - Class in com.tangosol.coherence.rest
-
- 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
-
- 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
-
- CachingSchemeMappingProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.CachingSchemeMappingProcessor
-
- CachingSchemesProcessor - Class in com.tangosol.coherence.config.xml.processor
-
- 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.
- 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.
- 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, Object>, ? extends MapIndex<? extends RK, ? extends V, Object>>, Set<? extends RK>) - 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.
- calculateHeadWeight() - Method in class com.tangosol.util.SafeSortedMap.Split
-
Estimate the weight of the head portion of the Split.
- 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.
- 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.
- calculateRandomLevel() - Method in class com.tangosol.util.SafeSortedMap
-
Randomly generate a level value 0 <= L <= MAX_LEVEL, in
such a way that the probability p(l) of generating level l
is equal to p(l)=(1/span)^(l+1) and
p(0)=1-(sum of p(l) over l=1..MAX_LEVEL).
- 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(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.
- 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.
- CANONICAL_NAME - Static variable in class com.tangosol.util.extractor.IdentityExtractor
-
Canonical name for identity extractor.
- 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.
- casNext(Object, Object) - Method in class com.tangosol.util.SafeSortedMap.EntryNode
-
Atomically set the next EntryNode to the specified node iff the current
next EntryNode matches the expected node.
- casNext(SafeSortedMap.SkipNode, SafeSortedMap.SkipNode) - Method in class com.tangosol.util.SafeSortedMap.SkipNode
-
Atomically set the specified next SkipNode iff the current next node
matches the expected node.
- casTopNode(SafeSortedMap.IndexNode, SafeSortedMap.IndexNode) - Method in class com.tangosol.util.SafeSortedMap
-
Atomically set specified IndexNode to the top node iff the current top
node is the expected top node.
- castReturnValue(MethodNode) - Static method in class com.tangosol.coherence.rest.util.PartialObject
-
Cast a return value into an appropriate type.
- casValue(Object, Object) - Method in class com.tangosol.util.SafeSortedMap.EntryNode
-
Atomically set the value of this EntryNode to the specified value iff
the current value matches the assumed value.
- 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(long) - Method in class com.tangosol.util.SimpleLongArray
-
- ceiling(long) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
-
- 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
-
- cEntries - Variable in class com.tangosol.util.SegmentedHashMap.Segment
-
The number of Entry objects (including synthetics) in this segment.
- 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(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
-
- ChainedExtractorBuilder(ExtractorBuilder...) - Constructor for class com.tangosol.coherence.dslquery.ChainedExtractorBuilder
-
- 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
-
- ChainedResourceResolver(ResourceResolver...) - Constructor for class com.tangosol.util.ChainedResourceResolver
-
- 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
-
- 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
- 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
- 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.
- 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() - Method in class com.tangosol.net.cache.SerializationCache
-
Make sure that the cache does not contain expired items.
- checkFlush() - Method in class com.tangosol.net.cache.OldCache
-
- 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.
- 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.
- 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.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.
- 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.
- 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
-
- 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.
- 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
-
- clear() - Method in class com.tangosol.io.DelegatingWriteBuffer
-
- 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
-
- 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.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 class com.tangosol.util.ChainedCollection
-
- 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.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
- 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.
- 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.
- clearPending() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.WriteQueue
-
Clear the map of pending entries.
- 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 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.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
-
- cloneEntryList(SafeHashMap.Entry) - Method in class com.tangosol.util.SafeHashMap
-
Clone an entire linked list of entries.
- 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.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.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
-
- 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() - 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
-
- 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
-
- 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
-
- ClusterQuorumPolicyBuilder(Map<String, Integer>, XmlElement) - Constructor for class com.tangosol.coherence.config.builder.ClusterQuorumPolicyBuilder
-
- 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
-
- 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
-
- CoalescedEvent(Event<S>, NonBlockingFiniteStateMachine.CoalescedEvent.Process, Object) - Constructor for class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.CoalescedEvent
-
- 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
-
- Codecs.ArrayCodec - Class in com.tangosol.io.pof.reflect
-
- Codecs.CollectionCodec - Class in com.tangosol.io.pof.reflect
-
- Codecs.DefaultCodec - Class in com.tangosol.io.pof.reflect
-
- Codecs.LongArrayCodec - Class in com.tangosol.io.pof.reflect
-
- Codecs.MapCodec - Class in com.tangosol.io.pof.reflect
-
- 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
-
- 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
-
- 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
-
- CoherenceCacheEntry(K, V) - Constructor for class com.tangosol.coherence.jcache.common.CoherenceCacheEntry
-
- CoherenceCacheEntry(K, V, V) - Constructor for class com.tangosol.coherence.jcache.common.CoherenceCacheEntry
-
- 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
-
- CoherenceCacheEntryEvent(Cache<K, V>, EventType, K, V, V) - Constructor for class com.tangosol.coherence.jcache.common.CoherenceCacheEntryEvent
-
- CoherenceCacheEntryEventFilteringIterable<K,V> - Class in com.tangosol.coherence.jcache.common
-
An adapter to provide
Iterable
s 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
Iterator
s to allow filtering of
CacheEntryEvent
s.
- 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
-
- CoherenceCacheEventEventDispatcher<K,V> - Class in com.tangosol.coherence.jcache.common
-
Collects and appropriately dispatches CacheEntryEvent
s to
CacheEntryListener
s.
- 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
-
- CoherenceConverterAdapter<T> - Class in com.tangosol.coherence.jcache.common
-
An
InternalConverter
that uses two Coherence
Converter
s
as a means of performing conversions to and from internal representations.
- CoherenceConverterAdapter(Converter, Converter) - Constructor for class com.tangosol.coherence.jcache.common.CoherenceConverterAdapter
-
- CoherenceEntryProcessorResult<T> - Class in com.tangosol.coherence.jcache.common
-
A Coherence-based EntryProcessorResult
.
- CoherenceEntryProcessorResult() - Constructor for class com.tangosol.coherence.jcache.common.CoherenceEntryProcessorResult
-
- CoherenceEntryProcessorResult(Exception) - Constructor for class com.tangosol.coherence.jcache.common.CoherenceEntryProcessorResult
-
- CoherenceEntryProcessorResult(T) - Constructor for class com.tangosol.coherence.jcache.common.CoherenceEntryProcessorResult
-
- 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
-
- CoherenceQueryLanguageEngine() - Constructor for class com.tangosol.coherence.rest.query.CoherenceQueryLanguageEngine
-
- CoherenceSession - Class in com.tangosol.net
-
- CoherenceSession(Session.Option...) - Constructor for class com.tangosol.net.CoherenceSession
-
- 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.
- CollectionHelper - Class in com.tangosol.util
-
- 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.
- 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.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.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.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.nio - package com.tangosol.io.nio
-
Contains classes related to J2SE 1.4 NIO functionality.
- com.tangosol.io.pof - package com.tangosol.io.pof
-
Contains classes related to POF serialization and deserialization.
- com.tangosol.io.pof.annotation - package com.tangosol.io.pof.annotation
-
Contains POF Annotation classes.
- com.tangosol.io.pof.reflect - package com.tangosol.io.pof.reflect
-
Contains classes related to POF stream navigation and manipulation.
- com.tangosol.net - package com.tangosol.net
-
Contains basic cluster interfaces and factories.
- com.tangosol.net.cache - package com.tangosol.net.cache
-
Contains classes providing various caching strategies.
- com.tangosol.net.events - package com.tangosol.net.events
-
Contains classes related to the Coherence Live Event Model.
- com.tangosol.net.events.annotation - package com.tangosol.net.events.annotation
-
Contains annotations related to the Coherence Live Event Model.
- com.tangosol.net.events.application - package com.tangosol.net.events.application
-
Contains classes related to application events within the Coherence
Live Event Model, including ConfigurableCacheFactory events.
- com.tangosol.net.events.partition - package com.tangosol.net.events.partition
-
Contains classes related to PartitionedService events within the Coherence
Live Event Model.
- com.tangosol.net.events.partition.cache - package com.tangosol.net.events.partition.cache
-
Contains classes related to PartitionedCache events within the Coherence
Live Event Model.
- com.tangosol.net.management - package com.tangosol.net.management
-
Contains classes related to the Coherence Management Framework.
- com.tangosol.net.management.annotation - package com.tangosol.net.management.annotation
-
Contains annotations used by the Coherence Management Framework.
- com.tangosol.net.partition - package com.tangosol.net.partition
-
Contains interfaces and classes related to partitioned services.
- com.tangosol.net.proxy - package com.tangosol.net.proxy
-
Contains interfaces and classes related to proxy services.
- com.tangosol.net.security - package com.tangosol.net.security
-
Contains classes related to the Coherence Security Framework.
- com.tangosol.net.topic - package com.tangosol.net.topic
-
- com.tangosol.persistence - package com.tangosol.persistence
-
Contains classes and helpers for implementing various types of persistence.
- com.tangosol.run.jca - package com.tangosol.run.jca
-
Contains classes providing Java 2 Connector Architecture functionality.
- com.tangosol.run.xml - package com.tangosol.run.xml
-
Contains classes providing basic XML related functionality.
- com.tangosol.util - package com.tangosol.util
-
Contains various generic utilities.
- com.tangosol.util.aggregator - package com.tangosol.util.aggregator
-
- com.tangosol.util.comparator - package com.tangosol.util.comparator
-
Contains concrete
Comparator
implementations and related interfaces.
- com.tangosol.util.extractor - package com.tangosol.util.extractor
-
- com.tangosol.util.filter - package com.tangosol.util.filter
-
Contains concrete
Filter
implementations and related interfaces.
- com.tangosol.util.fsm - package com.tangosol.util.fsm
-
Contains Finite state machine interfaces.
- com.tangosol.util.function - package com.tangosol.util.function
-
Contains Functional interfaces allowing remote execution of lambda expressions and method references.
- com.tangosol.util.processor - package com.tangosol.util.processor
-
- com.tangosol.util.stream - package com.tangosol.util.stream
-
Contains classes to support functional-style operations on remote streams of elements,
such as map-reduce transformations on collections.
- com.tangosol.util.transformer - package com.tangosol.util.transformer
-
- combine(Object) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics.PartitionedCacheStatisticsAggregator
-
- combine(Object) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics.PartitionedCacheStatisticsClear
-
- combine(Object) - Method in class com.tangosol.util.aggregator.AbstractAggregator
-
- combine(Object) - Method in class com.tangosol.util.aggregator.CompositeAggregator
-
- combine(Integer) - Method in class com.tangosol.util.aggregator.Count
-
- combine(Map<E, Object>) - Method in class com.tangosol.util.aggregator.GroupAggregator
-
- combine(P) - Method in class com.tangosol.util.aggregator.PriorityAggregator
-
- combine(QueryRecord.PartialResult) - Method in class com.tangosol.util.aggregator.QueryRecorder
-
- combine(P) - Method in class com.tangosol.util.aggregator.ScriptAggregator
-
- combine(TopNAggregator.PartialResult<E>) - Method in class com.tangosol.util.aggregator.TopNAggregator
-
- combine(Converter<F, I>, Converter<I, T>) - Static method in class com.tangosol.util.ConverterCollections
-
Create a new converter by combining two existing converters.
- combine(P) - Method in interface com.tangosol.util.InvocableMap.StreamingAggregator
-
Merge another partial result into the result.
- CommandsOPToken() - Constructor for class com.tangosol.coherence.dslquery.queryplus.CommandsStatementBuilder.CommandsOPToken
-
Construct a CommandsOPToken.
- CommandsQueryPlusStatement() - Constructor for class com.tangosol.coherence.dslquery.queryplus.CommandsStatementBuilder.CommandsQueryPlusStatement
-
- CommandsStatementBuilder - Class in com.tangosol.coherence.dslquery.queryplus
-
A class that builds the QueryPlus "COMMANDS" command.
- CommandsStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.queryplus.CommandsStatementBuilder
-
- CommandsStatementBuilder.CommandsOPToken - Class in com.tangosol.coherence.dslquery.queryplus
-
A CohQL OPToken representing the QueryPlus "commands" command.
- CommandsStatementBuilder.CommandsQueryPlusStatement - Class in com.tangosol.coherence.dslquery.queryplus
-
The implementation of the QueryPlus "commands" command.
- commit(Object) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
-
Commit a sequence of mutating operations represented by the given
token as an atomic unit.
- commit(Object) - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistentStore
-
Commit a sequence of mutating operations represented by the given
token as an atomic unit.
- commit(Object) - Method in class com.tangosol.util.NullImplementation.NullPersistentStore
-
- commit() - Method in interface com.tangosol.util.TransactionMap
-
Commit the changes made to the TransactionMap.
- commitAndMaybeInvalidate() - Method in class com.tangosol.net.cache.OverflowMap.Status
-
Finish the commit for the entry for which this Status exists.
- commitAndMaybeInvalidate() - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
-
Finish the commit for the entry for which this Status exists.
- commitInternal(Object) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
-
Commit a sequence of mutating operations represented by the given
token as an atomic unit.
- commitTransactionCollection(Collection, int) - Static method in class com.tangosol.net.CacheFactory
-
Commit the transaction represented by a collection of TransactionMap
objects.
- compactAll() - Method in class com.tangosol.io.nio.BinaryMap
-
Full linear compaction of the buffer.
- compactBegin() - Method in class com.tangosol.io.nio.BinaryMap
-
Configure the incremental compact.
- compactComplete() - Method in class com.tangosol.io.nio.BinaryMap
-
Complete the incremental compact.
- compactNext() - Method in class com.tangosol.io.nio.BinaryMap
-
Perform an incremental compaction of the next block.
- compactUntil(int) - Method in class com.tangosol.io.nio.BinaryMap
-
Perform an an incremental compact at the specified block.
- ComparableMax<T,R> - Class in com.tangosol.util.aggregator
-
Calculates a maximum among values extracted from a set of entries in a Map.
- ComparableMax() - Constructor for class com.tangosol.util.aggregator.ComparableMax
-
Default constructor (necessary for the ExternalizableLite interface).
- ComparableMax(ValueExtractor<? super T, ? extends E>) - Constructor for class com.tangosol.util.aggregator.ComparableMax
-
Construct a ComparableMax aggregator.
- ComparableMax(ValueExtractor<? super T, ? extends R>, Comparator<? super R>) - Constructor for class com.tangosol.util.aggregator.ComparableMax
-
Construct a ComparableMax aggregator.
- ComparableMax(String) - Constructor for class com.tangosol.util.aggregator.ComparableMax
-
Construct a ComparableMax aggregator.
- comparableMax(ValueExtractor<? super T, ? extends R>) - Static method in class com.tangosol.util.Aggregators
-
Return an aggregator that calculates a maximum of the
Comparable
values
extracted from a set of entries in a Map.
- comparableMax(ValueExtractor<? super T, ? extends R>, Comparator<? super R>) - Static method in class com.tangosol.util.Aggregators
-
Return an aggregator that calculates a maximum of the values extracted from a set
of entries in a Map.
- comparableMax(String) - Static method in class com.tangosol.util.Aggregators
-
Return an aggregator that calculates a maximum of the
Comparable
values
extracted from a set of entries in a Map.
- comparableMax(String, Comparator<? super R>) - Static method in class com.tangosol.util.Aggregators
-
Return an aggregator that calculates a maximum of the values extracted from a set
of entries in a Map.
- ComparableMin<T,R> - Class in com.tangosol.util.aggregator
-
Calculates a minimum among values extracted from a set of entries in a Map.
- ComparableMin() - Constructor for class com.tangosol.util.aggregator.ComparableMin
-
Default constructor (necessary for the ExternalizableLite interface).
- ComparableMin(ValueExtractor<? super T, ? extends E>) - Constructor for class com.tangosol.util.aggregator.ComparableMin
-
Construct a ComparableMin aggregator.
- ComparableMin(ValueExtractor<? super T, ? extends R>, Comparator<? super R>) - Constructor for class com.tangosol.util.aggregator.ComparableMin
-
Construct a ComparableMin aggregator.
- ComparableMin(String) - Constructor for class com.tangosol.util.aggregator.ComparableMin
-
Construct a ComparableMin aggregator.
- comparableMin(ValueExtractor<? super T, ? extends R>) - Static method in class com.tangosol.util.Aggregators
-
Return an aggregator that calculates a minimum of the
Comparable
values
extracted from a set of entries in a Map.
- comparableMin(ValueExtractor<? super T, ? extends R>, Comparator<? super R>) - Static method in class com.tangosol.util.Aggregators
-
Return an aggregator that calculates a minimum of the values extracted from a set
of entries in a Map.
- comparableMin(String) - Static method in class com.tangosol.util.Aggregators
-
Return an aggregator that calculates a minimum of the
Comparable
values
extracted from a set of entries in a Map.
- comparableMin(String, Comparator<? super R>) - Static method in class com.tangosol.util.Aggregators
-
Return an aggregator that calculates a minimum of the values extracted from a set
of entries in a Map.
- comparator() - Method in class com.tangosol.util.ConverterCollections.ConverterSortedMap
- comparator() - Method in class com.tangosol.util.ConverterCollections.ConverterSortedSet
- comparator(Remote.Comparator<T>) - Static method in class com.tangosol.util.function.Remote
-
Capture serializable Comparator.
- comparator() - Method in class com.tangosol.util.ImmutableArrayList
-
Returns the comparator associated with this sorted set, or
null if it uses its elements' natural ordering.
- comparator() - Method in class com.tangosol.util.RestrictedCollections.RestrictedSortedMap
-
Returns the comparator associated with this sorted map, or
null if it uses its keys' natural ordering.
- comparator() - Method in class com.tangosol.util.RestrictedCollections.RestrictedSortedSet
-
Returns the comparator associated with this sorted set, or
null if it uses its elements' natural ordering.
- comparator() - Method in class com.tangosol.util.SafeSortedMap
- comparator() - Method in class com.tangosol.util.SafeSortedMap.ViewMap
- comparator() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperSortedMap
- comparator() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperSortedSet
- ComparatorBuilder - Class in com.tangosol.coherence.rest.util
-
- ComparatorBuilder() - Constructor for class com.tangosol.coherence.rest.util.ComparatorBuilder
-
- ComparatorHelper - Class in com.tangosol.coherence.rest.util
-
ComparatorHelper is a utility class that provides a factory method used to
create a java.util.Comparator instance from a string expression.
- ComparatorHelper() - Constructor for class com.tangosol.coherence.rest.util.ComparatorHelper
-
- compare(Object, Object) - Method in class com.tangosol.net.cache.SimpleOverflowMap.HashcodeComparator
-
- compare(Object, Object) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.LoadComparator
- compare(Object, Object) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.StrengthComparator
- compare(T, T) - Method in interface com.tangosol.net.ServiceLoadBalancer
-
Compare to ServerLoad objects.
- compare(T, T) - Method in class com.tangosol.net.SimpleServiceLoadBalancer
-
- compare(String, String) - Method in class com.tangosol.util.CacheCollator
-
Compares the source string to the target string according to the
collation rules for this Collator.
- compare(T, T) - Method in class com.tangosol.util.comparator.ChainedComparator
-
Compares its two arguments for order.
- compare(Object, Object) - Method in class com.tangosol.util.comparator.EntryComparator
-
Compares two arguments for order.
- compare(T, T) - Method in class com.tangosol.util.comparator.ExtractorComparator
-
Compares extracted values (by specified ValueExtractor) of given arguments for order.
- compare(T, T) - Method in class com.tangosol.util.comparator.InverseComparator
-
Use the wrapped Comparator to compare the two arguments for order and
negate the result.
- compare(T, T) - Method in class com.tangosol.util.comparator.SafeComparator
-
Compares its two arguments for order.
- compare(T, T) - Method in class com.tangosol.util.ConverterCollections.ConverterComparator
- compare(Object, Object) - Method in class com.tangosol.util.extractor.AbstractExtractor
-
Compares its two arguments for order.
- compare(Object, Object) - Method in class com.tangosol.util.SortedBag.WrapperComparator
- compareEntries(QueryMap.Entry<?, T>, QueryMap.Entry<?, T>) - Method in class com.tangosol.util.comparator.ChainedComparator
-
Compare two entries based on the rules specified by
Comparator
.
- compareEntries(QueryMap.Entry, QueryMap.Entry) - Method in class com.tangosol.util.comparator.InverseComparator
-
Compare two entries using the underlying comparator and negate the
result.
- compareEntries(QueryMap.Entry<?, T>, QueryMap.Entry<?, T>) - Method in interface com.tangosol.util.comparator.QueryMapComparator
-
Compare two entries based on the rules specified by
Comparator
.
- compareEntries(QueryMap.Entry, QueryMap.Entry) - Method in class com.tangosol.util.comparator.SafeComparator
-
Compare two entries using the underlying comparator.
- compareEntries(QueryMap.Entry, QueryMap.Entry) - Method in class com.tangosol.util.extractor.AbstractExtractor
-
Compare two entries based on the rules specified by
Comparator
.
- compareEntries(QueryMap.Entry, QueryMap.Entry) - Method in class com.tangosol.util.extractor.MultiExtractor
-
Compare two entries based on the rules specified by
Comparator
.
- compareKeyList(ObjectName, ObjectName) - Static method in class com.tangosol.net.management.MBeanHelper
-
Compare two
global MBean names
forcing numeric comparison of the node ID while using string comparison
on all other key properties.
- compareSafe(Comparator, Object, Object) - Static method in class com.tangosol.util.comparator.SafeComparator
-
Compares its two arguments for order.
- compareSafe(Comparator, Object, Object, boolean) - Static method in class com.tangosol.util.comparator.SafeComparator
-
Compares its two arguments for order.
- compareTo(PropertySpec) - Method in class com.tangosol.coherence.rest.util.PropertySpec
-
Compare this object to another.
- compareTo(ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumRule) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumRule
-
Compare this Rule to another one based on the
threshold
.
- compareTo(Object) - Method in class com.tangosol.util.Binary
-
Compares this object with the specified object for order.
- compareTo(Object) - Method in class com.tangosol.util.filter.ArrayFilter.WeightedFilter
-
Compares this WeightedFilter with the specified WeightedFilter for
order.
- compareTo(Object) - Method in class com.tangosol.util.ImmutableArrayList
-
Compare this ImmutableArrayList with the passed Object to determine
order.
- compareTo(Object) - Method in class com.tangosol.util.SortedBag.UniqueElement
- compareTo(Object) - Method in class com.tangosol.util.UID
-
Compares this object with the specified object for order.
- compareTo(Object) - Method in class com.tangosol.util.UUID
-
Compares this object with the specified object for order.
- comparing(Remote.Function<? super T, ? extends U>, Remote.Comparator<? super U>) - Static method in interface com.tangosol.util.function.Remote.Comparator
-
Accepts a function that extracts a sort key from a type
T
,
and returns a
Comparator<T>
that compares by that sort key
using the specified
Remote.Comparator
.
- comparing(Remote.Function<? super T, ? extends U>) - Static method in interface com.tangosol.util.function.Remote.Comparator
-
Accepts a function that extracts a
Comparable
sort key from a type
T
, and returns a
Comparator<T>
that compares by that sort key.
- comparingDouble(Remote.ToDoubleFunction<? super T>) - Static method in interface com.tangosol.util.function.Remote.Comparator
-
Accepts a function that extracts a double
sort key from a
type T
, and returns a Comparator<T>
that compares by
that sort key.
- comparingInt(Remote.ToIntFunction<? super T>) - Static method in interface com.tangosol.util.function.Remote.Comparator
-
Accepts a function that extracts an int
sort key from a type
T
, and returns a Comparator<T>
that compares by that
sort key.
- comparingLong(Remote.ToLongFunction<? super T>) - Static method in interface com.tangosol.util.function.Remote.Comparator
-
Accepts a function that extracts a long
sort key from a type
T
, and returns a Comparator<T>
that compares by that
sort key.
- ComparisonFilter<T,E,C> - Class in com.tangosol.util.filter
-
Filter which compares the result of a method invocation with a value.
- ComparisonFilter() - Constructor for class com.tangosol.util.filter.ComparisonFilter
-
Default constructor (necessary for the ExternalizableLite interface).
- ComparisonFilter(ValueExtractor<? super T, ? extends E>, C) - Constructor for class com.tangosol.util.filter.ComparisonFilter
-
Construct a ComparisonFilter.
- ComparisonFilter(String, C) - Constructor for class com.tangosol.util.filter.ComparisonFilter
-
Construct a ComparisonFilter.
- ComparisonOperator - Class in com.tangosol.coherence.dslquery.operator
-
A base class for comparison operators, which are operators
that are used in conditional clauses such as equals, greater than,
less than, etc.
- ComparisonOperator(String, String...) - Constructor for class com.tangosol.coherence.dslquery.operator.ComparisonOperator
-
Construct a comparison operator with the given symbol and aliases.
- ComparisonValueExtractor<T,E extends Number> - Class in com.tangosol.util.extractor
-
A synthetic ValueExtractor that returns a result of comparison between two
values extracted from the same target.
- ComparisonValueExtractor() - Constructor for class com.tangosol.util.extractor.ComparisonValueExtractor
-
Default constructor (necessary for the ExternalizableLite interface).
- ComparisonValueExtractor(String, String) - Constructor for class com.tangosol.util.extractor.ComparisonValueExtractor
-
Construct a ComparisonValueExtractor based on two method names.
- ComparisonValueExtractor(String, String, Comparator<? super E>) - Constructor for class com.tangosol.util.extractor.ComparisonValueExtractor
-
Construct a ComparisonValueExtractor based on two method names and a
Comparator object.
- ComparisonValueExtractor(ValueExtractor<T, E>, ValueExtractor<T, E>) - Constructor for class com.tangosol.util.extractor.ComparisonValueExtractor
-
Construct a ComparisonValueExtractor based on two specified extractors.
- ComparisonValueExtractor(ValueExtractor<T, E>, ValueExtractor<T, E>, Comparator<? super E>) - Constructor for class com.tangosol.util.extractor.ComparisonValueExtractor
-
Construct a ComparisonValueExtractor based on two specified extractors and
a Comparator object.
- complete(int) - Method in class com.tangosol.io.pof.PofBufferReader
-
Register the completion of the parsing of a value.
- complete(int) - Method in class com.tangosol.io.pof.PofBufferReader.UserTypeReader
-
Register the completion of the parsing of a value.
- complete(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.ReadLatch
-
Complete the load operation.
- complete(Supplier<T>) - Method in class com.tangosol.util.AsynchronousAgent
-
Should be called if the operation completed successfully.
- completeExceptionally(Throwable) - Method in class com.tangosol.util.AsynchronousAgent
-
Should be called if the operation failed for any reason.
- CompleteOnEmpty() - Constructor for class com.tangosol.net.topic.Subscriber.CompleteOnEmpty
-
Default constructor for serialization.
- Complex(ValidatingPofHandler.Complex, int, boolean) - Constructor for class com.tangosol.io.pof.ValidatingPofHandler.Complex
-
Construct a Complex object for a data collection or user type.
- Complex(ValidatingPofHandler.Complex, int, boolean, int) - Constructor for class com.tangosol.io.pof.ValidatingPofHandler.Complex
-
Construct a Complex object for a uniformly-typed data collection.
- Complex(WritingPofHandler.Complex, boolean) - Constructor for class com.tangosol.io.pof.WritingPofHandler.Complex
-
Construct a Complex object for a data collection or user type.
- Complex(WritingPofHandler.Complex, boolean, int) - Constructor for class com.tangosol.io.pof.WritingPofHandler.Complex
-
Construct a Complex object for a uniformly-typed data collection.
- ComplexMap(ValidatingPofHandler.Complex, int) - Constructor for class com.tangosol.io.pof.ValidatingPofHandler.ComplexMap
-
Construct a Complex object for a uniform-keys map.
- ComplexMap(ValidatingPofHandler.Complex, int, int) - Constructor for class com.tangosol.io.pof.ValidatingPofHandler.ComplexMap
-
Construct a Complex object for a uniform-keys map.
- ComplexMap(ValidatingPofHandler.Complex, int, int, int) - Constructor for class com.tangosol.io.pof.ValidatingPofHandler.ComplexMap
-
Construct a Complex object for a uniform map.
- ComplexMap(WritingPofHandler.Complex, int) - Constructor for class com.tangosol.io.pof.WritingPofHandler.ComplexMap
-
Construct a ComplexMap object for maps with uniformly-typed keys.
- ComplexMap(WritingPofHandler.Complex, int, int) - Constructor for class com.tangosol.io.pof.WritingPofHandler.ComplexMap
-
Construct a ComplexMap object for maps with uniformly-typed keys
and values.
- ComplexPofValue - Class in com.tangosol.io.pof.reflect
-
An abstract base class for complex POF types, such as collections, arrays,
maps, and user types.
- ComplexPofValue(PofValue, ReadBuffer, PofContext, int, int, int) - Constructor for class com.tangosol.io.pof.reflect.ComplexPofValue
-
Construct a PofValue instance wrapping the supplied buffer.
- compose(ValueExtractor<? super V, ? extends T>) - Method in class com.tangosol.util.extractor.ChainedExtractor
-
- compose(Remote.DoubleUnaryOperator) - Method in interface com.tangosol.util.function.Remote.DoubleUnaryOperator
-
Returns a composed operator that first applies the before
operator to its input, and then applies this operator to the result.
- compose(Remote.Function<? super V, ? extends T>) - Method in interface com.tangosol.util.function.Remote.Function
-
Returns a composed function that first applies the before
function to its input, and then applies this function to the result.
- compose(Remote.IntUnaryOperator) - Method in interface com.tangosol.util.function.Remote.IntUnaryOperator
-
Returns a composed operator that first applies the before
operator to its input, and then applies this operator to the result.
- compose(Remote.LongUnaryOperator) - Method in interface com.tangosol.util.function.Remote.LongUnaryOperator
-
Returns a composed operator that first applies the before
operator to its input, and then applies this operator to the result.
- compose(ValueExtractor<? super V, ? extends T>) - Method in interface com.tangosol.util.ValueExtractor
-
Returns a composed extractor that first applies the before
extractor to its input, and then applies this extractor to the result.
- composite(InvocableMap.EntryAggregator...) - Static method in class com.tangosol.util.Aggregators
-
Return an aggregator that calculates the the combined set of results from a number of aggregators.
- composite(InvocableMap.EntryProcessor<K, V, ?>[]) - Static method in class com.tangosol.util.Processors
-
Construct a composite processor for the specified array of individual
entry processors.
- CompositeActionPolicy - Class in com.tangosol.net
-
CompositeActionPolicy represents the "intersection" of two policies.
- CompositeActionPolicy(ActionPolicy, ActionPolicy) - Constructor for class com.tangosol.net.CompositeActionPolicy
-
Construct a CompositeActionPolicy representing the specified policies.
- CompositeAddressProvider - Class in com.tangosol.net
-
CompositeAddressProvider is a composite of one or more AddressProviders or
addresses that also implements the Set interface.
- CompositeAddressProvider() - Constructor for class com.tangosol.net.CompositeAddressProvider
-
Default constructor.
- CompositeAddressProvider(AddressProvider) - Constructor for class com.tangosol.net.CompositeAddressProvider
-
Construct a CompositeAddressProvider from the specified AddressProvider.
- CompositeAddressProvider.AddressIterator - Class in com.tangosol.net
-
An Iterator over the addresses in this AddressProvider.
- CompositeAddressProvider.SingleProvider - Class in com.tangosol.net
-
AddressProvider wrapper for a single address dynamically added to this
AddressSet.
- CompositeAggregator<K,V> - Class in com.tangosol.util.aggregator
-
CompositeAggregator provides an ability to execute a collection of
aggregators against the same subset of the entries in an InvocableMap,
resulting in a list of corresponding aggregation results.
- CompositeAggregator() - Constructor for class com.tangosol.util.aggregator.CompositeAggregator
-
Default constructor (necessary for the ExternalizableLite interface).
- CompositeAggregator(InvocableMap.EntryAggregator[]) - Constructor for class com.tangosol.util.aggregator.CompositeAggregator
-
Construct a CompositeAggregator based on a specified EntryAggregator
array.
- CompositeAggregator.Parallel - Class in com.tangosol.util.aggregator
-
- CompositeKey<P,S> - Class in com.tangosol.util
-
Key class that consists of a primary and secondary component.
- CompositeKey() - Constructor for class com.tangosol.util.CompositeKey
-
Default constructor.
- CompositeKey(P, S) - Constructor for class com.tangosol.util.CompositeKey
-
Create a new CompositeKey that consists of the given primary and
secondary components.
- CompositeProcessor<K,V> - Class in com.tangosol.util.processor
-
The CompositeProcessor represents a collection of entry processors that are
invoked sequentially against the same Entry.
- CompositeProcessor() - Constructor for class com.tangosol.util.processor.CompositeProcessor
-
Default constructor (necessary for the ExternalizableLite interface).
- CompositeProcessor(InvocableMap.EntryProcessor<K, V, ?>[]) - Constructor for class com.tangosol.util.processor.CompositeProcessor
-
Construct a CompositeProcessor for the specified array of individual
entry processors.
- CompositeSchemeProcessor<T extends AbstractCompositeScheme> - Class in com.tangosol.coherence.config.xml.processor
-
- CompositeSchemeProcessor(Class<T>) - Constructor for class com.tangosol.coherence.config.xml.processor.CompositeSchemeProcessor
-
- CompositeSocketAddressProvider - Class in com.tangosol.net
-
CompositeSocketAddressProvider is a composite of one or more
SocketAddressProviders.
- CompositeSocketAddressProvider(SocketAddress) - Constructor for class com.tangosol.net.CompositeSocketAddressProvider
-
Construct a CompositeSocketAddressProvider from the specified
SocketAddress
.
- CompositeSocketAddressProvider(SocketAddressProvider) - Constructor for class com.tangosol.net.CompositeSocketAddressProvider
-
- CompositeUpdater - Class in com.tangosol.util.extractor
-
A ValueUpdater implementation based on an extractor-updater pair that could
also be used as a ValueManipulator.
- CompositeUpdater() - Constructor for class com.tangosol.util.extractor.CompositeUpdater
-
Default constructor (necessary for the ExternalizableLite interface).
- CompositeUpdater(ValueExtractor, ValueUpdater) - Constructor for class com.tangosol.util.extractor.CompositeUpdater
-
Construct a CompositeUpdater based on the specified extractor and
updater.
- CompositeUpdater(String) - Constructor for class com.tangosol.util.extractor.CompositeUpdater
-
Construct a CompositeUpdater for a specified method name sequence.
- CompoundBaseToken - Class in com.tangosol.coherence.dsltools.base
-
CompoundBaseToken is the abstract base class for all tokens processed by the
low level BaseTokenScanner that are made up of two or more BaseTokens.
- CompoundBaseToken() - Constructor for class com.tangosol.coherence.dsltools.base.CompoundBaseToken
-
- CompressionFilter - Class in com.tangosol.net
-
- CompressionFilter() - Constructor for class com.tangosol.net.CompressionFilter
-
Deprecated.
- CompressionFilter.DeflaterOutputShell - Class in com.tangosol.net
-
Deprecated.
DeflaterOutputShell enforces the "end" call for the
corresponding Deflater object.
- CompressionFilter.InflaterInputShell - Class in com.tangosol.net
-
Deprecated.
InflaterInputShell enforces the "end" call for the
corresponding Inflater object.
- compute(K, Remote.BiFunction<? super K, ? super V, ? extends V>) - Method in interface com.tangosol.net.AsyncNamedCache
-
Compute a new mapping for the specified key and its current value.
- compute(K, Remote.BiFunction<? super K, ? super V, ? extends V>) - Method in interface com.tangosol.util.InvocableMap
-
Compute a new mapping for the specified key and its current value.
- compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in interface com.tangosol.util.InvocableMap
-
- compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperMap
- compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- computeCanonicalName(String, Object[]) - Method in class com.tangosol.util.extractor.ReflectionExtractor
-
Compute the canonical name for this extractor.
- computeCanonicalName(String) - Static method in class com.tangosol.util.extractor.UniversalUpdater
-
Compute the canonical name for this updater.
- computeIfAbsent(K, Remote.Function<? super K, ? extends V>) - Method in interface com.tangosol.net.AsyncNamedCache
-
Compute the value using the given mapping function and enter it into this
map (unless null
), if the specified key is not already associated
with a value (or is mapped to null
).
- computeIfAbsent(K, Remote.Function<? super K, ? extends V>) - Method in interface com.tangosol.util.InvocableMap
-
Compute the value using the given mapping function and enter it into this
map (unless null
), if the specified key is not already associated
with a value (or is mapped to null
).
- computeIfAbsent(K, Function<? super K, ? extends V>) - Method in interface com.tangosol.util.InvocableMap
-
Note that the previous example will not work as expected if this method
is called on a distributed map, as the add
method will be called
on a client-side copy of the collection stored on the server.
- computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperMap
- computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- computeIfPresent(K, Remote.BiFunction<? super K, ? super V, ? extends V>) - Method in interface com.tangosol.net.AsyncNamedCache
-
Compute a new mapping given the key and its current mapped value, if the
value for the specified key is present and non-null.
- computeIfPresent(K, Remote.BiFunction<? super K, ? super V, ? extends V>) - Method in interface com.tangosol.util.InvocableMap
-
Compute a new mapping given the key and its current mapped value,
if the value for the specified key is present and non-null.
- computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in interface com.tangosol.util.InvocableMap
-
- computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperMap
- computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- computeProbabilityThresholds(int, int) - Static method in class com.tangosol.util.SafeSortedMap
-
compute and return an array, indexed by level, of the probability
thresholds used to determine what level an entry should be indexed to.
- computeSafeWaitTime(long) - Static method in class com.tangosol.util.Base
-
compute the number of milliseconds until the specified time.
- computeTarget() - Method in class com.tangosol.util.extractor.ChainedExtractor
-
Return the target of the first extractor in composite extractor.
- computeTmpDir() - Method in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
-
compute the system's temp directory.
- concat(Binary) - Method in class com.tangosol.util.Binary
-
Concatenate the passed Binary onto this Binary.
- CONCUR_EXTERNAL - Static variable in class com.tangosol.run.jca.CacheAdapter
-
- CONCUR_EXTERNAL - Static variable in interface com.tangosol.util.TransactionMap
-
External concurrency.
- CONCUR_OPTIMISTIC - Static variable in class com.tangosol.run.jca.CacheAdapter
-
- CONCUR_OPTIMISTIC - Static variable in interface com.tangosol.util.TransactionMap
-
Optimistic concurrency.
- CONCUR_PESSIMISTIC - Static variable in class com.tangosol.run.jca.CacheAdapter
-
- CONCUR_PESSIMISTIC - Static variable in interface com.tangosol.util.TransactionMap
-
Pessimistic concurrency.
- ConcurrentMap<K,V> - Interface in com.tangosol.util
-
Map with additional concurrency features.
- ConcurrentWrapperCollection(Collection<E>) - Constructor for class com.tangosol.util.WrapperCollections.ConcurrentWrapperCollection
-
Create an ConcurrentWrapperCollection which delegates to the
specified Collection.
- ConcurrentWrapperCollection(Collection<E>, ReadWriteLock) - Constructor for class com.tangosol.util.WrapperCollections.ConcurrentWrapperCollection
-
Create an ConcurrentWrapperCollection which delegates to the
specified Collection.
- ConcurrentWrapperEntry(Map.Entry<K, V>) - Constructor for class com.tangosol.util.WrapperCollections.ConcurrentWrapperEntry
-
Create an ConcurrentWrapperEntry which delegates to the
specified Map Entry.
- ConcurrentWrapperEntry(Map.Entry<K, V>, ReadWriteLock) - Constructor for class com.tangosol.util.WrapperCollections.ConcurrentWrapperEntry
-
Create an ConcurrentWrapperEntry which delegates to the
specified Map Entry.
- ConcurrentWrapperEntry(Map.Entry<K, V>, ReadWriteLock, boolean) - Constructor for class com.tangosol.util.WrapperCollections.ConcurrentWrapperEntry
-
Create an ConcurrentWrapperEntry which delegates to the
specified Map Entry.
- ConcurrentWrapperEntrySet(Set<Map.Entry<K, V>>, ReadWriteLock, boolean) - Constructor for class com.tangosol.util.WrapperCollections.ConcurrentWrapperEntrySet
-
Create an ConcurrentWrapperSet which delegates to the specified Set.
- ConcurrentWrapperMap() - Constructor for class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
-
- ConcurrentWrapperMap(Map<K, V>) - Constructor for class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
-
Create an ConcurrentWrapperMap which delegates to the specified Map.
- ConcurrentWrapperMap(Map<K, V>, ReadWriteLock) - Constructor for class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
-
Create an ConcurrentWrapperMap which delegates to the specified Map.
- ConcurrentWrapperMap(Map<K, V>, ReadWriteLock, boolean) - Constructor for class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
-
Create an ConcurrentWrapperMap which delegates to the specified Map.
- ConcurrentWrapperSet(Set<E>) - Constructor for class com.tangosol.util.WrapperCollections.ConcurrentWrapperSet
-
Create an ConcurrentWrapperSet which delegates to the specified Set.
- ConcurrentWrapperSet(Set<E>, ReadWriteLock) - Constructor for class com.tangosol.util.WrapperCollections.ConcurrentWrapperSet
-
Create an ConcurrentWrapperSet which delegates to the specified Set.
- conditional(Filter<V>, InvocableMap.EntryProcessor<K, V, T>) - Static method in class com.tangosol.util.Processors
-
Construct a conditional processor for a specified filter and the
processor.
- ConditionalElementProcessor<T> - Interface in com.tangosol.config.xml
-
- ConditionalExtractor<T,E> - Class in com.tangosol.util.extractor
-
An IndexAwareExtractor implementation that is only used to create a
ConditionalIndex
.
- ConditionalExtractor() - Constructor for class com.tangosol.util.extractor.ConditionalExtractor
-
Construct the ConditionalExtractor.
- ConditionalExtractor(Filter, ValueExtractor<T, E>, boolean) - Constructor for class com.tangosol.util.extractor.ConditionalExtractor
-
Construct the ConditionalExtractor.
- ConditionalExtractor(Filter, ValueExtractor<T, E>, boolean, boolean) - Constructor for class com.tangosol.util.extractor.ConditionalExtractor
-
Construct the ConditionalExtractor.
- ConditionalIndex - Class in com.tangosol.util
-
ConditionalIndex is a
MapIndex
implementation that uses an associated
filter to evaluate whether or not an entry should be indexed.
- ConditionalIndex(Filter, ValueExtractor, boolean, Comparator, boolean, BackingMapContext) - Constructor for class com.tangosol.util.ConditionalIndex
-
Construct a ConditionalIndex.
- ConditionalProcessor<K,V,T> - Class in com.tangosol.util.processor
-
Conditional entry processor represents a processor that is invoked
conditionally based on the result of an entry evaluation.
- ConditionalProcessor() - Constructor for class com.tangosol.util.processor.ConditionalProcessor
-
Default constructor (necessary for the ExternalizableLite interface).
- ConditionalProcessor(Filter<V>, InvocableMap.EntryProcessor<K, V, T>) - Constructor for class com.tangosol.util.processor.ConditionalProcessor
-
Construct a ConditionalProcessor for the specified filter and the
processor.
- ConditionalPut<K,V> - Class in com.tangosol.util.processor
-
ConditionalPut is an EntryProcessor that performs an
Entry.setValue
operation if the specified condition is satisfied.
- ConditionalPut() - Constructor for class com.tangosol.util.processor.ConditionalPut
-
Default constructor (necessary for the ExternalizableLite interface).
- ConditionalPut(Filter, V) - Constructor for class com.tangosol.util.processor.ConditionalPut
-
Construct a ConditionalPut that updates an entry with a new value if
and only if the filter applied to the entry evaluates to true.
- ConditionalPut(Filter, V, boolean) - Constructor for class com.tangosol.util.processor.ConditionalPut
-
Construct a ConditionalPut that updates an entry with a new value if
and only if the filter applied to the entry evaluates to true.
- ConditionalPutAll<K,V> - Class in com.tangosol.util.processor
-
ConditionalPutAll is an EntryProcessor that performs a
Entry.setValue
operation for multiple entries that satisfy the specified
condition.
- ConditionalPutAll() - Constructor for class com.tangosol.util.processor.ConditionalPutAll
-
Default constructor (necessary for the ExternalizableLite interface).
- ConditionalPutAll(Filter, Map<? extends K, ? extends V>) - Constructor for class com.tangosol.util.processor.ConditionalPutAll
-
Construct a ConditionalPutAll processor that updates an entry with a
new value if and only if the filter applied to the entry evaluates to
true.
- ConditionalRemove<K,V> - Class in com.tangosol.util.processor
-
ConditionalRemove is an EntryProcessor that performs an
Entry.remove
operation if the specified condition is satisfied.
- ConditionalRemove() - Constructor for class com.tangosol.util.processor.ConditionalRemove
-
Default constructor (necessary for the ExternalizableLite interface).
- ConditionalRemove(Filter) - Constructor for class com.tangosol.util.processor.ConditionalRemove
-
Construct a ConditionalRemove processor that removes an InvocableMap
entry if and only if the filter applied to the entry evaluates to true.
- ConditionalRemove(Filter, boolean) - Constructor for class com.tangosol.util.processor.ConditionalRemove
-
Construct a ConditionalRemove processor that removes an InvocableMap
entry if and only if the filter applied to the entry evaluates to true.
- ConditionalRemoveAction() - Constructor for class com.tangosol.util.SegmentedConcurrentMap.ConditionalRemoveAction
-
- Config - Class in com.tangosol.coherence.config
-
Config
is a helper class for processing a Coherence configuration
system properties.
- Config() - Constructor for class com.tangosol.coherence.config.Config
-
- ConfigurableAddressProvider - Class in com.tangosol.net
-
ConfigurableAddressProvider is an implementation of the AddressProvider
interface based on a static list of addresses configured in an XML element
that contains one or more items in the following format:
<socket-address>
<address>...
- ConfigurableAddressProvider(XmlElement) - Constructor for class com.tangosol.net.ConfigurableAddressProvider
-
Deprecated.
- ConfigurableAddressProvider(Iterable<ConfigurableAddressProvider.AddressHolder>, boolean) - Constructor for class com.tangosol.net.ConfigurableAddressProvider
-
- ConfigurableAddressProvider(XmlElement, boolean) - Constructor for class com.tangosol.net.ConfigurableAddressProvider
-
Deprecated.
- ConfigurableAddressProvider.AddressHolder - Class in com.tangosol.net
-
A stateful holder for an obtaining an InetSocketAddress object.
- ConfigurableAddressProviderFactory - Class in com.tangosol.net
-
Deprecated.
- ConfigurableAddressProviderFactory() - Constructor for class com.tangosol.net.ConfigurableAddressProviderFactory
-
Deprecated.
Default constructor.
- ConfigurableCacheFactory - Interface in com.tangosol.net
-
An interface for cache factory.
- ConfigurableCacheMap - Interface in com.tangosol.net.cache
-
An extension to the CacheMap interface that supports runtime configuration
and monitoring of various caching properties.
- ConfigurableCacheMap.Entry - Interface in com.tangosol.net.cache
-
A cache Entry carries information additional to the base Map Entry in
order to support eviction and expiry.
- ConfigurableCacheMap.EvictionApprover - Interface in com.tangosol.net.cache
-
EvictionApprover is used to approve the eviction of an entry
from the underlying ConfigurableCacheMap.
- ConfigurableCacheMap.EvictionPolicy - Interface in com.tangosol.net.cache
-
An eviction policy is an object that the cache provides with access
information, and when requested, the eviction policy selects and
evicts entries from the cache.
- ConfigurableCacheMap.UnitCalculator - Interface in com.tangosol.net.cache
-
A unit calculator is an object that can calculate the cost of caching
an object.
- ConfigurableLocalAddressProvider - Class in com.tangosol.net
-
ConfigurableLocalAddressProvider is an AddressProvider which is only
capable of returning local addresses.
- ConfigurableLocalAddressProvider(XmlElement) - Constructor for class com.tangosol.net.ConfigurableLocalAddressProvider
-
Deprecated.
- ConfigurableLocalAddressProvider(Iterable<ConfigurableAddressProvider.AddressHolder>, boolean) - Constructor for class com.tangosol.net.ConfigurableLocalAddressProvider
-
- ConfigurableLocalAddressProvider(int) - Constructor for class com.tangosol.net.ConfigurableLocalAddressProvider
-
Constructs a ConfigurableLocalAddressProvider for all local IPs and the given port.
- ConfigurableLocalAddressProvider(XmlElement, boolean) - Constructor for class com.tangosol.net.ConfigurableLocalAddressProvider
-
Deprecated.
- ConfigurablePofContext - Class in com.tangosol.io.pof
-
This class implements the
PofContext
interface using information
provided in a configuration file (or in a passed XML configuration).
- ConfigurablePofContext() - Constructor for class com.tangosol.io.pof.ConfigurablePofContext
-
Default constructor.
- ConfigurablePofContext(String) - Constructor for class com.tangosol.io.pof.ConfigurablePofContext
-
Create a ConfigurablePofContext that will load configuration
information from the specified locator.
- ConfigurablePofContext(XmlElement) - Constructor for class com.tangosol.io.pof.ConfigurablePofContext
-
Create a ConfigurablePofContext that will use the passed configuration
information.
- ConfigurablePofContext(ConfigurablePofContext) - Constructor for class com.tangosol.io.pof.ConfigurablePofContext
-
Copy constructor for a ConfigurablePofContext.
- ConfigurablePofContext.PofConfig - Class in com.tangosol.io.pof
-
The information related to the configuration of a particular PofContext
for a specific URI and ClassLoader.
- ConfigurableQuorumPolicy - Class in com.tangosol.net
-
ConfigurableQuorumPolicy provides a Quorum-based
ActionPolicy
for
services based on the cluster-configuration.
- ConfigurableQuorumPolicy() - Constructor for class com.tangosol.net.ConfigurableQuorumPolicy
-
Create a ConfigurableQuorumPolicy.
- ConfigurableQuorumPolicy.ClusterQuorumPolicy - Class in com.tangosol.net
-
ClusterQuorumPolicy defines an action policy that is applicable to the
cluster.
- ConfigurableQuorumPolicy.MembershipQuorumPolicy - Class in com.tangosol.net
-
MembershipQuorumPolicy is a quorum policy that is stateless and based
solely on service membership sizes.
- ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumListener - Class in com.tangosol.net
-
QuorumListener is used to subscribe the quorum policy to receive service
membership events.
- ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumRule - Class in com.tangosol.net
-
A quorum rule defines a set of allowable actions beyond the rule's
threshold size.
- ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy - Class in com.tangosol.net
-
PartitionedCacheQuorumPolicy defines a configurable quorum policy that is
applicable to a DistributedCacheService.
- ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy.ActionRule - Enum in com.tangosol.net
-
- ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy.Notification - Class in com.tangosol.net
-
Notification is a simple struct carrying the notification info.
- ConfigurableQuorumPolicy.ProxyQuorumPolicy - Class in com.tangosol.net
-
ProxyQuorumPolicy defines a configurable quorum policy that is applicable
to a proxy service.
- ConfigurableSerializerFactory - Class in com.tangosol.io
-
Deprecated.
- ConfigurableSerializerFactory() - Constructor for class com.tangosol.io.ConfigurableSerializerFactory
-
Deprecated.
- ConfigurableSnapshotArchiverFactory - Class in com.tangosol.persistence
-
A
SnapshotArchiverFactory
implementation that creates instances of
a SnapshotArchiver class configured using an XmlElement.
- ConfigurableSnapshotArchiverFactory() - Constructor for class com.tangosol.persistence.ConfigurableSnapshotArchiverFactory
-
- ConfigurationException - Exception in com.tangosol.config
-
- ConfigurationException(String, String) - Constructor for exception com.tangosol.config.ConfigurationException
-
- ConfigurationException(String, String, Throwable) - Constructor for exception com.tangosol.config.ConfigurationException
-
- ConfigurationProcessor - Class in com.tangosol.coherence.config.xml.processor
-
- ConfigurationProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.ConfigurationProcessor
-
- configure(XmlElement) - Method in class com.tangosol.coherence.rest.config.RestConfig
-
Configures this RestConfig instance using the specified XML element.
- configure() - Method in class com.tangosol.coherence.rest.server.InjectionBinder
-
- configure(BerkeleyDBBinaryStoreManager) - Method in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
-
Configure the new Environment.
- configure(XmlElement) - Method in class com.tangosol.net.ConfigurableAddressProvider
-
Deprecated.
- configure(ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumRule[]) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy
-
Configure and initialize this policy with the specified quorum rules.
- configure() - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
-
- configure(TcpDatagramSocket) - Method in class com.tangosol.net.TcpDatagramSocketProvider
-
Configure the socket.
- configure(XmlElement) - Method in class com.tangosol.net.WrapperService
-
Configure the controllable service.
- configure(XmlElement) - Method in interface com.tangosol.util.Controllable
-
Deprecated.
- configureBackingMap(DefaultConfigurableCacheFactory.CacheInfo, XmlElement, BackingMapManagerContext, ClassLoader, Map) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Configures a backing map according to the scheme.
- configureCache(DefaultConfigurableCacheFactory.CacheInfo, XmlElement, ClassLoader) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Ensures a cache for given scheme.
- configureCacheStore(ReadWriteBackingMap.StoreWrapper, boolean) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Set up the StoreWrapper that this backing map will use.
- configureEviction(int, ConfigurableCacheMap.EvictionPolicy) - Method in class com.tangosol.net.cache.OldCache
-
Deprecated.
Configure the eviction type and policy.
- configureFile(File) - Method in class com.tangosol.io.nio.MappedBufferManager
-
Configure the buffer manager based on the passed file, which may be
null to imply a default temp file, a directory to imply that a file
be created in that directory, or it may be the temp file itself.
- configureInterceptors(XmlElement) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Using the provided base XML find all interceptors instantiating as
appropriate and registering with the Events Registry
.
- configureInternalCache(ObservableMap) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Configure the internal cache that this backing map uses to store its
"in-memory" data.
- configureJaxbMarshaller(Marshaller) - Method in class com.tangosol.coherence.rest.io.JaxbXmlMarshaller
-
Configure a JAXB marshaller.
- configureJaxbUnmarshaller(Unmarshaller) - Method in class com.tangosol.coherence.rest.io.JaxbXmlMarshaller
-
Configure a JAXB unmarshaller.
- configureReadThread(double) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Set up the optional refresh-ahead thread and queue that this backing map
will use.
- configureSynchronization(boolean) - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
Set up the listeners that keep the ContinuousQueryCache
up-to-date.
- configureUnitCalculator(int, ConfigurableCacheMap.UnitCalculator) - Method in class com.tangosol.net.cache.OldCache
-
Deprecated.
Configure the unit calculator type and implementation.
- configureUnitCalculator(XmlElement, ConfigurableCacheMap, DefaultConfigurableCacheFactory.CacheInfo, BackingMapManagerContext, ClassLoader) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Configure a UnitCalculator for the specified ConfigurableCacheMap.
- configureWorker(Daemon.DaemonWorker) - Method in class com.tangosol.util.Daemon
-
Configure a worker to use as a daemon.
- configureWriteThread(int) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Set up the optional write-behind thread and queue that this backing map
will use.
- CONNECT - Static variable in interface com.tangosol.net.ProxyService.ProxyAction
-
Singleton action for accepting a client connection.
- connect(String, String, String) - Method in class com.tangosol.run.jca.CacheAdapter
-
Connect the adapter to the specified clustered service.
- connect(String, String, String, String) - Method in class com.tangosol.run.jca.CacheAdapter
-
Connect the adapter to the specified clustered service.
- CONNECT_RULE_NAME - Static variable in class com.tangosol.coherence.config.builder.ProxyQuorumPolicyBuilder
-
Connect description and also xml configuration element name.
- CONNECTION_MANAGER_TYPE - Static variable in interface com.tangosol.net.management.Registry
-
String representing the "type" part of ObjectName for the
ConnectionManagerMBean.
- CONNECTION_TYPE - Static variable in interface com.tangosol.net.management.Registry
-
String representing the "type" part of ObjectName for the
ConnectionMBean.
- Constants - Class in com.tangosol.coherence.jcache
-
Constants used by the Coherence JCache Adapter.
- Constants() - Constructor for class com.tangosol.coherence.jcache.Constants
-
- ConstructorQueryWalker - Class in com.tangosol.coherence.dslquery.internal
-
This is a specialized query walker that walks an AST
representing a constructor statement in the form of
package.ClassName(args) and results in an Object array
where the last entry in the array is a
ReflectionExtractor
.
- ConstructorQueryWalker(List, ParameterResolver, CoherenceQueryLanguage) - Constructor for class com.tangosol.coherence.dslquery.internal.ConstructorQueryWalker
-
Creates a ConstructorQueryWalker that uses the specified
bindings to replace any bind variables in the ASTs walked.
- consumer(Remote.Consumer<T>) - Static method in class com.tangosol.util.function.Remote
-
Capture serializable Consumer.
- ContainerHelper - Class in com.tangosol.coherence.jcache.common
-
Helpers for supporting Coherence JCache in Container Environment.
- ContainerHelper() - Constructor for class com.tangosol.coherence.jcache.common.ContainerHelper
-
- ContainerHelper.JCacheLifecycleInterceptor - Class in com.tangosol.coherence.jcache.common
-
- ContainerPassThroughResourceConfig - Class in com.tangosol.coherence.rest.server
-
An extension of
PassThroughResourceConfig
that should be used for
container deployments of Coherence REST when pass-through is required.
- ContainerPassThroughResourceConfig() - Constructor for class com.tangosol.coherence.rest.server.ContainerPassThroughResourceConfig
-
- ContainerResourceConfig - Class in com.tangosol.coherence.rest.server
-
- ContainerResourceConfig() - Constructor for class com.tangosol.coherence.rest.server.ContainerResourceConfig
-
Default constructor.
- contains(Object) - Method in class com.tangosol.io.nio.BinaryMap.EntrySet
-
Returns true if this collection contains the specified
element.
- contains(Object) - Method in class com.tangosol.io.nio.BinaryMap.KeySet
-
Determine if a particular key is present in the Set.
- contains(Object) - Method in class com.tangosol.net.cache.OverflowMap.InternalKeySet
- contains(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.EntrySet
-
Returns true if this collection contains the specified
element.
- contains(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.KeySet
-
Determine if a particular key is present in the Set.
- contains(int) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumRule
-
Return true if the current rule contains the specified action mask.
- contains(int) - Method in class com.tangosol.net.partition.PartitionSet
-
Check whether or not the specified partition belongs to the set.
- contains(PartitionSet) - Method in class com.tangosol.net.partition.PartitionSet
-
Check whether or not the specified partition set belongs to this set.
- contains(Object) - Method in class com.tangosol.util.AbstractKeyBasedMap.EntrySet
-
Returns true if this collection contains the specified
element.
- contains(Object) - Method in class com.tangosol.util.AbstractKeyBasedMap.KeySet
-
Returns true if this collection contains the specified
element.
- contains(Object) - Method in class com.tangosol.util.AbstractKeyBasedMap.ValuesCollection
-
Returns true if this collection contains the specified
element.
- contains(V) - Method in class com.tangosol.util.AbstractLongArray
-
Determine if the LongArray contains the specified element.
- contains(V) - Method in class com.tangosol.util.AbstractSafeLongArray
-
- contains(Object) - Method in class com.tangosol.util.ChainedCollection
-
- contains(Object) - Method in class com.tangosol.util.ChainedMap.EntrySet
-
Returns true if this collection contains the specified
element.
- contains(Object) - Method in class com.tangosol.util.CircularArrayList
- contains(Object) - Method in class com.tangosol.util.ConverterCollections.ConverterCollection
- contains(Object) - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet
- contains(T) - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray
-
- contains(Object) - Method in class com.tangosol.util.CopyOnWriteMap.EntrySet
- contains(Object) - Method in class com.tangosol.util.CopyOnWriteMap.KeySet
- contains(Object) - Method in class com.tangosol.util.DeltaSet
-
Returns true if this Collection contains the specified element.
- contains(ValueExtractor<T, C>, E) - Static method in class com.tangosol.util.Filters
-
Return a filter that tests if the extracted collection contains the
specified value.
- contains(Object) - Method in class com.tangosol.util.ImmutableArrayList
-
Returns true if this List contains the specified element.
- contains(Object) - Method in class com.tangosol.util.ImmutableMultiList
-
Returns true if this List contains the specified element.
- contains(Object) - Method in class com.tangosol.util.InflatableCollection
- contains(EventListener) - Method in class com.tangosol.util.Listeners
-
Check if a listener is in the list of listeners.
- contains(Object) - Method in class com.tangosol.util.LiteSet
-
Returns true if this Set contains the specified element.
- contains(V) - Method in interface com.tangosol.util.LongArray
-
Determine if the LongArray contains the specified element.
- contains(Object) - Method in class com.tangosol.util.MapSet
-
Returns true if this Set contains the specified element.
- contains(Object) - Method in class com.tangosol.util.NullImplementation.NullSet
-
Returns true if this Collection contains the specified element.
- contains(Object) - Method in class com.tangosol.util.OpenHashSet
- contains(Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedCollection
-
Returns true if this Collection contains the specified element.
- contains(Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet
-
Returns true if this Collection contains the specified element.
- contains(Object) - Method in class com.tangosol.util.SafeHashMap.EntrySet
-
Returns true if this collection contains the specified
element.
- contains(Object) - Method in class com.tangosol.util.SafeHashMap.KeySet
-
Determine if a particular key is present in the Set.
- contains(Object) - Method in class com.tangosol.util.SafeLinkedList
-
Returns true if this List contains the specified element.
- contains(Object) - Method in class com.tangosol.util.SegmentedHashMap.EntrySet
-
Returns true if this collection contains the specified
element.
- contains(Object) - Method in class com.tangosol.util.SegmentedHashMap.KeySet
-
Determine if a particular key is present in the Set.
- contains(Object) - Method in class com.tangosol.util.SimpleLongArray
-
Determine if the LongArray contains the specified element.
- contains(Object) - Method in class com.tangosol.util.SortedBag
- contains(String) - Method in class com.tangosol.util.StringTable
-
Determine if the passed string is in the table.
- contains(Object) - Method in class com.tangosol.util.SubList
- contains(Object) - Method in class com.tangosol.util.SubSet
- contains(Comparable) - Method in class com.tangosol.util.Tree
-
Determine if the passed key is in the tree.
- contains(Object) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperCollection
- contains(V) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
-
- contains(Object) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperCollection
- containsAll(Collection<?>) - Method in class com.tangosol.util.ChainedCollection
-
- containsAll(Collection<?>) - Method in class com.tangosol.util.ConverterCollections.ConverterCollection
- containsAll(Collection<?>) - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet
- containsAll(ValueExtractor<T, C>, Set<? extends E>) - Static method in class com.tangosol.util.Filters
-
Return a filter that tests if the extracted collection contains all of
the specified values.
- containsAll(ValueExtractor<T, C>, E...) - Static method in class com.tangosol.util.Filters
-
Return a filter that tests if the extracted collection contains all of
the specified values.
- containsAll(Collection<?>) - Method in class com.tangosol.util.LiteSet
-
Returns true if this Set contains all of the elements in the
specified Collection.
- containsAll(Collection) - Method in class com.tangosol.util.MapSet
-
Returns true if this Set contains all of the elements
in the specified Collection.
- containsAll(Collection) - Method in class com.tangosol.util.RestrictedCollections.RestrictedCollection
-
Returns true if this Collection contains all of the elements
in the specified Collection.
- containsAll(Collection) - Method in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet
-
Returns true if this Collection contains all of the elements
in the specified Collection.
- containsAll(Collection) - Method in class com.tangosol.util.SafeLinkedList
-
Returns true if this List contains all of the elements of the
specified collection.
- containsAll(Collection<?>) - Method in class com.tangosol.util.SubList
- containsAll(Collection<?>) - Method in class com.tangosol.util.SubSet
- containsAll(Collection<?>) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperCollection
- containsAll(Collection<?>) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperCollection
- ContainsAllFilter<T,E> - Class in com.tangosol.util.filter
-
Filter which tests a
Collection
or Object array value returned from
a method invocation for containment of all values in a Set.
- ContainsAllFilter() - Constructor for class com.tangosol.util.filter.ContainsAllFilter
-
Default constructor (necessary for the ExternalizableLite interface).
- ContainsAllFilter(ValueExtractor<? super T, ? extends E>, Set<?>) - Constructor for class com.tangosol.util.filter.ContainsAllFilter
-
Construct an ContainsAllFilter for testing containment of the given Set
of values.
- ContainsAllFilter(String, Set<?>) - Constructor for class com.tangosol.util.filter.ContainsAllFilter
-
Construct an ContainsAllFilter for testing containment of the given Set
of values.
- ContainsAllOperator - Class in com.tangosol.coherence.dslquery.operator
-
An operator representing the conditional "contains all" operation.
- ContainsAllOperator() - Constructor for class com.tangosol.coherence.dslquery.operator.ContainsAllOperator
-
Construct a ContainsAllOperator.
- containsAny(ValueExtractor<T, C>, Set<? extends E>) - Static method in class com.tangosol.util.Filters
-
Return a filter that tests if the extracted collection contains any of
the specified values.
- containsAny(ValueExtractor<T, C>, E...) - Static method in class com.tangosol.util.Filters
-
Return a filter that tests if the extracted collection contains any of
the specified values.
- ContainsAnyFilter<T,E> - Class in com.tangosol.util.filter
-
Filter which tests a
Collection
or Object array value returned from
a method invocation for containment of any value in a Set.
- ContainsAnyFilter() - Constructor for class com.tangosol.util.filter.ContainsAnyFilter
-
Default constructor (necessary for the ExternalizableLite interface).
- ContainsAnyFilter(ValueExtractor<? super T, ? extends E>, Set<?>) - Constructor for class com.tangosol.util.filter.ContainsAnyFilter
-
Construct an ContainsAnyFilter for testing containment of any value in
the given Set.
- ContainsAnyFilter(String, Set<?>) - Constructor for class com.tangosol.util.filter.ContainsAnyFilter
-
Construct an ContainsAnyFilter for testing containment of any value in
the given Set.
- ContainsAnyOperator - Class in com.tangosol.coherence.dslquery.operator
-
An operator representing the conditional "contains any" operation.
- ContainsAnyOperator() - Constructor for class com.tangosol.coherence.dslquery.operator.ContainsAnyOperator
-
Construct a ContainsAnyOperator.
- ContainsFilter<T,E> - Class in com.tangosol.util.filter
-
Filter which tests a
Collection
or Object array value returned from
a method invocation for containment of a given value.
- ContainsFilter() - Constructor for class com.tangosol.util.filter.ContainsFilter
-
Default constructor (necessary for the ExternalizableLite interface).
- ContainsFilter(ValueExtractor<? super T, ? extends E>, E) - Constructor for class com.tangosol.util.filter.ContainsFilter
-
Construct an ContainsFilter for testing containment of the given
object.
- ContainsFilter(String, E) - Constructor for class com.tangosol.util.filter.ContainsFilter
-
Construct an ContainsFilter for testing containment of the given
object.
- containsKey(K) - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
-
- containsKey(K) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
-
- containsKey(K) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
-
- containsKey(K) - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
-
- containsKey(Binary) - Method in interface com.tangosol.io.BinaryStore.KeySetAware
-
Return true iff this BinaryStore contains a mapping for the
specified key.
- containsKey(Object) - Method in class com.tangosol.io.nio.BinaryMap
-
Returns true if this map contains a mapping for the specified
key.
- containsKey(K) - Method in interface com.tangosol.net.AsyncNamedCache
-
Returns true if this cache contains a mapping for the specified
key.
- containsKey(Object) - Method in class com.tangosol.net.cache.CacheStoreMap.ReadWriteMap
-
Returns true if this map contains a mapping for the specified
key.
- containsKey(Object) - Method in class com.tangosol.net.cache.CachingMap
- containsKey(Object) - Method in class com.tangosol.net.cache.OldCache
-
Deprecated.
Returns true if this map contains a mapping for the specified
key.
- containsKey(Object) - Method in class com.tangosol.net.cache.OverflowMap
-
Returns true if this map contains a mapping for the specified
key.
- containsKey(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Returns true if this map contains a mapping for the specified
key.
- containsKey(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.WriteQueue
-
- containsKey(Object) - Method in class com.tangosol.net.cache.SerializationCache
-
Returns true if this map contains a mapping for the specified
key.
- containsKey(Object) - Method in class com.tangosol.net.cache.SimpleOverflowMap
-
Returns true if this map contains a mapping for the specified
key.
- containsKey(Object) - Method in class com.tangosol.net.cache.SimpleSerializationMap
-
Returns true if this map contains a mapping for the specified
key.
- containsKey(Object) - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
-
Returns true if this map contains a mapping for the specified
key.
- containsKey(Object) - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.MaskedPartitionMap
-
Returns true if this map contains a mapping for the specified
key.
- containsKey(Object) - Method in class com.tangosol.run.xml.SimpleElement.AttributeMap
-
- containsKey(Object) - Method in class com.tangosol.util.AbstractKeyBasedMap
-
Returns true if this map contains a mapping for the specified
key.
- containsKey(Object) - Method in class com.tangosol.util.AbstractKeySetBasedMap
-
Returns true if this map contains a mapping for the specified
key.
- containsKey(Object) - Method in class com.tangosol.util.ChainedMap
-
Returns true if this map contains a mapping for the specified
key.
- containsKey(Object) - Method in interface com.tangosol.util.ConcurrentMap
-
Returns true if this map contains a mapping for the specified
key.
- containsKey(Object) - Method in class com.tangosol.util.ConverterCollections.ConverterMap
- containsKey(Object) - Method in class com.tangosol.util.CopyOnWriteMap
- containsKey(Object) - Method in class com.tangosol.util.NullImplementation.NullMap
- containsKey(Object) - Method in class com.tangosol.util.OpenHashMap
-
Returns true if this map contains a mapping for the specified
key.
- containsKey(Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedMap
-
Returns true if this map contains a mapping for the
specified key.
- containsKey(Object) - Method in class com.tangosol.util.SafeHashMap
-
Returns true if this map contains a mapping for the specified
key.
- containsKey(Object) - Method in class com.tangosol.util.SafeSortedMap
- containsKey(Object) - Method in class com.tangosol.util.SafeSortedMap.ViewMap
- containsKey(Object) - Method in class com.tangosol.util.SegmentedHashMap
-
Returns true iff this map contains a mapping for the specified
key.
- containsKey(Object) - Method in class com.tangosol.util.SetMap
-
- containsKey(Object) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperMap
- containsKey(Object) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- containsNamedQuery(String) - Method in class com.tangosol.coherence.rest.config.QueryConfig
-
Return true if this configuration contains a query with
given name.
- ContainsOperator - Class in com.tangosol.coherence.dslquery.operator
-
An operator representing the conditional "contains" operation.
- ContainsOperator() - Constructor for class com.tangosol.coherence.dslquery.operator.ContainsOperator
-
Construct a ContainsOperator.
- ContainsOPToken - Class in com.tangosol.coherence.dsltools.precedence
-
ContainsOPToken is used to implement a contains operation that checks for
membership in a list.
- ContainsOPToken(String, int) - Constructor for class com.tangosol.coherence.dsltools.precedence.ContainsOPToken
-
Construct a new ContainsOPToken with the given parameters.
- containsStandardListeners(Filter) - Method in class com.tangosol.util.MapListenerSupport
-
Checks whether or not this MapListenerSupport object contains
any standard (not lite) listeners for a given filter.
- containsStandardListeners(Object) - Method in class com.tangosol.util.MapListenerSupport
-
Checks whether or not this MapListenerSupport object contains
any standard (not lite) listeners for a given key.
- containsValue(Object) - Method in class com.tangosol.net.cache.CachingMap
- containsValue(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Returns true if this CachingMap maps one or more keys to the
specified value.
- containsValue(Object) - Method in class com.tangosol.net.cache.SerializationCache
-
Returns true if this Map maps one or more keys to the
specified value.
- containsValue(Object) - Method in class com.tangosol.net.cache.SerializationMap
-
Returns true if this Map maps one or more keys to the
specified value.
- containsValue(Object) - Method in class com.tangosol.net.cache.SimpleSerializationMap
-
Returns true if this Map maps one or more keys to the
specified value.
- containsValue(Object) - Method in class com.tangosol.util.AbstractKeyBasedMap
-
Returns true if this Map maps one or more keys to the
specified value.
- containsValue(Object) - Method in interface com.tangosol.util.ConcurrentMap
-
Returns true if this map maps one or more keys to the
specified value.
- containsValue(Object) - Method in class com.tangosol.util.ConverterCollections.ConverterMap
- containsValue(Object) - Method in class com.tangosol.util.CopyOnWriteMap
- containsValue(Object) - Method in class com.tangosol.util.NullImplementation.NullMap
- containsValue(Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedMap
-
Returns true if this map maps one or more keys to the
specified value.
- containsValue(Object) - Method in class com.tangosol.util.SegmentedHashMap
-
Returns true if this map maps one or more keys to the
specified value.
- containsValue(Object) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperMap
- containsValue(Object) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- containsValue(Object) - Method in class com.tangosol.util.WrapperObservableMap
-
Returns true if this Map maps one or more keys to the
specified value.
- ContainsValueAction() - Constructor for class com.tangosol.util.SegmentedHashMap.ContainsValueAction
-
- contendForSegment(int) - Method in class com.tangosol.util.SegmentedHashMap
-
Wait for a segment to be unlocked.
- Context(Guardable, long, float) - Constructor for class com.tangosol.net.GuardSupport.Context
-
Construct a Context.
- contextDestroyed(ServletContextEvent) - Method in class com.tangosol.coherence.rest.servlet.DefaultServletContextListener
-
Notification that the servlet context is about to be shut down.
- contextInitialized(ServletContextEvent) - Method in class com.tangosol.coherence.rest.servlet.DefaultServletContextListener
-
Notification that the web application initialization process is
starting.
- ContextJCacheStatistics - Class in com.tangosol.coherence.jcache.common
-
JCache Statistics implementation.
- ContextJCacheStatistics() - Constructor for class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
-
Constructs ...
- ContextJCacheStatistics(JCacheIdentifier) - Constructor for class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
-
Constructs JCacheStatistics for cache id
- ContinuousQueryCache<K,V_BACK,V_FRONT> - Class in com.tangosol.net.cache
-
Create a materialized view of a
NamedCache
using the
Coherence
Continuous Query capability.
- ContinuousQueryCache(NamedCache<K, V_BACK>) - Constructor for class com.tangosol.net.cache.ContinuousQueryCache
-
- ContinuousQueryCache(Supplier<NamedCache<K, V_BACK>>) - Constructor for class com.tangosol.net.cache.ContinuousQueryCache
-
- ContinuousQueryCache(NamedCache<K, V_BACK>, Filter) - Constructor for class com.tangosol.net.cache.ContinuousQueryCache
-
Create a locally materialized view of a
NamedCache
using a Filter.
- ContinuousQueryCache(Supplier<NamedCache<K, V_BACK>>, Filter) - Constructor for class com.tangosol.net.cache.ContinuousQueryCache
-
- ContinuousQueryCache(NamedCache<K, V_BACK>, Filter, ValueExtractor<? super V_BACK, ? extends V_FRONT>) - Constructor for class com.tangosol.net.cache.ContinuousQueryCache
-
Create a locally materialized view of a
NamedCache
using a
Filter
and
a transformer.
- ContinuousQueryCache(NamedCache<K, V_BACK>, Filter, boolean) - Constructor for class com.tangosol.net.cache.ContinuousQueryCache
-
Create a materialized view of a
NamedCache
using a Filter.
- ContinuousQueryCache(NamedCache<K, V_BACK>, Filter, MapListener<? super K, ? super V_FRONT>) - Constructor for class com.tangosol.net.cache.ContinuousQueryCache
-
Create a materialized view of a
NamedCache
using a Filter.
- ContinuousQueryCache(NamedCache<K, V_BACK>, Filter, MapListener<? super K, ? super V_FRONT>, ValueExtractor<? super V_BACK, ? extends V_FRONT>) - Constructor for class com.tangosol.net.cache.ContinuousQueryCache
-
- ContinuousQueryCache(NamedCache<K, V_BACK>, Filter, boolean, MapListener<? super K, ? super V_FRONT>, ValueExtractor<? super V_BACK, ? extends V_FRONT>) - Constructor for class com.tangosol.net.cache.ContinuousQueryCache
-
Construct the ContinuousQueryCache.
- ContinuousQueryCache(Supplier<NamedCache<K, V_BACK>>, Filter, boolean, MapListener<? super K, ? super V_FRONT>, ValueExtractor<? super V_BACK, ? extends V_FRONT>, ClassLoader) - Constructor for class com.tangosol.net.cache.ContinuousQueryCache
-
- ContinuousQueryCache.AddListener - Class in com.tangosol.net.cache
-
A
MapListener
for adding items to the
ContinuousQueryCache
.
- ContinuousQueryCache.ConverterAsynchronousProcessor - Class in com.tangosol.net.cache
-
Wraps an
AsynchronousProcessor
to ensure the result of the EntryProcessor
execution is deserialized prior to passing to the provided AsynchronousProcessor.
- ContinuousQueryCache.DeactivationListener - Class in com.tangosol.net.cache
-
DeactivationListener for the underlying NamedCache.
- ContinuousQueryCache.EventRouter<K,V> - Class in com.tangosol.net.cache
-
An EventRouter routes events from the internal cache of the
ContinuousQueryCache
to the client listeners, and it can do so
asynchronously when appropriate.
- ContinuousQueryCache.InternalMapListener - Class in com.tangosol.net.cache
-
This listener allows interception of all events triggered by the the internal
ObservableMap
of the
ContinuousQueryCache
.
- ContinuousQueryCache.RemoveListener - Class in com.tangosol.net.cache
-
A
MapListener
for evicting items from the
ContinuousQueryCache
.
- ContinuousQueryCache.ServiceListener - Class in com.tangosol.net.cache
-
- ContinuousQueryCacheScheme - Class in com.tangosol.coherence.config.scheme
-
- ContinuousQueryCacheScheme() - Constructor for class com.tangosol.coherence.config.scheme.ContinuousQueryCacheScheme
-
- Controllable - Interface in com.tangosol.util
-
The Controllable interface represents a configurable daemon-like object,
quite often referred to as a service, that usually operates on its
own thread and has a controllable life cycle.
- convert(Object) - Method in class com.tangosol.net.cache.SimpleOverflowMap.FrontFilterConverter
-
Extracts the key from the Status object.
- Convert() - Constructor for class com.tangosol.net.topic.Subscriber.Convert
-
Default constructor for serialization.
- Convert(Function<? super V, U>) - Constructor for class com.tangosol.net.topic.Subscriber.Convert
-
- convert(Object, int) - Method in class com.tangosol.run.xml.SimpleValue
-
Convert the passed Object to the specified type.
- convert(Object, int) - Static method in class com.tangosol.run.xml.XmlHelper
-
Convert the passed Object to the specified type.
- convert(Collection, Converter) - Static method in class com.tangosol.util.CollectionHelper
-
Deprecated.
Convert a collection from one set of objects
to a new set of objects.
- convert(Iterator, Converter) - Static method in class com.tangosol.util.CollectionHelper
-
Deprecated.
Convert an Iterator from one set of objects to a new set of objects.
- convert(Enumeration, Converter) - Static method in class com.tangosol.util.CollectionHelper
-
Deprecated.
Convert an Enumeration from one set of objects to a new set of objects.
- convert(Object) - Method in class com.tangosol.util.NullImplementation.NullConverter
-
Convert the passed object to another object.
- convertArray(Object[], Converter) - Static method in class com.tangosol.util.ConverterCollections
-
Convert the contents of the passed array.
- convertArray(Object[], Converter, Object[]) - Static method in class com.tangosol.util.ConverterCollections
-
Convert the contents of the passed source array into an array with the
component type of the passed destination array, using the destination
array itself if it is large enough, and placing a null in the first
unused element of the destination array if it is larger than the
source array.
- convertConfiguration(Configuration<K, V>, ClassLoader) - Method in class com.tangosol.coherence.jcache.CoherenceBasedCachingProvider
-
- convertDouble(XmlValue) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Convert the value in the specified
XmlValue
to a double.
- Converter<F,T> - Interface in com.tangosol.util
-
Provide for "pluggable" object conversions.
- CONVERTER_FROM_BINARY - Static variable in class com.tangosol.util.ExternalizableHelper
-
A converter from Binary to Object format, which uses the DefaultSerializer.
- CONVERTER_STRIP_INTDECO - Static variable in class com.tangosol.util.ExternalizableHelper
-
A pass-through Binary converter that removes an IntDecoration if present.
- CONVERTER_TO_BINARY - Static variable in class com.tangosol.util.ExternalizableHelper
-
A converter from Object to Binary format that uses the DefaultSerializer.
- ConverterAsynchronousProcessor(AsynchronousProcessor) - Constructor for class com.tangosol.net.cache.ContinuousQueryCache.ConverterAsynchronousProcessor
-
Construct the processor to wrap the provided
AsynchronousProcessor
in order to
ensure results are properly converted prior to return.
- ConverterCacheEntry(ConfigurableCacheMap.Entry, Converter, Converter, Converter) - Constructor for class com.tangosol.util.ConverterCollections.ConverterCacheEntry
-
- ConverterCacheEvent(ObservableMap, CacheEvent, Converter, Converter) - Constructor for class com.tangosol.util.ConverterCollections.ConverterCacheEvent
-
Constructor.
- ConverterCacheEvent(ObservableMap, CacheEvent, Converter, Converter, BackingMapManagerContext) - Constructor for class com.tangosol.util.ConverterCollections.ConverterCacheEvent
-
Construct a ConverterMapEvent.
- ConverterCacheListener(NamedCache, MapListener, Converter, Converter) - Constructor for class com.tangosol.util.ConverterCollections.ConverterCacheListener
-
Constructor.
- ConverterCacheMap(CacheMap<FK, FV>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterCacheMap
-
Constructor.
- ConverterCollection(Collection<F>, Converter<F, T>, Converter<T, F>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterCollection
-
Constructor.
- ConverterCollections - Class in com.tangosol.util
-
A collection of Collection implementation classes that use the Converter
interface to convert the items stored in underlying collection objects.
- ConverterCollections() - Constructor for class com.tangosol.util.ConverterCollections
-
- ConverterCollections.AbstractConverterEntry<FK,TK,FV,TV> - Class in com.tangosol.util
-
An abstract Map Entry that lazily converts the key and value.
- ConverterCollections.ConverterCacheEntry - Class in com.tangosol.util
-
A ConfigurableCacheMap.Entry that lazily converts the key and value.
- ConverterCollections.ConverterCacheEvent - Class in com.tangosol.util
-
A Converter CacheEvent views an underlying CacheEvent through a set of
key and value Converters.
- ConverterCollections.ConverterCacheListener - Class in com.tangosol.util
-
A converter MapListener that converts events of the underlying
MapListener for the underlying NamedCache.
- ConverterCollections.ConverterCacheMap<FK,TK,FV,TV> - Class in com.tangosol.util
-
A Converter CacheMap views an underlying CacheMap through a set of key
and value Converters.
- ConverterCollections.ConverterCollection<F,T> - Class in com.tangosol.util
-
A Converter Collection views an underlying Collection through a
Converter.
- ConverterCollections.ConverterComparator<F,T> - Class in com.tangosol.util
-
A Comparator that Converts the elements before
comparing them.
- ConverterCollections.ConverterConcurrentMap<FK,TK,FV,TV> - Class in com.tangosol.util
-
A Converter ConcurrentMap views an underlying ConcurrentMap through a
set of key and value Converters.
- ConverterCollections.ConverterEntry<FK,TK,FV,TV> - Class in com.tangosol.util
-
A Map Entry that lazily converts the key and value.
- ConverterCollections.ConverterEntrySet<FK,TK,FV,TV> - Class in com.tangosol.util
-
A Converter Entry Set views an underlying Entry Set through a set of
key and value Converters.
- ConverterCollections.ConverterEntrySet.ConverterEntry - Class in com.tangosol.util
-
A Map Entry that lazily converts the key and value.
- ConverterCollections.ConverterEntrySet.ConverterIterator - Class in com.tangosol.util
-
A Map Entry Iterator that converts the key and value types.
- ConverterCollections.ConverterEnumerator<F,T> - Class in com.tangosol.util
-
Provide an implementation of an enumerator which converts each of the
items which it enumerates.
- ConverterCollections.ConverterHolder<F,T> - Class in com.tangosol.util
-
A Holder that converts the element before returning them.
- ConverterCollections.ConverterInvocableMap<FK,TK,FV,TV> - Class in com.tangosol.util
-
A Converter InvocableMap views an underlying InvocableMap through a
set of key and value Converters.
- ConverterCollections.ConverterList<F,T> - Class in com.tangosol.util
-
A Converter List views an underlying List through a Converter.
- ConverterCollections.ConverterListIterator<F,T> - Class in com.tangosol.util
-
A Converter ListIterator views an underlying ListIterator through a
Converter.
- ConverterCollections.ConverterLongArray<F,T> - Class in com.tangosol.util
-
ConverterLongArray converts the value of the LongArray from its raw form
(type F
) to the desired from (type T
).
- ConverterCollections.ConverterLongArray.ConverterLongArrayIterator - Class in com.tangosol.util
-
An Iterator that can convert from raw types to desired types.
- ConverterCollections.ConverterMap<FK,TK,FV,TV> - Class in com.tangosol.util
-
A Converter Map views an underlying Map through a set of key and value
Converters.
- ConverterCollections.ConverterMapEvent - Class in com.tangosol.util
-
A ConverterMapEvent views an underlying MapEvent through a set of key and
value Converters.
- ConverterCollections.ConverterMapEvent.ConverterMapEventBinaryEntry - Class in com.tangosol.util
-
ConverterMapEventBinaryEntry provides both the Map Entry and the
BinaryEntry interfaces to the information encapsulated inside the
ConverterMapEvent.
- ConverterCollections.ConverterMapEvent.ConverterMapEventEntry - Class in com.tangosol.util
-
ConverterMapEventEntry provides the Map Entry interface to the
information encapsulated inside the ConverterMapEvent.
- ConverterCollections.ConverterMapListener - Class in com.tangosol.util
-
A converter MapListener that converts events of the underlying
MapListener for the underlying map.
- ConverterCollections.ConverterNamedCache<FK,TK,FV,TV> - Class in com.tangosol.util
-
A Converter NamedCache views an underlying NamedCache through a set of
key and value Converters.
- ConverterCollections.ConverterObservableMap<FK,TK,FV,TV> - Class in com.tangosol.util
-
A Converter ObservableMap views an underlying ObservableMap through a
set of key and value Converters.
- ConverterCollections.ConverterQueryMap<FK,TK,FV,TV> - Class in com.tangosol.util
-
A Converter QueryMap views an underlying QueryMap through a set of key
and value Converters.
- ConverterCollections.ConverterSet<F,T> - Class in com.tangosol.util
-
A Converter Set views an underlying Set through a Converter.
- ConverterCollections.ConverterSortedMap<FK,TK,FV,TV> - Class in com.tangosol.util
-
A Converter SortedMap views an underlying SortedMap through a set of
key and value Converters.
- ConverterCollections.ConverterSortedSet<F,T> - Class in com.tangosol.util
-
A Converter SortedSet views an underlying SortedSet through a
Converter.
- ConverterComparator(Comparator<? super F>, Converter<T, F>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterComparator
-
Constructor.
- ConverterConcurrentMap(ConcurrentMap<FK, FV>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterConcurrentMap
-
Constructor.
- ConverterEntry(Map.Entry<FK, FV>, Converter<FK, TK>, Converter<FV, TV>, Converter<TV, FV>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterEntry
-
Constructor.
- ConverterEntry(Map.Entry<FK, FV>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterEntrySet.ConverterEntry
-
Constructor.
- ConverterEntrySet(Collection<Map.Entry<FK, FV>>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterEntrySet
-
Constructor.
- ConverterEnumerator(Enumeration<F>, Converter<F, T>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterEnumerator
-
Construct the Converter enumerator based on an Enumeration.
- ConverterEnumerator(Iterator<F>, Converter<F, T>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterEnumerator
-
Construct the Converter enumerator based on an Iterator.
- ConverterEnumerator(Object[], Converter<F, T>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterEnumerator
-
Construct the Converter enumerator based on an array of objects.
- ConverterEnumerator - Class in com.tangosol.util
-
- ConverterEnumerator(Enumeration, Converter) - Constructor for class com.tangosol.util.ConverterEnumerator
-
Deprecated.
Construct the Converter enumerator based on an Enumeration.
- ConverterEnumerator(Iterator, Converter) - Constructor for class com.tangosol.util.ConverterEnumerator
-
Deprecated.
Construct the Converter enumerator based on an Iterator.
- ConverterEnumerator(Object[], Converter) - Constructor for class com.tangosol.util.ConverterEnumerator
-
Deprecated.
Construct the Converter enumerator based on an array of objects.
- ConverterHolder(F, Converter<F, T>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterHolder
-
Constructor.
- ConverterInvocableMap(InvocableMap<FK, FV>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterInvocableMap
-
Constructor.
- ConverterIterator(Iterator<Map.Entry<FK, FV>>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterEntrySet.ConverterIterator
-
Constructor.
- ConverterList(List<F>, Converter<F, T>, Converter<T, F>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterList
-
Constructor.
- ConverterListIterator(ListIterator<F>, Converter<F, T>, Converter<T, F>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterListIterator
-
Constructor.
- ConverterLongArray(LongArray<F>, Converter<F, T>, Converter<T, F>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterLongArray
-
Construct a LongArray that converts the values from type F
to type T
.
- ConverterLongArrayIterator(LongArray.Iterator<F>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterLongArray.ConverterLongArrayIterator
-
Construct a converting iterator.
- ConverterMap(Map<FK, FV>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterMap
-
Constructor.
- ConverterMapEvent(ObservableMap, MapEvent, Converter, Converter) - Constructor for class com.tangosol.util.ConverterCollections.ConverterMapEvent
-
Construct a ConverterMapEvent.
- ConverterMapEvent(ObservableMap, MapEvent, Converter, Converter, BackingMapManagerContext) - Constructor for class com.tangosol.util.ConverterCollections.ConverterMapEvent
-
Construct a ConverterMapEvent.
- ConverterMapEventBinaryEntry(boolean) - Constructor for class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventBinaryEntry
-
Constructor.
- ConverterMapEventEntry(boolean) - Constructor for class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventEntry
-
Constructor.
- ConverterMapListener(ObservableMap, MapListener, Converter, Converter) - Constructor for class com.tangosol.util.ConverterCollections.ConverterMapListener
-
Constructor.
- ConverterNamedCache(NamedCache<FK, FV>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterNamedCache
-
Constructor.
- ConverterObservableMap(ObservableMap<FK, FV>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterObservableMap
-
Constructor.
- ConverterQueryMap(QueryMap<FK, FV>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterQueryMap
-
Constructor.
- ConverterSet(Collection<F>, Converter<F, T>, Converter<T, F>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterSet
-
Constructor.
- ConverterSortedMap(SortedMap<FK, FV>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterSortedMap
-
Constructor.
- ConverterSortedSet(SortedSet<F>, Converter<F, T>, Converter<T, F>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterSortedSet
-
Constructor.
- convertEvent(MapEvent, ObservableMap, Converter, Converter) - Static method in class com.tangosol.util.MapListenerSupport
-
Convert the specified map event into another MapEvent that ensures the
lazy event data conversion using the specified converters.
- convertInt(XmlValue) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Convert the value in the specified
XmlValue
to an int.
- convertInt(XmlValue, int) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Convert the value in the specified
XmlValue
to an int.
- convertList(List<String>, Class) - Method in class com.tangosol.coherence.rest.query.AbstractQueryEngine
-
Convert all elements of the source list into the specified type.
- convertLong(XmlValue) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Convert the value in the specified
XmlValue
to a long.
- convertNumber(Number, int) - Static method in class com.tangosol.io.pof.PofHelper
-
Convert the passed number to the specified type.
- convertSafe(Converter, Object) - Static method in class com.tangosol.util.ConverterCollections.ConverterInvocableMap
-
Convert the provided value with the given converter.
- convertToDate(Object) - Static method in class com.tangosol.io.pof.PofHelper
-
Convert a date, time or date/time value to a Java Date.
- convertUTF(int, int) - Method in class com.tangosol.io.AbstractByteArrayReadBuffer.ByteArrayBufferInput
-
Convert a UTF-8 encoded section of the binary stream into a String.
- convertUTF(int, int) - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
-
Convert a UTF-8 encoded section of the binary stream into a String.
- convertUTF(int, int) - Method in class com.tangosol.io.nio.ByteBufferReadBuffer.ByteBufferInput
-
Convert a UTF-8 encoded section of the binary stream into a String.
- convertUTF(byte[], int, int, char[]) - Static method in class com.tangosol.util.ExternalizableHelper
-
Convert binary UTF-8 encode data to a String.
- copy(InputStream, OutputStream, byte[]) - Method in class com.tangosol.net.LoadBalancer.SocketHandler
-
Process the transfer of data from one stream to another.
- copyAndOpenInternal(PersistentStore<ReadBuffer>) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
-
Copy the provided store to ensure both the contents are available
in the new store and it is open thus ready to receive requests.
- copyArray(LongArray<V>) - Method in class com.tangosol.util.CopyOnWriteLongArray
-
Return a shallow copy of the specified LongArray.
- copyBufferInputPortion(int, ReadBuffer.BufferInput, int) - Method in class com.tangosol.io.AbstractWriteBuffer
-
Read a portion of the specified BufferInput and write it to the
specified offset within this buffer.
- copyBufferInputRemainder(int, ReadBuffer.BufferInput, int) - Method in class com.tangosol.io.AbstractWriteBuffer
-
Read the remaining contents of the specified BufferInput and write it
to the specified offset within this buffer.
- copyBytes(int, int, byte[], int) - Method in class com.tangosol.io.AbstractByteArrayReadBuffer
-
Copies bytes from this ReadBuffer into the destination byte array.
- copyBytes(int, int, byte[], int) - Method in class com.tangosol.io.MultiBufferReadBuffer
-
Copies bytes from this ReadBuffer into the destination byte array.
- copyBytes(int, int, byte[], int) - Method in class com.tangosol.io.nio.ByteBufferReadBuffer
-
Copies bytes from this ReadBuffer into the destination byte array.
- copyBytes(int, int, byte[], int) - Method in interface com.tangosol.io.ReadBuffer
-
Copies bytes from this ReadBuffer into the destination byte array.
- copyClassAnnotations(ClassNode, ClassNode) - Static method in class com.tangosol.coherence.rest.util.PartialObject
-
Copy class-level annotations.
- copyDir(File, File) - Static method in class com.tangosol.io.FileHelper
-
Create a deep copy of the specified directory into the specified target
directory.
- copyFile(File, File) - Static method in class com.tangosol.io.FileHelper
-
Copy the specified file according to the source and destination File
objects preserving the time-stamp of the source.
- copyFrom(SafeHashMap.Entry) - Method in class com.tangosol.net.cache.OldCache.Entry
-
Deprecated.
Copy this Entry's information from another Entry.
- copyFrom(PartitionStatistics) - Method in class com.tangosol.net.partition.PartitionStatistics
-
Copy the statistics from the specified PartitionStatistics reference.
- copyFrom(SafeHashMap.Entry<K, V>) - Method in class com.tangosol.util.SafeHashMap.Entry
-
Copy this Entry's information from another Entry.
- copyMap(Map<K, V>) - Method in class com.tangosol.util.CopyOnWriteMap
-
Create an instance of
Map
based on the contents of the provided map.
- copyMetadata(File, File) - Static method in class com.tangosol.persistence.CachePersistenceHelper
-
Copy the metadata file from one directory to another.
- CopyOnWriteLongArray<V> - Class in com.tangosol.util
-
A thread-safe variant of
LongArray
in which all mutating operations
(e.g.
- CopyOnWriteLongArray() - Constructor for class com.tangosol.util.CopyOnWriteLongArray
-
Default constructor.
- CopyOnWriteLongArray(Class<? extends LongArray<V>>) - Constructor for class com.tangosol.util.CopyOnWriteLongArray
-
Construct a CopyOnWriteLongArray with an underlying array of the specified
type.
- CopyOnWriteLongArray(LongArray<V>) - Constructor for class com.tangosol.util.CopyOnWriteLongArray
-
Construct a CopyOnWriteLongArray, initialized with the contents of the
specified LongArray.
- CopyOnWriteLongArray.UnmodifiableIterator<V> - Class in com.tangosol.util
-
Unmodifiable view of a LongArray.Iterator.
- CopyOnWriteMap<K,V> - Class in com.tangosol.util
-
A thread-safe variant of
Map
in which all mutating operations
(e.g.
- CopyOnWriteMap(Class) - Constructor for class com.tangosol.util.CopyOnWriteMap
-
- CopyOnWriteMap(Map<K, V>) - Constructor for class com.tangosol.util.CopyOnWriteMap
-
Construct a CopyOnWriteMap, initialized with the contents of the
specified map.
- CopyOnWriteMap.EntrySet - Class in com.tangosol.util
-
A set of entries backed by this map.
- CopyOnWriteMap.KeySet - Class in com.tangosol.util
-
A set of keys backed by this map.
- copyOptions(SocketOptions) - Method in class com.tangosol.net.SocketOptions
-
Copy the options in the specified SocketOptions into this SocketOptions.
- copyStream(int, InputStreaming, int) - Method in class com.tangosol.io.AbstractWriteBuffer
-
Store the remaining contents of the specified InputStreaming object at
the specified offset within this buffer.
- copyStream(int, InputStreaming, int) - Method in class com.tangosol.io.ByteArrayWriteBuffer
-
Store the remaining contents of the specified InputStreaming object at
the specified offset within this buffer.
- copyStream(int, InputStreaming, int) - Method in class com.tangosol.io.DelegatingWriteBuffer
-
Store the remaining contents of the specified InputStreaming object at
the specified offset within this buffer.
- copyTransients(SimpleAssignmentStrategy.AnalysisContext) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
Copy transient values from another, generally the previous, AnalysisContext
to this AnalysisContext.
- Count<K,V> - Class in com.tangosol.util.aggregator
-
Calculates a number of values in an entry set.
- Count() - Constructor for class com.tangosol.util.aggregator.Count
-
Default constructor (necessary for the ExternalizableLite interface).
- count() - Static method in class com.tangosol.util.Aggregators
-
Return an aggregator that calculates the count of the entries in a Map.
- count() - Method in interface com.tangosol.util.stream.RemoteDoubleStream
-
Returns the count of elements in this stream.
- count() - Method in interface com.tangosol.util.stream.RemoteIntStream
-
Returns the count of elements in this stream.
- count() - Method in interface com.tangosol.util.stream.RemoteLongStream
-
Returns the count of elements in this stream.
- count() - Method in interface com.tangosol.util.stream.RemoteStream
-
Returns the count of elements in this stream.
- COUNT_FUNCTION_BUILDER - Static variable in class com.tangosol.coherence.dslquery.function.FunctionBuilders
-
This builder will realize instances of the
Count
aggregator.
- countBits(byte) - Static method in class com.tangosol.util.BitHelper
-
Count the number of bits set in the passed integral value.
- countBits(int) - Static method in class com.tangosol.util.BitHelper
-
Count the number of bits set in the passed integral value.
- countBits(long) - Static method in class com.tangosol.util.BitHelper
-
Count the number of bits set in the passed integral value.
- counting() - Static method in class com.tangosol.util.stream.RemoteCollectors
-
Returns a Collector
accepting elements of type T
that
counts the number of input elements.
- Crawler(AbstractSparseArray.Node<V>, int, boolean) - Constructor for class com.tangosol.util.AbstractSparseArray.Crawler
-
Crawler constructor.
- create(String) - Static method in class com.tangosol.coherence.dsltools.termtrees.Terms
-
Create a Tree of Terms using the Term Language in the given String
- create(String, CoherenceQueryLanguage) - Static method in class com.tangosol.coherence.dsltools.termtrees.Terms
-
Create a Tree of Terms using the Term Language in the given String
- create() - Static method in class com.tangosol.coherence.rest.config.RestConfig
-
Return a singleton instance of RestConfig based on the
REST configuration descriptor.
- create(Object, PropertySet) - Static method in class com.tangosol.coherence.rest.util.PartialObject
-
Create a PartialObject instance.
- create(Class, PropertySet, Map<String, Object>) - Static method in class com.tangosol.coherence.rest.util.PartialObject
-
Create a PartialObject instance based on an already extracted set of
properties.
- CREATE - Static variable in class com.tangosol.net.ClusterPermission
-
Create action.
- create(Session.Option...) - Static method in interface com.tangosol.net.Session
-
- create() - Method in class com.tangosol.net.TcpDatagramSocket.Impl
- CREATE_SNAPSHOT - Static variable in class com.tangosol.coherence.dslquery.internal.PersistenceToolsHelper
-
JMX operation to create a snapshot.
- CREATE_SNAPSHOT_BEGIN - Static variable in interface com.tangosol.persistence.PersistenceManagerMBean
-
Notification type for the start of snapshot creation.
- CREATE_SNAPSHOT_END - Static variable in interface com.tangosol.persistence.PersistenceManagerMBean
-
Notification type for the end of snapshot creation.
- createAddressProvider(ClassLoader) - Method in class com.tangosol.coherence.config.builder.CustomAddressProviderBuilder
-
Create a new AddressProvider using the specified class loader.
- createAddressProvider(ClassLoader) - Method in class com.tangosol.coherence.config.builder.FactoryBasedAddressProviderBuilder
-
Create a new AddressProvider using the specified class loader.
- createAddressProvider(ClassLoader) - Method in class com.tangosol.coherence.config.builder.ListBasedAddressProviderBuilder
-
Create a new AddressProvider using the specified class loader.
- createAddressProvider(ClassLoader) - Method in class com.tangosol.coherence.config.builder.LocalAddressProviderBuilder
-
Create a new AddressProvider using the specified class loader.
- createAddressProvider(ClassLoader) - Method in interface com.tangosol.net.AddressProviderFactory
-
Create a new AddressProvider using the specified class loader.
- createAddressProvider(ClassLoader) - Method in class com.tangosol.net.ConfigurableAddressProviderFactory
-
Deprecated.
Instantiate an AddressProvider configured according to the specified XML.
- createAggregator(String, NodeTerm, String, boolean, SelectListMaker) - Method in class com.tangosol.coherence.dslquery.statement.SelectStatementBuilder
-
Create the InvocableMap.EntryAggregator
that will aggregate the results of this
select query.
- createAggregator(ValueExtractor) - Method in class com.tangosol.coherence.rest.util.aggregator.DefaultAggregatorFactory
-
Create and initialize a new aggregator instance.
- createAggregatorMap(XmlElement) - Method in class com.tangosol.coherence.rest.config.RestConfig
-
Create a collection of AggregatorConfig objects from the given XML
configuration.
- createBinaryStore() - Method in class com.tangosol.io.AsyncBinaryStoreManager
-
Factory method: Returns a new BinaryStore.
- createBinaryStore() - Method in class com.tangosol.io.bdb.BerkeleyDBBinaryStoreManager
-
Factory method: Returns a new BinaryStore.
- createBinaryStore() - Method in interface com.tangosol.io.BinaryStoreManager
-
Factory method: Returns a new BinaryStore.
- createBinaryStore() - Method in class com.tangosol.io.nio.AbstractStoreManager
-
Factory method: Returns a new BinaryStore.
- createBinaryStore() - Method in class com.tangosol.net.cache.SerializationPagedCache
-
Create and register a new BinaryStore object, using this cache's
BinaryStoreManager.
- createBindings(Map<String, Object>, Map<String, Class>) - Method in class com.tangosol.coherence.rest.query.AbstractQueryEngine
-
Converts string parameters to their required types.
- createBoolean(String) - Static method in class com.tangosol.coherence.dsltools.base.LiteralBaseToken
-
Create new LiteralBaseToken representing a Boolean with given value
- createBoolean(String) - Static method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
-
Create new AtomicTerm representing a Boolean with given value
- createBufferManager() - Method in class com.tangosol.io.nio.AbstractStoreManager
-
Create a ByteBufferManager to be used by a BinaryStore.
- createBufferManager() - Method in class com.tangosol.io.nio.DirectStoreManager
-
Deprecated.
Create a ByteBufferManager to be used by a BinaryStore.
- createBufferManager() - Method in class com.tangosol.io.nio.MappedStoreManager
-
Create a ByteBufferManager to be used by a BinaryStore.
- createBytes(int) - Static method in class com.tangosol.io.ByteArrayWriteBuffer
-
Create a byte array of the specified size.
- createCache(String, C) - Method in class com.tangosol.coherence.jcache.CoherenceBasedCacheManager
-
- createCache(CoherenceBasedCacheManager, String) - Method in interface com.tangosol.coherence.jcache.CoherenceBasedConfiguration
-
- createCache(CoherenceBasedCacheManager, String) - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheConfiguration
-
- createCache(CoherenceBasedCacheManager, String) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheConfiguration
-
- createCache(CoherenceBasedCacheManager, String) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCacheConfiguration
-
- createCache(CoherenceBasedCacheManager, String) - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCacheConfiguration
-
- createCacheMananger(URI, ClassLoader, Properties) - Method in class com.tangosol.coherence.jcache.CoherenceBasedCachingProvider
-
Constructs a suitable CacheManager
for the specified parameters.
- CreateCacheStatement(String) - Constructor for class com.tangosol.coherence.dslquery.statement.CreateCacheStatementBuilder.CreateCacheStatement
-
Construct a CreateCacheStatement that will create a cache
with the specified name.
- CreateCacheStatementBuilder - Class in com.tangosol.coherence.dslquery.statement
-
- CreateCacheStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.statement.CreateCacheStatementBuilder
-
- CreateCacheStatementBuilder.CreateCacheStatement - Class in com.tangosol.coherence.dslquery.statement
-
Implementation of the CohQL "CREATE CACHE" command.
- createClass(ClassNode) - Static method in class com.tangosol.coherence.rest.util.PartialObject
-
Create partial class based on partial class definition.
- createComparator(String) - Method in class com.tangosol.coherence.rest.util.ComparatorBuilder
-
Create extractor comparator.
- createComparator(ValueExtractor) - Method in class com.tangosol.coherence.rest.util.ComparatorBuilder
-
Create extractor comparator.
- createComparator(String) - Static method in class com.tangosol.coherence.rest.util.ComparatorHelper
-
Create a new Comparator from the specified string.
- createConfiguration(ParameterResolver, ClassLoader) - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
-
Create a Configuration
based on the values contained in this scheme.
- createConstructors(ClassNode) - Static method in class com.tangosol.coherence.rest.util.PartialObject
-
Implement partial class constructors.
- createDefaultMarshaller(Class, String) - Method in class com.tangosol.coherence.rest.io.MarshallerRegistry
-
Create default marshaller for the specified class and media type.
- createDelta(ReadBuffer, ReadBuffer) - Method in class com.tangosol.io.BinaryDeltaCompressor
-
Actually create a delta in the binary delta format.
- createDelta(ReadBuffer, ReadBuffer) - Method in class com.tangosol.io.pof.PofDeltaCompressor
-
Actually create a delta in the binary delta format.
- createDouble(String) - Static method in class com.tangosol.coherence.dsltools.base.LiteralBaseToken
-
Create new LiteralBaseToken representing a Double with given value
- createDouble(String) - Static method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
-
Create new AtomicTerm representing a Double with given value
- createEvent(String, MapEvent<? extends K, ? extends V>) - Method in class com.tangosol.coherence.rest.events.MapEventOutput
-
Convert MapEvent to JSON-based OutboundEvent that can be sent to the client.
- createExtentInternal(long) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
-
Create the extent with the given identifier in the persistent
store.
- createExtractor(String) - Method in class com.tangosol.coherence.rest.util.ComparatorBuilder
-
Create expression extractor.
- createExtractor(String) - Static method in class com.tangosol.util.extractor.UniversalExtractor
-
Return a ValueExtractor representing dot separated list of property
and/or method names.
- createExtractor(String) - Static method in class com.tangosol.util.QueryHelper
-
Make a new ValueExtractor from the given String.
- createExtractor(String, CoherenceQueryLanguage) - Static method in class com.tangosol.util.QueryHelper
-
Make a new ValueExtractor from the given String.
- createExtractors(String) - Static method in class com.tangosol.util.extractor.ChainedExtractor
-
Parse a dot-delimited sequence of method names and instantiate
a corresponding array of
ReflectionExtractor
objects.
- createExtractors(String) - Static method in class com.tangosol.util.extractor.MultiExtractor
-
Parse a comma-delimited sequence of method names and instantiate
a corresponding array of
ValueExtractor
objects.
- createFilter(String) - Static method in class com.tangosol.util.QueryHelper
-
Make a new Filter from the given String.
- createFilter(String, Object[]) - Static method in class com.tangosol.util.QueryHelper
-
Make a new Filter from the given String.
- createFilter(String, Map) - Static method in class com.tangosol.util.QueryHelper
-
Make a new Filter from the given String.
- createFilter(String, Object[], Map) - Static method in class com.tangosol.util.QueryHelper
-
Make a new Filter from the given String.
- createFilter(String, Object[], Map, CoherenceQueryLanguage) - Static method in class com.tangosol.util.QueryHelper
-
Make a new Filter from the given String.
- createFloat(String) - Static method in class com.tangosol.coherence.dsltools.base.LiteralBaseToken
-
Create new LiteralBaseToken representing a float with given value
- createFloat(String) - Static method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
-
Create new AtomicTerm representing a float with given value
- createHiddenSnapshotDirectory(String) - Method in class com.tangosol.persistence.AbstractPersistenceEnvironment
-
Return a Path to a hidden directory within the snapshot directory that
does not exist.
- createIndex(boolean, Comparator, Map<ValueExtractor<T, E>, MapIndex>, BackingMapContext) - Method in class com.tangosol.util.extractor.ConditionalExtractor
-
Create an index and associate it with the corresponding extractor.
- createIndex(boolean, Comparator, Map, BackingMapContext) - Method in class com.tangosol.util.extractor.DeserializationAccelerator
-
Create an index and associate it with the corresponding extractor.
- createIndex(boolean, Comparator, Map<ValueExtractor<T, E>, MapIndex>, BackingMapContext) - Method in interface com.tangosol.util.extractor.IndexAwareExtractor
-
Create an index and associate it with the corresponding extractor.
- createIndexRegistrationKey(long, Binary) - Static method in class com.tangosol.persistence.CachePersistenceHelper
-
Create a key representing an index registration.
- CreateIndexStatement(String, ValueExtractor) - Constructor for class com.tangosol.coherence.dslquery.statement.CreateIndexStatementBuilder.CreateIndexStatement
-
Construct a CreateIndexStatement that will create an index on the
specified cache using the specified
ValueExtractor
.
- CreateIndexStatementBuilder - Class in com.tangosol.coherence.dslquery.statement
-
- CreateIndexStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.statement.CreateIndexStatementBuilder
-
- CreateIndexStatementBuilder.CreateIndexStatement - Class in com.tangosol.coherence.dslquery.statement
-
Implementation of the CohQL "CREATE INDEX" command.
- createInsertKey(Term, UpdateSetListMaker, Object) - Method in class com.tangosol.coherence.dslquery.statement.InsertStatementBuilder
-
Create the key to use in the insert statement.
- createInsertValue(Term, UpdateSetListMaker) - Method in class com.tangosol.coherence.dslquery.statement.InsertStatementBuilder
-
Create the instance of the value that will be inserted into the cache.
- createInstance(XmlElement, ClassLoader, XmlHelper.ParameterResolver) - Static method in class com.tangosol.run.xml.XmlHelper
-
Create an instance of the class configured using an XmlElement of the
following structure:
<!
- createInstance(XmlElement, ClassLoader, XmlHelper.ParameterResolver, Class) - Static method in class com.tangosol.run.xml.XmlHelper
-
Create an instance of the class configured using an XmlElement of the
following structure:
<!
- createInstance(InvocableMap.EntryAggregator[]) - Static method in class com.tangosol.util.aggregator.CompositeAggregator
-
Create an instance of CompositeAggregator based on a specified
EntryAggregator
array.
- createInstance(String, InvocableMap.EntryAggregator<K, V, R>) - Static method in class com.tangosol.util.aggregator.GroupAggregator
-
Create an instance of GroupAggregator based on a specified method
name(s) and an
EntryAggregator
.
- createInstance(String, InvocableMap.EntryAggregator<K, V, R>, Filter) - Static method in class com.tangosol.util.aggregator.GroupAggregator
-
Create an instance of GroupAggregator based on a specified method
name(s), an
EntryAggregator
and a result evaluation filter.
- createInstance(ValueExtractor<? super T, ? extends E>, InvocableMap.EntryAggregator<K, V, R>) - Static method in class com.tangosol.util.aggregator.GroupAggregator
-
Create an instance of GroupAggregator based on a specified extractor and
an
EntryAggregator
.
- createInstance(ValueExtractor<? super T, ? extends E>, InvocableMap.EntryAggregator<? super K, ? super V, R>, Filter) - Static method in class com.tangosol.util.aggregator.GroupAggregator
-
Create an instance of GroupAggregator based on a specified extractor
and an
EntryAggregator
and a result evaluation filter.
- createInteger(String) - Static method in class com.tangosol.coherence.dsltools.base.LiteralBaseToken
-
Create new LiteralBaseToken representing a Integer with given value
- createInteger(String) - Static method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
-
Create new AtomicTerm representing a Integer with given value
- createKey(Class, String) - Method in class com.tangosol.coherence.rest.io.MarshallerRegistry
-
Create a key for the marshallers map.
- createKey(Class, PropertySet) - Static method in class com.tangosol.coherence.rest.util.PartialObject
-
Create key for the partial class/constructor cache.
- createKeyConverter() - Method in class com.tangosol.coherence.rest.config.ResourceConfig
-
Create key converter instance.
- createListenerRegistrationKey(long, long, Binary) - Static method in class com.tangosol.persistence.CachePersistenceHelper
-
Create a key representing a cache listener registration.
- createLoadedLocalCacheValue(Object, long, ExpiryPolicy) - Static method in class com.tangosol.coherence.jcache.localcache.LocalCacheValue
-
Create a LocalCacheValue marked with Synthetic marker that it was loaded.
- createLocalCacheValue(Object, long, ExpiryPolicy) - Static method in class com.tangosol.coherence.jcache.localcache.LocalCacheValue
-
Create a LocalCacheValue for an LocalCache entry.
- createLockRegistrationKey(long, long, long, Binary) - Static method in class com.tangosol.persistence.CachePersistenceHelper
-
Create a key representing a cache entry lock.
- createLong(String) - Static method in class com.tangosol.coherence.dsltools.base.LiteralBaseToken
-
Create new LiteralBaseToken representing a Long with given value
- createLong(String) - Static method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
-
Create new AtomicTerm representing a Long with given value
- createMapAdapterMbean(Map<String, String>, Map<String, ?>) - Static method in class com.tangosol.net.management.MBeanHelper
-
Create a DynamicMBean driven by maps containing attribute descriptions and
values.
- createMarshaller(Class<?>, String, Class<?>) - Method in class com.tangosol.coherence.rest.io.MarshallerRegistry
-
Create marshaller instance.
- createMarshallerMap(XmlElement) - Method in class com.tangosol.coherence.rest.config.RestConfig
-
Create a map of REST marshaller classes keyed by media type from the
given XML configuration.
- createNamedDatabase(String) - Method in class com.tangosol.io.bdb.DatabaseFactory
-
Create a named Database instance.
- createNestedPofReader(int) - Method in class com.tangosol.io.pof.PofBufferReader
-
Obtain a PofReader that can be used to read a set of properties from a
single property of the current user type.
- createNestedPofReader(int) - Method in class com.tangosol.io.pof.PofBufferReader.UserTypeReader
-
Obtain a PofReader that can be used to read a set of properties from a
single property of the current user type.
- createNestedPofReader(int) - Method in interface com.tangosol.io.pof.PofReader
-
Obtain a PofReader that can be used to read a set of properties from a
single property of the current user type.
- createNestedPofWriter(int) - Method in class com.tangosol.io.pof.PofBufferWriter
-
Obtain a PofWriter that can be used to write a set of properties into
a single property of the current user type.
- createNestedPofWriter(int, int) - Method in class com.tangosol.io.pof.PofBufferWriter
-
Obtain a PofWriter that can be used to write a set of properties into
a single property of the current user type.
- createNestedPofWriter(int) - Method in class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
-
Obtain a PofWriter that can be used to write a set of properties into
a single property of the current user type.
- createNestedPofWriter(int, int) - Method in class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
-
Obtain a PofWriter that can be used to write a set of properties into
a single property of the current user type.
- createNestedPofWriter(int) - Method in interface com.tangosol.io.pof.PofWriter
-
Obtain a PofWriter that can be used to write a set of properties into
a single property of the current user type.
- createNestedPofWriter(int, int) - Method in interface com.tangosol.io.pof.PofWriter
-
Obtain a PofWriter that can be used to write a set of properties into
a single property of the current user type.
- createNull(String) - Static method in class com.tangosol.coherence.dsltools.base.LiteralBaseToken
-
Create new LiteralBaseToken representing a null with given value
- createNull(String) - Static method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
-
Create new AtomicTerm representing a null with given value
- createNull() - Static method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
-
Create new AtomicTerm representing a null.
- createObject(String, ClassLoader) - Static method in class com.tangosol.util.fsm.ReflectionHelper
-
Create an Object via reflection (using the specified
ClassLoader
).
- createObject(String, Object[], ClassLoader) - Static method in class com.tangosol.util.fsm.ReflectionHelper
-
Create an Object via reflection (using the specified
ClassLoader
).
- createParameterResolver(ClassLoader, BackingMapManagerContext) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
-
Return the ParameterResolver that has been initialized with the built-in
Coherence parameters.
- createPartialClass(Class, PropertySet<T>) - Static method in class com.tangosol.coherence.rest.util.PartialObject
-
Create a partial class for the specified source class and property set.
- createPartition(int) - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
-
Add a partition to the PartitionAwareBackingMap.
- createPartition(int) - Method in class com.tangosol.net.partition.ObservableSplittingBackingMap
-
Add a partition to the PartitionAwareBackingMap.
- createPartition(int) - Method in interface com.tangosol.net.partition.PartitionAwareBackingMap
-
Add a partition to the PartitionAwareBackingMap.
- createPartition(int) - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
-
Add a partition to the PartitionAwareBackingMap.
- createPartition(int) - Method in class com.tangosol.net.partition.ReadWriteSplittingBackingMap
-
Add a partition to the PartitionAwareBackingMap.
- createPersistentEnvironment() - Method in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
-
Create a persistent Environment.
- createPofConfig() - Method in class com.tangosol.io.pof.ConfigurablePofContext
-
Create a PofConfig object based on a configuration that was either
provided as XML, or can be loaded from the specified (or default) URI
using the provided ClassLoader.
- createProcessor(String) - Method in class com.tangosol.coherence.rest.util.processor.DefaultProcessorFactory
-
Create and initialize a new processor instance.
- createProcessorMap(XmlElement) - Method in class com.tangosol.coherence.rest.config.RestConfig
-
Create a collection of ProcessorConfig objects from the given XML
configuration.
- createPublisher(Publisher.Option<? super V>...) - Method in interface com.tangosol.net.topic.NamedTopic
-
- createPublisher() - Method in interface com.tangosol.net.topic.NamedTopic
-
- createQueryConfig(XmlElement) - Method in class com.tangosol.coherence.rest.config.RestConfig
-
Create a map of
QueryConfig
objects from the given XML
configuration.
- createQueryEngine(Class) - Static method in class com.tangosol.coherence.rest.query.QueryEngineRegistry
-
Create a query engine instance.
- createQueryEngines(XmlElement) - Method in class com.tangosol.coherence.rest.config.RestConfig
-
- createResolver(String, String) - Method in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder
-
Create a
resolver
based on the provided
cluster, service name and the state of this builder (active, snapshot
and trash directories).
- createResourceMap(XmlElement) - Method in class com.tangosol.coherence.rest.config.RestConfig
-
Create a map of ResourceConfig keyed by cache name or alias (if
defined) from the given XML configuration.
- createSelectListMaker(List, ParameterResolver, CoherenceQueryLanguage) - Method in class com.tangosol.coherence.dslquery.statement.SelectStatementBuilder
-
- createSerializer(ClassLoader) - Method in class com.tangosol.io.ConfigurableSerializerFactory
-
Deprecated.
Create a new Serializer.
- createSerializer(ClassLoader) - Method in interface com.tangosol.io.SerializerFactory
-
Create a new Serializer.
- createSession(Session.Option...) - Method in interface com.tangosol.net.CacheFactoryBuilder
-
- createSession(Session.Option...) - Method in interface com.tangosol.net.SessionProvider
-
- createShort(String) - Static method in class com.tangosol.coherence.dsltools.base.LiteralBaseToken
-
Create new LiteralBaseToken representing a Integer with given value
- createShort(String) - Static method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
-
Create new AtomicTerm representing a Short with given value
- createSnapshot(String, PersistenceManager<ReadBuffer>) - Method in class com.tangosol.persistence.AbstractPersistenceEnvironment
-
Create a PersistenceManager used to manage the snapshot with the
specified identifier.
- createSnapshot(String) - Method in interface com.tangosol.persistence.PersistenceManagerMBean
-
Create a snapshot of the service with the specified name.
- createSnapshot(String, PersistenceManager<R>) - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceEnvironment
-
Create a PersistenceManager used to manage the snapshot with the
specified identifier.
- createSnapshot(String, PersistenceManager<R>) - Method in class com.tangosol.util.NullImplementation.NullPersistenceEnvironment
-
Create a PersistenceManager used to manage the snapshot with the
specified identifier.
- createSnapshotArchiver(String, String) - Method in class com.tangosol.persistence.ConfigurableSnapshotArchiverFactory
-
Create a new SnapshotArchiver.
- createSnapshotArchiver(String, String) - Method in interface com.tangosol.persistence.SnapshotArchiverFactory
-
Create a new SnapshotArchiver.
- createSnapshotInternal(File, String, PersistenceManager<ReadBuffer>) - Method in class com.tangosol.persistence.AbstractPersistenceEnvironment
-
Create a snapshot with the specified identifier.
- CreateSnapshotStatement(String, String) - Constructor for class com.tangosol.coherence.dslquery.statement.persistence.CreateSnapshotStatementBuilder.CreateSnapshotStatement
-
Create a new CreateSnapshotStatement for the snapshot and service name.
- CreateSnapshotStatementBuilder - Class in com.tangosol.coherence.dslquery.statement.persistence
-
- CreateSnapshotStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.statement.persistence.CreateSnapshotStatementBuilder
-
- CreateSnapshotStatementBuilder.CreateSnapshotStatement - Class in com.tangosol.coherence.dslquery.statement.persistence
-
Implementation of the CohQL "CREATE SNAPSHOT" command.
- createSortedEntries(Map<K, Object[]>) - Static method in class com.tangosol.persistence.GUIDHelper
-
Return an array of entries
based on the provided map
ensuring the value (Object[]
) is sorted.
- createSSLSettings(SSLSocketProvider.Dependencies) - Static method in class com.tangosol.net.SocketProviderFactory
-
Return an SSLSettings initilize via SSLSocketProvider.Dependencies
- createStatements() - Method in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
-
Create the CohQL
StatementBuilder
map and initialise
it with the standard CohQL statements.
- createStore(String) - Method in class com.tangosol.persistence.AbstractPersistenceManager
-
Create a PersistentStore
associated with the specified
identifier.
- createStore(String) - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceManager
-
Create a PersistentStore
associated with the specified
identifier.
- createStore(String) - Method in class com.tangosol.util.NullImplementation.NullPersistenceManager
-
- createString(String) - Static method in class com.tangosol.coherence.dsltools.base.LiteralBaseToken
-
Create new LiteralBaseToken representing a String with given value
- createString(String) - Static method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
-
Create new AtomicTerm representing a String with given value
- createSubscriber(Subscriber.Option<? super V, U>...) - Method in interface com.tangosol.net.topic.NamedTopic
-
- createSubscriber() - Method in interface com.tangosol.net.topic.NamedTopic
-
- createSymbol(String) - Static method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
-
Create new AtomicTerm representing a Symbol with given value
- createTempDir() - Static method in class com.tangosol.io.FileHelper
-
Create a unique temporary directory.
- createTempEnvironment(File, String) - Method in class com.tangosol.persistence.AbstractSnapshotArchiver
-
Create a temporary PersistenceEnvironment to write archived snapshots to
in the given format.
- createTemporaryEnvironment() - Method in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
-
Create a temporary Environment.
- createTransformerFilter(MapEventFilter) - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
- createTriggerRegistrationKey(long, Binary) - Static method in class com.tangosol.persistence.CachePersistenceHelper
-
Create a key representing an trigger registration.
- createUnexpectedStateException(int, int) - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
Simple helper to create an exception for communicating invalid state transitions.
- createUpdater(String) - Static method in class com.tangosol.util.extractor.UniversalUpdater
-
- createUpdateSetListMaker(ExecutionContext, List, ParameterResolver) - Method in class com.tangosol.coherence.dslquery.statement.InsertStatementBuilder
-
- createUpdateSetListMaker(ExecutionContext, List, ParameterResolver) - Method in class com.tangosol.coherence.dslquery.statement.UpdateStatementBuilder
-
- CurlyToken - Class in com.tangosol.coherence.dsltools.termlanguage
-
CurlyToken is used to process expressions between bracketing characters
such as are between "{" and "}" which should result in a bag
such as {1,3,4,5}.
- CurlyToken(String, int) - Constructor for class com.tangosol.coherence.dsltools.termlanguage.CurlyToken
-
Construct a new CurlyToken with the given parameters.
- current() - Method in class com.tangosol.run.xml.SimpleParser
-
Returns the current token and advances to the next token.
- current - Variable in class com.tangosol.util.AbstractSparseArray.Crawler
-
- currentNode() - Method in class com.tangosol.util.AbstractSparseArray.Crawler
-
Returns the current Node in the iteration.
- CUSTOM - Static variable in class com.tangosol.coherence.config.scheme.BackingMapScheme
-
A custom backup storage.
- custom(IntSupplier) - Static method in class com.tangosol.net.AsyncNamedCache.OrderBy
-
Return the order that will use the specified supplier to provide
unit-of-order for each async operation.
- CustomAddressProviderBuilder - Class in com.tangosol.coherence.config.builder
-
- CustomAddressProviderBuilder(ParameterizedBuilder<AddressProvider>) - Constructor for class com.tangosol.coherence.config.builder.CustomAddressProviderBuilder
-
- CustomAddressProviderBuilder(ParameterizedBuilder<AddressProvider>, ParameterResolver) - Constructor for class com.tangosol.coherence.config.builder.CustomAddressProviderBuilder
-
- CustomAddressProviderBuilder(ParameterizedBuilder<AddressProvider>, ParameterResolver, XmlElement) - Constructor for class com.tangosol.coherence.config.builder.CustomAddressProviderBuilder
-
- CustomizableBinaryStoreManagerBuilderProcessor<T extends BinaryStoreManagerBuilderCustomization> - Class in com.tangosol.coherence.config.xml.processor
-
- CustomizableBinaryStoreManagerBuilderProcessor(Class<T>) - Constructor for class com.tangosol.coherence.config.xml.processor.CustomizableBinaryStoreManagerBuilderProcessor
-
- CustomizableBuilderProcessor<T> - Class in com.tangosol.coherence.config.xml.processor
-
- CustomizableBuilderProcessor(Class<T>) - Constructor for class com.tangosol.coherence.config.xml.processor.CustomizableBuilderProcessor
-
- CustomScheme - Class in com.tangosol.coherence.config.scheme
-
- CustomScheme(ParameterizedBuilder<Map>) - Constructor for class com.tangosol.coherence.config.scheme.CustomScheme
-
- CustomStoreManagerBuilder - Class in com.tangosol.coherence.config.builder.storemanager
-
The CustomStoreManagerBuilder class builds an instance of a custom
BinaryStoreManager.
- CustomStoreManagerBuilder() - Constructor for class com.tangosol.coherence.config.builder.storemanager.CustomStoreManagerBuilder
-
- E_ALL - Static variable in class com.tangosol.util.filter.MapEventFilter
-
This value indicates that all events should be evaluated.
- E_DELETED - Static variable in class com.tangosol.util.filter.MapEventFilter
-
This value indicates that
ENTRY_DELETED
events should be evaluated.
- E_INSERTED - Static variable in class com.tangosol.util.filter.MapEventFilter
-
- E_KEYSET - Static variable in class com.tangosol.util.filter.MapEventFilter
-
- E_NATURAL - Static variable in class com.tangosol.util.filter.CacheEventFilter
-
Bitmask to select natural events.
- E_SYNTHETIC - Static variable in class com.tangosol.util.filter.CacheEventFilter
-
Bitmask to select synthetic events.
- E_UPDATED - Static variable in class com.tangosol.util.filter.MapEventFilter
-
This value indicates that
ENTRY_UPDATED
events should be evaluated.
- E_UPDATED_ENTERED - Static variable in class com.tangosol.util.filter.MapEventFilter
-
This value indicates that
ENTRY_UPDATED
events should be evaluated, but only if filter evaluation is false for
the old value and true for the new value.
- E_UPDATED_LEFT - Static variable in class com.tangosol.util.filter.MapEventFilter
-
This value indicates that
ENTRY_UPDATED
events should be evaluated, but only if filter evaluation is true for
the old value and false for the new value.
- E_UPDATED_WITHIN - Static variable in class com.tangosol.util.filter.MapEventFilter
-
This value indicates that
ENTRY_UPDATED
events should be evaluated, but only if filter evaluation is true for
both the old and the new value.
- EDITION_COMMUNITY - Static variable in interface com.tangosol.net.ClusterDependencies
-
Standard edition (SE).
- EDITION_DATA_CLIENT - Static variable in interface com.tangosol.net.ClusterDependencies
-
Data Client edition (DC).
- EDITION_ENTERPRISE - Static variable in interface com.tangosol.net.ClusterDependencies
-
Enterprise edition (EE).
- EDITION_GRID - Static variable in interface com.tangosol.net.ClusterDependencies
-
Grid Edition (GE).
- EDITION_REAL_TIME_CLIENT - Static variable in interface com.tangosol.net.ClusterDependencies
-
Real time client edition (RTC).
- EDITION_STANDARD - Static variable in interface com.tangosol.net.ClusterDependencies
-
Standard edition (SE).
- effectiveIndex(int) - Method in class com.tangosol.util.CircularArrayList
-
Calculate the effective index taking into account offsets and the
circular nature of CircularArrayList.
- ELEMENT_NAME - Static variable in class com.tangosol.coherence.config.xml.processor.BackingMapSchemeProcessor
-
- ElementIterator(String) - Constructor for class com.tangosol.run.xml.SimpleElement.ElementIterator
-
- ElementList() - Constructor for class com.tangosol.run.xml.SimpleElement.ElementList
-
- ElementProcessor<T> - Interface in com.tangosol.config.xml
-
- ElementProcessorHelper - Class in com.tangosol.coherence.config.xml.processor
-
- ElementProcessorHelper() - Constructor for class com.tangosol.coherence.config.xml.processor.ElementProcessorHelper
-
- elements() - Method in class com.tangosol.util.LiteSet
-
Returns an Enumerator over the elements in this Set.
- elements() - Method in class com.tangosol.util.StringTable
-
Create an enumerator for the values in the table.
- elements() - Method in class com.tangosol.util.Tree
-
Create an enumerator for the tree's values.
- emitLossNotification(PartitionSet) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
Emit a partition loss notification for given partitions.
- EMPTY - Static variable in class com.tangosol.io.Base64InputStream
-
Empty binary data.
- EMPTY - Static variable in class com.tangosol.util.SimpleLongArray
-
Empty array of objects.
- EMPTY_ARRAY - Static variable in class com.tangosol.util.CopyOnWriteLongArray
-
An empty placeholder array.
- EMPTY_ARRAY - Static variable in class com.tangosol.util.SubSet
-
An empty immutable array.
- EMPTY_BINARY_ARRAY - Static variable in class com.tangosol.util.ExternalizableHelper
-
An empty array of Binary objects.
- EMPTY_BYTES - Static variable in class com.tangosol.io.MultiByteArrayInputStream
-
Empty array of bytes.
- EMPTY_SUBJECT - Static variable in class com.tangosol.net.security.SecurityHelper
-
A subject that represents nobody.
- enable(String) - Method in class com.tangosol.coherence.dsltools.precedence.TokenTable
-
Enable an installed token stored under the given name
- ENABLED - Static variable in class com.tangosol.net.security.Security
-
Indicates if security is enabled by the operational configuration.
- enabled() - Static method in class com.tangosol.net.topic.Publisher.FailOnFull
-
Obtain the Option indicating futures should complete exceptionally if the topic is full.
- enabled() - Static method in class com.tangosol.net.topic.Subscriber.CompleteOnEmpty
-
Obtain the Option indicating futures should complete if the topic is empty.
- enableManagement(String, boolean) - Method in class com.tangosol.coherence.jcache.CoherenceBasedCacheManager
-
- enableReference() - Method in class com.tangosol.io.pof.PofBufferWriter
-
Ensure that reference support (necessary for cyclic dependencies) is
enabled.
- enableReference() - Method in class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
-
Ensure that reference support (necessary for cyclic dependencies) is
enabled.
- enableStatistics(String, boolean) - Method in class com.tangosol.coherence.jcache.CoherenceBasedCacheManager
-
- enableTokenNamed(String) - Method in class com.tangosol.coherence.dsltools.precedence.OPScanner
-
Enable the token named by the given string.
- encode(byte[]) - Static method in class com.tangosol.io.Base64OutputStream
-
Encode the passed binary data using Base64 encoding.
- encode(byte[], boolean) - Static method in class com.tangosol.io.Base64OutputStream
-
Encode the passed binary data using Base64 encoding.
- encode(byte[], int, int, boolean) - Static method in class com.tangosol.io.Base64OutputStream
-
Encode the passed binary data using Base64 encoding.
- encode(PofWriter, int, Object) - Method in interface com.tangosol.io.pof.reflect.Codec
-
Serialize an object using the provided
PofWriter
.
- encode(PofWriter, int, Object) - Method in class com.tangosol.io.pof.reflect.Codecs.AbstractCodec
-
Serialize an object using the provided
PofWriter
.
- encodeAttribute(String, char) - Static method in class com.tangosol.run.xml.XmlHelper
-
Encode an attribute value so that it can be quoted and made part of a
valid and well formed XML document.
- encodeContent(String, boolean) - Static method in class com.tangosol.run.xml.XmlHelper
-
Encode an element's content value so that it can be made part of a
valid and well formed XML document.
- encodeExpiry(ReadBuffer, long) - Static method in class com.tangosol.util.ExternalizableHelper
-
Return a ReadBuffer whose contents represent the specified buffer with
the specified expiry encoded as a DECO_EXPIRY decoration.
- encodeInitParams(XmlElement, XmlElement) - Static method in class com.tangosol.run.xml.XmlHelper
-
Encode the supplied xmlConfig XmlElement as a series of init-param
elements.
- encodePosition(int) - Method in class com.tangosol.io.pof.WritingPofHandler
-
Called for each and every value going into the POF stream, in case the
value needs its position to be encoded into the stream.
- encodeString(String) - Static method in class com.tangosol.run.xml.SimpleAdapter
-
Parse escaped string into a string.
- encodeTinyInt(int) - Static method in class com.tangosol.io.pof.PofHelper
-
Encode an integer value into one of the reserved single-byte combined
type and value indicators.
- encodeUri(String) - Static method in class com.tangosol.run.xml.XmlHelper
-
Encode a System Identifier as per the XML 1.0 Specification
second edition, section 4.2.2.
- encrypt(Object, Subject) - Method in interface com.tangosol.net.security.AccessController
-
Encrypt the specified object using the private credentials for the
given Subject (encryptor), which is usually associated with the
current thread.
- encrypt(Object, Subject) - Method in class com.tangosol.net.security.DefaultController
-
Encrypt the specified object using the private credentials for the
given Subject (encryptor), which is usually associated with the
current thread.
- encrypt(Serializable, PrivateKey) - Method in class com.tangosol.net.security.DefaultController
-
Encrypt the specified object using the specified private key.
- end() - Method in class com.tangosol.io.pof.LoggingPofHandler
-
End a complex data structure.
- endBulkKeyProcess(Object[], SimpleOverflowMap.Status[]) - Method in class com.tangosol.net.cache.SimpleOverflowMap
-
Finish the processing of any number of keys.
- endComplexValue() - Method in class com.tangosol.io.pof.AbstractPofHandler
-
Signifies the termination of the current complex value.
- endComplexValue() - Method in class com.tangosol.io.pof.DuplexingPofHandler
-
Signifies the termination of the current complex value.
- endComplexValue() - Method in class com.tangosol.io.pof.LoggingPofHandler
-
Signifies the termination of the current complex value.
- endComplexValue() - Method in interface com.tangosol.io.pof.PofHandler
-
Signifies the termination of the current complex value.
- endComplexValue() - Method in class com.tangosol.io.pof.ValidatingPofHandler
-
Signifies the termination of the current complex value.
- endComplexValue() - Method in class com.tangosol.io.pof.WritingPofHandler
-
Signifies the termination of the current complex value.
- endComplexValue() - Method in class com.tangosol.util.NullImplementation.NullPofHandler
-
Signifies the termination of the current complex value.
- endKeyProcess(Object, OverflowMap.Status) - Method in class com.tangosol.net.cache.OverflowMap
-
Finish the processing of a single key.
- endKeyProcess(Object, SimpleOverflowMap.Status) - Method in class com.tangosol.net.cache.SimpleOverflowMap
-
Finish the processing of a single key.
- endMapProcess() - Method in class com.tangosol.net.cache.OverflowMap
-
Release exclusive access for the OverflowMap.
- endMapProcess() - Method in class com.tangosol.net.cache.SimpleOverflowMap
-
Release exclusive access for the OverflowMap.
- EndOfStatementOPToken - Class in com.tangosol.coherence.dsltools.precedence
-
An OPToken representing the end of a CohQL statement.
- EndOfStatementOPToken() - Constructor for class com.tangosol.coherence.dsltools.precedence.EndOfStatementOPToken
-
Create a new EndOfStatementOPToken
- EndOPToken - Class in com.tangosol.coherence.dsltools.precedence
-
An OPToken representing the end of a token stream.
- EndOPToken() - Constructor for class com.tangosol.coherence.dsltools.precedence.EndOPToken
-
Create a new EndOPToken
- endProperty(int) - Method in class com.tangosol.io.pof.PofBufferWriter
-
Signifies the termination of the current POF property.
- endProperty(int) - Method in class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
-
Signifies the termination of the current POF property.
- endsWith(Binary) - Method in class com.tangosol.util.Binary
-
Tests if this Binary object ends with the specified suffix.
- enlist(TransactionMap, Object) - Method in class com.tangosol.run.jca.SimpleValidator
-
Enlist the resource with the specified transaction.
- enlist(TransactionMap, Object) - Method in interface com.tangosol.util.TransactionMap.Validator
-
Enlist the resource with the specified transaction.
- enrichEvent(MapEvent, Listeners) - Static method in class com.tangosol.util.MapListenerSupport
-
Transform the given MapEvent into a FilterEvent if it is not already a
FilterEvent and there are matching filters associated with the
specified Listeners object.
- ensure(Throwable, String) - Static method in exception com.tangosol.util.WrapperException
-
Ensure a WrapperException from a Throwable object and an additional
description.
- ensure(Throwable) - Static method in exception com.tangosol.util.WrapperException
-
Ensure a WrapperException from a Throwable object.
- ensureActive() - Method in class com.tangosol.persistence.AbstractPersistenceManager
-
Return control if this PersistenceManager is still active, otherwise
throw an exception.
- ensureAdded() - Method in class com.tangosol.util.DeltaSet
-
Get a mutable set of items that were added to the delta set.
- ensureArgument(Object, String) - Static method in class com.tangosol.net.TcpDatagramSocketProvider.DefaultDependencies
-
Ensure that the specified object is non-null
- ensureBigDecimal(Number) - Static method in class com.tangosol.util.aggregator.AbstractBigDecimalAggregator
-
Ensure the specified Number is a BigDecimal value or convert it into a
new BigDecimal object.
- ensureBigDecimal(Number) - Static method in class com.tangosol.util.Base
-
Ensure the specified Number is a BigDecimal value or convert it into a
new BigDecimal object.
- ensureBuffer(Socket) - Method in class com.tangosol.net.LoadBalancer.SocketHandler
-
Return the existing buffer, if there is one, or create one to use
for reading from the passed socket.
- ensureBufferOutput(int) - Method in class com.tangosol.io.MultiBufferWriteBuffer
-
Obtain the internal MultiBufferOutput, creating it if necessary.
- ensureBundles(ParameterResolver, BundlingNamedCache) - Method in class com.tangosol.coherence.config.scheme.BundleManager
-
Create a BundlingNamedCache using the operation-bundling element.
- ensureBundles(ParameterResolver, ReadWriteBackingMap.StoreWrapper) - Method in class com.tangosol.coherence.config.scheme.BundleManager
-
Create a BundlingNamedCache using the "operation-bundling" element.
- ensureCache(MapEvent) - Method in class com.tangosol.net.cache.AbstractEvictionPolicy
-
Return the ConfigurableCacheMap that uses this eviction policy.
- ensureCache(String, ClassLoader) - Method in interface com.tangosol.net.CacheProvider
-
Deprecated.
Ensure an Object-based cache for the given name.
- ensureCache(String, ClassLoader) - Method in interface com.tangosol.net.CacheService
-
Obtain a NamedCache interface that provides a view of resources shared
among members of a cluster.
- ensureCache(String, ClassLoader) - Method in interface com.tangosol.net.ConfigurableCacheFactory
-
Ensure an cache for the given name and classloader (using raw types).
- ensureCache(String, ClassLoader, NamedCache.Option...) - Method in interface com.tangosol.net.ConfigurableCacheFactory
-
Ensure an cache for the given name, classloader and options.
- ensureCache(String, ClassLoader, NamedCache.Option...) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Ensure an cache for the given name, classloader and options.
- ensureCache(DefaultConfigurableCacheFactory.CacheInfo, XmlElement, ClassLoader) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Obtain the NamedCache reference for the cache service defined by the
specified scheme.
- ensureCache(String, ClassLoader, NamedCache.Option...) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
-
- ensureCache(String, ClassLoader) - Method in class com.tangosol.net.WrapperCacheService
-
Obtain a NamedCache interface that provides a view of resources shared
among members of a cluster.
- ensureCapacity(int) - Method in class com.tangosol.util.CircularArrayList
-
Increase the capacity of this list instance, if necessary, to ensure
that it can hold at least the specified number of elements.
- ensureClassLoader(ClassLoader) - Method in class com.tangosol.coherence.config.builder.StaticFactoryInstanceBuilder
-
Ensures we have a non-null
ClassLoader
that we can use for loading classes.
- ensureClassLoader(ClassLoader) - Static method in class com.tangosol.util.Base
-
Obtain a non-null ClassLoader.
- ensureCluster() - Static method in class com.tangosol.net.CacheFactory
-
Obtain a Cluster object running Coherence services.
- ensureCohQLException(Throwable, String) - Static method in class com.tangosol.coherence.dslquery.internal.PersistenceToolsHelper
-
Return a CohQLException with the given cause.
- ensureCollection(Object) - Method in class com.tangosol.util.SimpleMapIndex
-
Return a Collection representation of the specified value, which could be
a Collection, Object[], scalar, or NO_VALUE.
- ensureCompactness() - Method in class com.tangosol.util.CircularArrayList
-
Ensure the representation of this list is appropriatly compact
by shrinking if necessary.
- ensureConfigCCFMap(ClassLoader) - Method in class com.tangosol.net.ScopedCacheFactoryBuilder
-
Ensure that a map from URI to ConfigurableCacheFactory for the specified
loader exists (creating it if necessary).
- ensureConfigMap(ClassLoader) - Method in class com.tangosol.net.ScopedCacheFactoryBuilder
-
Ensure that a map from URL to ConfigurableCacheFactory for the specified
loader exists (creating it if necessary).
- ensureConfiguredService(ParameterResolver, MapBuilder.Dependencies) - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
-
Ensure service and its topic configuration.
- ensureConfiguredService(ParameterResolver, MapBuilder.Dependencies) - Method in interface com.tangosol.coherence.config.scheme.TopicScheme
-
Obtain a configured topic service.
- ensureConnection(SocketAddress) - Method in class com.tangosol.net.TcpDatagramSocket.Impl
-
Obtain a Connection for the specified address.
- ensureConverted(InvocableMap.EntryProcessor) - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
Wrap any
AsynchronousProcessor
instances with a custom wrapper to perform
conversion of result returned by the processor.
- ensureConverted(Converter) - Method in class com.tangosol.util.filter.InKeySetFilter
-
Ensure that the underlying keys are converted using the specified
converter.
- ensureConverters(NamedCache) - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
Instantiate the
converters
necessary to support the processing mode that this
ContinuousQueryCache
will be operating under.
- ensureDatagramSocketProvider(String, SocketProviderFactory.Dependencies, int) - Method in class com.tangosol.net.SocketProviderFactory
-
Create DatatgramSocketProvider
- ensureDir(File) - Static method in class com.tangosol.io.FileHelper
-
Validate that the given File represents a directory, creating it if
it doesn't already exist.
- ensureDomain(String) - Static method in class com.tangosol.net.management.MBeanHelper
-
Ensure the Canonical name is prefixed with the domain name.
- ensureEffectiveIndex(int) - Method in class com.tangosol.util.CircularArrayList
-
After range checking Calculate the effective index while taking into
account the offsets and the circular nature of the list.
- ensureElement(String) - Method in class com.tangosol.run.xml.SimpleElement
-
Ensure that a child element exists.
- ensureElement(String) - Method in interface com.tangosol.run.xml.XmlElement
-
Ensure that a child element exists.
- ensureElement(XmlElement, String) - Static method in class com.tangosol.run.xml.XmlHelper
-
Ensure that a child element exists.
- ensureEraseBundler(int) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
Configure the bundler for the "erase" operations.
- ensureEventQueue() - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
Obtain the existing event queue or create one if none exists.
- ensureExtent(long) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
-
Ensure that an extent with the given identifier exists in the
persistent store, returning true iff the extent was created.
- ensureExtent(long) - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistentStore
-
Ensure that an extent with the given identifier exists in the
persistent store, returning true iff the extent was created.
- ensureExtent(long) - Method in class com.tangosol.util.NullImplementation.NullPersistentStore
-
- ensureExtentInternal(long) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
-
Ensure the provided extent id has been registered and created, thus
allowing subsequent load and store operations against the same extent
id.
- ensureFactory(BerkeleyDBBinaryStoreManager) - Method in class com.tangosol.io.bdb.DatabaseFactoryManager
-
Find, or if needed create a DatabaseFactory for the specified
manager.
- ensureFilter(NodeTerm, String, String, List, ParameterResolver, ExecutionContext) - Static method in class com.tangosol.coherence.dslquery.statement.AbstractStatementBuilder
-
Build a
Filter
for the given cache using the given where clause,
alias and bind environments.
- ensureGetBundler(int) - Method in class com.tangosol.net.cache.BundlingNamedCache
-
Configure the bundler for the "get" operations.
- ensureGlobalName(String) - Method in interface com.tangosol.net.management.Registry
-
Convert the passed MBean name to a global name if necessary.
- ensureGlobalName(String, Member) - Method in interface com.tangosol.net.management.Registry
-
Convert the passed MBean name to a global name for a given cluster Member
if necessary.
- ensureIndexMap() - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
Ensure that the map of indexes maintained by this cache exists.
- ensureInflated(Object, Object) - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
If the internal cache value associated with the provided key is
Binary
,
deserialize the value and store it back to the internal cache in its deserialized form.
- ensureInitialized() - Method in class com.tangosol.io.pof.ConfigurablePofContext
-
Fully initialize the ConfigurablePofContext if it has not already been
initialized.
- ensureInitialized(boolean) - Method in class com.tangosol.util.aggregator.AbstractAggregator
-
Ensure that this aggregator is initialized.
- ensureInitialized() - Method in class com.tangosol.util.aggregator.CompositeAggregator
-
Ensure that this aggregator is initialized.
- ensureInitialized() - Method in class com.tangosol.util.aggregator.GroupAggregator
-
Ensure that this aggregator is initialized.
- ensureInitialized() - Method in class com.tangosol.util.aggregator.TopNAggregator
-
Ensure that this aggregator is initialized.
- ensureInputStream() - Method in class com.tangosol.io.WrapperInputStream
-
Return the underlying InputStream.
- ensureInstance(ConfigurableCacheFactory) - Static method in class com.tangosol.net.DefaultCacheServer
-
Returns the DefaultCacheServer singleton, creating it if necessary.
- ensureInternalCache() - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
Create and initialize this ContinuousQueryCache
's (if not already present) internal cache.
- ensureInternalIterator() - Method in class com.tangosol.net.CompositeAddressProvider
-
Create (if necessary) and return the default iterator.
- ensureInternalListener() - Method in class com.tangosol.util.WrapperObservableMap
-
Obtain the internal MapListener, creating one if necessary.
- ensureInvalidationStrategy() - Method in class com.tangosol.net.cache.CachingMap
-
Ensure that a strategy has been chosen and that any appropriate global
listeners have been registered.
- ensureIterator() - Method in class com.tangosol.net.RefreshableAddressProvider.CircularIterator
-
Return the cache iterator.
- ensureListener(MapIndex) - Static method in class com.tangosol.util.InvocableMapHelper
-
Ensure a MapListener for the given index.
- ensureListenerSupport() - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
- ensureLoadBundler(int) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
Configure the bundler for the "load" operations.
- ensureLoadFactor(SegmentedHashMap.Segment) - Method in class com.tangosol.util.SegmentedHashMap
-
Check whether or not the specified segment is overloaded and if so,
grow the bucket array (which suggests with high probability that the
per-segment load will decrease).
- ensureMap() - Method in class com.tangosol.util.aggregator.ReducerAggregator
-
Return a map that can be used to store reduced values, creating it if
one has not already been created.
- ensureMapFilters() - Method in class com.tangosol.net.management.MBeanAccessor.QueryBuilder
-
Ensure a Map is created to store
Filter
s to apply against
values of the key/value pairs within the ObjectName.
- ensureMapListenerSupport() - Method in class com.tangosol.util.WrapperObservableMap
-
Obtain the MapListenerSupport, creating it if necessary.
- ensureMutable() - Method in class com.tangosol.run.xml.XmlBean
-
Make sure that this XML bean is mutable.
- ensureNamespace(XmlElement, String, String) - Static method in class com.tangosol.run.xml.XmlHelper
-
Ensure the existence of the Namespace declaration attribute in a context
of the specified XmlElement.
- ensureNamespaceHandler(String, NamespaceHandler) - Method in class com.tangosol.config.xml.DefaultProcessingContext
-
- ensureNamespaceHandler(String, URI) - Method in class com.tangosol.config.xml.DefaultProcessingContext
-
- ensureNamespaceHandler(String, URI) - Method in interface com.tangosol.config.xml.ProcessingContext
-
- ensureNamespaceHandler(String, NamespaceHandler) - Method in interface com.tangosol.config.xml.ProcessingContext
-
- ensureOpen() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCache
-
- ensureOutputStream() - Method in class com.tangosol.io.WrapperOutputStream
-
Return the underlying OutputStream.
- ensurePersistenceException(Throwable) - Method in class com.tangosol.persistence.AbstractPersistenceEnvironment
-
Return a PersistenceException with the given cause.
- ensurePersistenceException(Throwable, String) - Method in class com.tangosol.persistence.AbstractPersistenceEnvironment
-
Return a PersistenceException with the given cause and detail message.
- ensurePersistenceException(Throwable) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
-
Return a PersistenceException with the given cause.
- ensurePersistenceException(Throwable, String) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
-
Return a PersistenceException with the given cause and detail
message.
- ensurePersistenceException(Throwable) - Method in class com.tangosol.persistence.AbstractPersistenceManager
-
Return a PersistenceException with the given cause.
- ensurePersistenceException(Throwable, String) - Method in class com.tangosol.persistence.AbstractPersistenceManager
-
Return a PersistenceException with the given cause and detail message.
- ensurePersistenceException(Throwable) - Static method in class com.tangosol.persistence.CachePersistenceHelper
-
Return a PersistenceException with the given cause.
- ensurePersistenceException(Throwable, String) - Static method in class com.tangosol.persistence.CachePersistenceHelper
-
Return a PersistenceException with the given cause and detail message.
- ensurePersistenceToolsHelper(ExecutionContext) - Static method in class com.tangosol.coherence.dslquery.internal.PersistenceToolsHelper
-
- ensurePutBundler(int) - Method in class com.tangosol.net.cache.BundlingNamedCache
-
Configure the bundler for the "put" operations.
- ensureQueueDaemon() - Method in class com.tangosol.io.AsyncBinaryStore
-
Obtain the QueueDaemon, if one already exists; otherwise, create and
start one.
- ensureReadOnly() - Method in class com.tangosol.run.xml.XmlBean
-
Make sure that this value is read-only (immutable).
- ensureReady(boolean, String) - Method in class com.tangosol.coherence.dslquery.internal.PersistenceToolsHelper
-
Ensures that the specified service is in a ready state to begin snapshot operations.
- ensureReady(ExecutionContext, String) - Method in class com.tangosol.coherence.dslquery.internal.PersistenceToolsHelper
-
Ensures that the services are in a ready state to begin snapshot operations.
- ensureReady() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
-
Block the calling thread until the store is either ready to accept
requests or the store has been closed.
- ensureReferenceRegistry() - Method in class com.tangosol.io.pof.PofBufferReader
-
Obtain the registry for identity-reference pairs, creating it if
necessary.
- ensureReferenceRegistry() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Obtain the registry for identity-reference pairs, creating it if
necessary.
- ensureRefreshThread() - Method in class com.tangosol.net.RefreshableAddressProvider
-
Start the refresh thread if not already running.
- ensureRegistration() - Static method in class com.tangosol.net.security.SecurityProvider
-
Ensure that an instance of this provider has been registered with the
system.
- ensureRemoveBundler(int) - Method in class com.tangosol.net.cache.BundlingNamedCache
-
Configure the bundler for the "remove" operations.
- ensureRemoved() - Method in class com.tangosol.util.DeltaSet
-
Get a mutable set of items that were removed from the delta set.
- ensureRemoved() - Method in class com.tangosol.util.SubSet
-
Get a mutable set of items that are removed in the subset.
- ensureResults() - Method in class com.tangosol.net.cache.AbstractBinaryEntryBundler.Bundle
-
Obtain results of the bundled requests.
- ensureResults() - Method in class com.tangosol.net.cache.AbstractBundler.Bundle
-
Obtain results of the bundled requests.
- ensureResults(boolean) - Method in class com.tangosol.net.cache.AbstractBundler.Bundle
-
Obtain results of the bundled requests or ensure that the results
have already been retrieved.
- ensureResults() - Method in class com.tangosol.net.cache.AbstractEntryBundler.Bundle
-
Obtain results of the bundled requests.
- ensureResults() - Method in class com.tangosol.net.cache.AbstractKeyBundler.Bundle
-
Obtain results of the bundled requests.
- ensureRetained() - Method in class com.tangosol.util.SubSet
-
Get a mutable set of items that are retained in the subset.
- ensureRuntimeException(Throwable) - Static method in class com.tangosol.util.Base
-
Convert the passed exception to a RuntimeException if necessary.
- ensureRuntimeException(Throwable, String) - Static method in class com.tangosol.util.Base
-
Convert the passed exception to a RuntimeException if necessary.
- ensureSafeSet(Set) - Static method in class com.tangosol.util.filter.ExtractorFilter
-
Return a non-null Set.
- ensureSerializer(ClassLoader) - Static method in class com.tangosol.util.ExternalizableHelper
-
Obtain a Serializer for the specified ClassLoader.
- ensureService(String, String) - Method in interface com.tangosol.net.Cluster
-
Obtains a Service object for the specified service name and type.
- ensureService(String) - Method in interface com.tangosol.net.ConfigurableCacheFactory
-
Ensure a service for the given name.
- ensureService(String) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Ensure a service for the given name.
- ensureService(XmlElement) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Ensure the service for the specified scheme.
- ensureService(String) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
-
Ensure a service for the given name.
- ensureService(ServiceScheme) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
-
Ensure the service for the specified scheme then start the service if
it isn't running.
- ensureServiceInternal(XmlElement) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Ensure the service for the specified scheme.
- ensureSet(Set) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.ClusterQuorumPolicy
-
Return the specified set, or an empty set if null.
- ensureSet() - Method in class com.tangosol.util.aggregator.DistinctValues
-
Return a set that can be used to store distinct values, creating it if
one has not already been created.
- ensureSingletonMBean(String) - Static method in class com.tangosol.net.management.MBeanHelper
-
Ensure that there is an instance of a local MBean of the specified type
registered with the default MBeansServer.
- ensureSocketException(IOException) - Static method in class com.tangosol.net.TcpDatagramSocket.Impl
-
Convert an IOException into a SocketException.
- ensureSocketProvider(String, SocketProviderFactory.Dependencies, int) - Method in class com.tangosol.net.SocketProviderFactory
-
Create SocketProvider
- ensureStep(Filter) - Method in interface com.tangosol.util.QueryRecord.PartialResult.ExplainStep
-
Ensure an inner nested explain step for the given filter.
- ensureStep(Filter) - Method in interface com.tangosol.util.QueryRecord.PartialResult.TraceStep
-
Ensure an inner nested trace step for the given filter.
- ensureStep(Filter) - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.ExplainStep
-
Ensure an inner nested explain step for the given filter.
- ensureStep(Filter) - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.TraceStep
-
Ensure an inner nested trace step for the given filter.
- ensureStoreBundler(int) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
Configure the bundler for the "store" operations.
- ensureSynchronized(boolean) - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
Ensure that the
ContinuousQueryCache
listeners have been registered
and its content synchronized with the underlying
NamedCache
.
- ensureSynthetic() - Method in class com.tangosol.net.cache.LocalCache.KeyMask
-
Ensure that the synthetic operation flag is set.
- ensureTarget() - Method in class com.tangosol.util.extractor.ChainedExtractor
-
Ensure that this target is correct after first extractor manually updated.
- ensureThreadGroup() - Method in class com.tangosol.util.Daemon
-
Obtain the existing ThreadGroup or create one if none exists or the
current one is destroyed.
- ensureTopic(String, NamedCollection.Option...) - Method in interface com.tangosol.net.ConfigurableCacheFactory
-
Ensure an Object-based topic for the given name.
- ensureTopic(String, ClassLoader, NamedCollection.Option...) - Method in interface com.tangosol.net.ConfigurableCacheFactory
-
Ensure an Object-based topic for the given name.
- ensureTopic(String, ClassLoader, NamedCollection.Option...) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
- ensureTopic(String, ClassLoader, NamedCollection.Option...) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
-
Ensure an Object-based topic for the given name.
- ensureType(Object, int, PofContext) - Static method in class com.tangosol.io.pof.reflect.PofReflectionHelper
-
Validate that the supplied object is compatible with the specified type.
- ensureType(int) - Method in class com.tangosol.run.xml.SimpleValue
-
Change the type of the internal representation of the XmlValue.
- ensureTypedCache(String, ClassLoader, TypeAssertion<K, V>) - Method in interface com.tangosol.net.CacheProvider
-
Deprecated.
Ensure a cache for the given name satisfying the specified type assertion.
- ensureTypedCache(String, ClassLoader, TypeAssertion<K, V>) - Method in interface com.tangosol.net.ConfigurableCacheFactory
-
Ensure a cache for the given name satisfying the specified type assertion.
- ensureUnconverted(Converter) - Method in class com.tangosol.util.filter.InKeySetFilter
-
Ensure that the underlying keys are un-converted using the specified
converter.
- ensureUpdatedPartitions() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
Ensure and return the set of updated partitions.
- ensureValid() - Method in class com.tangosol.util.AbstractSafeLongArray.SafeIterator
-
Ensure that the cached value/index are valid.
- ensureValue(Object) - Method in class com.tangosol.util.SetMap
-
Return a value for the specified key.
- enter() - Method in class com.tangosol.util.ThreadGateLite
-
- enter(long) - Method in class com.tangosol.util.ThreadGateLite
-
Enter the gate.
- enter(long) - Method in class com.tangosol.util.WrapperReentrantGate
-
Enter the gate.
- enter() - Method in class com.tangosol.util.WrapperReentrantGate
-
- ENTRY - Static variable in class com.tangosol.io.nio.BinaryMap.Block
-
State of a block that holds an Entry object's data.
- Entry(Binary, Binary) - Constructor for class com.tangosol.io.nio.BinaryMap.Entry
-
Construct an Entry with a key and a value.
- Entry() - Constructor for class com.tangosol.net.cache.LocalCache.Entry
-
- Entry() - Constructor for class com.tangosol.net.cache.OldCache.Entry
-
Deprecated.
Construct the cacheable entry that holds the cached value.
- Entry(Binary, Binary, Binary, long, BackingMapManagerContext) - Constructor for class com.tangosol.net.cache.ReadWriteBackingMap.Entry
-
Construct an Entry with just a key.
- Entry(Object, Object) - Constructor for class com.tangosol.net.cache.SerializationCache.EntrySet.Entry
-
Construct an Entry.
- Entry(Object, Object) - Constructor for class com.tangosol.net.partition.ObservableSplittingBackingCache.EntrySet.Entry
-
Construct an Entry.
- Entry(Object, Object) - Constructor for class com.tangosol.run.xml.SimpleElement.AttributeMap.Entry
-
Construct an Entry.
- Entry(K, V) - Constructor for class com.tangosol.util.AbstractKeyBasedMap.EntrySet.Entry
-
Construct an Entry.
- Entry() - Constructor for class com.tangosol.util.ObservableHashMap.Entry
-
- Entry(Object, Object) - Constructor for class com.tangosol.util.OpenHashMap.EntrySet.Entry
-
Construct an Entry.
- Entry() - Constructor for class com.tangosol.util.SafeHashMap.Entry
-
- Entry(Object, Object, int) - Constructor for class com.tangosol.util.SegmentedHashMap.Entry
-
Construct an Entry object with the specified key, value and hash.
- ENTRY_DELETED - Static variable in class com.tangosol.net.cache.OverflowMap
-
This event indicates that an entry has been removed from the map.
- ENTRY_DELETED - Static variable in class com.tangosol.net.cache.SimpleOverflowMap
-
This event indicates that an entry has been removed from the map.
- ENTRY_DELETED - Static variable in class com.tangosol.util.MapEvent
-
This event indicates that an entry has been removed from the map.
- ENTRY_INSERTED - Static variable in class com.tangosol.net.cache.OverflowMap
-
This event indicates that an entry has been added to the map.
- ENTRY_INSERTED - Static variable in class com.tangosol.net.cache.SimpleOverflowMap
-
This event indicates that an entry has been added to the map.
- ENTRY_INSERTED - Static variable in class com.tangosol.util.MapEvent
-
This event indicates that an entry has been added to the map.
- ENTRY_OVERHEAD - Static variable in class com.tangosol.util.SimpleMapIndex.IndexCalculator
-
The average memory cost of creating SegmentedHashMap$Entry or SafeHashMap$Entry.
- ENTRY_TO_KEY_CONVERTER - Static variable in class com.tangosol.util.InvocableMapHelper
-
Trivial Entry-to-Key converter.
- ENTRY_TO_VALUE_CONVERTER - Static variable in class com.tangosol.util.InvocableMapHelper
-
Trivial Entry-to-Value converter.
- ENTRY_UPDATED - Static variable in class com.tangosol.net.cache.OverflowMap
-
This event indicates that an entry has been updated in the map.
- ENTRY_UPDATED - Static variable in class com.tangosol.net.cache.SimpleOverflowMap
-
This event indicates that an entry has been updated in the map.
- ENTRY_UPDATED - Static variable in class com.tangosol.util.MapEvent
-
This event indicates that an entry has been updated in the map.
- EntryActionAdapter() - Constructor for class com.tangosol.util.SegmentedHashMap.EntryActionAdapter
-
- EntryAttributes(long, long, int) - Constructor for class com.tangosol.net.cache.SerializationCache.EntryAttributes
-
Construct an attribute holder for an entry.
- EntryAwareComparator<T> - Interface in com.tangosol.util.comparator
-
EntryAwareComparator is an extension to the
Comparator
interface that allows the
EntryComparator
to know whether the
underlying comparator expects to compare the corresponding Entries' keys or
values.
- EntryComparator - Class in com.tangosol.util.comparator
-
Comparator implementation used to compare map entries.
- EntryComparator() - Constructor for class com.tangosol.util.comparator.EntryComparator
-
Default constructor (for ExternalizableLite and PortableObject).
- EntryComparator(Comparator) - Constructor for class com.tangosol.util.comparator.EntryComparator
-
Construct an EntryComparator to compare entries' values using the
provided Comparator object.
- EntryComparator(Comparator, int) - Constructor for class com.tangosol.util.comparator.EntryComparator
-
Construct an EntryComparator to compare entries using the provided
Comparator object according to the specified comparison style.
- entryDeleted(MapEvent) - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheAsynchronousMapListener
-
- entryDeleted(MapEvent) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheAsynchronousMapListener
-
- entryDeleted(MapEvent) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheConfigurationMapListener
-
Remove JCacheContext for JCache identified by evt.getKey().
- entryDeleted(MapEvent) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughMapListenerAdapter
-
- entryDeleted(MapEvent<K, V>) - Method in class com.tangosol.coherence.rest.events.MapEventOutput
-
- entryDeleted(MapEvent) - Method in class com.tangosol.net.cache.AbstractEvictionPolicy
-
Invoked when a map entry has been removed.
- entryDeleted(MapEvent) - Method in class com.tangosol.net.cache.CachingMap.DeactivationListener
-
- entryDeleted(MapEvent) - Method in class com.tangosol.net.cache.CachingMap.FrontMapListener
-
- entryDeleted(MapEvent) - Method in class com.tangosol.net.cache.ContinuousQueryCache.DeactivationListener
-
- entryDeleted(MapEvent) - Method in class com.tangosol.net.cache.LocalCache.InternalListener
-
Invoked when a map entry has been removed.
- entryDeleted(MapEvent) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.InternalMapListener
-
Invoked when a map entry has been removed.
- entryDeleted(MapEvent) - Method in class com.tangosol.net.cache.SeppukuMapListener
-
Invoked when a map entry has been removed.
- entryDeleted(MapEvent) - Method in class com.tangosol.net.cache.VersionedNearCache.VersionCacheListener
-
Deprecated.
Invoked when a map entry has been removed.
- entryDeleted(MapEvent) - Method in class com.tangosol.util.AbstractMapListener
-
Invoked when a map entry has been removed.
- entryDeleted(MapEvent) - Method in class com.tangosol.util.InvocableMapHelper.IndexAdapter
-
Invoked when a map entry has been removed.
- entryDeleted(MapEvent<K, V>) - Method in interface com.tangosol.util.MapListener
-
Invoked when a map entry has been removed.
- entryDeleted(MapEvent<K, V>) - Method in class com.tangosol.util.MultiplexingMapListener
-
Invoked when a map entry has been removed.
- EntryEvent<K,V> - Interface in com.tangosol.net.events.partition.cache
-
An EntryEvent captures information relating to actions performed
on
entries
.
- EntryEvent.Type - Enum in com.tangosol.net.events.partition.cache
-
- EntryExtractor - Class in com.tangosol.util.extractor
-
The EntryExtractor is a base abstract class for special purpose custom
ValueExtractor implementations.
- EntryExtractor() - Constructor for class com.tangosol.util.extractor.EntryExtractor
-
Default constructor (for backward compatibility).
- EntryExtractor(int) - Constructor for class com.tangosol.util.extractor.EntryExtractor
-
Construct an EntryExtractor based on the entry extraction target.
- EntryFilter<K,V> - Interface in com.tangosol.util.filter
-
EntryFilter provides an extension to Filter for those cases in which both
a key and a value may be necessary to evaluate the conditional inclusion
of a particular object.
- entryFromBucket(SegmentedHashMap.Entry[], int) - Static method in class com.tangosol.util.SegmentedHashMap
-
Return the first non-synthetic Entry object contained by in the
specified bucket.
- entryInserted(MapEvent) - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheAsynchronousMapListener
-
- entryInserted(MapEvent) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheAsynchronousMapListener
-
- entryInserted(MapEvent) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughMapListenerAdapter
-
- entryInserted(MapEvent<K, V>) - Method in class com.tangosol.coherence.rest.events.MapEventOutput
-
- entryInserted(MapEvent) - Method in class com.tangosol.net.cache.AbstractEvictionPolicy
-
Invoked when a map entry has been inserted.
- entryInserted(MapEvent) - Method in class com.tangosol.net.cache.LocalCache.InternalListener
-
Invoked when a map entry has been inserted.
- entryInserted(MapEvent) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.InternalMapListener
-
Invoked when a map entry has been inserted.
- entryInserted(MapEvent) - Method in class com.tangosol.net.cache.SeppukuMapListener
-
Invoked when a map entry has been inserted.
- entryInserted(MapEvent) - Method in class com.tangosol.util.AbstractMapListener
-
Invoked when a map entry has been inserted.
- entryInserted(MapEvent) - Method in class com.tangosol.util.InvocableMapHelper.IndexAdapter
-
Invoked when a map entry has been inserted.
- entryInserted(MapEvent<K, V>) - Method in interface com.tangosol.util.MapListener
-
Invoked when a map entry has been inserted.
- entryInserted(MapEvent<K, V>) - Method in class com.tangosol.util.MultiplexingMapListener
-
Invoked when a map entry has been inserted.
- EntryIterator(Iterator<Map.Entry<K, V>>, LocalCache<K, V>) - Constructor for class com.tangosol.coherence.jcache.localcache.LocalCache.EntryIterator
-
Construct an EntryIterator backed by the specified iterator.
- EntryIterator(Iterator<Map.Entry<K, V>>, PartitionedCache<K, V>) - Constructor for class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache.EntryIterator
-
- EntryIterator() - Constructor for class com.tangosol.util.SafeSortedMap.ViewMap.EntryIterator
-
- EntryNode(Object, Object) - Constructor for class com.tangosol.util.SafeSortedMap.EntryNode
-
Construct an EntryNode for the specified key and value.
- EntryNode(Object, Object, SafeSortedMap.EntryNode) - Constructor for class com.tangosol.util.SafeSortedMap.EntryNode
-
Construct an EntryNode for the specified key, value and next node.
- EntryProcessorEvent - Interface in com.tangosol.net.events.partition.cache
-
- EntryProcessorEvent.Type - Enum in com.tangosol.net.events.partition.cache
-
- EntryResource - Class in com.tangosol.coherence.rest
-
REST resource representing a single cache entry.
- EntryResource(NamedCache, Object, Class) - Constructor for class com.tangosol.coherence.rest.EntryResource
-
Construct EntryResource.
- entrySet() - Method in class com.tangosol.io.nio.BinaryMap
-
Returns a set view of the mappings contained in this map.
- EntrySet() - Constructor for class com.tangosol.io.nio.BinaryMap.EntrySet
-
- entrySet() - Method in class com.tangosol.io.pof.PofHelper.ReadableEntrySetMap
-
Returns a set view of the mappings contained in this map.
- entrySet() - Method in class com.tangosol.io.pof.PofHelper.WriteableEntrySetMap
-
Returns a set view of the mappings contained in this map.
- entrySet() - Method in interface com.tangosol.net.AsyncNamedCache
-
Return a set view of all the entries contained in this map.
- entrySet(Filter) - Method in interface com.tangosol.net.AsyncNamedCache
-
Return a set view of the entries contained in this map that satisfy the
criteria expressed by the filter.
- entrySet(Filter, Comparator) - Method in interface com.tangosol.net.AsyncNamedCache
-
Return a set view of the entries contained in this map that satisfy the
criteria expressed by the filter.
- entrySet(BiConsumer<? super K, ? super V>) - Method in interface com.tangosol.net.AsyncNamedCache
-
Stream all the entries contained in this map to the provided callback.
- entrySet(Consumer<? super Map.Entry<? extends K, ? extends V>>) - Method in interface com.tangosol.net.AsyncNamedCache
-
Stream all the entries contained in this map to the provided callback.
- entrySet(Filter, BiConsumer<? super K, ? super V>) - Method in interface com.tangosol.net.AsyncNamedCache
-
Stream the entries that satisfy the specified filter to the provided
callback.
- entrySet(Filter, Consumer<? super Map.Entry<? extends K, ? extends V>>) - Method in interface com.tangosol.net.AsyncNamedCache
-
Stream the entries that satisfy the specified filter to the provided
callback.
- entrySet() - Method in class com.tangosol.net.cache.CachingMap
- entrySet(Filter) - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
- entrySet(Filter, Comparator) - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
- entrySet(Filter) - Method in class com.tangosol.net.cache.NearCache
-
Return a set view of the entries contained in this map that satisfy the
criteria expressed by the filter.
- entrySet(Filter, Comparator) - Method in class com.tangosol.net.cache.NearCache
-
Return a set view of the entries contained in this map that satisfy the
criteria expressed by the filter.
- EntrySet() - Constructor for class com.tangosol.net.cache.OldCache.EntrySet
-
Deprecated.
- EntrySet() - Constructor for class com.tangosol.net.cache.OverflowMap.EntrySet
-
- entrySet() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Returns an set view of the mappings contained in this map.
- EntrySet() - Constructor for class com.tangosol.net.cache.ReadWriteBackingMap.EntrySet
-
- EntrySet() - Constructor for class com.tangosol.net.cache.SerializationCache.EntrySet
-
- entrySet(Filter) - Method in class com.tangosol.net.cache.WrapperNamedCache
-
Return a set view of the entries contained in this map that satisfy the
criteria expressed by the filter.
- entrySet(Filter, Comparator) - Method in class com.tangosol.net.cache.WrapperNamedCache
-
Return a set view of the entries contained in this map that satisfy the
criteria expressed by the filter.
- EntrySet() - Constructor for class com.tangosol.net.partition.ObservableSplittingBackingCache.EntrySet
-
- entrySet() - Method in class com.tangosol.run.xml.SimpleElement.AttributeMap
-
- EntrySet() - Constructor for class com.tangosol.run.xml.SimpleElement.AttributeMap.EntrySet
-
- entrySet() - Method in class com.tangosol.util.AbstractKeyBasedMap
-
Returns a set view of the mappings contained in this map.
- EntrySet() - Constructor for class com.tangosol.util.AbstractKeyBasedMap.EntrySet
-
- EntrySet() - Constructor for class com.tangosol.util.AbstractKeySetBasedMap.EntrySet
-
- entrySet() - Method in class com.tangosol.util.ChainedMap
-
Returns a set view of the mappings contained in this map.
- EntrySet() - Constructor for class com.tangosol.util.ChainedMap.EntrySet
-
- entrySet() - Method in class com.tangosol.util.ConverterCollections.ConverterMap
- entrySet(Filter) - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
-
Return a set view of the entries contained in this map that satisfy the
criteria expressed by the filter.
- entrySet(Filter, Comparator) - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
-
Return a set view of the entries contained in this map that satisfy the
criteria expressed by the filter.
- entrySet(Filter) - Method in class com.tangosol.util.ConverterCollections.ConverterQueryMap
-
Return a set view of the entries contained in this map that satisfy the
criteria expressed by the filter.
- entrySet(Filter, Comparator) - Method in class com.tangosol.util.ConverterCollections.ConverterQueryMap
-
Return a set view of the entries contained in this map that satisfy the
criteria expressed by the filter.
- entrySet() - Method in class com.tangosol.util.CopyOnWriteMap
-
Return a set view of the underlying map.
- EntrySet() - Constructor for class com.tangosol.util.CopyOnWriteMap.EntrySet
-
- entrySet() - Method in class com.tangosol.util.EntrySetMap
-
- entrySet() - Method in class com.tangosol.util.NullImplementation.NullMap
- EntrySet() - Constructor for class com.tangosol.util.OpenHashMap.EntrySet
-
- entrySet(Filter) - Method in interface com.tangosol.util.QueryMap
-
Return a set view of the entries contained in this map that satisfy the
criteria expressed by the filter.
- entrySet(Filter, Comparator) - Method in interface com.tangosol.util.QueryMap
-
Return a set view of the entries contained in this map that satisfy the
criteria expressed by the filter.
- entrySet() - Method in class com.tangosol.util.RestrictedCollections.RestrictedMap
-
Returns a set view of the mappings contained in this map.
- entrySet() - Method in class com.tangosol.util.SafeHashMap
-
Returns a set view of the mappings contained in this map.
- EntrySet() - Constructor for class com.tangosol.util.SafeHashMap.EntrySet
-
- entrySet() - Method in class com.tangosol.util.SafeSortedMap
- entrySet() - Method in class com.tangosol.util.SafeSortedMap.ViewMap
- EntrySet() - Constructor for class com.tangosol.util.SafeSortedMap.ViewMap.EntrySet
-
- entrySet() - Method in class com.tangosol.util.SegmentedHashMap
-
Returns a set view of the mappings contained in this map.
- EntrySet() - Constructor for class com.tangosol.util.SegmentedHashMap.EntrySet
-
- entrySet() - Method in class com.tangosol.util.SetMap
-
- entrySet() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperMap
- entrySet() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- entrySetInternal(Filter) - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
Return multiple values from the back cache based on a filter,
transforming them in the process if necessary.
- entrySetInternal(Filter, Comparator) - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
Return multiple values from the back cache based on a filter,
transforming them in the process if necessary.
- EntrySetIterator() - Constructor for class com.tangosol.net.cache.OverflowMap.EntrySet.EntrySetIterator
-
- EntrySetIterator() - Constructor for class com.tangosol.run.xml.SimpleElement.AttributeMap.EntrySet.EntrySetIterator
-
- EntrySetIterator() - Constructor for class com.tangosol.util.AbstractKeyBasedMap.EntrySet.EntrySetIterator
-
- EntrySetIterator() - Constructor for class com.tangosol.util.OpenHashMap.EntrySet.EntrySetIterator
-
- EntrySetIterator() - Constructor for class com.tangosol.util.SafeHashMap.EntrySet.EntrySetIterator
-
Construct an Iterator over the Entries in the SafeHashMap.
- EntrySetIterator() - Constructor for class com.tangosol.util.SegmentedHashMap.EntrySet.EntrySetIterator
-
Construct an Iterator over the Entries in the SegmentedHashMap.
- EntrySetMap - Class in com.tangosol.util
-
A trivial Map implementation that is based on a specified set of entries.
- EntrySetMap(Set) - Constructor for class com.tangosol.util.EntrySetMap
-
- EntrySetResource - Class in com.tangosol.coherence.rest
-
REST resource representing a set of cache entries.
- EntrySetResource(NamedCache, Set, Class) - Constructor for class com.tangosol.coherence.rest.EntrySetResource
-
Construct an EntrySetResource.
- entryTouched(ConfigurableCacheMap.Entry) - Method in interface com.tangosol.net.cache.ConfigurableCacheMap.EvictionPolicy
-
This method is called by the cache to indicate that an entry has
been touched.
- entryTouched(ConfigurableCacheMap.Entry) - Method in class com.tangosol.net.cache.OldCache.InternalEvictionPolicy
-
Deprecated.
This method is called by the cache to indicate that an entry has
been touched.
- entryTouched(ConfigurableCacheMap.Entry) - Method in class com.tangosol.net.cache.SerializationCache.InternalEvictionPolicy
-
This method is called by the cache to indicate that an entry has
been touched.
- entryUpdated(MapEvent) - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheAsynchronousMapListener
-
- entryUpdated(MapEvent) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheAsynchronousMapListener
-
- entryUpdated(MapEvent) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheSyntheticDeleteMapListener
-
These updated mapEvents were decorated with JACHE_SYNTHETIC_EXPIRY or JCACHE_SYNTHETIC_EXPIRY_EVENT_FOR_ORIGINAL_VALUES.
- entryUpdated(MapEvent) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughMapListenerAdapter
-
- entryUpdated(MapEvent<K, V>) - Method in class com.tangosol.coherence.rest.events.MapEventOutput
-
- entryUpdated(MapEvent) - Method in class com.tangosol.net.cache.AbstractEvictionPolicy
-
Invoked when a map entry has been updated.
- entryUpdated(ConfigurableCacheMap.Entry) - Method in class com.tangosol.net.cache.AbstractEvictionPolicy
-
This method is called to indicate that an entry has been either
inserted or updated.
- entryUpdated(MapEvent) - Method in class com.tangosol.net.cache.CachingMap.DeactivationListener
-
- entryUpdated(MapEvent) - Method in class com.tangosol.net.cache.ContinuousQueryCache.DeactivationListener
-
- entryUpdated(MapEvent) - Method in class com.tangosol.net.cache.LocalCache.InternalListener
-
Invoked when a map entry has been updated.
- entryUpdated(MapEvent) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.InternalMapListener
-
Invoked when a map entry has been updated.
- entryUpdated(MapEvent) - Method in class com.tangosol.net.cache.SeppukuMapListener
-
Invoked when a map entry has been updated.
- entryUpdated(MapEvent) - Method in class com.tangosol.net.cache.VersionedNearCache.VersionCacheListener
-
Deprecated.
Invoked when a map entry has been updated.
- entryUpdated(MapEvent) - Method in class com.tangosol.util.AbstractMapListener
-
Invoked when a map entry has been updated.
- entryUpdated(MapEvent) - Method in class com.tangosol.util.InvocableMapHelper.IndexAdapter
-
Invoked when a map entry has been updated.
- entryUpdated(MapEvent<K, V>) - Method in interface com.tangosol.util.MapListener
-
Invoked when a map entry has been updated.
- entryUpdated(MapEvent<K, V>) - Method in class com.tangosol.util.MultiplexingMapListener
-
Invoked when a map entry has been updated.
- EntryWriter - Class in com.tangosol.coherence.rest.providers
-
Provider responsible for marshalling map entries.
- EntryWriter() - Constructor for class com.tangosol.coherence.rest.providers.EntryWriter
-
Default constructor.
- EntryWriter(MarshallerRegistry) - Constructor for class com.tangosol.coherence.rest.providers.EntryWriter
-
Construct an EntryWriter instance.
- EnumerationIterator<E> - Class in com.tangosol.util
-
Provide a implementation of an Iterator based on data from an Enumeration.
- EnumerationIterator(Enumeration<E>) - Constructor for class com.tangosol.util.EnumerationIterator
-
Construct the Iterator based on an Enumeration.
- EnumPofSerializer - Class in com.tangosol.io.pof
-
PofSerializer
implementation that can be used to serialize all enum
values.
- EnumPofSerializer() - Constructor for class com.tangosol.io.pof.EnumPofSerializer
-
- EnumProcessor<T extends Enum<?>> - Class in com.tangosol.coherence.config.xml.processor
-
A
EnumProcessor
is responsible for processing Coherence Enum values
and return the corresponding Enum type.
- EnumProcessor(Class<T>) - Constructor for class com.tangosol.coherence.config.xml.processor.EnumProcessor
-
- ENVIRONMENT_NAME_PREFIX - Static variable in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
-
Prefix for temporary environment names.
- EnvironmentHolder(BerkeleyDBBinaryStoreManager) - Constructor for class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
-
Construct a EnvironmentHolder for a given Berkeley DB
Environment.
- EnvironmentVariableResolver - Interface in com.tangosol.coherence.config
-
An abstraction that allows us to make environment variable resolution
customizable.
- EnvironmentVariableResolver.Default - Class in com.tangosol.coherence.config
-
- equal(String, E) - Static method in class com.tangosol.util.Filters
-
Return a filter that tests for equality using a
UniversalExtractor
instance to extract the specified field.
- equal(ValueExtractor<T, ? extends E>, E) - Static method in class com.tangosol.util.Filters
-
Return a filter that tests for equality.
- equals(Object) - Method in class com.tangosol.coherence.config.builder.SimpleParameterizedBuilderRegistry.RegistryKey
-
- equals(Object) - Method in class com.tangosol.coherence.config.SchemeMappingRegistry.SchemeMappingKey
- equals(Object) - Method in class com.tangosol.coherence.config.xml.processor.TopicMappingProcessor
-
- equals(Object) - Method in class com.tangosol.coherence.dsltools.precedence.OPToken
-
- equals(Object) - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
-
- equals(Object) - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheEntry
-
- equals(Object) - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheEntryListenerRegistration
-
- equals(Object) - Method in class com.tangosol.coherence.jcache.common.JCacheIdentifier
-
- equals(Object) - Method in class com.tangosol.coherence.rest.util.extractor.MvelExtractor
-
Compare the MvelExtractor with another object to determine equality.
- equals(Object) - Method in class com.tangosol.coherence.rest.util.MvelManipulator
-
Compare the MvelManipulator with another object to determine equality.
- equals(Object) - Method in class com.tangosol.coherence.rest.util.PropertySet
-
Test equality of this object with another.
- equals(Object) - Method in class com.tangosol.coherence.rest.util.PropertySpec
-
Test equality of this object with another.
- equals(Object) - Method in class com.tangosol.coherence.rest.util.updater.MvelUpdater
-
Compare the MvelUpdater with another object to determine equality.
- equals(Object) - Method in class com.tangosol.io.AbstractByteArrayReadBuffer
-
Compare two ReadBuffer objects for equality.
- equals(Object) - Method in class com.tangosol.io.AbstractReadBuffer
-
Compare two ReadBuffer objects for equality.
- equals(Object) - Method in class com.tangosol.io.bdb.BerkeleyDBBinaryStoreManager
-
Compares two BerkeleyDBBinaryStoreManagers for equality.
- equals(Object) - Method in class com.tangosol.io.MultiBufferReadBuffer
-
Compare two ReadBuffer objects for equality.
- equals(Object) - Method in class com.tangosol.io.pof.PofPrincipal
-
Compares this Principal to the specified object.
- equals(Object) - Method in class com.tangosol.io.pof.RawDate
-
Compare this object with another for equality.
- equals(Object) - Method in class com.tangosol.io.pof.RawDateTime
-
Compare this object with another for equality.
- equals(Object) - Method in class com.tangosol.io.pof.RawDayTimeInterval
- equals(Object) - Method in class com.tangosol.io.pof.RawQuad
-
Compare this object with another for equality.
- equals(Object) - Method in class com.tangosol.io.pof.RawTime
-
Compare this object with another for equality.
- equals(Object) - Method in class com.tangosol.io.pof.RawTimeInterval
- equals(Object) - Method in class com.tangosol.io.pof.RawYearMonthInterval
- equals(Object) - Method in class com.tangosol.io.pof.reflect.SimplePofPath
-
Compare the SimplePofPath with another object to determine equality.
- equals(Object) - Method in interface com.tangosol.io.ReadBuffer
-
Compare two ReadBuffer objects for equality.
- equals(Object) - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
-
Compares the specified object with this entry for equality.
- equals(Object) - Method in class com.tangosol.net.cache.ContinuousQueryCache.EventRouter
-
Compare the EventRouter with another object to determine equality.
- equals(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Compares the specified object with this map for equality.
- equals(Object) - Method in class com.tangosol.net.cache.SimpleOverflowMap.HashcodeComparator
-
- equals(Object) - Method in class com.tangosol.net.cache.TypeAssertion.WithTypesAssertion
- equals(Object) - Method in class com.tangosol.net.ClusterPermission
-
Checks two Permission objects for equality.
- equals(Object) - Method in class com.tangosol.net.CompositeAddressProvider
-
SocketAddressProvider instances are considered equivalent iff they
consistently produce the same resulting set of addresses.
- equals(Object) - Method in class com.tangosol.net.CompositeAddressProvider.SingleProvider
-
SocketAddressProvider instances are considered equivalent iff they
consistently produce the same resulting set of addresses.
- equals(Object) - Method in class com.tangosol.net.ConfigurableAddressProvider.AddressHolder
-
Return true iff this ProvidedAddress is equal to the specified
Object.
- equals(Object) - Method in class com.tangosol.net.ConfigurableAddressProvider
-
AddressProvider instances should compare to be equals() iff
they should be expected to consistently produce the same resulting set
of addresses.
- equals(Object) - Method in class com.tangosol.net.management.ObjectNameExcludeFilter
-
Compare the ObjectNameExcludeFilter with another object to determine
equality.
- equals(Object) - Method in class com.tangosol.net.partition.Ownership
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in class com.tangosol.net.partition.PartitionSet
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in class com.tangosol.net.partition.SimplePartitionKey
- equals(Object) - Method in class com.tangosol.net.partition.VersionedOwnership
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in class com.tangosol.net.RefreshableAddressProvider
-
SocketAddressProvider instances are considered equivalent iff they
consistently produce the same resulting set of addresses.
- equals(Object) - Method in class com.tangosol.net.security.SimpleHandler
-
Compare this principal to the specified object.
- equals(Object) - Method in interface com.tangosol.net.SocketAddressProvider
-
SocketAddressProvider instances are considered equivalent iff they
consistently produce the same resulting set of addresses.
- equals(Object) - Method in class com.tangosol.net.ValueTypeAssertion.WithValueTypeAssertion
- equals(Object) - Method in class com.tangosol.run.xml.QualifiedName
- equals(Object) - Method in class com.tangosol.run.xml.SimpleDocument
-
Compare this XML document and all of its contained information with
another XML document for equality.
- equals(Object) - Method in class com.tangosol.run.xml.SimpleElement.AttributeMap
-
- equals(Object) - Method in class com.tangosol.run.xml.SimpleElement
-
Compare this XML element and all of its contained information with
another XML element for equality.
- equals(Object) - Method in class com.tangosol.run.xml.SimpleValue
-
Compare this XML value with another XML value for equality.
- equals(Object) - Method in class com.tangosol.run.xml.XmlBean
-
Determine if this value object is equal to the passed value object.
- equals(Object) - Method in interface com.tangosol.run.xml.XmlDocument
-
Compare this XML document and all of its contained information with
another XML document for equality.
- equals(Object) - Method in interface com.tangosol.run.xml.XmlElement
-
Compare this XML element and all of its contained information with
another XML element for equality.
- equals(Object) - Method in interface com.tangosol.run.xml.XmlValue
-
Compare this XML value with another XML value for equality.
- equals(Object) - Method in class com.tangosol.util.AbstractByteSequence
- equals(Object) - Method in class com.tangosol.util.AbstractKeyBasedMap
-
Compares the specified object with this map for equality.
- equals(Object) - Method in class com.tangosol.util.AbstractLongArray
-
Test for LongArray equality.
- equals(Object) - Method in class com.tangosol.util.aggregator.AbstractAggregator
-
Compares this object with another object for equality.
- equals(Object) - Method in class com.tangosol.util.aggregator.CompositeAggregator
-
Compare the CompositeAggregator with another object to determine
equality.
- equals(Object) - Method in class com.tangosol.util.aggregator.GroupAggregator
-
Compare the GroupAggregator with another object to determine
equality.
- equals(Object, Object) - Static method in class com.tangosol.util.Base
-
Compare two references for equality.
- equals(Object) - Method in class com.tangosol.util.Binary
-
Compares this Binary object with another object for equality.
- equals(byte[], int, byte[], int, int) - Static method in class com.tangosol.util.Binary
-
Compare two binary regions, testing for equality.
- equals(Object) - Method in class com.tangosol.util.CacheCollator
-
Compares the equality of two Collators.
- equals(Object) - Method in class com.tangosol.util.ClassFilter
-
Compare the ClassFilter with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.comparator.ChainedComparator
-
Determine if two ChainedComparator objects are equal.
- equals(Object) - Method in class com.tangosol.util.comparator.EntryComparator
-
Determine if two EntryComparator objects are equal.
- equals(Object) - Method in class com.tangosol.util.comparator.InverseComparator
-
Compare the InverseComparator with another object to determine
equality.
- equals(Object) - Method in class com.tangosol.util.comparator.SafeComparator
-
Determine if two comparators are equal.
- equals(Object) - Method in class com.tangosol.util.CompositeKey
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in class com.tangosol.util.ConditionalIndex
-
Compares the specified object with this index for equality.
- equals(Object) - Method in class com.tangosol.util.ConverterCollections.AbstractConverterEntry
- equals(Object) - Method in class com.tangosol.util.ConverterCollections.ConverterCollection
-
Compares the specified object with this collection for equality.
- equals(Object) - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet
- equals(Object) - Method in class com.tangosol.util.ConverterCollections.ConverterHolder
- equals(Object) - Method in class com.tangosol.util.ConverterCollections.ConverterList
-
Compares the specified object with this collection for equality.
- equals(Object) - Method in class com.tangosol.util.ConverterCollections.ConverterMap
- equals(Object) - Method in class com.tangosol.util.ConverterCollections.ConverterMapListener
-
Compare the ConverterMapListener with another object to
determine equality.
- equals(Object) - Method in class com.tangosol.util.ConverterCollections.ConverterSet
-
Compares the specified object with this collection for equality.
- equals(Object) - Method in class com.tangosol.util.CopyOnWriteMap
- equals(Object) - Method in class com.tangosol.util.extractor.AbstractCompositeExtractor
-
Compare the AbstractCompositeExtractor with another object to determine
equality.
- equals(Object) - Method in class com.tangosol.util.extractor.AbstractExtractor
-
Equivalence by canonical name and target.
- equals(Object) - Method in class com.tangosol.util.extractor.CompositeUpdater
- equals(Object) - Method in class com.tangosol.util.extractor.ConditionalExtractor
-
Equivalence by canonical name and target.
- equals(Object) - Method in class com.tangosol.util.extractor.DeserializationAccelerator
-
Equivalence by canonical name and target.
- equals(Object) - Method in class com.tangosol.util.extractor.IdentityExtractor
-
Compare the IdentityExtractor with another object to determine
equality.
- equals(Object) - Method in class com.tangosol.util.extractor.KeyExtractor
-
- equals(Object) - Method in class com.tangosol.util.extractor.PofExtractor
-
Compare the PofExtractor with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.extractor.PofUpdater
-
Compare the PofUpdater with another object to determine
equality.
- equals(Object) - Method in class com.tangosol.util.extractor.ReflectionExtractor
-
Compare the ReflectionExtractor with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.extractor.ReflectionUpdater
-
Compare the ReflectionUpdater with another object to determine
equality.
- equals(Object) - Method in class com.tangosol.util.extractor.UniversalExtractor
-
Compare the UniversalExtractor
with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.extractor.UniversalUpdater
-
Compare the UniversalUpdater with another object to determine
equality.
- equals(Object) - Method in class com.tangosol.util.filter.AlwaysFilter
-
Compare the AlwaysFilter with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.filter.ArrayFilter
-
Compare the ArrayFilter with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.filter.CacheEventFilter
-
Compare the CacheEventFilter with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.filter.ComparisonFilter
-
Compare the ComparisonFilter with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.filter.FilterTrigger
-
Compare the FilterTrigger with another object to determine
equality.
- equals(Object) - Method in class com.tangosol.util.filter.KeyAssociatedFilter
-
Compare the KeyAssociatedFilter with another object to determine
equality.
- equals(Object) - Method in class com.tangosol.util.filter.MapEventFilter
-
Compare the MapEventFilter with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.filter.MapEventTransformerFilter
-
Compare the MapEventTransformerFilter with another object to determine
equality.
- equals(Object) - Method in class com.tangosol.util.filter.NeverFilter
-
Compare the NeverFilter with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.filter.NotFilter
-
Compare the NotFilter with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.filter.PartitionedFilter
-
Compare the PartitionedFilter with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.filter.PresentFilter
-
Compare the PresentFilter with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.filter.ValueChangeEventFilter
-
Compare the ValueChangeEventFilter with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.ForwardOnlyMapIndex
-
Compares the specified object with this index for equality.
- equals(Object) - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.CoalescedEvent.Discriminator
- equals(Object) - Method in class com.tangosol.util.ImmutableArrayList
-
Compare this Collection / List / Set / SortedSet with some other Object
and determine if the caller would believe this Object to equal that
other Object.
- equals(Object) - Method in class com.tangosol.util.ImmutableArrayList.ListView
- equals(Object) - Method in class com.tangosol.util.ImmutableArrayList.SetView
- equals(Object) - Method in class com.tangosol.util.ImmutableArrayList.SortedSetView
- equals(Object) - Method in class com.tangosol.util.ImmutableMultiList
-
Compare this Collection / List / Set with some other Object and determine
if the caller would believe this Object to equal that other Object.
- equals(Object) - Method in class com.tangosol.util.ImmutableMultiList.ListView
-
Compares the specified object with this list for equality.
- equals(Object) - Method in class com.tangosol.util.ImmutableMultiList.SetView
-
Compares the specified object with this set for equality.
- equals(Object) - Method in class com.tangosol.util.InflatableCollection
- equals(Object) - Method in class com.tangosol.util.InflatableList
- equals(Object) - Method in class com.tangosol.util.InvocableMapHelper.IndexAdapter
-
Compare this IndexMapListener with another object for equality.
- equals(Object) - Method in class com.tangosol.util.InvocableMapHelper.SimpleEntry
-
Compare this SimpleEntry with another object for equality.
- equals(Object) - Method in interface com.tangosol.util.LongArray
-
Test for LongArray equality.
- equals(Object) - Method in class com.tangosol.util.MapListenerSupport.WrapperListener
-
Compare the WrapperSynchronousListener with another object to
determine equality.
- equals(Object) - Method in class com.tangosol.util.NullFilter
-
Compare the NullFilter with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.NullImplementation.NullMap
- equals(Object) - Method in class com.tangosol.util.NullImplementation.NullSet
- equals(Object) - Method in class com.tangosol.util.NullImplementation.NullValueExtractor
-
Compare the ValueExtractor with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.processor.CompositeProcessor
-
Compare the ConditionalProcessor with another object to determine
equality.
- equals(Object) - Method in class com.tangosol.util.processor.ConditionalProcessor
-
Compare the ConditionalProcessor with another object to determine
equality.
- equals(Object) - Method in class com.tangosol.util.processor.ConditionalPut
-
Compare the ConditionalPut with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.processor.ConditionalPutAll
-
Compare the ConditionalPutAll with another object to determine
equality.
- equals(Object) - Method in class com.tangosol.util.processor.ConditionalRemove
-
Compare the ConditionalRemove with another object to determine
equality.
- equals(Object) - Method in class com.tangosol.util.processor.ExtractorProcessor
-
Compare the ExtractorProcessor with another object to determine
equality.
- equals(Object) - Method in class com.tangosol.util.processor.PreloadRequest
-
Compare the PreloadRequest with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.processor.PropertyManipulator
-
Compare the PropertyManipulator with another object to determine
equality.
- equals(Object) - Method in class com.tangosol.util.processor.PropertyProcessor
-
Compare the PropertyProcessor with another object to determine
equality.
- equals(Object) - Method in class com.tangosol.util.processor.UpdaterProcessor
-
Compare the UpdaterProcessor with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.processor.VersionedPut
-
Compare the VersionedPut with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.processor.VersionedPutAll
-
Compare the VersionedPutAll with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedCollection
-
Compares the specified object with this collection for equality.
- equals(Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet
-
Compares the specified object with this collection for equality.
- equals(Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet.RestrictedEntry
-
Compares the specified object with this entry
for equality.
- equals(Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet.RestrictedIterator
-
Compares the specified object with this Iterator
for equality.
- equals(Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedMap
-
Compares the specified object with this map for equality.
- equals(Object) - Method in class com.tangosol.util.SafeHashMap.Entry
-
Compares the specified object with this entry for equality.
- equals(Object) - Method in class com.tangosol.util.SafeLinkedList.Node
-
Compare this Node with an object for equality.
- equals(Object) - Method in class com.tangosol.util.SafeSortedMap.EntryNode.MapEntry
- equals(Object) - Method in class com.tangosol.util.SegmentedHashMap.Entry
-
Compares the specified object with this entry for equality.
- equals(Object) - Method in class com.tangosol.util.SegmentedHashMap
-
Compares the specified object with this map for equality.
- equals(Object) - Method in class com.tangosol.util.SimpleHolder
-
- equals(Object) - Method in class com.tangosol.util.SimpleMapEntry
-
Compares the specified object with this entry for equality.
- equals(Object) - Method in class com.tangosol.util.SimpleMapIndex
-
Compares the specified object with this index for equality.
- equals(Object) - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.IndexLookupRecord
- equals(Object) - Method in class com.tangosol.util.SimpleResourceRegistry.RegistryKey
- equals(Object) - Method in class com.tangosol.util.StringTable
-
Test for equality of two string tables.
- equals(Object) - Method in class com.tangosol.util.SubList
- equals(Object) - Method in class com.tangosol.util.transformer.ExtractorEventTransformer
-
Compare the ExtractorEventTransformer with another object to determine
equality.
- equals(Object) - Method in class com.tangosol.util.transformer.SemiLiteEventTransformer
-
Compare the SemiLiteEventTransformer with another object to determine
equality.
- equals(Object) - Method in class com.tangosol.util.Tree
-
Test for tree equality.
- equals(Object) - Method in class com.tangosol.util.UID
-
Determine if two UIDs are equal.
- equals(Object) - Method in class com.tangosol.util.UUID
-
Determine if two UUIDs are equal.
- equals(Object) - Method in interface com.tangosol.util.ValueExtractor
-
- equals(Object) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperCollection
- equals(Object) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperEntry
- equals(Object) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperIterator
- equals(Object) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperMap
- equals(Object) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperCollection
- equals(Object) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperEntry
- equals(Object) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- equals(Object) - Method in class com.tangosol.util.WrapperObservableMap
-
- equalsDeep(Object, Object) - Static method in class com.tangosol.util.Base
-
Deeply compare two references for equality.
- equalsElement(XmlElement, XmlElement) - Static method in class com.tangosol.run.xml.XmlHelper
-
Compare one XML element with another XML element for equality.
- EqualsFilter<T,E> - Class in com.tangosol.util.filter
-
Filter which compares the result of a method invocation with a value for
equality.
- EqualsFilter() - Constructor for class com.tangosol.util.filter.EqualsFilter
-
Default constructor (necessary for the ExternalizableLite interface).
- EqualsFilter(ValueExtractor<? super T, ? extends E>, E) - Constructor for class com.tangosol.util.filter.EqualsFilter
-
Construct an EqualsFilter for testing equality.
- EqualsFilter(String, E) - Constructor for class com.tangosol.util.filter.EqualsFilter
-
Construct an EqualsFilter for testing equality.
- equalsMostly(Subject, Subject) - Method in class com.tangosol.net.security.DefaultController
-
Check whether the specified Subject objects have the same set of
principals and public credentials.
- equalsName(String) - Method in enum com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.NameListDependencies.USAGE
-
- EqualsOperator - Class in com.tangosol.coherence.dslquery.operator
-
An operator implementation representing the equality operator.
- EqualsOperator() - Constructor for class com.tangosol.coherence.dslquery.operator.EqualsOperator
-
Construct a EqualsOperator.
- equalsValue(Object, Object) - Method in class com.tangosol.run.xml.ArrayAdapter
-
Compare the two passed objects for equality.
- equalsValue(Object, Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.BooleanArrayAdapter
-
Compare the two passed objects for equality.
- equalsValue(Object, Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.ByteArrayAdapter
-
Compare the two passed objects for equality.
- equalsValue(Object, Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.CharArrayAdapter
-
Compare the two passed objects for equality.
- equalsValue(Object, Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.DoubleArrayAdapter
-
Compare the two passed objects for equality.
- equalsValue(Object, Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter
-
Compare the two passed objects for equality.
- equalsValue(Object, Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.FloatArrayAdapter
-
Compare the two passed objects for equality.
- equalsValue(Object, Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.IntArrayAdapter
-
Compare the two passed objects for equality.
- equalsValue(Object, Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.LongArrayAdapter
-
Compare the two passed objects for equality.
- equalsValue(Object, Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.ShortArrayAdapter
-
Compare the two passed objects for equality.
- equalsValue(Object, Object) - Method in class com.tangosol.run.xml.PropertyAdapter
-
Compare the two passed objects for equality.
- equalsValue(XmlValue, XmlValue) - Static method in class com.tangosol.run.xml.XmlHelper
-
Compare one XML value with another XML value for equality.
- equalsValue(Object) - Method in class com.tangosol.util.SafeLinkedList.Node
-
Compare this Node's value with another value for equality.
- erase(BinaryEntry) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheBinaryEntryStore
-
- erase(Binary) - Method in class com.tangosol.io.AbstractBinaryStore
-
Remove the specified key from the underlying store if present.
- erase(Binary) - Method in class com.tangosol.io.AsyncBinaryStore
-
Remove the specified key from the underlying store if present.
- erase(Binary) - Method in class com.tangosol.io.bdb.BerkeleyDBBinaryStore
-
Remove the specified key from the underlying store if present.
- erase(Binary) - Method in interface com.tangosol.io.BinaryStore
-
Remove the specified key from the underlying store if present.
- erase(Binary) - Method in class com.tangosol.io.nio.BinaryMapStore
-
Remove the specified key from the underlying store if present.
- erase(K) - Method in class com.tangosol.net.cache.AbstractCacheStore
-
Remove the specified key from the underlying store if present.
- erase(BinaryEntry<K, V>) - Method in interface com.tangosol.net.cache.BinaryEntryStore
-
Remove the specified entry from the underlying store.
- erase(K) - Method in class com.tangosol.net.cache.BinaryStoreCacheStore
-
Remove the specified key from the underlying store if present.
- erase(K) - Method in interface com.tangosol.net.cache.CacheStore
-
Remove the specified key from the underlying store if present.
- erase(K) - Method in class com.tangosol.net.cache.MapCacheStore
-
Remove the specified key from the underlying store if present.
- erase(ReadWriteBackingMap.Entry) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
Remove the specified entry from the underlying store.
- erase(Binary) - Method in class com.tangosol.net.cache.SerializationPagedCache.FakeBinaryStore
-
Remove the specified key from the underlying store if present.
- erase(Binary) - Method in class com.tangosol.net.cache.SerializationPagedCache.PagedBinaryStore
-
Remove the specified key from the underlying store if present.
- erase(Binary) - Method in class com.tangosol.net.cache.SerializationPagedCache.WrapperBinaryStore
-
Remove the specified key from the underlying store if present.
- erase(long, ReadBuffer) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore.BatchTask
-
Queue an erase operation.
- erase(long, ReadBuffer, Object) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
-
Remove the specified key from the underlying store if present.
- erase(long, R, Object) - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistentStore
-
Remove the specified key from the underlying store if present.
- erase(Object) - Method in class com.tangosol.util.NullImplementation.NullCacheStore
-
Remove the specified key from the underlying store if present.
- erase(long, R, Object) - Method in class com.tangosol.util.NullImplementation.NullPersistentStore
-
- eraseAll(Set) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheBinaryEntryStore
-
- eraseAll() - Method in class com.tangosol.io.AbstractBinaryStore
-
Remove all data from the underlying store.
- eraseAll() - Method in class com.tangosol.io.AsyncBinaryStore
-
Remove all data from the underlying store.
- eraseAll() - Method in class com.tangosol.io.bdb.BerkeleyDBBinaryStore
-
Remove all data from the underlying store.
- eraseAll() - Method in interface com.tangosol.io.BinaryStore
-
Remove all data from the underlying store.
- eraseAll() - Method in class com.tangosol.io.nio.BinaryMapStore
-
Remove all data from the underlying store.
- eraseAll(Collection<? extends K>) - Method in class com.tangosol.net.cache.AbstractCacheStore
-
Remove the specified keys from the underlying store if present.
- eraseAll(Set<? extends BinaryEntry<K, V>>) - Method in interface com.tangosol.net.cache.BinaryEntryStore
-
Remove the specified entries from the underlying store.
- eraseAll(Collection<? extends K>) - Method in interface com.tangosol.net.cache.CacheStore
-
Remove the specified keys from the underlying store if present.
- eraseAll(Collection<? extends K>) - Method in class com.tangosol.net.cache.MapCacheStore
-
Remove the specified keys from the underlying store if present.
- eraseAll(Set) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
Remove the specified entries from the underlying store.
- eraseAll() - Method in class com.tangosol.net.cache.SerializationPagedCache.FakeBinaryStore
-
Remove all data from the underlying store.
- eraseAll() - Method in class com.tangosol.net.cache.SerializationPagedCache.PagedBinaryStore
-
Remove all data from the underlying store.
- eraseAll() - Method in class com.tangosol.net.cache.SerializationPagedCache.WrapperBinaryStore
-
Remove all data from the underlying store.
- eraseAll(Collection) - Method in class com.tangosol.util.NullImplementation.NullCacheStore
-
Remove the specified keys from the underlying store if present.
- eraseAllInternal(Set) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.BinaryEntryStoreWrapper
-
Remove the specified entries from the underlying store.
- eraseAllInternal(Set) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.CacheStoreWrapper
-
Remove the specified entries from the underlying store.
- eraseAllInternal(Set) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
Remove the specified entries from the underlying store.
- eraseInternal(ReadWriteBackingMap.Entry) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.BinaryEntryStoreWrapper
-
Remove the specified entry from the underlying store.
- eraseInternal(ReadWriteBackingMap.Entry) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.CacheStoreWrapper
-
Remove the specified entry from the underlying store.
- eraseInternal(ReadWriteBackingMap.Entry) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
Remove the specified entry from the underlying store.
- eraseInternal(long, ReadBuffer, Object) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
-
Remove the specified key from the underlying persistent storage
if present.
- EraseOperation(long, ReadBuffer) - Constructor for class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore.BatchTask.EraseOperation
-
Create a new EraseOperation.
- eraseStore() - Method in class com.tangosol.net.cache.SerializationMap
-
Erase all entries from the underlying store.
- eraseStore() - Method in class com.tangosol.net.cache.SerializationPagedCache
-
Erase all entries from the underlying store.
- err() - Static method in class com.tangosol.util.Base
-
Prints a blank line to the trace Writer.
- err(Object) - Static method in class com.tangosol.util.Base
-
Prints the passed Object to the trace Writer.
- err(String) - Static method in class com.tangosol.util.Base
-
Prints the passed String value to the trace Writer.
- err(Class) - Static method in class com.tangosol.util.Base
-
Prints the passed class information to the trace Writer.
- err(Throwable) - Static method in class com.tangosol.util.Base
-
Prints the passed exception information to the trace Writer.
- error(SAXParseException) - Method in class com.tangosol.run.xml.SaxParser.ValidationHandler
-
Routine called when a error occurs in parser.
- escape(char, char[], int) - Static method in class com.tangosol.util.Base
-
Format a char to a printable escape if necessary, putting the result
into the passed array.
- establishMapListeners(Map, ParameterResolver, MapBuilder.Dependencies) - Method in class com.tangosol.coherence.config.scheme.AbstractCachingScheme
-
- establishMapListeners(Map, ParameterResolver, MapBuilder.Dependencies) - Method in class com.tangosol.coherence.config.scheme.NearScheme
-
- establishMapListeners(Map, ParameterResolver, MapBuilder.Dependencies) - Method in interface com.tangosol.coherence.config.scheme.ObservableCachingScheme
-
- establishMapListeners(Map, ParameterResolver, MapBuilder.Dependencies) - Method in class com.tangosol.coherence.config.scheme.OverflowScheme
-
- establishMapListeners(Map, ParameterResolver, MapBuilder.Dependencies) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
-
- EVAL_COST - Static variable in class com.tangosol.util.filter.BetweenFilter
-
The evaluation cost as a factor to the single index access operation.
- EVAL_COST - Static variable in class com.tangosol.util.filter.ExtractorFilter
-
The evaluation cost as a factor to the single index access operation.
- evalLine(String) - Method in class com.tangosol.coherence.dslquery.QueryPlus
-
Evaluate the given CohQL statement.
- evaluate(ParameterResolver) - Method in class com.tangosol.coherence.config.ParameterMacroExpression
-
Evaluates the Expression
to produce a value of type T.
- evaluate(ParameterResolver) - Method in class com.tangosol.coherence.config.xml.processor.InitParamProcessor.CacheRefExpression
-
Evaluates the Expression
to produce a value of type T.
- evaluate(ParameterResolver) - Method in class com.tangosol.coherence.config.xml.processor.InitParamProcessor.CollectionRefExpression
-
Evaluates the Expression
to produce a value of type T.
- evaluate(ParameterResolver) - Method in class com.tangosol.coherence.config.xml.processor.InitParamProcessor.SchemeRefExpression
-
Evaluates the Expression
to produce a value of type T.
- evaluate(T) - Method in class com.tangosol.coherence.jcache.common.NonSyntheticEntryFilter
-
- evaluate(T) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheSyntheticDeleteMapListener.JCacheExpiryEntryFilter
-
- evaluate(Object) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughFilterAdapter
-
- evaluate(Object) - Method in class com.tangosol.net.cache.SimpleOverflowMap.FrontFilterConverter
-
Filters keys out that are not in the front map.
- evaluate(Object) - Method in class com.tangosol.net.management.ObjectNameExcludeFilter
-
Apply the test to the input argument.
- evaluate(Object) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.NotOwnedFilter
-
Apply the test to the input argument.
- evaluate(Object) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.SafetyFilter
-
Apply the test to the input argument.
- evaluate(Object) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.UnderloadedFilter
-
Apply the test to the input argument.
- evaluate(Object) - Method in class com.tangosol.util.ClassFilter
-
Filter interface: evaluate().
- evaluate(Object) - Method in class com.tangosol.util.filter.AllFilter
-
Apply the test to the input argument.
- evaluate(T) - Method in class com.tangosol.util.filter.AlwaysFilter
-
Apply the test to the input argument.
- evaluate(Object) - Method in class com.tangosol.util.filter.AnyFilter
-
Apply the test to the input argument.
- evaluate(Object) - Method in class com.tangosol.util.filter.BetweenFilter
-
Apply the test to the input argument.
- evaluate(MapEvent<K, V>) - Method in class com.tangosol.util.filter.CacheEventFilter
-
Apply the test to the input argument.
- evaluate(T) - Method in interface com.tangosol.util.Filter
-
Apply the test to the input argument.
- evaluate(T) - Method in class com.tangosol.util.filter.ExtractorFilter
-
Apply the test to the input argument.
- evaluate(T) - Method in class com.tangosol.util.filter.InKeySetFilter
-
Apply the test to the input argument.
- evaluate(T) - Method in class com.tangosol.util.filter.KeyAssociatedFilter
-
Apply the test to the input argument.
- evaluate(Object) - Method in class com.tangosol.util.filter.KeyFilter
-
Apply the test to the input argument.
- evaluate(T) - Method in class com.tangosol.util.filter.LimitFilter
-
Apply the test to the input argument.
- evaluate(MapEvent<K, V>) - Method in class com.tangosol.util.filter.MapEventFilter
-
Apply the test to the input argument.
- evaluate(T) - Method in class com.tangosol.util.filter.MapEventTransformerFilter
-
Apply the test to the input argument.
- evaluate(T) - Method in class com.tangosol.util.filter.NeverFilter
-
Apply the test to the input argument.
- evaluate(T) - Method in class com.tangosol.util.filter.NotFilter
-
Apply the test to the input argument.
- evaluate(T) - Method in class com.tangosol.util.filter.PartitionedFilter
-
Apply the test to the input argument.
- evaluate(T) - Method in class com.tangosol.util.filter.PresentFilter
-
Apply the test to the input argument.
- evaluate(T) - Method in class com.tangosol.util.filter.PriorityFilter
-
Apply the test to the input argument.
- evaluate(V) - Method in class com.tangosol.util.filter.ScriptFilter
-
- evaluate(MapEvent<?, V>) - Method in class com.tangosol.util.filter.ValueChangeEventFilter
-
Apply the test to the input argument.
- evaluate(T) - Method in class com.tangosol.util.filter.WrapperQueryRecorderFilter
-
Apply the test to the input argument.
- evaluate(Object) - Method in class com.tangosol.util.filter.XorFilter
-
Apply the test to the input argument.
- evaluate(Object) - Method in class com.tangosol.util.NullFilter
-
Filter interface: evaluate().
- evaluate(Stream<? extends InvocableMap.Entry<? extends K, ? extends V>>) - Method in interface com.tangosol.util.stream.RemotePipeline
-
Evaluate this pipeline against the specified stream of InvocableMap.Entry
objects.
- evaluateEntry(Map.Entry) - Method in class com.tangosol.coherence.jcache.common.NonSyntheticEntryFilter
-
- evaluateEntry(Map.Entry) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheSyntheticDeleteMapListener.JCacheExpiryEntryFilter
-
- evaluateEntry(Map.Entry) - Method in class com.tangosol.util.ConditionalIndex
-
Evaluate the given entry using this index's filter.
- evaluateEntry(Map.Entry, QueryContext, QueryRecord.PartialResult.TraceStep) - Method in class com.tangosol.util.filter.AllFilter
-
Check if the given entry passes the filter's evaluation.
- evaluateEntry(Map.Entry) - Method in class com.tangosol.util.filter.AlwaysFilter
-
Apply the test to a Map Entry.
- evaluateEntry(Map.Entry, QueryContext, QueryRecord.PartialResult.TraceStep) - Method in class com.tangosol.util.filter.AnyFilter
-
Check if the given entry passes the filter's evaluation.
- evaluateEntry(Map.Entry) - Method in class com.tangosol.util.filter.ArrayFilter
-
Apply the test to a Map Entry.
- evaluateEntry(Map.Entry, QueryContext, QueryRecord.PartialResult.TraceStep) - Method in class com.tangosol.util.filter.ArrayFilter
-
Check if the given entry passes the filter's evaluation.
- evaluateEntry(Map.Entry) - Method in class com.tangosol.util.filter.BetweenFilter
-
Apply the test to a Map Entry.
- evaluateEntry(Map.Entry, QueryContext, QueryRecord.PartialResult.TraceStep) - Method in class com.tangosol.util.filter.BetweenFilter
-
Check if the given entry passes the filter's evaluation.
- evaluateEntry(Map.Entry<? extends K, ? extends V>) - Method in interface com.tangosol.util.filter.EntryFilter
-
Apply the test to a Map Entry.
- evaluateEntry(Map.Entry<?, ? extends T>) - Method in class com.tangosol.util.filter.ExtractorFilter
-
Apply the test to a Map Entry.
- evaluateEntry(Map.Entry) - Method in class com.tangosol.util.filter.InKeySetFilter
-
Apply the test to a Map Entry.
- evaluateEntry(Map.Entry) - Method in class com.tangosol.util.filter.KeyFilter
-
Apply the test to a Map Entry.
- evaluateEntry(Map.Entry) - Method in class com.tangosol.util.filter.LimitFilter
-
Apply the test to a Map Entry.
- evaluateEntry(Map.Entry) - Method in class com.tangosol.util.filter.NeverFilter
-
Apply the test to a Map Entry.
- evaluateEntry(Map.Entry) - Method in class com.tangosol.util.filter.NotFilter
-
Apply the test to a Map Entry.
- evaluateEntry(Map.Entry) - Method in class com.tangosol.util.filter.PartitionedFilter
-
Apply the test to a Map Entry.
- evaluateEntry(Map.Entry) - Method in class com.tangosol.util.filter.PresentFilter
-
Apply the test to a Map Entry.
- evaluateEntry(Map.Entry) - Method in class com.tangosol.util.filter.PriorityFilter
-
Apply the test to a Map Entry.
- evaluateEntry(Map.Entry) - Method in class com.tangosol.util.filter.WrapperQueryRecorderFilter
-
Apply the test to a Map Entry.
- evaluateEntry(Map.Entry, QueryContext, QueryRecord.PartialResult.TraceStep) - Method in class com.tangosol.util.filter.XorFilter
-
Check if the given entry passes the filter's evaluation.
- evaluateEntry(Filter, Map.Entry<K, V>) - Static method in class com.tangosol.util.InvocableMapHelper
-
Check if the entry passes the filter evaluation.
- evaluateEntry(Filter, K, V) - Static method in class com.tangosol.util.InvocableMapHelper
-
Check if an entry, expressed as a key and value, passes the filter
evaluation.
- evaluateEvent(Filter, MapEvent) - Method in class com.tangosol.util.MapListenerSupport
-
Evaluate whether or not the specified event should be delivered to the
listener associated with the specified filter.
- evaluateExtracted(Object) - Method in class com.tangosol.util.filter.BetweenFilter
-
Evaluate the specified extracted value.
- evaluateExtracted(E) - Method in class com.tangosol.util.filter.ContainsAllFilter
-
Evaluate the specified extracted value.
- evaluateExtracted(E) - Method in class com.tangosol.util.filter.ContainsAnyFilter
-
Evaluate the specified extracted value.
- evaluateExtracted(E) - Method in class com.tangosol.util.filter.ContainsFilter
-
Evaluate the specified extracted value.
- evaluateExtracted(E) - Method in class com.tangosol.util.filter.EqualsFilter
-
Evaluate the specified extracted value.
- evaluateExtracted(E) - Method in class com.tangosol.util.filter.ExtractorFilter
-
Evaluate the specified extracted value.
- evaluateExtracted(E) - Method in class com.tangosol.util.filter.GreaterEqualsFilter
-
Evaluate the specified extracted value.
- evaluateExtracted(E) - Method in class com.tangosol.util.filter.GreaterFilter
-
Evaluate the specified extracted value.
- evaluateExtracted(E) - Method in class com.tangosol.util.filter.InFilter
-
Evaluate the specified extracted value.
- evaluateExtracted(E) - Method in class com.tangosol.util.filter.LessEqualsFilter
-
Evaluate the specified extracted value.
- evaluateExtracted(E) - Method in class com.tangosol.util.filter.LessFilter
-
Evaluate the specified extracted value.
- evaluateExtracted(E) - Method in class com.tangosol.util.filter.LikeFilter
-
Evaluate the specified extracted value.
- evaluateExtracted(E) - Method in class com.tangosol.util.filter.NotEqualsFilter
-
Evaluate the specified extracted value.
- evaluateExtracted(E) - Method in class com.tangosol.util.filter.PredicateFilter
-
- evaluateExtracted(E) - Method in class com.tangosol.util.filter.RegexFilter
-
Evaluate the specified extracted value.
- evaluateFilter(Filter, Map.Entry, QueryContext, QueryRecord.PartialResult.TraceStep) - Method in class com.tangosol.util.filter.ArrayFilter
-
Check if the given entry passes the given filter's evaluation.
- evaluateGUID(String, String[], Set<String>, int) - Static method in class com.tangosol.persistence.GUIDHelper
-
Evaluate the provided GUID ensuring asGUIDNewest
references the
latest and setPrevGUIDs
references previous GUIDs.
- evaluateName(ParameterResolver, Class<? extends ResourceMapping>, String) - Method in class com.tangosol.coherence.config.xml.processor.InitParamProcessor.DataStructureRefExpression
-
- evaluateOriginalEntry(Filter, MapTrigger.Entry) - Static method in class com.tangosol.util.InvocableMapHelper
-
Check if the entry, in its "original" form, passes the filter evaluation.
- Event<T extends Enum<T>> - Interface in com.tangosol.net.events
-
An
Event
object captures the necessary information required to
adequately describe some activity that has occurred.
- Event<T extends Enum<T>> - Interface in com.tangosol.net.events.partition.cache
-
- Event<T extends Enum<T>> - Interface in com.tangosol.net.events.partition
-
A PartitionedServiceEvent captures information concerning an operation on
a PartitionedService.
- Event<S extends Enum<S>> - Interface in com.tangosol.util.fsm
-
- EventDispatcher - Interface in com.tangosol.net.events
-
- EventDispatcher.InterceptorRegistrationEvent<E extends Event<? extends Enum>> - Interface in com.tangosol.net.events
-
- EventDispatcher.InterceptorRegistrationEvent.Type - Enum in com.tangosol.net.events
-
The InterceptorRegistrationEvent types.
- EventDispatcherAwareInterceptor<E extends Event<?>> - Interface in com.tangosol.net.events
-
- EventDispatcherRegistry - Interface in com.tangosol.net.events
-
- EventHelper - Class in com.tangosol.net.events
-
Helper class providing various functionality related to event handling.
- EventHelper() - Constructor for class com.tangosol.net.events.EventHelper
-
- EventInterceptor<E extends Event<? extends Enum>> - Interface in com.tangosol.net.events
-
An EventInterceptor provides an implementation that is capable of
intercepting and processing
Event
s.
- eventOccurred(AnyEvent) - Method in interface com.tangosol.util.AnyListener
-
- EventRouter(MapListener<? super K, ? super V>, boolean) - Constructor for class com.tangosol.net.cache.ContinuousQueryCache.EventRouter
-
Construct an EventRouter to route events from the internal cache
of the ContinuousQueryCache
to the client listeners.
- evict() - Method in class com.tangosol.net.cache.AbstractSerializationCache
-
Flush items that have expired.
- evict(Object) - Method in interface com.tangosol.net.cache.ConfigurableCacheMap
-
Evict a specified key from the cache, as if it had expired from the
cache.
- evict() - Method in interface com.tangosol.net.cache.ConfigurableCacheMap
-
Evict all entries from the cache that are no longer valid, and
potentially prune the cache size if the cache is size-limited
and its size is above the caching low water mark.
- evict(Object) - Method in class com.tangosol.net.cache.OldCache
-
Deprecated.
Evict a specified key from the cache, as if it had expired from the
cache.
- evict() - Method in class com.tangosol.net.cache.OldCache
-
Deprecated.
Evict all entries from the cache that are no longer valid, and
potentially prune the cache size if the cache is size-limited
and its size is above the caching low water mark.
- evict() - Method in class com.tangosol.net.cache.OverflowMap
-
Flush items that have expired.
- evict(Map) - Static method in class com.tangosol.net.cache.OverflowMap
-
If the passed Map supports it, evict its expired data.
- evict(Object) - Method in class com.tangosol.net.cache.SerializationCache
-
Evict a specified key from the cache, as if it had expired from the
cache.
- evict() - Method in class com.tangosol.net.cache.SerializationCache
-
Flush items that have expired.
- evict() - Method in class com.tangosol.net.cache.SerializationPagedCache
-
Flush items that have expired.
- evict(Object) - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
-
Evict a specified key from the cache, as if it had expired from the
cache.
- evict() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
-
Evict all entries from the cache that are no longer valid, and
potentially prune the cache size if the cache is size-limited
and its size is above the caching low water mark.
- evictAll(Collection) - Method in interface com.tangosol.net.cache.ConfigurableCacheMap
-
Evict the specified keys from the cache, as if they had each expired
from the cache.
- evictAll(Collection) - Method in class com.tangosol.net.cache.OldCache
-
Deprecated.
Evict the specified keys from the cache, as if they had each expired
from the cache.
- evictAll(Collection) - Method in class com.tangosol.net.cache.SerializationCache
-
Evict the specified keys from the cache, as if they had each expired
from the cache.
- evictAll(Collection) - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
-
Evict the specified keys from the cache, as if they had each expired
from the cache.
- EvictingBackupMap() - Constructor for class com.tangosol.net.cache.ReadWriteBackingMap.EvictingBackupMap
-
Default constructor.
- EVICTION_POLICY_EXTERNAL - Static variable in class com.tangosol.net.cache.OldCache
-
Deprecated.
The cache can prune using an external eviction policy.
- EVICTION_POLICY_HYBRID - Static variable in class com.tangosol.net.cache.OldCache
-
Deprecated.
By default, the cache prunes based on a hybrid LRU+LFU algorithm.
- EVICTION_POLICY_LFU - Static variable in class com.tangosol.net.cache.OldCache
-
Deprecated.
The cache can prune based on a pure Least Frequently Used (LFU)
algorithm.
- EVICTION_POLICY_LRU - Static variable in class com.tangosol.net.cache.OldCache
-
Deprecated.
The cache can prune based on a pure Least Recently Used (LRU)
algorithm.
- EvictionPolicyBuilder - Class in com.tangosol.coherence.config.builder
-
- EvictionPolicyBuilder() - Constructor for class com.tangosol.coherence.config.builder.EvictionPolicyBuilder
-
- EvictionPolicyProcessor - Class in com.tangosol.coherence.config.xml.processor
-
- EvictionPolicyProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.EvictionPolicyProcessor
-
- Evolvable - Interface in com.tangosol.io
-
The Evolvable interface is implemented by classes that require forwards-
and backwards-compatibility of their serialized form.
- EvolvableHolder - Class in com.tangosol.io.pof
-
Storage for evolvable classes.
- EvolvableHolder() - Constructor for class com.tangosol.io.pof.EvolvableHolder
-
- EvolvableObject - Interface in com.tangosol.io.pof
-
Defines an interface that should be implemented by the classes that want to
support evolution.
- EvolvablePortableObject - Interface in com.tangosol.io.pof
-
Extension of the
PortableObject
interface that supports forwards- and
backwards-compatibility of POF data streams.
- exact() - Method in class com.tangosol.net.management.MBeanAccessor.QueryBuilder
-
Ensure the generated query does not include a wild card (exact).
- exact(boolean) - Method in class com.tangosol.net.management.MBeanAccessor.QueryBuilder
-
Ensure the generated query does not include a wild card (exact).
- exclusively() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
-
- exclusively() - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistentStore
-
Suggest to this PersistentStore that the caller requires exclusive access
to this store until
close
is called on the
returned
AutoCloseable
.
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.queryplus.CommandsStatementBuilder.CommandsQueryPlusStatement
-
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.queryplus.ExtendedLanguageStatementBuilder.ExtendedLanguageQueryPlusStatement
-
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.queryplus.HelpStatementBuilder.HelpQueryPlusStatement
-
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.queryplus.SanityCheckStatementBuilder.SanityCheckQueryPlusStatement
-
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.queryplus.ServicesStatementBuilder.ServicesQueryPlusStatement
-
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.queryplus.SetTimeoutStatementBuilder.SetTimeoutStatement
-
Set the current timeout to be used by the CohQL session.
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.queryplus.TraceStatementBuilder.TraceQueryPlusStatement
-
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.queryplus.WheneverStatementBuilder.WheneverQueryPlusStatement
-
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.BackupStatementBuilder.BackupStatement
-
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.CreateCacheStatementBuilder.CreateCacheStatement
-
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.CreateIndexStatementBuilder.CreateIndexStatement
-
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.DeleteStatementBuilder.DeleteStatement
-
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.DropCacheStatementBuilder.DropCacheStatement
-
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.DropIndexStatementBuilder.DropIndexStatement
-
- execute(ExecutionContext) - Method in interface com.tangosol.coherence.dslquery.Statement
-
Execute a CohQL query or command and return the relevant
result
.
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.InsertStatementBuilder.InsertStatement
-
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.persistence.ArchiveSnapshotStatementBuilder.ArchiveSnapshotStatement
-
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.persistence.CreateSnapshotStatementBuilder.CreateSnapshotStatement
-
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.persistence.ForceRecoveryStatementBuilder.ForceRecoveryStatement
-
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.persistence.ListArchiverStatementBuilder.ListArchiverStatement
-
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.persistence.ListServicesStatementBuilder.ListServicesStatement
-
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.persistence.ListSnapshotsStatementBuilder.ListSnapshotsStatement
-
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.persistence.RecoverSnapshotStatementBuilder.RecoverSnapshotStatement
-
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.persistence.RemoveSnapshotStatementBuilder.RemoveSnapshotStatement
-
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.persistence.ResumeServiceStatementBuilder.ResumeServiceStatement
-
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.persistence.RetrieveSnapshotStatementBuilder.RetrieveSnapshotStatement
-
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.persistence.SuspendServiceStatementBuilder.SuspendServiceStatement
-
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.persistence.ValidateSnapshotStatementBuilder.ValidateSnapshotStatement
-
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.QueryRecorderStatementBuilder.QueryRecorderStatement
-
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.RestoreStatementBuilder.RestoreStatement
-
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.SelectStatementBuilder.SelectStatement
-
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.SourceStatementBuilder.SourceStatement
-
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.TruncateCacheStatementBuilder.TruncateCacheStatement
-
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.UpdateStatementBuilder.UpdateStatement
-
- execute(Reader, ExecutionContext) - Method in class com.tangosol.coherence.dslquery.StatementExecutor
-
Parse and execute all of the CohQL statements read from the specified
Reader
.
- execute(NamedCache, ValueExtractor<Map.Entry, ? extends E>, String, int, int) - Method in interface com.tangosol.coherence.rest.query.Query
-
Return the values that satisfy this query.
- execute(Invocable, Set, InvocationObserver) - Method in interface com.tangosol.net.InvocationService
-
Asynchronously invoke the specified task on each of the specified
members.
- execute(Remote.Function<MBeanServer, R>) - Method in interface com.tangosol.net.management.MBeanServerProxy
-
A function
executed on the management node.
- execute(Remote.Function<MBeanServer, R>) - Method in class com.tangosol.net.management.WrapperMBeanServerProxy
-
- execute(Invocable, Set, InvocationObserver) - Method in class com.tangosol.net.WrapperInvocationService
-
Asynchronously invoke the specified task on each of the specified
members.
- execute() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore.BatchTask
-
Execute all queued operations and commit changes.
- execute() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore.DeleteExtentTask
-
- execute() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore.OpenTask
-
- execute() - Method in class com.tangosol.persistence.AbstractPersistenceManager.Task
-
Execute the task.
- executePeriodicTask(Runnable, long) - Method in class com.tangosol.util.TaskDaemon
-
Schedule a periodic task to be run "as soon as possible", and to repeat
at the specified interval.
- executeQuery(String, ValueExtractor<Map.Entry, ?>, int, int, String) - Method in class com.tangosol.coherence.rest.CacheResource
-
Returns a collection of extracted values for cache entries that satisfy
the criteria expressed by the query.
- executeQuery(UriInfo, ValueExtractor<Map.Entry, ?>, int, int, String) - Method in class com.tangosol.coherence.rest.NamedQueryResource
-
Returns a collection of extracted values for cache entries that satisfy
the criteria expressed by the query.
- executeStatement(String) - Static method in class com.tangosol.util.QueryHelper
-
Execute a CohQL statement.
- executeStatement(String, ExecutionContext) - Static method in class com.tangosol.util.QueryHelper
-
Execute a CohQL statement.
- executeTask(AbstractPersistenceManager<PS>.Task) - Method in class com.tangosol.persistence.AbstractPersistenceManager
-
Execute the specified task with the calling thread.
- executeTask(Runnable) - Method in class com.tangosol.util.TaskDaemon
-
Schedule a task to be run by the daemon "as soon as possible".
- executeTaskExclusive(AbstractPersistenceManager<PS>.Task) - Method in class com.tangosol.persistence.AbstractPersistenceManager
-
Execute the specified task with the calling thread.
- ExecutionContext - Class in com.tangosol.coherence.dslquery
-
Instances of this context are passed to
Statement
s to allow
commands to discern execution conditions, altering their behavior / result
as needed.
- ExecutionContext() - Constructor for class com.tangosol.coherence.dslquery.ExecutionContext
-
Construct an ExecutionContext.
- ExecutionContext - Interface in com.tangosol.util.fsm
-
- ExecutorProcessor - Class in com.tangosol.coherence.config.xml.processor
-
An
ElementProcessor
that will parse and produce a
Executor based on an ssl/executor configuration element.
- ExecutorProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.ExecutorProcessor
-
- exists() - Method in class com.tangosol.coherence.rest.EntryResource
-
Return true if the referenced entry exists in the cache.
- exists(long) - Method in class com.tangosol.util.AbstractLongArray
-
Determine if the specified index is in use.
- exists(long) - Method in class com.tangosol.util.AbstractSafeLongArray
-
- exists(long) - Method in class com.tangosol.util.AbstractSparseArray
-
Determine if the specified index is in use.
- exists(long) - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray
-
- exists(long) - Method in interface com.tangosol.util.LongArray
-
Determine if the specified index is in use.
- exists(long) - Method in class com.tangosol.util.SimpleLongArray
-
Determine if the specified index is in use.
- exists(long) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
-
- exit() - Method in class com.tangosol.util.ThreadGateLite
-
Exit the gate.
- exit() - Method in class com.tangosol.util.WrapperReentrantGate
-
Exit the gate.
- ExpirableStatus() - Constructor for class com.tangosol.net.cache.OverflowMap.ExpirableStatus
-
Construct a Status object for a specific key.
- expire(long) - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
-
Update the entry with the specified expiry delay.
- expire(long) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.Entry
-
Update the entry with the specified expiry delay.
- expire(long) - Method in interface com.tangosol.util.BinaryEntry
-
Update the entry with the specified expiry delay.
- expire(long) - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventBinaryEntry
-
Update the entry with the specified expiry delay.
- expire(long) - Method in class com.tangosol.util.InvocableMapHelper.RoutingBinaryEntry
-
- EXPIRY_DEFAULT - Static variable in interface com.tangosol.net.cache.CacheMap
-
A special time-to-live value that can be passed to the extended
put
method to indicate that the
cache's default expiry should be used.
- EXPIRY_NEVER - Static variable in interface com.tangosol.net.cache.CacheMap
-
A special time-to-live value that can be passed to the extended
put
method to indicate that the
cache entry should never expire.
- explain(QueryContext, QueryRecord.PartialResult.ExplainStep, Set) - Method in class com.tangosol.util.filter.AbstractQueryRecorderFilter
-
Record the projected query execution cost by this filter.
- explain(Filter<T>, Map, Set, QueryRecord.PartialResult.ExplainStep) - Static method in class com.tangosol.util.filter.AbstractQueryRecorderFilter
-
Record an estimated cost of query execution for a given filter.
- explain(Filter<T>, Map, Set, QueryRecord.PartialResult.ExplainStep, ValueExtractor) - Static method in class com.tangosol.util.filter.AbstractQueryRecorderFilter
-
Record an estimated cost of query execution for a given filter.
- explain(QueryContext, QueryRecord.PartialResult.ExplainStep, Set) - Method in class com.tangosol.util.filter.ArrayFilter
-
Record the projected query execution cost by this filter.
- explain(QueryContext, QueryRecord.PartialResult.ExplainStep, Set) - Method in class com.tangosol.util.filter.BetweenFilter
-
Record the projected query execution cost by this filter.
- explain(QueryContext, QueryRecord.PartialResult.ExplainStep, Set) - Method in interface com.tangosol.util.filter.QueryRecorderFilter
-
Record the projected query execution cost by this filter.
- explain(QueryContext, QueryRecord.PartialResult.ExplainStep, Set) - Method in class com.tangosol.util.filter.WrapperQueryRecorderFilter
-
Record the projected query execution cost by this filter.
- EXPLAIN_INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.QueryRecorderStatementBuilder
-
An instance of a QueryRecorderStatementBuilder that builds EXPLAIN PLAN queries.
- ExplainStep(Filter) - Constructor for class com.tangosol.util.SimpleQueryRecord.PartialResult.ExplainStep
-
Construct an ExplainStep
- expression(int) - Method in class com.tangosol.coherence.dsltools.precedence.OPParser
-
Parse the next expression into an Abstract Syntax Tree using the
given right binding power.
- ExtendedLanguageCommandOPToken() - Constructor for class com.tangosol.coherence.dslquery.queryplus.ExtendedLanguageStatementBuilder.ExtendedLanguageCommandOPToken
-
Construct a ExtendedLanguageCommandOPToken.
- ExtendedLanguageQueryPlusStatement(boolean) - Constructor for class com.tangosol.coherence.dslquery.queryplus.ExtendedLanguageStatementBuilder.ExtendedLanguageQueryPlusStatement
-
Construct a ExtendedLanguageQueryPlusStatement to turn on or off
extended CohQL.
- ExtendedLanguageStatementBuilder - Class in com.tangosol.coherence.dslquery.queryplus
-
A class that builds the QueryPlus "EXTENDED LANGUAGE" command.
- ExtendedLanguageStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.queryplus.ExtendedLanguageStatementBuilder
-
- ExtendedLanguageStatementBuilder.ExtendedLanguageCommandOPToken - Class in com.tangosol.coherence.dslquery.queryplus
-
A CohQL OPToken representing the QueryPlus "extended language" command.
- ExtendedLanguageStatementBuilder.ExtendedLanguageQueryPlusStatement - Class in com.tangosol.coherence.dslquery.queryplus
-
The command to turn on or off extended CohQL.
- extendedSqlTokenTable() - Method in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
-
Return an initialized TokenTable for the full CoherenceQueryLanguage.
- ExtendPreprocessor - Class in com.tangosol.coherence.config.xml.preprocessor
-
- ExtendPreprocessor() - Constructor for class com.tangosol.coherence.config.xml.preprocessor.ExtendPreprocessor
-
- ExtensibleConfigurableCacheFactory - Class in com.tangosol.net
-
ExtensibleConfigurableCacheFactory provides a facility to access caches
declared in a "coherence-cache-config.xsd" compliant configuration file.
- ExtensibleConfigurableCacheFactory(ExtensibleConfigurableCacheFactory.Dependencies) - Constructor for class com.tangosol.net.ExtensibleConfigurableCacheFactory
-
- ExtensibleConfigurableCacheFactory.DefaultDependencies - Class in com.tangosol.net
-
- ExtensibleConfigurableCacheFactory.Dependencies - Interface in com.tangosol.net
-
- ExtensibleConfigurableCacheFactory.DependenciesHelper - Class in com.tangosol.net
-
- ExtensibleConfigurableCacheFactory.Manager - Class in com.tangosol.net
-
The Manager class uses builders to create the required backing maps
and provides client access to those maps.
- ExtensibleConfigurableCacheFactory.PartitionedBackingMapManager - Class in com.tangosol.net
-
The PartitionedBackingMapManager is used by PartitionAwareBackingMap(s) to
lazily configure the enclosing PABM based on the configuration settings of
the enclosed maps.
- extents() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
-
Return a list of the extent identifiers in the underlying store.
- extents() - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistentStore
-
Return a list of the extent identifiers in the underlying store.
- extents() - Method in class com.tangosol.util.NullImplementation.NullPersistentStore
-
- ExternalizableHelper - Class in com.tangosol.util
-
Helpers for the Serializable, Externalizable and the ExternalizableLite
interface.
- ExternalizableHelper() - Constructor for class com.tangosol.util.ExternalizableHelper
-
- ExternalizableHelper.DecoratedMultiBufferReadBuffer - Class in com.tangosol.util
-
- ExternalizableHelper.DefaultObjectStreamFactory - Class in com.tangosol.util
-
Default ObjectStreamFactory implementation.
- ExternalizableHelper.FormatAwareCompressor - Class in com.tangosol.util
-
A DeltaCompressor wrapper implementation that removes/replaces the
serialization format byte (FMT_EXT) before/after delegating to the
underlying compressor.
- ExternalizableHelper.IntDecoratedObject - Class in com.tangosol.util
-
Integer decorated object.
- ExternalizableHelper.Shielded - Interface in com.tangosol.util
-
Marker interface.
- ExternalizableHelper.ShieldedDataOutputStream - Class in com.tangosol.util
-
An OutputStream that implements DataOutput that delegates all
operations other than flush and close to an underlying object that
implements DataOutput.
- ExternalizableHelper.ShieldedInputStream - Class in com.tangosol.util
-
An InputStream that delegates all operations other than close to an
underlying InputStream.
- ExternalizableHelper.ShieldedObjectOutputStream - Class in com.tangosol.util
-
An OutputStream that implements ObjectOutput that delegates all
operations other than flush and close to an underlying object that
implements ObjectOutput.
- ExternalizableHelper.ShieldedOutputStream - Class in com.tangosol.util
-
An OutputStream that delegates all operations other than flush and
close to an underlying OutputStream.
- ExternalizableHelper.SimpleXmlBeanClassCache - Class in com.tangosol.util
-
An implementation XmlBeanClassCache that uses a pre-defined list of
XmlBean implementations.
- ExternalizableHelper.Stats - Class in com.tangosol.util
-
Serialization statistics for a given user type.
- ExternalizableHelper.XmlBeanClassCache - Interface in com.tangosol.util
-
An interface for caching class reference by integer ID values.
- ExternalizableLite - Interface in com.tangosol.io
-
Optimized serialization.
- ExternalizableLitePofSerializer - Class in com.tangosol.io.pof
-
- ExternalizableLitePofSerializer(int) - Constructor for class com.tangosol.io.pof.ExternalizableLitePofSerializer
-
Create a new ExternalizableLitePofSerializer for the user type with the
given type identifier.
- ExternalizablePofSerializer - Class in com.tangosol.io.pof
-
PofSerializer
implementation that supports the serialization and
deserialization of any class that implements
Externalizable
to
and from a POF stream.
- ExternalizablePofSerializer(int) - Constructor for class com.tangosol.io.pof.ExternalizablePofSerializer
-
Create a new ExternalizablePofSerializer for the user type with the
given type identifier.
- ExternalScheme - Class in com.tangosol.coherence.config.scheme
-
The
ExternalScheme
class is responsible for building
a fully configured instance of a ExternalCache.
- ExternalScheme() - Constructor for class com.tangosol.coherence.config.scheme.ExternalScheme
-
- ExternalSerializer(Serializer, boolean) - Constructor for class com.tangosol.io.pof.SafeConfigurablePofContext.ExternalSerializer
-
- extract(Object) - Method in class com.tangosol.coherence.rest.util.extractor.MvelExtractor
-
Extract the value from the passed object.
- extract(Collection<? extends T>) - Method in class com.tangosol.coherence.rest.util.PropertySet
-
Extract a collection of partial objects.
- extract(Object[]) - Method in class com.tangosol.coherence.rest.util.PropertySet
-
Extract an array of partial objects.
- extract(T) - Method in class com.tangosol.coherence.rest.util.PropertySet
-
Extract a partial object from a source object.
- extract(ValueExtractor) - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
-
Extract a value out of the Entry's key or value.
- extract(ValueExtractor) - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventBinaryEntry
-
Depending upon the type of the ValueExtractor route the call
to the appropriate extract method.
- extract(T) - Method in class com.tangosol.util.extractor.AbstractExtractor
-
- extract(Object) - Method in class com.tangosol.util.extractor.ChainedExtractor
-
Extract the value from the passed object.
- extract(Object) - Method in class com.tangosol.util.extractor.ComparisonValueExtractor
-
Extract the value from the passed object.
- extract(Object) - Method in class com.tangosol.util.extractor.ConditionalExtractor
-
Using a ConditionalExtractor to extract values in not supported.
- extract(Object) - Method in class com.tangosol.util.extractor.DeserializationAccelerator
-
Using a DeserializationAccelerator to extract values in not supported.
- extract(T) - Method in class com.tangosol.util.extractor.IdentityExtractor
-
Simply return the passed object.
- extract(T) - Method in class com.tangosol.util.extractor.KeyExtractor
-
Extract the value from the passed object.
- extract(Object) - Method in class com.tangosol.util.extractor.MultiExtractor
-
Extract a collection of values from the passed object using the underlying
array of ValueExtractor objects.
- extract(T) - Method in class com.tangosol.util.extractor.ReflectionExtractor
-
Extract from target using reflection.
- extract(T) - Method in class com.tangosol.util.extractor.ScriptValueExtractor
-
- extract(T) - Method in class com.tangosol.util.extractor.UniversalExtractor
-
Extract from target using reflection or map access.
- extract(String) - Static method in class com.tangosol.util.Extractors
-
Returns an extractor that extracts the value of the specified field.
- extract(String, Object...) - Static method in class com.tangosol.util.Extractors
-
Returns an extractor that extracts the value of the specified field.
- extract(T) - Method in class com.tangosol.util.filter.ExtractorFilter
-
Get the result of ValueExtractor invocation.
- extract(V) - Method in class com.tangosol.util.filter.ValueChangeEventFilter
-
Extract value from a target object.
- extract(ValueExtractor) - Method in class com.tangosol.util.InvocableMapHelper.RoutingMapTriggerEntry
-
Extract a value out of the Entry's key or value.
- extract(Object) - Method in class com.tangosol.util.NullImplementation.NullValueExtractor
-
Extract the value from the passed object.
- extract(ValueExtractor<? super T, ? extends R>) - Static method in class com.tangosol.util.Processors
-
- extract(String) - Static method in class com.tangosol.util.Processors
-
Construct an extract processor for a given property or method name.
- extract(ValueExtractor<T, E>) - Method in interface com.tangosol.util.QueryMap.Entry
-
Extract a value out of the Entry's key or value.
- extract(ValueExtractor<T, E>) - Method in class com.tangosol.util.SimpleMapEntry
-
Extract a value out of the Entry's key or value.
- extract(T) - Method in interface com.tangosol.util.ValueExtractor
-
Extract the value from the passed object.
- extractCertificates(Set) - Method in class com.tangosol.net.security.DefaultController
-
Extract a set of Certificate objects from the set of public credentials.
- extractChild(ReadBuffer, int, int) - Method in class com.tangosol.io.pof.reflect.ComplexPofValue
-
Extract child PofValue from a buffer.
- extractComplex(T) - Method in class com.tangosol.util.extractor.UniversalExtractor
-
Extract from target using reflection or map access.
- extractDelta(ReadBuffer, ReadBuffer) - Method in class com.tangosol.io.BinaryDeltaCompressor
-
Compare an old value to a new value and generate a delta that represents
the changes that must be made to the old value in order to transform it
into the new value.
- extractDelta(ReadBuffer, ReadBuffer) - Method in class com.tangosol.io.DecoratedBinaryDeltaCompressor
-
Compare an old value to a new value and generate a delta that represents
the changes that must be made to the old value in order to transform it
into the new value.
- extractDelta(ReadBuffer, ReadBuffer) - Method in class com.tangosol.io.DecorationOnlyDeltaCompressor
-
Compare an old value to a new value and generate a delta that represents
the changes that must be made to the old value in order to transform it
into the new value.
- extractDelta(ReadBuffer, ReadBuffer) - Method in interface com.tangosol.io.DeltaCompressor
-
Compare an old value to a new value and generate a delta that represents
the changes that must be made to the old value in order to transform it
into the new value.
- extractDelta(ReadBuffer, ReadBuffer) - Method in class com.tangosol.util.ExternalizableHelper.FormatAwareCompressor
-
Compare an old value to a new value and generate a delta that represents
the changes that must be made to the old value in order to transform it
into the new value.
- extractDelta(ReadBuffer, ReadBuffer) - Method in class com.tangosol.util.NullImplementation.NullDeltaCompressor
-
Compare an old value to a new value and generate a delta that represents
the changes that must be made to the old value in order to transform it
into the new value.
- extractExpiry(ReadWriteBackingMap.Entry) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Return the expiration value for the given entry.
- extractFlag(int) - Method in class com.tangosol.net.cache.OverflowMap.Status
-
Extract a particular masked flag from the state of the Status
object.
- extractFlag(int) - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
-
Extract a particular masked flag from the state of the Status
object.
- extractFromEntry(Map.Entry) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics.CacheStatisticsExtractor
-
- extractFromEntry(Map.Entry) - Method in class com.tangosol.util.extractor.AbstractExtractor
-
Extract the value from the passed Entry object.
- extractFromEntry(Map.Entry) - Method in class com.tangosol.util.extractor.ChainedExtractor
-
Extract the value from the passed entry.
- extractFromEntry(Map.Entry) - Method in class com.tangosol.util.extractor.MultiExtractor
-
Extract a collection of values from the passed entry using the underlying
array of ValueExtractor objects.
- extractFromEntry(Map.Entry) - Method in class com.tangosol.util.extractor.PofExtractor
-
Extracts the value from the passed Entry object.
- extractFromEntry(ValueExtractor<? super T, ? extends E>, Map.Entry<? extends K, ? extends V>) - Static method in class com.tangosol.util.InvocableMapHelper
-
Extract a value from the specified entry using the specified extractor.
- extractFromKey(ValueExtractor<? super K, E>) - Method in interface com.tangosol.util.QueryMap.Entry
-
Extract a value out of the Entry's key.
- extractFromValue(ValueExtractor<? super V, E>) - Method in interface com.tangosol.util.QueryMap.Entry
-
Extract a value out of the Entry's value.
- extractIntDecoration(ReadBuffer) - Static method in class com.tangosol.util.ExternalizableHelper
-
Extract a decoration value from the specified ReadBuffer that contains a
representation of an IntDecoratedObject.
- extractNewValue(Map.Entry) - Method in class com.tangosol.util.SimpleMapIndex
-
Extract the "new" value from the specified entry.
- extractOldValue(MapTrigger.Entry) - Method in class com.tangosol.util.SimpleMapIndex
-
Extract the "old" value from the specified entry.
- ExtractorBuilder - Interface in com.tangosol.coherence.dslquery
-
- ExtractorComparator<T> - Class in com.tangosol.util.comparator
-
Comparator implementation that uses specified
ValueExtractor
to extract value(s) to be used for comparison.
- ExtractorComparator() - Constructor for class com.tangosol.util.comparator.ExtractorComparator
-
Default constructor (for PortableObject).
- ExtractorComparator(ValueExtractor<? super T, ? extends E>) - Constructor for class com.tangosol.util.comparator.ExtractorComparator
-
Construct a ExtractorComparator with the specified extractor.
- ExtractorEventTransformer<K,V,E> - Class in com.tangosol.util.transformer
-
ExtractorEventTransformer is a special purpose
MapEventTransformer
implementation that transforms emitted events, extracting one or more
properties from either the OldValue or the NewValue.
- ExtractorEventTransformer() - Constructor for class com.tangosol.util.transformer.ExtractorEventTransformer
-
No-argument constructor for lite deserialization.
- ExtractorEventTransformer(ValueExtractor<? super V, ? extends E>) - Constructor for class com.tangosol.util.transformer.ExtractorEventTransformer
-
Construct a ExtractorEventTransformer that transforms MapEvent values
based on the specified extractor.
- ExtractorEventTransformer(String) - Constructor for class com.tangosol.util.transformer.ExtractorEventTransformer
-
Construct a ExtractorEventTransformer that transforms MapEvent's values
based on the specified method name.
- ExtractorEventTransformer(ValueExtractor<? super V, ? extends E>, ValueExtractor<? super V, ? extends E>) - Constructor for class com.tangosol.util.transformer.ExtractorEventTransformer
-
Construct a ExtractorEventTransformer that transforms MapEvent values
based on the specified extractors.
- ExtractorFilter<T,E> - Class in com.tangosol.util.filter
-
Base Filter implementation for doing extractor-based processing.
- ExtractorFilter() - Constructor for class com.tangosol.util.filter.ExtractorFilter
-
Default constructor (necessary for the ExternalizableLite interface).
- ExtractorFilter(ValueExtractor<? super T, ? extends E>) - Constructor for class com.tangosol.util.filter.ExtractorFilter
-
Construct a ExtractorFilter for a given ValueExtractor.
- ExtractorFilter(String) - Constructor for class com.tangosol.util.filter.ExtractorFilter
-
Construct an ExtractorFilter for a given method name.
- extractorFor(String) - Method in class com.tangosol.coherence.dslquery.internal.PropertyBuilder
-
Make a ValueExtractor for the given String.
- extractorFor(String[]) - Method in class com.tangosol.coherence.dslquery.internal.PropertyBuilder
-
Make a ValueExtractor for the given array of property Strings.
- extractOriginalFromEntry(MapTrigger.Entry) - Method in class com.tangosol.util.extractor.AbstractExtractor
-
Extract the value from the "original value" of the passed Entry object
or the key (if targeted).
- extractOriginalFromEntry(MapTrigger.Entry) - Method in class com.tangosol.util.extractor.ChainedExtractor
-
- extractOriginalFromEntry(MapTrigger.Entry) - Method in class com.tangosol.util.extractor.MultiExtractor
-
- extractOriginalFromEntry(MapTrigger.Entry) - Method in class com.tangosol.util.extractor.PofExtractor
-
- extractOriginalFromEntry(ValueExtractor, MapTrigger.Entry) - Static method in class com.tangosol.util.InvocableMapHelper
-
Extract a value from the "original value" of the specified entry using
the specified extractor.
- ExtractorProcessor<K,V,T,E> - Class in com.tangosol.util.processor
-
ExtractorProcessor is an EntryProcessor implementations that extracts a
value from an object cached in an InvocableMap.
- ExtractorProcessor() - Constructor for class com.tangosol.util.processor.ExtractorProcessor
-
Default constructor (necessary for the ExternalizableLite interface).
- ExtractorProcessor(ValueExtractor<? super T, ? extends E>) - Constructor for class com.tangosol.util.processor.ExtractorProcessor
-
Construct an ExtractorProcessor based on the specified ValueExtractor.
- ExtractorProcessor(String) - Constructor for class com.tangosol.util.processor.ExtractorProcessor
-
Construct an ExtractorProcessor for a given method name.
- Extractors - Class in com.tangosol.util
-
Simple Extractor DSL.
- Extractors() - Constructor for class com.tangosol.util.Extractors
-
- extractorStringFor(String) - Method in class com.tangosol.coherence.dslquery.internal.PropertyBuilder
-
Make a getter String suitable for use in a ValueExtractor.
- extractPage(Object[]) - Method in class com.tangosol.util.filter.LimitFilter
-
Extract a subset of the specified array to fit the filter's parameters
(i.e. page size and page number).
- extractPage(Set) - Method in class com.tangosol.util.filter.LimitFilter
-
Extract a subset of the specified set to fit the filter's parameters
(i.e. page size and page number).
- extractPage(Iterator) - Method in class com.tangosol.util.filter.LimitFilter
-
Extract a subset of the specified iterator to fit the filter's parameters
(i.e. page size and page number).
- extractPublicKeys(Set) - Method in class com.tangosol.net.security.DefaultController
-
Extract a set of PublicKeys from the set of public credentials.
- extractState(int) - Method in class com.tangosol.net.cache.OverflowMap.Status
-
Extract a particular masked value from the state of the Status
object.
- extractState(int) - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
-
Extract a particular masked value from the state of the Status
object.
- Gate<R> - Interface in com.tangosol.util
-
A thin extension of Gate
.
- generateEnvironmentName() - Method in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
-
Generate a potentially unique Environment name.
- generateGUID(int, long, long, Member) - Static method in class com.tangosol.persistence.GUIDHelper
-
Generate and return a new GUID for the specified partition.
- get() - Method in class com.tangosol.coherence.config.unit.Bytes
-
Obtain the MemorySize
in bytes.
- get() - Method in class com.tangosol.coherence.config.unit.Megabytes
-
Obtain the MemorySize
in megabytes.
- get() - Method in class com.tangosol.coherence.config.unit.Millis
-
Obtain the Duration
in units of milliseconds.
- get() - Method in class com.tangosol.coherence.config.unit.Seconds
-
Obtain the Duration
in units of seconds.
- get() - Method in class com.tangosol.coherence.config.xml.processor.PasswordProviderBuilderProcessor.DefaultPasswordProvider
-
Returns the password.
- get(int) - Method in class com.tangosol.coherence.dsltools.base.CompoundBaseToken
-
Return the BaseToken at the given index
- get() - Method in class com.tangosol.coherence.jcache.common.CoherenceEntryProcessorResult
-
- get(K) - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
-
- get() - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheValue
-
Gets the internal value (without updating the access time).
- get(K) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
-
- get(K) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
-
- get(K) - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
-
- get(PropertySet, Request) - Method in class com.tangosol.coherence.rest.EntryResource
-
Return the entry value or a subset of its properties.
- get(String) - Method in class com.tangosol.coherence.rest.util.PartialObject
-
Get a property value.
- get(Object) - Method in class com.tangosol.io.nio.BinaryMap
-
Returns the value to which this map maps the specified key.
- get(Integer) - Method in class com.tangosol.io.pof.EvolvableHolder
-
Return an
Evolvable
for the specified type id.
- get(K) - Method in interface com.tangosol.net.AsyncNamedCache
-
Returns the value to which the specified key is mapped, or null
if this map contains no mapping for the key.
- get(Object) - Method in class com.tangosol.net.cache.BundlingNamedCache
-
Returns the value to which this map maps the specified key.
- get(Object) - Method in class com.tangosol.net.cache.CacheStoreMap.ReadWriteMap
-
Returns the value to which this map maps the specified key.
- get(Object) - Method in class com.tangosol.net.cache.CachingMap
- get() - Method in class com.tangosol.net.cache.ContinuousQueryCache.ConverterAsynchronousProcessor
-
- get(long, TimeUnit) - Method in class com.tangosol.net.cache.ContinuousQueryCache.ConverterAsynchronousProcessor
-
- get(Object) - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
- get(Object) - Method in class com.tangosol.net.cache.LocalCache
-
If the specified item is in the cache, return it.
- get(Object) - Method in class com.tangosol.net.cache.OldCache
-
Deprecated.
Returns the value to which this map maps the specified key.
- get(Object) - Method in class com.tangosol.net.cache.OverflowMap
-
Returns the value to which this map maps the specified key.
- get(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.EvictingBackupMap
-
Returns the value to which this map maps the specified key.
- get(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Returns the value to which this map maps the specified key.
- get(Object) - Method in class com.tangosol.net.cache.SerializationCache
-
Returns the value to which this map maps the specified key.
- get(Object) - Method in class com.tangosol.net.cache.SerializationMap
-
Returns the value to which this map maps the specified key.
- get(Object) - Method in class com.tangosol.net.cache.SerializationPagedCache
-
Returns the value to which this map maps the specified key.
- get(Object) - Method in class com.tangosol.net.cache.SimpleOverflowMap
-
Returns the value to which this map maps the specified key.
- get(Object) - Method in class com.tangosol.net.cache.SimpleSerializationMap
-
Returns the value to which this map maps the specified key.
- get(Object) - Method in class com.tangosol.net.cache.VersionedNearCache
-
Deprecated.
Returns the value to which this map maps the specified key.
- get(Object) - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
-
Returns the value to which this map maps the specified key.
- get(Object) - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.MaskedPartitionMap
-
Returns the value to which this map maps the specified key.
- get() - Method in interface com.tangosol.net.PasswordProvider
-
Returns the password to be used in clear format.
- get(SessionProvider.Option...) - Static method in interface com.tangosol.net.SessionProvider
-
- get(String) - Method in class com.tangosol.persistence.AbstractSnapshotArchiver
-
- get(String) - Method in interface com.tangosol.persistence.SnapshotArchiver
-
Return a
Snapshot
which represents the archived snapshot with
the given identifier.
- get(XmlBean) - Method in class com.tangosol.run.xml.PropertyAdapter
-
Extract the property value from the passed bean reference.
- get(Object) - Method in class com.tangosol.run.xml.SimpleElement.AttributeMap
-
- get(Object) - Method in class com.tangosol.util.AbstractKeyBasedMap
-
Returns the value to which this map maps the specified key.
- get(long) - Method in class com.tangosol.util.AbstractLongArray
-
Return the value stored at the specified index.
- get(long) - Method in class com.tangosol.util.AbstractSafeLongArray
-
- get(long) - Method in class com.tangosol.util.AbstractSparseArray
-
Return the value stored at the specified index.
- get() - Method in class com.tangosol.util.AsynchronousAgent
-
- get(long, TimeUnit) - Method in class com.tangosol.util.AsynchronousAgent
-
- get(Object) - Method in class com.tangosol.util.ChainedMap
-
Returns the value to which this map maps the specified key.
- get(int) - Method in class com.tangosol.util.CircularArrayList
- get(Object) - Method in interface com.tangosol.util.ConcurrentMap
-
Returns the value to which this map maps the specified key.
- get(Object) - Method in class com.tangosol.util.ConditionalIndex
-
Using the index information if possible, get the value associated with
the specified key.
- get() - Method in class com.tangosol.util.ConverterCollections.ConverterHolder
-
- get(int) - Method in class com.tangosol.util.ConverterCollections.ConverterList
- get(long) - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray
-
- get(Object) - Method in class com.tangosol.util.ConverterCollections.ConverterMap
- get(Object) - Method in class com.tangosol.util.CopyOnWriteMap
- get(Object) - Method in class com.tangosol.util.ForwardOnlyMapIndex
-
Using the index information if possible, get the value associated with
the specified key.
- get(int) - Method in class com.tangosol.util.ImmutableArrayList
-
Returns the element at the specified position in this List.
- get(int) - Method in class com.tangosol.util.ImmutableMultiList
-
Returns the element at the specified position in this List.
- get(int) - Method in class com.tangosol.util.InflatableList
- get(Object) - Method in class com.tangosol.util.KeyValueArrayMap
-
Returns the value to which this map maps the specified key.
- get(long) - Method in interface com.tangosol.util.LongArray
-
Return the value stored at the specified index.
- get(K) - Method in interface com.tangosol.util.MapIndex
-
Using the index information if possible, get the value associated with
the specified key.
- get(Object) - Method in class com.tangosol.util.NullImplementation.NullMap
- get(Object) - Method in class com.tangosol.util.OpenHashMap
-
Returns the value to which this map maps the specified key.
- get(InvocableMap.Entry<K, V>) - Method in class com.tangosol.util.processor.PropertyProcessor
-
Get the property value from the passed Entry object.
- get(int) - Method in class com.tangosol.util.RestrictedCollections.RestrictedList
-
Returns the element at the specified position in this list.
- get(Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedMap
-
Returns the value to which this map maps the specified key.
- get(Object) - Method in class com.tangosol.util.SafeHashMap
-
Returns the value to which this map maps the specified key.
- get(int) - Method in class com.tangosol.util.SafeLinkedList
-
Returns the element at the specified position in this List.
- get(Object) - Method in class com.tangosol.util.SafeSortedMap
- get(Object) - Method in class com.tangosol.util.SafeSortedMap.ViewMap
- get(Object) - Method in class com.tangosol.util.SegmentedHashMap
-
Returns the value to which this map maps the specified key.
- get(Object) - Method in class com.tangosol.util.SetMap
-
- get(long) - Method in class com.tangosol.util.SimpleLongArray
-
Return the value stored at the specified index.
- get(Object) - Method in class com.tangosol.util.SimpleMapIndex
-
Using the index information if possible, get the value associated with
the specified key.
- get(String) - Method in class com.tangosol.util.StringTable
-
Find the specified string in the table and return its value.
- get(int) - Method in class com.tangosol.util.SubList
- get() - Method in class com.tangosol.util.ThreadLocalObject
-
Get the value of the ThreadLocalObject for the current thread.
- get(Comparable) - Method in class com.tangosol.util.Tree
-
Find the specified key and return its value.
- get(int) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperList
- get(long) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
-
- get(Object) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperMap
- get(Object) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- get(Object) - Method in class com.tangosol.util.WrapperObservableMap
-
Returns the value to which this map maps the specified key.
- getAbsolutePath() - Method in class com.tangosol.run.xml.SimpleElement
-
Get the '/'-delimited path of the element starting from the
root element.
- getAbsolutePath() - Method in interface com.tangosol.run.xml.XmlElement
-
Get the '/'-delimited path of the element starting from the
root element.
- getAbsolutePath(XmlElement) - Static method in class com.tangosol.run.xml.XmlHelper
-
Get the '/'-delimited path of the passed element starting from the
root element.
- getAcceptAddress() - Method in interface com.tangosol.net.NameService.RequestContext
-
Get the
InetAddress
that the NameService received the request on.
- getAccessCount() - Method in class com.tangosol.coherence.jcache.common.JCacheEntryMetaInf
-
Gets the number of times the internal value has been accessed.
- getAccessCount() - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheValue
-
Gets the number of times the internal value has been accessed.
- getAccessor() - Method in class com.tangosol.run.xml.PropertyAdapter
-
Obtain the Method object that is used to call the property accessor.
- getAccessTime() - Method in class com.tangosol.coherence.jcache.common.JCacheEntryMetaInf
-
Gets the time (since the Epoc) in milliseconds since the internal value
was last accessed.
- getAccessTime() - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheValue
-
Gets the time (since the Epoc) in milliseconds since the internal value
was last accessed.
- getAction() - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.HostnameVerifierBuilder
-
The action to take on a name mismatch.
- getAction() - Method in class com.tangosol.util.filter.FilterTrigger
-
Obtain the action code for this FilterTrigger.
- getAction() - Method in class com.tangosol.util.fsm.Transition
-
- getActionName(int) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy
-
Return the string description of the given rule mask.
- getActionPolicy() - Static method in class com.tangosol.util.NullImplementation
-
Factory method: Obtain a null implementation of an ActionPolicy.
- getActions() - Method in class com.tangosol.net.ClusterPermission
-
Return the actions as a String in a canonical form.
- getActivatedCount() - Method in class com.tangosol.coherence.jcache.common.ContainerHelper.JCacheLifecycleInterceptor
-
Added for Coherence JCache functional testing.
- getActivePageArray() - Method in class com.tangosol.net.cache.SerializationPagedCache.PagedBinaryStore
-
Get the array of BinaryStore objects, one for each active page.
- getActivePageCount() - Method in class com.tangosol.net.cache.SerializationPagedCache.PagedBinaryStore
-
Determine the number of pages that the PagedBinaryStore is
currently managing.
- getActualBackupCount() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
Return the number of backups to maintain, given the actual set of
ownership-enabled and leaving members.
- getAdapters() - Method in class com.tangosol.run.xml.XmlBean.BeanInfo
-
Obtain the PropertyAdapter objects for the properties of this XML bean.
- getAdapters() - Method in class com.tangosol.run.xml.XmlBean
-
Obtain the PropertyAdapter objects for this XmlBean.
- getAdded() - Method in class com.tangosol.util.DeltaSet
-
Determine what items were added to the delta set.
- getAddress() - Method in interface com.tangosol.net.Member
-
Return the IP address of the Member's DatagramSocket for
point-to-point communication.
- getAddress() - Method in class com.tangosol.net.proxy.RemoteMember
-
Return the IP address of the Member's DatagramSocket for
point-to-point communication.
- getAddress() - Method in class com.tangosol.util.UID
-
Determine the internet address of the host that generated the UID
instance (or a random number if no internet address was available)
- getAddress() - Method in class com.tangosol.util.UUID
-
Determine the internet address of the host that generated the UUID
instance.
- getAddressDescriptions() - Method in class com.tangosol.net.CompositeAddressProvider
-
Retrieve a human readable description of underlying addresses.
- getAddressDescriptions() - Method in class com.tangosol.net.ConfigurableAddressProvider
-
Retrieve a human readable description of underlying addresses.
- getAddressDescriptions() - Method in interface com.tangosol.net.DescribableAddressProvider
-
Retrieve a human readable description of underlying addresses.
- getAddressDescriptions(Collection) - Static method in class com.tangosol.net.InetAddressHelper
-
Return an array of strings representing addresses in the specified collection.
- getAddressDescriptions() - Method in class com.tangosol.net.RefreshableAddressProvider
-
Retrieve a human readable description of underlying addresses.
- getAddressProvider() - Static method in class com.tangosol.util.NullImplementation
-
- getAddressProviderMap() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the address provider map.
- getAddressProviderMap() - Method in interface com.tangosol.net.OperationalContext
-
Return a Map of address provider factories.
- getAdvanceFrequency() - Method in class com.tangosol.net.TcpDatagramSocketProvider.DefaultDependencies
-
Get the frequency at which the DatagramSocket will advance over
the sub-sockets during receive
- getAdvanceFrequency() - Method in interface com.tangosol.net.TcpDatagramSocketProvider.Dependencies
-
Get the frequency at which the DatagramSocket will advance over
the sub-sockets during receive
- getAdvice() - Method in exception com.tangosol.config.ConfigurationException
-
Returns advice to resolve the issue.
- getAggregator() - Method in class com.tangosol.coherence.dslquery.statement.SelectStatementBuilder.SelectStatement
-
Return the InvocableMap.EntryAggregator
to use to
execute this query.
- getAggregator(String...) - Method in interface com.tangosol.coherence.rest.util.aggregator.AggregatorFactory
-
Returns an aggregator instance.
- getAggregator(String) - Method in class com.tangosol.coherence.rest.util.aggregator.AggregatorRegistry
-
Returns a configured aggregator.
- getAggregator(String...) - Method in class com.tangosol.coherence.rest.util.aggregator.DefaultAggregatorFactory
-
Return an aggregator instantiated by calling an aggregator class
constructor.
- getAggregator() - Method in class com.tangosol.util.aggregator.AbstractAsynchronousAggregator
-
Return the underlying streaming aggregator.
- getAggregator() - Method in class com.tangosol.util.aggregator.GroupAggregator
-
Obtain the underlying EntryAggregator.
- getAggregator() - Method in class com.tangosol.util.aggregator.PriorityAggregator
-
Obtain the underlying aggregator.
- getAggregatorClass() - Method in class com.tangosol.coherence.rest.config.AggregatorConfig
-
Determine the class of the aggregator or aggregator factory.
- getAggregatorName() - Method in class com.tangosol.coherence.rest.config.AggregatorConfig
-
Determine the name of the aggregator.
- getAggregatorRegistry() - Method in class com.tangosol.coherence.rest.config.RestConfig
-
Return the configured aggregator registry.
- getAggregators() - Method in class com.tangosol.util.aggregator.CompositeAggregator
-
Obtain the EntryAggregator array.
- getAlgorithm() - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.DefaultManagerDependencies
-
Get algorithm
- getAlgorithm() - Method in interface com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.ManagerDependencies
-
- getAlias(NodeTerm) - Static method in class com.tangosol.coherence.dslquery.statement.AbstractStatementBuilder
-
Return the String that represents the cache name alias from the given AST
node by looking for the "alias" term in the AST.
- getAliases() - Method in class com.tangosol.coherence.dslquery.operator.BaseOperator
-
Return the alternative symbols to use in CohQL that represent this operator.
- getAll(Set<? extends K>) - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
-
- getAll(Set<? extends K>) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
-
- getAll(Set<? extends K>) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
-
- getAll(Set<? extends K>) - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
-
- getAll(Collection<? extends K>) - Method in interface com.tangosol.net.AsyncNamedCache
-
Get all the specified keys, if they are in the cache.
- getAll(Filter) - Method in interface com.tangosol.net.AsyncNamedCache
-
Get all the entries that satisfy the specified filter.
- getAll(Collection<? extends K>, BiConsumer<? super K, ? super V>) - Method in interface com.tangosol.net.AsyncNamedCache
-
Stream the entries associated with the specified keys to the provided
callback.
- getAll(Collection<? extends K>, Consumer<? super Map.Entry<? extends K, ? extends V>>) - Method in interface com.tangosol.net.AsyncNamedCache
-
Stream the entries associated with the specified keys to the provided
callback.
- getAll(Collection) - Method in class com.tangosol.net.cache.BundlingNamedCache
-
Get all the specified keys, if they are in the Map.
- getAll(Collection<? extends K>) - Method in interface com.tangosol.net.cache.CacheMap
-
Get all the specified keys, if they are in the cache.
- getAll(Collection) - Method in class com.tangosol.net.cache.CacheStoreMap.ReadWriteMap
-
Get all the specified keys, if they are in the Map.
- getAll(Collection<? extends K>) - Method in class com.tangosol.net.cache.CachingMap
-
Get all the specified keys, if they are in the cache.
- getAll(Collection<? extends K>) - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
- getAll(Collection) - Method in class com.tangosol.net.cache.LocalCache
-
Get all the specified keys, if they are in the cache.
- getAll(Collection) - Method in class com.tangosol.net.cache.OldCache
-
Deprecated.
Get all the specified keys, if they are in the cache.
- getAll(Collection) - Method in class com.tangosol.net.cache.OverflowMap
-
Get all the specified keys, if they are in the Map.
- getAll(Collection) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Retrieve values for all the specified keys.
- getAll(Collection) - Method in class com.tangosol.net.cache.VersionedNearCache
-
Deprecated.
Get all the specified keys, if they are in the cache.
- getAll(Collection<? extends K>) - Method in class com.tangosol.net.cache.WrapperNamedCache
-
Get all the specified keys, if they are in the Map.
- getAll(Collection<? extends K>) - Method in class com.tangosol.util.AbstractKeyBasedMap
-
Get all the specified keys, if they are in the Map.
- getAll(Collection<? extends TK>) - Method in class com.tangosol.util.ConverterCollections.ConverterCacheMap
-
Get all the specified keys, if they are in the cache.
- getAllFromFrontMap(Collection<? extends K>) - Method in class com.tangosol.net.cache.CachingMap
-
Retrieve entries from the front map.
- getAllInternal(Collection<? extends K>) - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
Return multiple values from the back cache, transforming them in the
process if necessary.
- getAllocations() - Static method in class com.tangosol.io.nio.DirectBufferManager
-
Deprecated.
Return the total number of buffers allocated by the DirectBufferManager.
- getAnalysisDelay() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
Return the number of milliseconds the analysis should be delayed;
0L
suggests immediate analysis.
- getAndPut(K, V) - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
-
- getAndPut(K, V) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
-
- getAndPut(K, V) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
-
- getAndPut(K, V) - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
-
- getAndRemove(K) - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
-
- getAndRemove(K) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
-
- getAndRemove(K) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
-
- getAndRemove(K) - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
-
- getAndReplace(K, V) - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
-
- getAndReplace(K, V) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
-
- getAndReplace(K, V) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
-
- getAndReplace(K, V) - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
-
- getAnnouncingMemberSet() - Method in interface com.tangosol.net.Cluster.MemberTimeoutAction
-
Return the set of Members who are "announcing".
- getAppendingBufferOutput() - Method in class com.tangosol.io.AbstractWriteBuffer
-
Get a BufferOutput object to write data to this buffer.
- getAppendingBufferOutput() - Method in interface com.tangosol.io.WriteBuffer
-
Get a BufferOutput object to write data to this buffer.
- getApplicationName() - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
-
- getApplicationName() - Method in interface com.tangosol.coherence.dslquery.QueryPlus.Dependencies
-
Return the optional application name to use if
loading a GAR file.
- getArchiver(String) - Method in class com.tangosol.coherence.dslquery.internal.PersistenceToolsHelper
-
Return the archiver configured for the given service.
- getArchiverPersistenceTools(ExtensibleConfigurableCacheFactory, String, String) - Static method in class com.tangosol.persistence.CachePersistenceHelper
-
Return an implementation specific instance of PersistenceTools for
the given archived snapshot.
- getArgs() - Method in class com.tangosol.util.processor.MethodInvocationProcessor
-
Return the method arguments.
- getArrayOffset(Binary) - Method in class com.tangosol.util.Unsafe
-
- getAssignableValue(Class<?>, Parameter, ParameterResolver, ClassLoader) - Static method in class com.tangosol.coherence.config.builder.ParameterizedBuilderHelper
-
Obtains an assignment compatible value of the required type given an actual Parameter
.
- getAssociatedKey(Object) - Method in interface com.tangosol.net.partition.KeyAssociator
-
Determine the key object to which the specified key object is
associated.
- getAssociatedKey() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore.BatchTask
-
Determine the host key (or base) object to which this object is associated.
- getAssociatedKey() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore.DeleteExtentTask
-
- getAssociatedKey() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore.OpenTask
-
- getAssociatedKey() - Method in class com.tangosol.util.CompositeKey
-
Determine the host key (or base) object to which this object is associated.
- getAssociatedKey() - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.DefaultTaskDependencies
-
Return the associated key for the task.
- getAssociatedKey() - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.Task
-
Determine the host key (or base) object to which this object is associated.
- getAssociatedKey() - Method in interface com.tangosol.util.fsm.NonBlockingFiniteStateMachine.TaskDependencies
-
Return the associated key for the task.
- getAssociatedPartitions(Object) - Method in class com.tangosol.net.partition.BroadKeyPartitioningStrategy
-
Determine the set of partitions that all keys associated with the
specified key are assigned to.
- getAssociatedPartitions(Object) - Method in class com.tangosol.net.partition.DefaultKeyPartitioningStrategy
-
Determine the set of partitions that all keys associated with the
specified key are assigned to.
- getAssociatedPartitions(Object) - Method in interface com.tangosol.net.partition.KeyPartitioningStrategy
-
Determine the set of partitions that all keys associated with the
specified key are assigned to.
- getAssociatedService() - Method in class com.tangosol.net.partition.MirroringAssignmentStrategy
-
Return the associated service.
- getAsynchronousListeners() - Method in class com.tangosol.util.Listeners
-
Get the array of asynchronous event listeners.
- getAsyncLimit(ParameterResolver) - Method in class com.tangosol.coherence.config.builder.storemanager.AsyncStoreManagerBuilder
-
Return the maximum number of bytes that are queued to be written
asynchronously.
- getAttribute(String, String) - Method in interface com.tangosol.net.management.MBeanServerProxy
-
Obtain the value of the specified MBean attribute.
- getAttribute(String, String) - Method in class com.tangosol.net.management.WrapperMBeanServerProxy
-
- getAttribute(String) - Method in class com.tangosol.run.xml.SimpleElement
-
Get an attribute value.
- getAttribute(String) - Method in interface com.tangosol.run.xml.XmlElement
-
Get an attribute value.
- getAttribute(XmlElement, String, String) - Static method in class com.tangosol.run.xml.XmlHelper
-
Get an attribute of the specified XmlElement that matches
to the specified local name and the specified Namespace URI.
- getAttributeList(Map<String, Object>) - Method in class com.tangosol.net.management.MBeanAccessor.SetAttributes
-
- getAttributeMap() - Method in class com.tangosol.run.xml.SimpleElement
-
Get the map of all attributes.
- getAttributeMap() - Method in interface com.tangosol.run.xml.XmlElement
-
Get the map of all attributes.
- getAttributeProcessor(XmlAttribute) - Method in class com.tangosol.config.xml.AbstractNamespaceHandler
-
- getAttributeProcessor(String) - Method in class com.tangosol.config.xml.AbstractNamespaceHandler
-
Obtains the
AttributeProcessor
registered with the specified
localName (in the namespace).
- getAttributeProcessor(XmlAttribute) - Method in interface com.tangosol.config.xml.NamespaceHandler
-
- getAttributes() - Method in class com.tangosol.net.cache.SerializationCache.EntrySet.Entry
-
Obtain the cache attributes for this entry.
- getAttributes() - Method in class com.tangosol.net.DefaultConfigurableCacheFactory.CacheInfo
-
Deprecated.
Obtain the attribute map.
- getAttributes(MBeanAccessor.QueryBuilder.ParsedQuery) - Method in class com.tangosol.net.management.MBeanAccessor
-
- getAttributes(MBeanAccessor.QueryBuilder.ParsedQuery, Filter<MBeanAttributeInfo>, boolean) - Method in class com.tangosol.net.management.MBeanAccessor
-
- GetAttributes() - Constructor for class com.tangosol.net.management.MBeanAccessor.GetAttributes
-
Default constructor.
- GetAttributes(MBeanAccessor.QueryBuilder.ParsedQuery) - Constructor for class com.tangosol.net.management.MBeanAccessor.GetAttributes
-
Create a GetAttributes object.
- GetAttributes(MBeanAccessor.QueryBuilder.ParsedQuery, Filter<MBeanAttributeInfo>, boolean) - Constructor for class com.tangosol.net.management.MBeanAccessor.GetAttributes
-
Create a GetAttributes object.
- getAttributes(String, Filter<String>) - Method in interface com.tangosol.net.management.MBeanServerProxy
-
Return a Map of attribute name to attribute value for a given MBean
name.
- getAttributes(String, Filter<String>) - Method in class com.tangosol.net.management.WrapperMBeanServerProxy
-
- getAuthenticationScheme() - Method in class com.tangosol.coherence.rest.providers.SecurityFilter.Authorizer
-
- getAuthorizedHostFilter() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the filter that is used by the cluster to determine whether to
accept a new Cluster member.
- getAutoCloseable() - Static method in class com.tangosol.util.NullImplementation
-
Factory method: Obtain a null implementation of an
AutoCloseable
.
- getAverageBatchSize() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
Determine the average number of entries stored per store() operation.
- getAverageEraseMillis() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
Determine the average time spent per erase() operation.
- getAverageGetMillis() - Method in interface com.tangosol.net.cache.CacheStatistics
-
Determine the average number of milliseconds per get()
invocation since the cache statistics were last reset.
- getAverageGetMillis() - Method in class com.tangosol.net.cache.SimpleCacheStatistics
-
Determine the average number of milliseconds per get()
invocation since the cache statistics were last reset.
- getAverageGetMillis() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.AggregatingCacheStatistics
-
Determine the average number of milliseconds per get()
invocation since the cache statistics were last reset.
- getAverageGetTime() - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
-
- getAverageGetTime() - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
-
- getAverageGetTime() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
-
- getAverageHitMillis() - Method in interface com.tangosol.net.cache.CacheStatistics
-
Determine the average number of milliseconds per get()
invocation that is a hit.
- getAverageHitMillis() - Method in class com.tangosol.net.cache.SimpleCacheStatistics
-
Determine the average number of milliseconds per get()
invocation that is a hit.
- getAverageHitMillis() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.AggregatingCacheStatistics
-
Determine the average number of milliseconds per get()
invocation that is a hit.
- getAverageLoadMillis() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
Determine the average time spent per load() operation.
- getAverageMissMillis() - Method in interface com.tangosol.net.cache.CacheStatistics
-
Determine the average number of milliseconds per get()
invocation that is a miss.
- getAverageMissMillis() - Method in class com.tangosol.net.cache.SimpleCacheStatistics
-
Determine the average number of milliseconds per get()
invocation that is a miss.
- getAverageMissMillis() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.AggregatingCacheStatistics
-
Determine the average number of milliseconds per get()
invocation that is a miss.
- getAveragePartitionSize() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.JMXPartitionStats
-
Return average partition storage size.
- getAveragePartitionSizeKB() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
Get the average partition storage size.
- getAveragePartitionSizeKB() - Method in interface com.tangosol.net.partition.SimpleStrategyMBean
-
Get the average partition storage size.
- getAveragePruneMillis() - Method in class com.tangosol.net.cache.SimpleCacheStatistics
-
Calculate the average number of milliseconds that a prune takes.
- getAveragePutMillis() - Method in interface com.tangosol.net.cache.CacheStatistics
-
Determine the average number of milliseconds per put()
invocation since the cache statistics were last reset.
- getAveragePutMillis() - Method in class com.tangosol.net.cache.SimpleCacheStatistics
-
Determine the average number of milliseconds per put()
invocation since the cache statistics were last reset.
- getAveragePutMillis() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.AggregatingCacheStatistics
-
Determine the average number of milliseconds per put()
invocation since the cache statistics were last reset.
- getAveragePutTime() - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
-
- getAveragePutTime() - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
-
- getAveragePutTime() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
-
- getAverageRemoveTime() - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
-
- getAverageRemoveTime() - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
-
- getAverageRemoveTime() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
-
- getAverageStorageSize() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.JMXPartitionStats
-
Return average node storage size.
- getAverageStorageSizeKB() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
Get the average node storage size.
- getAverageStorageSizeKB() - Method in interface com.tangosol.net.partition.SimpleStrategyMBean
-
Get the average node storage size.
- getAverageStoreMillis() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
Determine the average time spent per store() operation.
- getBackCache() - Method in class com.tangosol.net.cache.NearCache
-
Obtain the NamedCache object that sits behind this NearCache.
- getBackEvent() - Method in class com.tangosol.net.cache.OverflowMap.Status
-
For internal use only, return the current event from the back
Map.
- getBackingMap() - Method in interface com.tangosol.net.BackingMapContext
-
- getBackingMap(String) - Method in interface com.tangosol.net.BackingMapManagerContext
-
- getBackingMap() - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
-
Obtain a reference to the backing map that this Entry corresponds to.
- getBackingMap() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.Entry
-
Obtain a reference to the backing map that this Entry corresponds to.
- getBackingMap(String) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory.Manager
-
Deprecated.
Get the backing Map associated with a given cache.
- getBackingMap(String) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.Manager
-
Get the backing Map associated with a given cache.
- getBackingMap(Object) - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
-
Obtain a backing map for the specified key.
- getBackingMap(int) - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.MapArray
-
Obtain the backing map that corresponds to a specified partition.
- getBackingMap() - Method in interface com.tangosol.util.BinaryEntry
-
- getBackingMap() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventBinaryEntry
-
Obtain a reference to the backing map that this Entry corresponds to.
- getBackingMap() - Method in class com.tangosol.util.InvocableMapHelper.RoutingBinaryEntry
-
- getBackingMap(String) - Method in class com.tangosol.util.NullImplementation.NullBackingMapManagerContext
-
Obtain a reference to the backing map that corresponds to the specified
cache name.
- getBackingMapContext(String) - Method in interface com.tangosol.net.BackingMapManagerContext
-
Obtain a reference to the
BackingMapContext
that corresponds to
the specified cache name.
- getBackingMapContext() - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
-
- getBackingMapContext() - Method in interface com.tangosol.net.events.partition.cache.PartitionedCacheDispatcher
-
- getBackingMapContext() - Method in interface com.tangosol.util.BinaryEntry
-
- getBackingMapContext() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventBinaryEntry
-
- getBackingMapContext() - Method in class com.tangosol.util.InvocableMapHelper.RoutingBinaryEntry
-
- getBackingMapContext(String) - Method in class com.tangosol.util.NullImplementation.NullBackingMapManagerContext
-
Obtain a reference to the
BackingMapContext
that corresponds to
the specified cache name.
- getBackingMapContext() - Method in interface com.tangosol.util.QueryContext
-
- getBackingMapEntry(Object) - Method in interface com.tangosol.net.BackingMapContext
-
Return an InvocableMap.Entry for the specified key (in its internal
format) from the associated cache, obtaining exclusive access to that
cache entry.
- getBackingMapManager() - Method in interface com.tangosol.net.CacheService
-
Return a backing map manager used by this CacheService.
- getBackingMapManager() - Method in class com.tangosol.net.partition.ObservableSplittingBackingMap
-
Obtain the BackingMapManager that this PartitionAwareBackingMap uses to
instantiate and release backing maps.
- getBackingMapManager() - Method in interface com.tangosol.net.partition.PartitionAwareBackingMap
-
Obtain the BackingMapManager that this PartitionAwareBackingMap uses to
instantiate and release backing maps.
- getBackingMapManager() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
-
Obtain the BackingMapManager that this PartitionAwareBackingMap uses to
instantiate and release backing maps.
- getBackingMapManager() - Method in class com.tangosol.net.partition.ReadWriteSplittingBackingMap
-
Obtain the BackingMapManager that this PartitionAwareBackingMap uses to
instantiate and release backing maps.
- getBackingMapManager() - Method in class com.tangosol.net.WrapperCacheService
-
Return a backing map manager used by this CacheService.
- getBackingMapManagerContext() - Method in class com.tangosol.coherence.config.builder.MapBuilder.Dependencies
-
- getBackingMapManagerContext() - Static method in class com.tangosol.util.NullImplementation
-
Factory method: Obtain a null implementation of a BackingMapManagerContext.
- getBackingMaps() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.MapArray
-
Obtain an array of all of the current backing maps, one for each
partition.
- getBackingMaps(PartitionSet) - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.MapArray
-
Obtain an array of the current backing maps for the partitions
specified in the passed PartitionSet.
- getBackingMapScheme() - Method in interface com.tangosol.coherence.config.scheme.ClusteredCachingScheme
-
- getBackingMapScheme() - Method in class com.tangosol.coherence.config.scheme.DistributedScheme
-
Return the
BackingMapScheme
which builds the backing map for
the clustered scheme.
- getBackingMapScheme() - Method in class com.tangosol.coherence.config.scheme.ReplicatedScheme
-
Return the
BackingMapScheme
which builds the backing map for
the clustered scheme.
- getBacklog() - Method in interface com.tangosol.net.ThreadPoolManager
-
Return the backlog of the thread pool.
- getBackMap() - Method in class com.tangosol.net.cache.CachingMap
-
Obtain the back map reference.
- getBackMap() - Method in class com.tangosol.net.cache.OverflowMap
-
Returns the back Map.
- getBackMap() - Method in class com.tangosol.net.cache.SimpleOverflowMap
-
Returns the back Map.
- getBackMapListener() - Method in class com.tangosol.net.cache.OverflowMap
-
Get the MapListener for the back map.
- getBackPaddingSize() - Method in class com.tangosol.io.MultiByteArrayOutputStream
-
Determine the number of extra bytes of padding that will be allocated
and left blank at the end of each block after the data portion.
- getBackScheme() - Method in class com.tangosol.coherence.config.scheme.AbstractCompositeScheme
-
Return the back scheme.
- getBackupCount() - Method in class com.tangosol.net.partition.Ownership
-
Return the backup count for this Ownership object.
- getBackupCount() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
Get the configured number of backups.
- getBackupCount() - Method in interface com.tangosol.net.partition.SimpleStrategyMBean
-
Get the configured number of backups.
- getBackupCount() - Method in interface com.tangosol.net.PartitionedService
-
Determine the configured redundancy count that this service has been
configured to maintain.
- getBackupLoadCalculator() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
Return the LoadCalculator used to calculate the backup partition load.
- getBackupMapConfig() - Method in class com.tangosol.coherence.config.scheme.DistributedScheme
-
Return the
BackupMapConfig
which which is used to configure
the backup map.
- getBackupOwner(int, int) - Method in interface com.tangosol.net.PartitionedService
-
Determine the backup owner of the specified partition.
- getBackupSchemeName(ParameterResolver) - Method in interface com.tangosol.coherence.config.scheme.BackupMapConfig
-
Return the name of the caching scheme to use as a backup map.
- getBackupSchemeName(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.DistributedScheme.BackupConfig
-
Return the name of the caching scheme to use as a backup map.
- getBackupStrength() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
Return the BackupStrength for this analysis context.
- getBaseMap() - Method in interface com.tangosol.util.TransactionMap
-
Return the base map, which contains this TransactionMap's committed data.
- getBaseName(String) - Static method in class com.tangosol.io.FileHelper
-
Gets the base name, minus the full path and extension, from a full
filename.
- getBaseNode() - Method in class com.tangosol.util.SafeSortedMap
-
Return the base entry node.
- getBatchSize() - Method in class com.tangosol.util.filter.LimitFilter
-
Return the number of members query concurrently.
- getBeanId() - Method in class com.tangosol.run.xml.XmlBean.BeanInfo
-
Get the serialization ID for the specific XML bean implementation.
- getBeanInfo() - Method in class com.tangosol.run.xml.PropertyAdapter
-
Obtain the containing BeanInfo object.
- getBeanInfo() - Method in class com.tangosol.run.xml.XmlBean
-
Obtain the BeanInfo for this XmlBean object, or create and configure
a BeanInfo if one does not exist.
- getBelow() - Method in class com.tangosol.util.SafeSortedMap.SkipNode
-
Return the node below this one in the skip-list.
- getBigDecimal() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Return the BigDecimal which this PofValue represents.
- getBigDecimal() - Method in interface com.tangosol.io.pof.reflect.PofValue
-
Return the BigDecimal which this PofValue represents.
- getBigInteger() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Return the BigInteger which this PofValue represents.
- getBigInteger() - Method in interface com.tangosol.io.pof.reflect.PofValue
-
Return the BigInteger which this PofValue represents.
- getBinary() - Method in class com.tangosol.run.xml.SimpleValue
-
Get the value as binary.
- getBinary(Binary) - Method in class com.tangosol.run.xml.SimpleValue
-
Get the value as binary.
- getBinary() - Method in interface com.tangosol.run.xml.XmlValue
-
Get the value as binary.
- getBinary(Binary) - Method in interface com.tangosol.run.xml.XmlValue
-
Get the value as binary.
- getBinaryEntryStore() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.BinaryEntryStoreWrapper
-
The wrapped BinaryEntryStore.
- getBinaryKey() - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
-
Return a raw binary key for this entry.
- getBinaryKey() - Method in interface com.tangosol.util.BinaryEntry
-
Return a raw binary key for this entry.
- getBinaryKey() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventEntry
-
Return a raw binary key for this entry.
- getBinaryKey() - Method in class com.tangosol.util.InvocableMapHelper.RoutingBinaryEntry
-
Return a raw binary key for this entry.
- getBinaryMap() - Method in class com.tangosol.io.nio.BinaryMapStore
-
Obtain the underlying BinaryMap.
- getBinaryMap() - Method in class com.tangosol.net.cache.SerializationPagedCache.FakeBinaryStore
-
Obtain the map that stores the binary values held by this
BinaryStore.
- getBinaryStore() - Method in class com.tangosol.io.AsyncBinaryStore
-
Obtain the BinaryStore that this AsyncBinaryStore wraps.
- getBinaryStore() - Method in class com.tangosol.net.cache.BinaryStoreCacheStore
-
Returns the BinaryStore that this CacheStore uses for its storage.
- getBinaryStore() - Method in class com.tangosol.net.cache.SerializationMap
-
Returns the BinaryStore that this map uses for its storage.
- getBinaryStore() - Method in class com.tangosol.net.cache.SerializationPagedCache.WrapperBinaryStore
-
- getBinaryStore() - Method in class com.tangosol.net.cache.SimpleSerializationMap
-
Returns the BinaryStore that this map uses for its storage.
- getBinaryStoreKeyMap() - Method in class com.tangosol.net.cache.SerializationPagedCache.WrapperBinaryStore
-
- getBinaryStoreList() - Method in class com.tangosol.net.cache.SerializationPagedCache
-
Get the list of registered BinaryStore objects.
- getBinaryStoreManager() - Method in class com.tangosol.io.AsyncBinaryStoreManager
-
- getBinaryStoreManager() - Method in class com.tangosol.net.cache.SerializationPagedCache
-
Returns the BinaryStoreManager that provides BinaryStore objects
this cache uses for its storage.
- getBinaryStoreManagerBuilder() - Method in class com.tangosol.coherence.config.builder.storemanager.AsyncStoreManagerBuilder
-
- getBinaryStoreManagerBuilder() - Method in interface com.tangosol.coherence.config.builder.storemanager.BinaryStoreManagerBuilderCustomization
-
- getBinaryStoreManagerBuilder() - Method in class com.tangosol.coherence.config.scheme.ExternalScheme
-
- getBinaryStoreManagerBuilder() - Method in class com.tangosol.coherence.config.scheme.PagedExternalScheme
-
- getBinaryStoreMap() - Method in class com.tangosol.io.AsyncBinaryStoreManager
-
- getBinaryValue() - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
-
Return a raw binary value for this entry.
- getBinaryValue() - Method in interface com.tangosol.util.BinaryEntry
-
Return a raw binary value for this entry.
- getBinaryValue() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventEntry
-
Return a raw binary value for this entry.
- getBinaryValue() - Method in class com.tangosol.util.InvocableMapHelper.RoutingBinaryEntry
-
Return an OriginalBinaryValue from the underlying entry.
- getBindingPower() - Method in class com.tangosol.coherence.dsltools.precedence.OPToken
-
Get The binding precedence of this token.
- getBits() - Method in class com.tangosol.io.pof.RawQuad
-
Obtain the raw binary form of the 128-bit float.
- getBlock(int) - Method in class com.tangosol.io.MultiByteArrayOutputStream
-
Obtain the specified block of data.
- getBlockCount() - Method in class com.tangosol.io.MultiByteArrayOutputStream
-
Determine the number of blocks that have been written thus far.
- getBlockCount() - Method in class com.tangosol.util.WrapperConcurrentMap.Lock
-
Return the blocked threads count.
- getBlockDataSize(int) - Method in class com.tangosol.io.MultiByteArrayOutputStream
-
Determine the specific number of bytes of data stored in the specified
block.
- getBlockDataSize() - Method in class com.tangosol.io.MultiByteArrayOutputStream
-
Determine the maximum number of bytes of data that will be stored in
each block.
- getBoolean(String) - Static method in class com.tangosol.coherence.config.Config
-
Returns true if coherence system property sName
exists and
value is equal to string true.
- getBoolean(String, boolean) - Static method in class com.tangosol.coherence.config.Config
-
Return true if property sName
exists and its value is string true.
- getBoolean() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Return the boolean which this PofValue represents.
- getBoolean() - Method in interface com.tangosol.io.pof.reflect.PofValue
-
Return the boolean which this PofValue represents.
- getBoolean() - Method in class com.tangosol.run.xml.SimpleValue
-
Get the value as a boolean.
- getBoolean(boolean) - Method in class com.tangosol.run.xml.SimpleValue
-
Get the value as a boolean.
- getBoolean() - Method in interface com.tangosol.run.xml.XmlValue
-
Get the value as a boolean.
- getBoolean(boolean) - Method in interface com.tangosol.run.xml.XmlValue
-
Get the value as a boolean.
- getBooleanArray() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Return the boolean[] which this PofValue represents.
- getBooleanArray() - Method in interface com.tangosol.io.pof.reflect.PofValue
-
Return the boolean[] which this PofValue represents.
- getBottomAnchor() - Method in class com.tangosol.util.filter.LimitFilter
-
Obtain the bottom anchor object, which is the last value object
on the current page.
- getBucketCount() - Method in class com.tangosol.io.nio.BinaryMap
-
Determine the number of hash buckets.
- getBucketIndex(int, int) - Method in class com.tangosol.util.SafeHashMap
-
Calculate the bucket number for a particular hash code.
- getBucketIndex(int, int) - Method in class com.tangosol.util.SegmentedHashMap
-
Calculate the bucket number for a particular hash code.
- getBucketLevel() - Method in class com.tangosol.io.nio.BinaryMap
-
Determine the hash bucket level.
- getBucketOffset(int) - Method in class com.tangosol.io.nio.BinaryMap
-
Get the first Entry block in the linked list of Entry blocks that fall
into a certain hash bucket.
- getBuffer() - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
-
Get the ReadBuffer object that this BufferInput is reading from.
- getBuffer() - Method in class com.tangosol.io.AbstractWriteBuffer.AbstractBufferOutput
-
Get the WriteBuffer object that this BufferOutput is writing to.
- getBuffer(int) - Method in class com.tangosol.io.MultiBufferReadBuffer
-
Obtain the specified buffer.
- getBuffer(int) - Method in class com.tangosol.io.MultiBufferWriteBuffer
-
Obtain the specified buffer.
- getBuffer() - Method in class com.tangosol.io.nio.AbstractBufferManager
-
Get the current ByteBuffer reference.
- getBuffer() - Method in class com.tangosol.io.nio.BinaryMap
-
Obtain the ByteBuffer that the BinaryMap is backed by.
- getBuffer() - Method in interface com.tangosol.io.nio.ByteBufferManager
-
Get the current ByteBuffer reference.
- getBuffer() - Method in interface com.tangosol.io.ReadBuffer.BufferInput
-
Get the ReadBuffer object that this BufferInput is reading from.
- getBuffer() - Method in class com.tangosol.io.SizeEstimatingBufferOutput
-
- getBuffer() - Method in class com.tangosol.io.WrapperBufferInput
-
Get the ReadBuffer object that this BufferInput is reading from.
- getBuffer() - Method in class com.tangosol.io.WrapperBufferOutput
-
Get the WriteBuffer object that this BufferOutput is writing to.
- getBuffer() - Method in interface com.tangosol.io.WriteBuffer.BufferOutput
-
Get the WriteBuffer object that this BufferOutput is writing to.
- getBufferCount() - Method in class com.tangosol.io.MultiBufferReadBuffer
-
Determine the number of ReadBuffer objects that contain the data
presented by this MultiBufferReadBuffer.
- getBufferCount() - Method in class com.tangosol.io.MultiBufferWriteBuffer
-
Determine the number of WriteBuffer objects allocated by this
MultiBufferWriteBuffer from the WriteBufferPool.
- getBufferIndexByOffset(int) - Method in class com.tangosol.io.MultiBufferReadBuffer
-
Determine which underlying ReadBuffer contains the specified offset.
- getBufferIndexByOffset(int) - Method in class com.tangosol.io.MultiBufferWriteBuffer
-
Determine which underlying WriteBuffer contains the specified offset.
- getBufferInput() - Method in class com.tangosol.io.AbstractReadBuffer
-
Get a BufferInput object to read data from this buffer.
- getBufferInput() - Method in class com.tangosol.io.nio.BinaryMap
-
Get the DataInputStream that maps to the underlying ByteBuffer.
- getBufferInput() - Method in interface com.tangosol.io.ReadBuffer
-
Get a BufferInput object to read data from this buffer.
- getBufferManager() - Method in class com.tangosol.io.nio.BinaryMap
-
Obtain the ByteBufferManager that provides the ByteBuffer objects.
- getBufferOffset(int) - Method in class com.tangosol.io.MultiBufferReadBuffer
-
Determine the offset of the specified buffer.
- getBufferOffset(int) - Method in class com.tangosol.io.MultiBufferWriteBuffer
-
Determine the offset of the specified buffer.
- getBufferOutput() - Method in class com.tangosol.io.AbstractWriteBuffer
-
Get a BufferOutput object to write data to this buffer, starting at
the beginning of the WriteBuffer.
- getBufferOutput(int) - Method in class com.tangosol.io.AbstractWriteBuffer
-
Get a BufferOutput object to write data to this buffer starting at a
particular offset.
- getBufferOutput(int) - Method in class com.tangosol.io.ByteArrayWriteBuffer
-
Get a BufferOutput object to write data to this buffer starting at a
particular offset.
- getBufferOutput(int) - Method in class com.tangosol.io.DelegatingWriteBuffer
-
Get a BufferOutput object to write data to this buffer starting at a
particular offset.
- getBufferOutput(int) - Method in class com.tangosol.io.MultiBufferWriteBuffer
-
Get a BufferOutput object to write data to this buffer starting at a
particular offset.
- getBufferOutput() - Method in class com.tangosol.io.nio.BinaryMap
-
Get the DataOutputStream that maps to the underlying ByteBuffer.
- getBufferOutput(int) - Method in class com.tangosol.io.nio.ByteBufferWriteBuffer
-
Get a BufferOutput object to write data to this buffer starting at a
particular offset.
- getBufferOutput() - Method in class com.tangosol.io.pof.PofBufferWriter
-
Return the BufferOutput that this PofBufferWriter writes to.
- getBufferOutput() - Method in class com.tangosol.io.pof.WritingPofHandler
-
Obtain the DataOutput object that this Writing POF Handler is writing
to.
- getBufferOutput() - Method in interface com.tangosol.io.WriteBuffer
-
Get a BufferOutput object to write data to this buffer, starting at
the beginning of the WriteBuffer.
- getBufferOutput(int) - Method in interface com.tangosol.io.WriteBuffer
-
Get a BufferOutput object to write data to this buffer starting at a
particular offset.
- getBufferPool() - Method in class com.tangosol.io.MultiBufferWriteBuffer
-
Obtain the factory used to create WriteBuffer objects.
- getBuilder(Class<T>) - Method in interface com.tangosol.coherence.config.builder.ParameterizedBuilderRegistry
-
Attempts to retrieve the builder that was registered with the
specified class.
- getBuilder(Class<T>, String) - Method in interface com.tangosol.coherence.config.builder.ParameterizedBuilderRegistry
-
Attempts to retrieve the builder that was registered with the
specified class and name.
- getBuilder() - Method in interface com.tangosol.coherence.config.builder.ParameterizedBuilderRegistry.Registration
-
- getBuilder() - Method in class com.tangosol.coherence.config.builder.SimpleParameterizedBuilderRegistry.BuilderRegistration
-
- getBuilder(Class<T>) - Method in class com.tangosol.coherence.config.builder.SimpleParameterizedBuilderRegistry
-
- getBuilder(Class<T>, String) - Method in class com.tangosol.coherence.config.builder.SimpleParameterizedBuilderRegistry
-
- getBuilder() - Method in class com.tangosol.coherence.config.builder.SimpleParameterizedBuilderRegistry.RegistryValue
-
Return the registered builder.
- getBuilderRegistry() - Method in interface com.tangosol.net.ClusterDependencies
-
The registry for all builders associated with the cluster.
- getBuilderRegistry() - Method in interface com.tangosol.net.OperationalContext
-
The registry for all builders associated with the cluster.
- getBundleManager() - Method in interface com.tangosol.coherence.config.scheme.BundlingScheme
-
- getBundleManager() - Method in class com.tangosol.coherence.config.scheme.CacheStoreScheme
-
- getBundleManager() - Method in class com.tangosol.coherence.config.scheme.DistributedScheme
-
- getBundleManager() - Method in class com.tangosol.coherence.config.scheme.RemoteCacheScheme
-
- GetBundler() - Constructor for class com.tangosol.net.cache.BundlingNamedCache.GetBundler
-
- getBundleSize() - Method in class com.tangosol.net.cache.AbstractBinaryEntryBundler.Bundle
-
Obtain this bundle size.
- getBundleSize() - Method in class com.tangosol.net.cache.AbstractBundler.Bundle
-
Obtain this bundle size.
- getBundleSize() - Method in class com.tangosol.net.cache.AbstractEntryBundler.Bundle
-
Obtain this bundle size.
- getBundleSize() - Method in class com.tangosol.net.cache.AbstractKeyBundler.Bundle
-
Obtain this bundle size.
- getByte() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Return the byte which this PofValue represents.
- getByte() - Method in interface com.tangosol.io.pof.reflect.PofValue
-
Return the byte which this PofValue represents.
- getByteArray() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Return the byte[] which this PofValue represents.
- getByteArray() - Method in interface com.tangosol.io.pof.reflect.PofValue
-
Return the byte[] which this PofValue represents.
- getByteArray(Binary) - Method in class com.tangosol.util.Unsafe
-
Return the underlying byte[] for the specified Binary.
- getByteBuffer() - Method in class com.tangosol.io.nio.ByteBufferInputStream
-
Obtain the ByteBuffer that this InputStream is based on.
- getByteBuffer() - Method in class com.tangosol.io.nio.ByteBufferOutputStream
-
Obtain the ByteBuffer that this OutputStream is based on.
- getByteBuffer() - Method in class com.tangosol.io.nio.ByteBufferReadBuffer.ByteBufferInput
-
Obtain the NIO ByteBuffer that this BufferInput is based on.
- getByteBuffer() - Method in class com.tangosol.io.nio.ByteBufferReadBuffer
-
Obtain the ByteBuffer that this ReadBuffer is based on.
- getByteBuffer() - Method in class com.tangosol.io.nio.ByteBufferWriteBuffer
-
Obtain the ByteBuffer that this WriteBuffer is based on.
- getBytesWritten() - Method in class com.tangosol.io.WrapperDataOutputStream
-
Return the total number of bytes written to the wrapped DataOutput object.
- getBytesWritten() - Method in class com.tangosol.io.WrapperObjectOutputStream
-
Return the total number of bytes written to the wrapped DataOutput object.
- getCache(String, Class<K>, Class<V>) - Method in class com.tangosol.coherence.jcache.CoherenceBasedCacheManager
-
- getCache(String) - Method in class com.tangosol.coherence.jcache.CoherenceBasedCacheManager
-
- getCache() - Method in class com.tangosol.coherence.rest.events.SimpleMapEvent
-
Return the cache name.
- getCache() - Method in class com.tangosol.net.cache.AbstractEvictionPolicy
-
Return the ConfigurableCacheMap that uses this eviction policy.
- getCache() - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
Obtain the
NamedCache
that this
ContinuousQueryCache
is based on.
- getCache(String) - Static method in class com.tangosol.net.CacheFactory
-
- getCache(String, NamedCache.Option...) - Static method in class com.tangosol.net.CacheFactory
-
Return an instance of an cache configured by the current ConfigurableCacheFactory,
using the specified
NamedCache.Option
s.
- getCache(String, ClassLoader) - Static method in class com.tangosol.net.CacheFactory
-
Return an instance of a cache configured by the current ConfigurableCacheFactory
with a specific
ClassLoader
no options.
- getCache(String, ClassLoader, NamedCache.Option...) - Static method in class com.tangosol.net.CacheFactory
-
- getCache(String, NamedCache.Option...) - Method in class com.tangosol.net.CoherenceSession
-
- getCache(String, NamedCache.Option...) - Method in interface com.tangosol.net.Session
-
- getCache() - Method in class com.tangosol.util.CacheCollator
-
- getCacheConfig() - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.DefaultDependencies
-
- getCacheConfig() - Method in interface com.tangosol.net.ExtensibleConfigurableCacheFactory.Dependencies
-
- getCacheConfig() - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
-
Return the
CacheConfig
that contains the configuration used by
this factory.
- getCachedOrPending(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Get a value from the internal cache in a way that respects a potentially
pending write-behind operation.
- getCacheEntry(Object) - Method in interface com.tangosol.net.cache.ConfigurableCacheMap
-
Locate a cache Entry in the cache based on its key.
- getCacheEntry(Object) - Method in class com.tangosol.net.cache.OldCache
-
Deprecated.
Locate a cache Entry in the cache based on its key.
- getCacheEntry(Object) - Method in class com.tangosol.net.cache.SerializationCache
-
Locate a cache Entry in the cache based on its key.
- getCacheEntry() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache.EntrySet.Entry
-
Obtain the actual cache entry from the partition-specific
backing map.
- getCacheEntry(Object) - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
-
Locate a cache Entry in the cache based on its key.
- getCacheEntryEventFilter() - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughFilterAdapter
-
Obtains the CacheEntryEventFilter
to which to delegate
CacheEntryEvent
s.
- getCacheEntryFilter() - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheEntryListenerRegistration
-
Obtains an instance of the CacheEntryEventFilter
for the
registration.
- getCacheEntryListener() - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheEntryListenerRegistration
-
Obtains an instance of the CacheEntryListener
for the
registration.
- getCacheEntryListener() - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughMapListenerAdapter
-
Obtains the
CacheEntryListener
to which
MapEvent
s will be delegated.
- getCacheEntryListenerConfiguration() - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughListenerRegistration
-
Obtains the CacheEntryListenerConfiguration
for the
registration.
- getCacheEntryListenerConfigurations() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
-
- getCacheEvent() - Method in class com.tangosol.util.ConverterCollections.ConverterCacheEvent
-
Return the underlying CacheEvent.
- getCacheEvictions() - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
-
- getCacheEvictions() - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
-
- getCacheEvictions() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
-
- getCacheFactory() - Method in class com.tangosol.coherence.dslquery.ExecutionContext
-
- getCacheFactory() - Method in interface com.tangosol.net.BackingMapManager
-
Obtain the "container" ConfigurableCacheFactory that created
this manager and which this manager is bound to.
- getCacheFactory() - Method in class com.tangosol.net.DefaultConfigurableCacheFactory.Manager
-
Deprecated.
Obtain the "container" DefaultConfigurableCacheFactory that created
this manager and which this manager is bound to.
- getCacheFactory() - Method in class com.tangosol.net.DefaultConfigurableCacheFactory.PartitionedBackingMapManager
-
Deprecated.
Obtain the "container" DefaultConfigurableCacheFactory that created
this manager and which this manager is bound to.
- getCacheFactory() - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.Manager
-
Obtain the "container" ConfigurableCacheFactory that created
this manager and which this manager is bound to.
- getCacheFactory() - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.PartitionedBackingMapManager
-
Obtain the "container" ConfigurableCacheFactory that created
this manager and which this manager is bound to.
- getCacheFactoryBuilder() - Static method in class com.tangosol.net.CacheFactory
-
Obtain the CacheFactoryBuilder singleton using the configuration
info from the "cache-factory-builder-config" element.
- getCacheFactoryBuilderConfig() - Static method in class com.tangosol.net.CacheFactory
-
Return the cache factory builder configuration as defined by the
"cache-factory-builder-config" element in the tangosol-coherence.xml
configuration file.
- getCacheGets() - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
-
- getCacheGets() - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
-
- getCacheGets() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
-
- getCacheHitPercentage() - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
-
- getCacheHitPercentage() - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
-
- getCacheHitPercentage() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
-
- getCacheHits() - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
-
- getCacheHits() - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
-
- getCacheHits() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
-
- getCacheHits() - Method in interface com.tangosol.net.cache.CacheStatistics
-
Determine the rough number of cache hits since the cache statistics
were last reset.
- getCacheHits() - Method in class com.tangosol.net.cache.OldCache
-
Deprecated.
Determine the rough number of cache hits since the cache statistics
were last reset.
- getCacheHits() - Method in class com.tangosol.net.cache.SimpleCacheStatistics
-
Determine the rough number of cache hits since the cache statistics
were last reset.
- getCacheHits() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.AggregatingCacheStatistics
-
Determine the rough number of cache hits since the cache statistics
were last reset.
- getCacheHitsMillis() - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
-
- getCacheHitsMillis() - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
-
get time elapsed in milliseconds performing operations resulting in a hit
- getCacheHitsMillis() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
-
- getCacheHitsMillis() - Method in interface com.tangosol.net.cache.CacheStatistics
-
Determine the total number of milliseconds (since that last statistics
reset) for the get() operations for which an entry existed in
this map.
- getCacheHitsMillis() - Method in class com.tangosol.net.cache.SimpleCacheStatistics
-
Determine the total number of milliseconds (since that last statistics
reset) for the get() operations for which an entry existed in
this map.
- getCacheHitsMillis() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.AggregatingCacheStatistics
-
Determine the total number of milliseconds (since that last statistics
reset) for the get() operations for which an entry existed in
this map.
- getCacheLoader() - Method in class com.tangosol.coherence.jcache.common.JCacheContext
-
Return the configured CacheLoader independent if read-through is enabled or not.
- getCacheLoader() - Method in class com.tangosol.net.cache.LocalCache
-
Determine the loader used by this LocalCache, if any.
- getCacheLoader() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.CacheLoaderCacheStore
-
The wrapped CacheLoader.
- getCacheLoaderFactory() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
-
- getCacheManager() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCache
-
- getCacheManager(URI, ClassLoader, Properties) - Method in class com.tangosol.coherence.jcache.CoherenceBasedCachingProvider
-
Return a CacheManager.
- getCacheManager(URI, ClassLoader) - Method in class com.tangosol.coherence.jcache.CoherenceBasedCachingProvider
-
- getCacheManager() - Method in class com.tangosol.coherence.jcache.CoherenceBasedCachingProvider
-
- getCacheManagerURI() - Method in class com.tangosol.coherence.jcache.common.JCacheIdentifier
-
Get the JCache CacheManager URI, a unique identifier for the JCache CacheManager
- getCacheMap() - Method in class com.tangosol.util.ConverterCollections.ConverterCacheMap
-
Return the underlying CacheMap.
- getCacheMap(CacheMap<FK, FV>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Static method in class com.tangosol.util.ConverterCollections
-
Returns a Converter instance of CacheMap.
- getCacheMappingRegistry() - Method in class com.tangosol.coherence.config.CacheConfig
-
- getCacheMisses() - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
-
- getCacheMisses() - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
-
- getCacheMisses() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
-
- getCacheMisses() - Method in interface com.tangosol.net.cache.CacheStatistics
-
Determine the rough number of cache misses since the cache statistics
were last reset.
- getCacheMisses() - Method in class com.tangosol.net.cache.OldCache
-
Deprecated.
Determine the rough number of cache misses since the cache statistics
were last reset.
- getCacheMisses() - Method in class com.tangosol.net.cache.SimpleCacheStatistics
-
Determine the rough number of cache misses since the cache statistics
were last reset.
- getCacheMisses() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.AggregatingCacheStatistics
-
Determine the rough number of cache misses since the cache statistics
were last reset.
- getCacheMissesMillis() - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
-
- getCacheMissesMillis() - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
-
get time elapsed in milliseconds performing operations resulting in a miss
- getCacheMissesMillis() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
-
- getCacheMissesMillis() - Method in interface com.tangosol.net.cache.CacheStatistics
-
Determine the total number of milliseconds (since that last statistics
reset) for the get() operations for which no entry existed in
this map.
- getCacheMissesMillis() - Method in class com.tangosol.net.cache.SimpleCacheStatistics
-
Determine the total number of milliseconds (since that last statistics
reset) for the get() operations for which no entry existed in
this map.
- getCacheMissesMillis() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.AggregatingCacheStatistics
-
Determine the total number of milliseconds (since that last statistics
reset) for the get() operations for which no entry existed in
this map.
- getCacheMissPercentage() - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
-
- getCacheMissPercentage() - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
-
- getCacheMissPercentage() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
-
- getCacheName() - Method in class com.tangosol.coherence.config.builder.MapBuilder.Dependencies
-
Return the cache name.
- getCacheName(NodeTerm) - Static method in class com.tangosol.coherence.dslquery.statement.AbstractStatementBuilder
-
Return the String that represents the cache name from the given AST
node by looking for the "from" term AST.
- getCacheName() - Method in class com.tangosol.coherence.rest.config.ResourceConfig
-
Determine the name of the cache.
- getCacheName() - Method in interface com.tangosol.net.BackingMapContext
-
Return the name of the
cache
that this BackingMapContext
is associated with.
- getCacheName() - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
- getCacheName() - Method in class com.tangosol.net.cache.NearCache
-
Return the cache name.
- getCacheName() - Method in class com.tangosol.net.cache.WrapperNamedCache
-
Return the cache name.
- getCacheName() - Method in class com.tangosol.net.ClusterPermission
-
Return the cache name for this permission object or null
if the permission applies to any cache.
- getCacheName() - Method in class com.tangosol.net.DefaultConfigurableCacheFactory.CacheInfo
-
Deprecated.
Obtain the cache name.
- getCacheName() - Method in interface com.tangosol.net.events.partition.cache.CacheLifecycleEvent
-
The name of the cache that the event is associated with.
- getCacheName() - Method in interface com.tangosol.net.events.partition.cache.PartitionedCacheDispatcher
-
Return the name of the
cache
that this
PartitionedCacheDispatcher is associated with.
- getCacheName() - Method in interface com.tangosol.net.NamedCache
-
Return the cache name.
- getCacheName(long) - Method in class com.tangosol.persistence.AbstractPersistenceTools.StatsVisitor
-
Return the cache name based upon the old cache id.
- getCacheName() - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
-
Return the cache name.
- getCacheNamePattern() - Method in class com.tangosol.coherence.config.CacheMapping
-
- getCacheNames() - Method in class com.tangosol.coherence.jcache.CoherenceBasedCacheManager
-
- getCacheNames() - Method in interface com.tangosol.net.CacheService
-
Returns an Enumeration of String objects, one for each cache name that
has been previously registered with this CacheService.
- getCacheNames() - Method in class com.tangosol.net.WrapperCacheService
-
Returns an Enumeration of String objects, one for each cache name that
has been previously registered with this CacheService.
- getCacheNames(PersistentStore<ReadBuffer>) - Static method in class com.tangosol.persistence.CachePersistenceHelper
-
Return the cache names that have been
stored
in the specified store.
- getCachePrunes() - Method in interface com.tangosol.net.cache.CacheStatistics
-
Determine the rough number of cache pruning cycles since the cache
statistics were last reset.
- getCachePrunes() - Method in class com.tangosol.net.cache.SimpleCacheStatistics
-
Determine the rough number of cache pruning cycles since the cache
statistics were last reset.
- getCachePrunes() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.AggregatingCacheStatistics
-
Determine the rough number of cache pruning cycles since the cache
statistics were last reset.
- getCachePrunesMillis() - Method in interface com.tangosol.net.cache.CacheStatistics
-
Determine the total number of milliseconds (since that last statistics
reset) spent on cache pruning.
- getCachePrunesMillis() - Method in class com.tangosol.net.cache.SimpleCacheStatistics
-
Determine the total number of milliseconds (since that last statistics
reset) spent on cache pruning.
- getCachePrunesMillis() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.AggregatingCacheStatistics
-
Determine the total number of milliseconds (since that last statistics
reset) spent on cache pruning.
- getCachePuts() - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
-
- getCachePuts() - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
-
- getCachePuts() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
-
- getCachePutsMillis() - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
-
- getCachePutsMillis() - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
-
get time elapsed in milliseconds performing operations resulting in a put
- getCachePutsMillis() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
-
- getCacheRemovals() - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
-
- getCacheRemovals() - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
-
- getCacheRemovals() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
-
- getCacheRemoveMillis() - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
-
- getCacheRemoveMillis() - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
-
get time elapsed in milliseconds performing operations resulting in a remove
- getCacheRemoveMillis() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
-
- getCacheResource(String) - Method in class com.tangosol.coherence.rest.DefaultRootResource
-
Returns a resource representing single named cache.
- getCacheResource(String) - Method in class com.tangosol.coherence.rest.PassThroughRootResource
-
Returns a resource representing a single named cache.
- getCacheService() - Method in interface com.tangosol.net.BackingMapManagerContext
-
Return the CacheService associated with this context.
- getCacheService() - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
- getCacheService() - Method in class com.tangosol.net.cache.NearCache
-
Return the CacheService that this NamedCache is a part of.
- getCacheService() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Return the CacheService.
- getCacheService() - Method in class com.tangosol.net.cache.WrapperNamedCache
-
Return the CacheService that this NamedCache is a part of.
- getCacheService() - Method in interface com.tangosol.net.NamedCache
-
Return the CacheService that this NamedCache is a part of.
- getCacheService() - Method in class com.tangosol.net.WrapperCacheService
-
Return the wrapped CacheService.
- getCacheService() - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
-
Return the CacheService that this NamedCache is a part of.
- getCacheService() - Method in class com.tangosol.util.NullImplementation.NullBackingMapManagerContext
-
Return the CacheService associated with this context.
- getCacheStatistics() - Method in class com.tangosol.net.cache.CachingMap
-
Obtain the CacheStatistics for this cache.
- getCacheStatistics() - Method in class com.tangosol.net.cache.OldCache
-
Deprecated.
Returns the CacheStatistics for this cache.
- getCacheStatistics() - Method in class com.tangosol.net.cache.OverflowMap
-
Returns the CacheStatistics for this cache.
- getCacheStatistics() - Method in class com.tangosol.net.cache.SerializationMap
-
Returns the CacheStatistics for this cache.
- getCacheStatistics() - Method in class com.tangosol.net.cache.SimpleOverflowMap
-
Returns the CacheStatistics for this cache.
- getCacheStatistics() - Method in class com.tangosol.net.cache.SimpleSerializationMap
-
Returns the CacheStatistics for this cache.
- getCacheStatistics() - Method in class com.tangosol.net.partition.ObservableSplittingBackingMap
-
Return the CacheStatistics for this cache.
- getCacheStatistics() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
-
Returns the CacheStatistics for this cache.
- getCacheStatistics() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.MapArray
-
Obtain an array of all of the CacheStatistics objects for the
current backing maps, one for each partition.
- getCacheStatistics() - Method in class com.tangosol.util.WrapperObservableMap
-
Return the CacheStatistics for this cache.
- getCacheStore() - Method in class com.tangosol.net.cache.LocalCache
-
Determine the store used by this LocalCache, if any.
- getCacheStore() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.CacheStoreWrapper
-
The wrapped CacheStore.
- getCacheStore() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Get the representative of the "persistent" storage for this backing
map.
- getCacheStore() - Static method in class com.tangosol.util.NullImplementation
-
Factory method: Obtain a null implementation of a CacheStore.
- getCacheStoreScheme() - Method in class com.tangosol.coherence.config.scheme.LocalScheme
-
- getCacheStoreScheme() - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
-
- getCacheStoreTimeout(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
-
Return the timeout interval to use for CacheStore read and write
operations.
- getCacheStoreTimeoutMillis() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Return the timeout used for CacheStore operations, or 0 if no timeout is
specified.
- getCacheToConfigurationMapping(JCacheIdentifier) - Method in class com.tangosol.coherence.jcache.CoherenceBasedCacheManager
-
Provide access to meta cache that maps JCache cache names to JCache configuration.
- getCacheWriter() - Method in class com.tangosol.coherence.jcache.common.JCacheContext
-
If write-through is enabled, return the CacheWriter.
- getCacheWriterFactory() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
-
- getCachingProvider() - Method in class com.tangosol.coherence.jcache.CoherenceBasedCacheManager
-
- getCachingScheme() - Method in class com.tangosol.coherence.config.scheme.WrapperCachingScheme
-
- getCachingSchemeName() - Method in class com.tangosol.coherence.config.CacheMapping
-
- getCalculator() - Method in class com.tangosol.util.SimpleMapIndex
-
Return the UnitCalculator used to size this index's contents.
- getCalculatorState(Class) - Method in class com.tangosol.util.SimpleMapIndex.IndexCalculator
-
Determine which method to use to count the size of an instance of the
specified class.
- getCalibratedHighUnits() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
-
- getCalibratedLowUnits() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
-
- getCallerStackFrame() - Static method in class com.tangosol.util.Base
-
Get the StackFrame information for the caller of the current method.
- getCanonicalCacheName() - Method in class com.tangosol.coherence.jcache.common.JCacheIdentifier
-
- getCanonicalName() - Method in class com.tangosol.util.extractor.AbstractExtractor
-
- getCanonicalName() - Method in class com.tangosol.util.extractor.ChainedExtractor
-
Compute a canonical name as a dot-separated concatenation of
the canonical name of each
ValueExtractor
array element, starting
from lowest index array element.
- getCanonicalName() - Method in class com.tangosol.util.extractor.IdentityExtractor
-
- getCanonicalName() - Method in class com.tangosol.util.extractor.KeyExtractor
-
- getCanonicalName() - Method in class com.tangosol.util.extractor.ReflectionExtractor
-
- getCanonicalName() - Method in class com.tangosol.util.extractor.UniversalExtractor
-
- getCanonicalName() - Method in class com.tangosol.util.extractor.UniversalUpdater
-
Return the canonical name for this updater.
- getCanonicalName() - Method in interface com.tangosol.util.ValueExtractor
-
Return the canonical name for this extractor.
- getCapacity() - Method in class com.tangosol.io.AbstractWriteBuffer
-
Determine the number of bytes that the buffer can hold without resizing
itself.
- getCapacity() - Method in class com.tangosol.io.ByteArrayWriteBuffer
-
Determine the number of bytes that the buffer can hold without resizing
itself.
- getCapacity() - Method in class com.tangosol.io.DelegatingWriteBuffer
-
Determine the number of bytes that the buffer can hold without resizing
itself.
- getCapacity() - Method in class com.tangosol.io.MultiBufferWriteBuffer
-
Determine the number of bytes that the buffer can hold without resizing
itself.
- getCapacity() - Method in class com.tangosol.io.nio.AbstractBufferManager
-
Get the capacity of the current ByteBuffer.
- getCapacity() - Method in class com.tangosol.io.nio.BinaryMap
-
Determine the capacity of the map in bytes.
- getCapacity() - Method in interface com.tangosol.io.nio.ByteBufferManager
-
Get the capacity of the current ByteBuffer.
- getCapacity() - Method in class com.tangosol.io.nio.ByteBufferWriteBuffer
-
Determine the number of bytes that the buffer can hold without resizing
itself.
- getCapacity() - Method in interface com.tangosol.io.WriteBuffer
-
Determine the number of bytes that the buffer can hold without resizing
itself.
- getChangedBinaryValue() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.Entry
-
Return the Binary value changed by the BinaryEntryStore.
- getChanges() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Return a buffer containing changes made to this PofValue in the format
defined by the
BinaryDeltaCompressor
.
- getChanges() - Method in interface com.tangosol.io.pof.reflect.PofValue
-
Return a buffer containing changes made to this PofValue in the format
defined by the
BinaryDeltaCompressor
.
- getChar() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Return the char which this PofValue represents.
- getChar() - Method in interface com.tangosol.io.pof.reflect.PofValue
-
Return the char which this PofValue represents.
- getCharArray() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Return the char[] which this PofValue represents.
- getCharArray() - Method in interface com.tangosol.io.pof.reflect.PofValue
-
Return the char[] which this PofValue represents.
- getCharBuf(int) - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
-
Obtain a temp buffer used to avoid allocations when building
Strings from UTF binary data.
- getCharBuf() - Method in class com.tangosol.io.AbstractWriteBuffer.AbstractBufferOutput
-
- getChild(int) - Method in class com.tangosol.io.pof.reflect.ComplexPofValue
-
Locate a child PofValue contained within this PofValue.
- getChild(int) - Method in interface com.tangosol.io.pof.reflect.PofValue
-
Locate a child PofValue contained within this PofValue.
- getChild(int) - Method in class com.tangosol.io.pof.reflect.SimplePofValue
-
Locate a child PofValue contained within this PofValue.
- getChildrenIterator() - Method in class com.tangosol.io.pof.reflect.ComplexPofValue
-
Return an iterator over all parsed child values.
- getClass(int) - Method in class com.tangosol.io.pof.ConfigurablePofContext
-
Determine the class associated with the given user type identifier.
- getClass(int) - Method in interface com.tangosol.io.pof.PofContext
-
Determine the class associated with the given user type identifier.
- getClass(int, PofContext) - Static method in class com.tangosol.io.pof.reflect.PofReflectionHelper
-
Determine the class associated with the given type identifier.
- getClass(int) - Method in class com.tangosol.io.pof.SafeConfigurablePofContext
-
Determine the class associated with the given user type identifier.
- getClass(int) - Method in class com.tangosol.io.pof.SimplePofContext
-
Determine the class associated with the given user type identifier.
- getClass(Type) - Static method in class com.tangosol.util.ClassHelper
-
Obtains the most concrete runtime
Class
that may be used for
the specified
Type
(taking generic declarations into account).
- getClass(String) - Static method in class com.tangosol.util.ExternalizableHelper
-
Return class for the specified class name; null if not found.
- getClass(int, ClassLoader) - Method in class com.tangosol.util.ExternalizableHelper.SimpleXmlBeanClassCache
-
Look up the class for the specified ID.
- getClass(int, ClassLoader) - Method in interface com.tangosol.util.ExternalizableHelper.XmlBeanClassCache
-
Look up the class for the specified ID.
- getClass(int) - Method in class com.tangosol.util.NullImplementation.NullPofContext
-
Determine the class associated with the given user type identifier.
- getClassArray(Object[]) - Static method in class com.tangosol.util.ClassHelper
-
Calculate the class array based on the parameter array.
- getClassArrayFromObjectArray(Object[]) - Static method in class com.tangosol.util.fsm.ReflectionHelper
-
Returns an array of Class objects representing the class of the
objects in the parameter.
- getClassExtracted() - Method in class com.tangosol.util.extractor.PofExtractor
-
Obtain the Class of the extracted value.
- getClassForTypeId(PofContext, int) - Method in class com.tangosol.io.pof.PortableTypeSerializer
-
Return the class associated with a specified type identifier, or null
if the identifier is not defined in the current POF context.
- getClassId(Class) - Method in class com.tangosol.util.ExternalizableHelper.SimpleXmlBeanClassCache
-
Look up the class ID for the specified class.
- getClassId(Class) - Method in interface com.tangosol.util.ExternalizableHelper.XmlBeanClassCache
-
Look up the class ID for the specified class.
- getClassLoader() - Method in class com.tangosol.coherence.config.builder.MapBuilder.Dependencies
-
Returns the
ClassLoader
to use in the context of
realizing
Map
s and other associated infrastructure.
- getClassLoader() - Method in class com.tangosol.coherence.config.xml.processor.InitParamProcessor.DataStructureRefExpression
-
- getClassLoader() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCache
-
- getClassLoader() - Method in class com.tangosol.coherence.jcache.CoherenceBasedCacheManager
-
- getClassLoader() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
-
get class loader for this Cache
- getClassLoader() - Method in class com.tangosol.io.WrapperDataInputStream
-
- getClassLoader() - Method in interface com.tangosol.net.BackingMapManagerContext
-
Return the ClassLoader associated with this context.
- getClassLoader() - Method in class com.tangosol.net.cache.BinaryStoreCacheStore
-
Returns the ClassLoader that this CacheStore uses for deserialization,
if it has one.
- getClassLoader() - Method in class com.tangosol.net.cache.SerializationMap
-
Returns the ClassLoader that this map uses for deserialization, if it
has one.
- getClassLoader() - Method in class com.tangosol.net.cache.SimpleSerializationMap
-
Returns the ClassLoader that this map uses for deserialization, if it
has one.
- getClassLoader() - Static method in class com.tangosol.util.NullImplementation
-
Factory method: Obtain a null implementation of a ClassLoader.
- getClassLoader() - Method in class com.tangosol.util.NullImplementation.NullBackingMapManagerContext
-
Return the ClassLoader associated with this context.
- getClassName() - Method in class com.tangosol.coherence.config.builder.InstanceBuilder
-
Return the expression representing the name of the class this builder
will attempt to instantiate.
- getClassName(int) - Method in class com.tangosol.io.pof.ConfigurablePofContext
-
Determine the name of the class associated with the given user type
identifier.
- getClassName(int) - Method in interface com.tangosol.io.pof.PofContext
-
Determine the name of the class associated with the given user type
identifier.
- getClassName(int) - Method in class com.tangosol.io.pof.SimplePofContext
-
Determine the name of the class associated with the given user type
identifier.
- getClassName() - Method in class com.tangosol.util.Base.StackFrame
-
- getClassName(int) - Method in class com.tangosol.util.NullImplementation.NullPofContext
-
Determine the name of the class associated with the given user type
identifier.
- getClassNode(Class) - Static method in class com.tangosol.coherence.rest.util.PartialObject
-
Return a class definition for the specified class.
- getCleanupMethod() - Static method in class com.tangosol.io.nio.DirectBufferManager
-
Deprecated.
Return the method used for buffers cleanup when the threshold is met.
- getCleanupThreshold() - Static method in class com.tangosol.io.nio.DirectBufferManager
-
Deprecated.
Return the value used to calculate the size threshold for the
uncollected buffers that triggers a cleanup operation.
- getCloner() - Method in class com.tangosol.run.xml.PropertyAdapter
-
Obtain the Method object that is used to deep-clone the property value.
- getCluster() - Method in class com.tangosol.coherence.dslquery.ExecutionContext
-
Return the current
Cluster
to be used
by commands executed under this context.
- getCluster() - Static method in class com.tangosol.net.CacheFactory
-
Return a Cluster object for Coherence services.
- getCluster() - Method in class com.tangosol.net.management.MBeanAccessor.QueryBuilder
-
The Coherence cluster name to be used for the query.
- getCluster() - Method in interface com.tangosol.net.Service
-
Return the Cluster object that this Service is a part of.
- getCluster() - Method in class com.tangosol.net.WrapperService
-
Return the Cluster object that this Service is a part of.
- getClusterActionPolicyBuilder() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the action policy builder used by the cluster to control cluster
membership actions.
- getClusterAnnounceTimeoutMillis() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the maximum amount of time that the cluster service will announce
itself without receiving a response before deciding that a cluster does
not exist and a new cluster should be formed.
- getClusterConfig() - Static method in class com.tangosol.net.CacheFactory
-
Return the default cluster configuration as defined by the
"cluster-config" element in the tangosol-coherence.xml configuration
file.
- getClusterHeartbeatDelayMillis() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the amount of time between heartbeat messages.
- getClusterName() - Method in interface com.tangosol.net.Cluster
-
Determine the configured name for the Cluster.
- getClusterName() - Method in class com.tangosol.net.ClusterPermission
-
Return the cluster name.
- getClusterName() - Method in interface com.tangosol.net.MemberIdentity
-
Return the name of the cluster with which this member is associated.
- getClusterName() - Method in class com.tangosol.net.proxy.RemoteMember
-
Return the name of the cluster with which this member is associated.
- getClusterName() - Static method in class com.tangosol.persistence.CachePersistenceHelper
-
Return the cluster name without starting the cluster service.
- getClusterPermissions(Principal) - Method in class com.tangosol.net.security.DefaultController
-
Obtain the permissions for the specified principal.
- getClusterQuorumMap() - Method in class com.tangosol.net.ConfigurableQuorumPolicy.ClusterQuorumPolicy
-
Return the cluster quorum map, keyed by role name.
- getClusterTimestampMaxVarianceMillis() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the maximum variance between sending and receiving broadcast messages
when trying to determine the difference between a new cluster Member's
wall time and the cluster time.
- getCode() - Method in enum com.tangosol.net.partition.SimpleStrategyMBean.HAStatus
-
Return the integer representation of the HAStatus.
- getCodec(Class<?>) - Static method in class com.tangosol.io.pof.reflect.Codecs
-
Return a
Codec
based on the provided Class.
- getCoherenceQueryLanguage() - Method in class com.tangosol.coherence.dslquery.ExecutionContext
-
- getCoherenceQueryLanguage() - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
-
- getCoherenceQueryLanguage() - Method in interface com.tangosol.coherence.dslquery.QueryPlus.Dependencies
-
- getCollationKey(String) - Method in class com.tangosol.util.CacheCollator
-
Transforms the String into a series of bits that can be compared bitwise
to other CollationKeys.
- getCollection(Collection) - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Return the Collection which this PofValue represents.
- getCollection(Collection) - Method in interface com.tangosol.io.pof.reflect.PofValue
-
Return the Collection which this PofValue represents.
- getCollection() - Method in class com.tangosol.util.ConverterCollections.ConverterCollection
-
Return the underlying Collection.
- getCollection(Collection<F>, Converter<F, T>, Converter<T, F>) - Static method in class com.tangosol.util.ConverterCollections
-
Returns an instance of Collection that uses a Converter to view an
underlying Collection.
- getCollection(Collection, Class) - Static method in class com.tangosol.util.RestrictedCollections
-
Returns a restricted instance of Collection.
- getCollector() - Static method in class com.tangosol.util.NullImplementation
-
Factory method: Obtain a null implementation of a Collector
.
- getComment() - Method in class com.tangosol.run.xml.SimpleElement
-
Get the text of any comments that are in the XML element.
- getComment() - Method in interface com.tangosol.run.xml.XmlElement
-
Get the text of any comments that are in the XML element.
- getCommonMonitor(int) - Static method in class com.tangosol.util.Base
-
Return the common monitor associated with the specified integer value.
- getCommonMonitor(long) - Static method in class com.tangosol.util.Base
-
Return the common monitor associated with the specified long value.
- getCommonMonitor(Object) - Static method in class com.tangosol.util.Base
-
Return the common monitor associated with the specified object based on
its identity hashCode.
- getComparator() - Method in class com.tangosol.util.comparator.SafeComparator
-
Obtain the wrapped Comparator.
- getComparator() - Method in class com.tangosol.util.extractor.ComparisonValueExtractor
-
Return a Comparator used by this extractor.
- getComparator() - Method in class com.tangosol.util.filter.LimitFilter
-
Obtain the Comparator used to partition the entry values into pages.
- getComparator() - Method in class com.tangosol.util.ForwardOnlyMapIndex
-
Get the Comparator used to sort the index.
- getComparator() - Method in interface com.tangosol.util.MapIndex
-
Get the Comparator used to sort the index.
- getComparator() - Method in class com.tangosol.util.SimpleMapIndex
-
Get the Comparator used to sort the index.
- getComparator() - Method in class com.tangosol.util.SortedBag
-
Return the Comparator used to order the bag contents.
- getComparators() - Method in class com.tangosol.util.comparator.ChainedComparator
-
Obtain the underlying Comparator array.
- getComparisonStyle() - Method in class com.tangosol.util.comparator.EntryComparator
-
Obtain the comparison style value utilized by this EntryComparator.
- getCompatibleConstructor(Class<?>, Class<?>[]) - Static method in class com.tangosol.util.fsm.ReflectionHelper
-
Get a compatible constructor to the supplied parameter types.
- getCompatibleMethod(Class<?>, String, Object...) - Static method in class com.tangosol.util.fsm.ReflectionHelper
-
Obtains the
Method
that is compatible to the supplied
parameter types.
- getCompiledExpression() - Method in class com.tangosol.coherence.rest.util.extractor.MvelExtractor
-
Return a compiled MVEL expression.
- getCompiledExpression() - Method in class com.tangosol.coherence.rest.util.updater.MvelUpdater
-
Return a compiled MVEL expression.
- getCompletableFuture() - Method in class com.tangosol.net.cache.ContinuousQueryCache.ConverterAsynchronousProcessor
-
- getCompletableFuture() - Method in class com.tangosol.util.AsynchronousAgent
-
Get the CompletableFuture.
- getCompletedTime() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
Return the time at which the analysis associated with this context
was completed, or 0 if it has not been completed.
- getComplex() - Method in class com.tangosol.io.pof.ValidatingPofHandler
-
Obtain the current Complex object, if any.
- getComplex() - Method in class com.tangosol.io.pof.WritingPofHandler
-
Obtain the current Complex object that represents the complex type that
is being written to the POF stream.
- getComponentType(Type) - Static method in class com.tangosol.util.ClassHelper
-
Obtains the component type of a collection or array (taking generic declarations into account).
- getCompositeName(Class, String) - Static method in class com.tangosol.util.ClassHelper
-
Build the composite name of a class based on an existing class and a
second class name.
- getCompositeName(String, String) - Static method in class com.tangosol.util.ClassHelper
-
Build the composite name of a class based on an existing class name and
a second class name.
- getCompositePackage(String, String) - Static method in class com.tangosol.util.ClassHelper
-
Build the composite name of a package based on two package names.
- getConcreteType(Type) - Static method in class com.tangosol.util.fsm.ReflectionHelper
-
Obtains the concrete (non-parameterized)
Class
given a specified
(possibly parameterized) type.
- getConcurrency() - Method in class com.tangosol.run.jca.CacheAdapter.CacheConnectionSpec
-
- getConcurrency() - Method in interface com.tangosol.util.TransactionMap
-
Retrieve this TransactionMap's current concurrency mode.
- getConcurrentMap() - Method in class com.tangosol.util.ConverterCollections.ConverterConcurrentMap
-
Return the underlying ConcurrentMap.
- getConcurrentMap(ConcurrentMap<FK, FV>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Static method in class com.tangosol.util.ConverterCollections
-
Returns a Converter instance of ConcurrentMap.
- getConditionalRemoveAction() - Method in class com.tangosol.util.SegmentedConcurrentMap
-
Return the registered action for conditional remove.
- getConfig() - Method in class com.tangosol.io.bdb.BerkeleyDBBinaryStoreManager
-
Retrieve the manager's configuration.
- getConfig() - Method in class com.tangosol.io.ConfigurableSerializerFactory
-
Deprecated.
Determine the current configuration of the object.
- getConfig() - Method in class com.tangosol.io.pof.ConfigurablePofContext
-
Determine the current configuration of the object.
- getConfig() - Method in interface com.tangosol.net.BackingMapManagerContext
-
Determine the current configuration of the associated BackingMapManager.
- getConfig() - Method in class com.tangosol.net.cache.SerializationPagedCache
-
Determine the current configuration of the object.
- getConfig() - Method in class com.tangosol.net.CompressionFilter
-
Deprecated.
Determine the current configuration of the object.
- getConfig() - Method in class com.tangosol.net.ConfigurableAddressProviderFactory
-
Deprecated.
Determine the current configuration of the object.
- getConfig() - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Obtain the factory configuration XML.
- getConfig() - Method in class com.tangosol.net.SocketOptions
-
Deprecated.
- getConfig() - Method in class com.tangosol.persistence.ConfigurableSnapshotArchiverFactory
-
Determine the current configuration of the object.
- getConfig() - Method in interface com.tangosol.run.xml.XmlConfigurable
-
Deprecated.
Determine the current configuration of the object.
- getConfig() - Method in class com.tangosol.util.NullImplementation.NullBackingMapManagerContext
-
Determine the current configuration of the associated BackingMapManager.
- getConfigClassLoader() - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Return the class loader used to load the configuration for this factory.
- getConfigClassLoader() - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
-
Return the class loader used to load the configuration for this factory.
- getConfigElementName() - Method in class com.tangosol.coherence.config.CacheMapping
-
- getConfigElementName() - Method in class com.tangosol.coherence.config.ResourceMapping
-
Obtain the xml element name of this mapping.
- getConfigElementName() - Method in class com.tangosol.coherence.config.TopicMapping
-
- getConfigLocation() - Method in class com.tangosol.io.pof.ConfigurablePofContext
-
Obtain the location of the configuration that the
ConfigurablePofContext used to configure itself.
- getConfigUnsafe() - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Obtain a mutable reference to the factory configuration XML.
- getConfigurableCacheFactory() - Method in class com.tangosol.coherence.config.builder.MapBuilder.Dependencies
-
- getConfigurableCacheFactory() - Method in class com.tangosol.coherence.jcache.CoherenceBasedCacheManager
-
Get ConfigurableCacheFactory context.
- getConfigurableCacheFactory() - Static method in class com.tangosol.net.CacheFactory
-
Obtain the ConfigurableCacheFactory singleton using the configuration
info from the "configurable-cache-factory-config" element located in the
tangosol-coherence.xml configuration file.
- getConfigurableCacheFactory(ClassLoader) - Static method in class com.tangosol.net.CacheFactory
-
Obtain the ConfigurableCacheFactory associated with the specified class
loader.
- getConfigurableCacheFactory(ClassLoader) - Method in interface com.tangosol.net.CacheFactoryBuilder
-
Return the default ConfigurableCacheFactory for a given class loader.
- getConfigurableCacheFactory(String, ClassLoader) - Method in interface com.tangosol.net.CacheFactoryBuilder
-
Return the ConfigurableCacheFactory for a given URI and class loader.
- getConfigurableCacheFactory() - Static method in class com.tangosol.net.DefaultCacheServer
-
Gets a ConfigurableCacheFactory based on the default configuration.
- getConfigurableCacheFactory() - Method in interface com.tangosol.net.events.application.LifecycleEvent
-
- getConfigurableCacheFactory(ClassLoader) - Method in class com.tangosol.net.ScopedCacheFactoryBuilder
-
Return the default ConfigurableCacheFactory for a given class loader.
- getConfigurableCacheFactory(String, ClassLoader) - Method in class com.tangosol.net.ScopedCacheFactoryBuilder
-
Return the ConfigurableCacheFactory for a given URI and class loader.
- getConfigurableCacheFactoryConfig() - Static method in class com.tangosol.net.CacheFactory
-
Return the configurable cache factory configuration as defined by the
"configurable-cache-factory-config" element in the tangosol-coherence.xml
configuration file.
- getConfigurableCacheFactoryConfig() - Method in class com.tangosol.net.ScopedCacheFactoryBuilder
-
- getConfiguration(Class<T>) - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCache
-
- getConfiguration() - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheEntryListenerRegistration
-
Obtains the underlying CacheEntryListenerConfiguration
used to
create the registration
- getConfiguration() - Method in class com.tangosol.coherence.jcache.common.JCacheContext
-
Return the JCache cache configuration
- getConfiguration(Class<T>) - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
-
- getConfiguredAddresses(AddressProvider) - Method in class com.tangosol.net.CompositeAddressProvider
-
Return a list of configured addresses in the specified AddressProvider.
- getConfiguredName() - Method in class com.tangosol.util.Daemon
-
Determine the configured name for the daemon.
- getConfiguredPriority() - Method in class com.tangosol.util.Daemon
-
Determine the configured priority for the daemon.
- getConfirmationMessage(String) - Method in class com.tangosol.coherence.dslquery.statement.persistence.AbstractSnapshotStatement
-
Return a confirmation message.
- getConnectionCount() - Method in interface com.tangosol.net.ServiceLoad
-
Return the connection count.
- getConnectionLimit() - Method in interface com.tangosol.net.ServiceLoad
-
Return the maximum number of simultaneous connections allowed.
- getConnectionPendingCount() - Method in interface com.tangosol.net.ServiceLoad
-
Return the number of connections that are pending.
- getConnectionPort() - Static method in class com.tangosol.net.management.MBeanConnector
-
Get the configured connection port for the RMI Connector Server.
- getConnectionPortMax() - Static method in class com.tangosol.net.management.MBeanConnector
-
Get the max configured connection port for the RMI Connector Server.
- getConstructor(Constructor[]) - Method in class com.tangosol.coherence.rest.util.aggregator.DefaultAggregatorFactory
-
Search the given constructors for a constructor that accepts a single
ValueExtractor
parameter.
- getConstructor(Constructor[]) - Method in class com.tangosol.coherence.rest.util.processor.DefaultProcessorFactory
-
Search the given constructors for a constructor that accepts a
String
parameter.
- getConstructorParameterList() - Method in class com.tangosol.coherence.config.builder.InstanceBuilder
-
Return the
ParameterList
to be used for constructor parameters
when realizing the class.
- getContainsValueAction() - Method in class com.tangosol.util.SegmentedHashMap
-
Return the registered action for containsValue().
- getContent() - Method in class com.tangosol.coherence.rest.util.StaticContent
-
Return content as Binary.
- getContentionObserver() - Method in class com.tangosol.util.SegmentedConcurrentMap
-
Return the ContentionObserver for this SegmentedConcurrentMap.
- getContext(ResourceRegistry, JCacheIdentifier) - Static method in class com.tangosol.coherence.jcache.common.JCacheContext
-
- getContext(ResourceRegistry, JCacheIdentifier, CompleteConfiguration) - Static method in class com.tangosol.coherence.jcache.common.JCacheContext
-
- getContext() - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
-
Get the JCache context for this JCache's operations
- getContext() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
-
- getContext(Class<?>) - Method in class com.tangosol.coherence.rest.providers.JacksonMapperProvider
- getContext() - Method in class com.tangosol.net.AbstractBackingMapManager
-
Determine the current BackingMapManagerContext for this
BackingMapManager.
- getContext() - Method in interface com.tangosol.net.BackingMapManager
-
Determine the current BackingMapManagerContext for this
BackingMapManager.
- getContext() - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
-
Return the context this entry operates within.
- getContext() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Get the context information provided by the CacheService.
- getContext() - Method in interface com.tangosol.net.Guardable
-
Return the guard context monitoring this guardable, or null
if this Guardable is no longer being monitored.
- getContext() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
-
Obtain the BackingMapManagerContext that provides the partition
information for keys that are stored in the backing map.
- getContext() - Method in interface com.tangosol.util.BinaryEntry
-
Return the context this entry operates within.
- getContext() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventBinaryEntry
-
Return the context this entry operates within.
- getContext() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent
-
Get the BackingMapManagerContext if one was provided.
- getContext() - Method in class com.tangosol.util.Daemon
-
Return the guard context monitoring this guardable, or null
if this Guardable is no longer being monitored.
- getContext() - Method in class com.tangosol.util.InvocableMapHelper.RoutingBinaryEntry
-
- getContextClassLoader() - Method in class com.tangosol.coherence.rest.config.RestConfig
-
Return the context class loader to use.
- getContextClassLoader() - Method in class com.tangosol.config.xml.DefaultProcessingContext
-
- getContextClassLoader() - Method in class com.tangosol.config.xml.DocumentProcessor.DefaultDependencies
-
Obtains the
ClassLoader
to use for dynamically loading classes during processing.
- getContextClassLoader() - Method in interface com.tangosol.config.xml.DocumentProcessor.Dependencies
-
Obtains the
ClassLoader
to use for dynamically loading classes during processing.
- getContextClassLoader() - Method in interface com.tangosol.config.xml.ProcessingContext
-
- getContextClassLoader() - Method in interface com.tangosol.io.ClassLoaderAware
-
Retrieve the context ClassLoader for this object.
- getContextClassLoader() - Method in class com.tangosol.io.DefaultSerializer
-
- getContextClassLoader() - Method in class com.tangosol.io.pof.ConfigurablePofContext
-
Retrieve the context ClassLoader for this object.
- getContextClassLoader() - Method in class com.tangosol.net.cache.NearCache
-
Retrieve the context ClassLoader for this object.
- getContextClassLoader() - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.DefaultDependencies
-
- getContextClassLoader() - Method in interface com.tangosol.net.ExtensibleConfigurableCacheFactory.Dependencies
-
- getContextClassLoader() - Method in class com.tangosol.net.WrapperService
-
Retrieve the context ClassLoader for this object.
- getContextClassLoader() - Static method in class com.tangosol.util.Base
-
Try to determine the ClassLoader that supports the current context.
- getContextClassLoader(Object) - Static method in class com.tangosol.util.Base
-
Try to determine the ClassLoader that supports the current context.
- getContextSerializer() - Method in interface com.tangosol.io.SerializerAware
-
Retrieve the context Serializer for this object.
- getContinuation() - Static method in class com.tangosol.util.NullImplementation
-
Factory method: Obtain a null implementation of a Continuation
.
- getControlMap() - Method in class com.tangosol.net.cache.CachingMap
-
Obtain the ConcurrentMap that should be used to synchronize
the front map modification access.
- getControlMap() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Get the concurrency control map for this backing map.
- getConverter() - Static method in class com.tangosol.util.NullImplementation
-
Factory method: Obtain a null implementation of a Converter.
- getConverter() - Method in class com.tangosol.util.SimpleMapIndex.IndexCalculator
-
Return the converter used by this IndexCalculator, or null.
- getConverterDown() - Method in class com.tangosol.util.ConverterCollections.ConverterCollection
-
Return the Converter used to pass values down to the underlying
Collection.
- getConverterDown() - Method in class com.tangosol.util.ConverterCollections.ConverterListIterator
-
Return the Converter used to pass values down to the underlying
ListIterator.
- getConverterHolder(F, Converter<F, T>) - Static method in class com.tangosol.util.ConverterCollections
-
Returns a Converter instance of Holder..
- getConverterKeyDown() - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet
-
Return the Converter used to pass keys down to the underlying Entry
Set.
- getConverterKeyDown() - Method in class com.tangosol.util.ConverterCollections.ConverterMap
-
Return the Converter used to pass keys down to the underlying Map.
- getConverterKeyUp() - Method in class com.tangosol.util.ConverterCollections.AbstractConverterEntry
-
Return the Converter to view the underlying Entry's key through.
- getConverterKeyUp() - Method in class com.tangosol.util.ConverterCollections.ConverterEntry
-
Return the Converter to view the underlying Entry's key through.
- getConverterKeyUp() - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet.ConverterEntry
-
Return the Converter to view the underlying Entry's key
through.
- getConverterKeyUp() - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet
-
Return the Converter used to view the underlying Entry Set's keys
through.
- getConverterKeyUp() - Method in class com.tangosol.util.ConverterCollections.ConverterMap
-
Return the Converter used to view the underlying Map's keys
through.
- getConverterKeyUp() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent
-
Return the Converter used to view the underlying MapEvent's key
through.
- getConverterKeyUp() - Method in class com.tangosol.util.ConverterCollections.ConverterMapListener
-
Return the Converter used to view an underlying CacheEvent's key
through.
- getConverterListener(MapListener<? super TK, ? super TV>) - Method in class com.tangosol.util.ConverterCollections.ConverterObservableMap
-
Create a converter listener for the specified listener.
- getConverterUp() - Method in class com.tangosol.util.ConverterCollections.ConverterCollection
-
Return the Converter used to view the underlying Collection's
values through.
- getConverterUp() - Method in class com.tangosol.util.ConverterCollections.ConverterListIterator
-
Return the Converter used to view the underlying ListIterator's
values through.
- getConverterValueDown() - Method in class com.tangosol.util.ConverterCollections.AbstractConverterEntry
-
Return the Converter used to change value in the underlying Entry.
- getConverterValueDown() - Method in class com.tangosol.util.ConverterCollections.ConverterEntry
-
Return the Converter used to change value in the underlying Entry.
- getConverterValueDown() - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet.ConverterEntry
-
Return the Converter used to change value in the underlying
Entry.
- getConverterValueDown() - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet
-
Return the Converter used to pass values down to the underlying
Entry Set.
- getConverterValueDown() - Method in class com.tangosol.util.ConverterCollections.ConverterMap
-
Return the Converter used to pass values down to the underlying
Map.
- getConverterValueUp() - Method in class com.tangosol.util.ConverterCollections.AbstractConverterEntry
-
Return the Converter to view the underlying Entry's value through.
- getConverterValueUp() - Method in class com.tangosol.util.ConverterCollections.ConverterEntry
-
Return the Converter to view the underlying Entry's value through.
- getConverterValueUp() - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet.ConverterEntry
-
Return the Converter to view the underlying Entry's value
through.
- getConverterValueUp() - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet
-
Return the Converter used to view the underlying Entry Set's values
through.
- getConverterValueUp() - Method in class com.tangosol.util.ConverterCollections.ConverterMap
-
Return the Converter used to view the underlying Map's values
through.
- getConverterValueUp() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent
-
Return the Converter used to view the underlying MapEvent's value
through.
- getConverterValueUp() - Method in class com.tangosol.util.ConverterCollections.ConverterMapListener
-
Return the Converter used to view an underlying CacheEvent's value
through.
- getCookie(Class<T>, String) - Method in class com.tangosol.config.xml.DefaultProcessingContext
-
Locates and returns the cookie with the specified type and name.
- getCookie(Class<T>) - Method in class com.tangosol.config.xml.DefaultProcessingContext
-
Locates and returns the cookie with the specified type.
- getCookie(Class<T>, String) - Method in interface com.tangosol.config.xml.ProcessingContext
-
Locates and returns the cookie with the specified type and name.
- getCookie(Class<T>) - Method in interface com.tangosol.config.xml.ProcessingContext
-
Locates and returns the cookie with the specified type.
- getCookie() - Method in class com.tangosol.util.filter.LimitFilter
-
Obtain the cookie object.
- getCoordinatorId() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
Get the node id of the ownership distribution coordinator.
- getCoordinatorId() - Method in interface com.tangosol.net.partition.SimpleStrategyMBean
-
Get the node id of the ownership distribution coordinator.
- getCoordinatorId() - Method in interface com.tangosol.persistence.PersistenceManagerMBean
-
Return the node id of the persistence coordinator.
- getCount() - Method in class com.tangosol.util.UID
-
Determine the "counter" portion of the UID that ensures that two UIDs
generated at the same exact time by the same process are unique.
- getCount() - Method in class com.tangosol.util.UUID
-
Determine the "counter" portion of the UUID that ensures that two UUIDs
generated at the same exact time by the same process are unique.
- getCreatedMillis() - Method in class com.tangosol.net.cache.OldCache.Entry
-
Deprecated.
Determine when the cache entry was created.
- getCreationTime() - Method in class com.tangosol.coherence.jcache.common.JCacheEntryMetaInf
-
Gets the time (since the Epoc) in milliseconds since the internal value
was created.
- getCreationTime() - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheValue
-
Gets the time (since the Epoc) in milliseconds since the internal value
was created.
- getCurrent() - Method in class com.tangosol.coherence.dsltools.precedence.OPScanner
-
Answer the current OPToken.
- getCurrentAsString() - Method in class com.tangosol.coherence.dsltools.precedence.OPScanner
-
Answer the string representation of the current BaseToken.
- getCurrentAsStringWithAdvance() - Method in class com.tangosol.coherence.dsltools.precedence.OPScanner
-
Answer the string representation of the current BaseToken and advance.
- getCurrentBaseToken() - Method in class com.tangosol.coherence.dsltools.precedence.OPScanner
-
Answer the current BaseToken.
- getCurrentBuffer() - Method in class com.tangosol.io.MultiBufferWriteBuffer
-
Obtain the current buffer.
- getCurrentBufferAbsoluteOffset() - Method in class com.tangosol.io.MultiBufferWriteBuffer
-
Determine the offset of the first byte of the current buffer.
- getCurrentBufferRemaining() - Method in class com.tangosol.io.MultiBufferWriteBuffer
-
Determine the maximum number of bytes that can still be written to the
current underlying WriteBuffer.
- getCurrentChar() - Method in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
-
Answer the current char of the underlying Reader
- getCurrentPage() - Method in class com.tangosol.net.cache.SerializationPagedCache.PagedBinaryStore
-
Obtain the page to which current updates are being performed.
- getCurrentPageNumber() - Method in class com.tangosol.net.cache.SerializationPagedCache.PagedBinaryStore
-
Determine the number of pages that the PagedBinaryStore has
managed in total, including those it is currently managing.
- getCurrentPageTime() - Method in class com.tangosol.net.cache.SerializationPagedCache
-
Determine the time that the current page was created.
- getCurrentProvider() - Method in class com.tangosol.net.CompositeAddressProvider.AddressIterator
-
Return the current AddressProvider.
- getCurrentRule() - Method in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy
-
Return the current quorum rule used by the policy.
- getCurrentSubject() - Static method in class com.tangosol.net.security.SecurityHelper
-
Return the Subject from the current security context.
- getCurrentTimeMillis() - Static method in class com.tangosol.coherence.jcache.common.Helper
-
Common method for getting current time to make it easy to change time lookup.
- getCurrentTimeMillis() - Method in class com.tangosol.net.cache.OldCache
-
Deprecated.
- getCurrentToken() - Method in class com.tangosol.coherence.dsltools.base.BaseTokenStream
-
Answer a current BaseToken base on the position of streaming
- getCustomBuilder() - Method in interface com.tangosol.coherence.config.builder.BuilderCustomization
-
- getCustomBuilder() - Method in class com.tangosol.coherence.config.builder.DefaultBuilderCustomization
-
- getCustomBuilder() - Method in class com.tangosol.coherence.config.builder.NamedEventInterceptorBuilder
-
- getCustomBuilder() - Method in class com.tangosol.coherence.config.builder.storemanager.AbstractStoreManagerBuilder
-
- getCustomBuilder() - Method in class com.tangosol.coherence.config.scheme.AbstractLocalCachingScheme
-
- getCustomBuilder() - Method in class com.tangosol.coherence.config.scheme.CacheStoreScheme
-
- getCustomBuilder() - Method in class com.tangosol.coherence.config.scheme.DistributedScheme.BackupConfig
-
- getDaemon() - Method in class com.tangosol.util.Daemon.DaemonWorker
-
- getDaemonActiveCount() - Method in interface com.tangosol.net.ServiceLoad
-
Return the number of daemon threads that are currently processing
messages.
- getDaemonCount() - Method in interface com.tangosol.net.ServiceLoad
-
Return number of daemon threads that are used to process messages.
- getDaemonPool() - Method in class com.tangosol.persistence.AbstractPersistenceEnvironment
-
Return the optional DaemonPool used to execute tasks.
- getDaemonPool() - Method in class com.tangosol.persistence.AbstractPersistenceManager
-
Return the optional DaemonPool used to execute tasks.
- getDataDirectory() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
-
The directory used to store persisted data.
- getDataDirectory() - Method in class com.tangosol.persistence.AbstractPersistenceManager
-
Return the directory used to store persisted data.
- getDatagramSocketProvider(int) - Method in class com.tangosol.coherence.config.builder.SocketProviderBuilder
-
Return an instance of the specified DatagramSocketProvider, creating it if necessary.
- getDatagramSocketProvider(XmlElement, int) - Method in class com.tangosol.net.SocketProviderFactory
-
Deprecated.
- getDatagramSocketProvider(String, SocketProviderFactory.Dependencies, int) - Method in class com.tangosol.net.SocketProviderFactory
-
Return an instance of the specified DatagramSocketProvider, creating it if necessary.
- getDataInput() - Method in class com.tangosol.io.WrapperBufferInput
-
Obtain the underlying object providing the DataInput interface that
this object is delegating to.
- getDataInput() - Method in class com.tangosol.io.WrapperDataInputStream
-
Obtain the underlying object providing the DataInput interface that
this object is delegating to.
- getDataOutput() - Method in class com.tangosol.io.WrapperBufferOutput
-
Obtain the underlying object providing the DataOutput interface that
this object is delegating to.
- getDataOutput() - Method in class com.tangosol.io.WrapperDataOutputStream
-
Obtain the underlying object providing the DataOutput interface that
this object is delegating to.
- getDataOutput() - Static method in class com.tangosol.util.NullImplementation
-
Factory method: Obtain a null implementation of a DataOutput.
- getDataVersion() - Method in class com.tangosol.io.AbstractEvolvable
-
Obtain the version associated with the data stream from which this
object was deserialized.
- getDataVersion() - Method in interface com.tangosol.io.Evolvable
-
Obtain the version associated with the data stream from which this
object was deserialized.
- getDataVersion() - Method in class com.tangosol.io.SimpleEvolvable
-
Obtain the version associated with the data stream from which this
object was deserialized.
- getDate() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Return the Date which this PofValue represents.
- getDate() - Method in interface com.tangosol.io.pof.reflect.PofValue
-
Return the Date which this PofValue represents.
- getDate() - Method in class com.tangosol.run.xml.SimpleValue
-
Get the value as a Date.
- getDate(Date) - Method in class com.tangosol.run.xml.SimpleValue
-
Get the value as a Date.
- getDate() - Method in interface com.tangosol.run.xml.XmlValue
-
Get the value as a Date.
- getDate(Date) - Method in interface com.tangosol.run.xml.XmlValue
-
Get the value as a Date.
- getDateTime() - Method in class com.tangosol.run.xml.SimpleValue
-
Get the value as a Timestamp.
- getDateTime(Timestamp) - Method in class com.tangosol.run.xml.SimpleValue
-
Get the value as a Timestamp.
- getDateTime() - Method in interface com.tangosol.run.xml.XmlValue
-
Get the value as a Timestamp.
- getDateTime(Timestamp) - Method in interface com.tangosol.run.xml.XmlValue
-
Get the value as a Timestamp.
- getDay() - Method in class com.tangosol.io.pof.RawDate
-
Determine the date's day value.
- getDays() - Method in class com.tangosol.io.pof.RawDayTimeInterval
-
Determine the number of days in the day-time interval.
- getDb() - Method in class com.tangosol.io.bdb.BerkeleyDBBinaryStore.DatabaseHolder
-
Get the underlying Database handle.
- getDbConfig() - Method in class com.tangosol.io.bdb.DatabaseFactory
-
Get the DatabaseConfiguration used to create Databases.
- getDbHolder() - Method in class com.tangosol.io.bdb.BerkeleyDBBinaryStore
-
Get the DatabaseHolder.
- getDbIdCounter() - Method in class com.tangosol.io.bdb.DatabaseFactory
-
Get the DB ID Counter value.
- getDecimal() - Method in class com.tangosol.run.xml.SimpleValue
-
Get the value as a decimal.
- getDecimal(BigDecimal) - Method in class com.tangosol.run.xml.SimpleValue
-
Get the value as a decimal.
- getDecimal() - Method in interface com.tangosol.run.xml.XmlValue
-
Get the value as a decimal.
- getDecimal(BigDecimal) - Method in interface com.tangosol.run.xml.XmlValue
-
Get the value as a decimal.
- getDecomposition() - Method in class com.tangosol.util.CacheCollator
-
Get the decomposition mode of this Collator.
- getDecoration(Binary, int) - Static method in class com.tangosol.util.ExternalizableHelper
-
- getDecoration(ReadBuffer, int) - Static method in class com.tangosol.util.ExternalizableHelper
-
Extract and return the specified decoration from the passed ReadBuffer.
- getDecoration() - Method in class com.tangosol.util.ExternalizableHelper.IntDecoratedObject
-
Return the int decoration.
- getDecorations(ReadBuffer) - Static method in class com.tangosol.util.ExternalizableHelper
-
Return an array containing all of the decorations from the passed
ReadBuffer.
- getDeepMessage(Throwable, String) - Static method in class com.tangosol.util.Base
-
Extract a throwable's message, and all causal messages.
- getDefaultClassLoader() - Method in class com.tangosol.coherence.jcache.CoherenceBasedCachingProvider
-
Returns a non-null ClassLoader.
- getDefaultCoherenceBasedConfigurationClassName() - Method in class com.tangosol.coherence.jcache.CoherenceBasedCachingProvider
-
Determines the fully-qualified-class-name of the default
CoherenceBasedConfiguration
class to use when provided
with a JCache
Configuration
.
- getDefaultDatagramSocketProvider(SocketProviderBuilder, int) - Method in class com.tangosol.net.SocketProviderFactory
-
Return an instance of the specified DatagramSocketProvider, creating it if necessary.
- getDefaultDirectory() - Static method in class com.tangosol.io.AbstractBinaryStore
-
Obtain a File object for the default directory to use for file storage.
- getDefaultDomain() - Static method in class com.tangosol.net.management.MBeanHelper
-
Return the the default domain name as configured in the Coherence
operational configuration descriptor ("default-domain-name" element).
- getDefaultGuardRecovery() - Method in interface com.tangosol.net.Guardian
-
Default recovery percentage for Guardables monitored by this Guardian.
- getDefaultGuardTimeout() - Method in interface com.tangosol.net.Guardian
-
Default timeout interval (in milliseconds) for Guardables monitored by
this Guardian.
- getDefaultLoadBalancer() - Method in class com.tangosol.coherence.config.builder.InvalidConfigServiceLoadBalancerBuilder
-
- getDefaultLoadBalancer() - Method in class com.tangosol.coherence.config.builder.ProxyServiceLoadBalancerBuilder
-
- getDefaultLoadBalancer() - Method in class com.tangosol.coherence.config.builder.ServiceLoadBalancerBuilder
-
- getDefaultName(String, Filter, ValueExtractor) - Static method in class com.tangosol.net.cache.ContinuousQueryCache
-
Return the default name used by the CQC.
- getDefaultNamespaceHandler() - Method in class com.tangosol.config.xml.DocumentProcessor.DefaultDependencies
-
- getDefaultNamespaceHandler() - Method in interface com.tangosol.config.xml.DocumentProcessor.Dependencies
-
- getDefaultParameterResolver() - Method in class com.tangosol.coherence.config.CacheConfig
-
Obtain the
ParameterResolver
to use for the
CacheConfig
when no other is available or in context.
- getDefaultParameterResolver() - Method in class com.tangosol.coherence.config.scheme.AbstractCachingScheme
-
Obtains the ParameterResolver to use when resolving parameters
without one being available in a context.
- getDefaultParameterResolver() - Method in class com.tangosol.config.xml.DefaultProcessingContext
-
Obtains the ParameterResolver
to use for resolving parameters
defined externally to the document being processed (ie: the
operating system or container)
- getDefaultParameterResolver() - Method in class com.tangosol.config.xml.DocumentProcessor.DefaultDependencies
-
Obtains the default ParameterResolver
that may be used for
resolving externally defined configuration parameters, like those
from the operating system or container.
- getDefaultParameterResolver() - Method in interface com.tangosol.config.xml.DocumentProcessor.Dependencies
-
Obtains the default ParameterResolver
that may be used for
resolving externally defined configuration parameters, like those
from the operating system or container.
- getDefaultParameterResolver() - Method in interface com.tangosol.config.xml.ProcessingContext
-
Obtains the ParameterResolver
to use for resolving parameters
defined externally to the document being processed (ie: the
operating system or container)
- getDefaultPersistenceEnvironmentHomeDirectory() - Static method in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder
-
Return the default 'base' persistence directory.
- getDefaultProperties() - Method in class com.tangosol.coherence.jcache.CoherenceBasedCachingProvider
-
- getDefaultServiceName() - Method in class com.tangosol.coherence.config.scheme.AbstractServiceScheme
-
DefaultServiceName to use if none configured.
- getDefaultServiceName() - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
-
DefaultServiceName to use if none configured.
- getDefaultURI() - Method in class com.tangosol.coherence.jcache.CoherenceBasedCachingProvider
-
- getDeferredList() - Method in class com.tangosol.net.cache.OverflowMap
-
Obtain the List of keys that may have deferred events.
- getDeferredList() - Method in class com.tangosol.net.cache.SimpleOverflowMap
-
Obtain the List of keys that may have deferred events.
- getDelayMillis(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.BundleManager.BundleConfig
-
Specifies the maximum amount of time that individual execution
requests are allowed to be deferred for a purpose of "bundling"
them and passing into a corresponding bulk operation.
- getDelayMillis() - Method in class com.tangosol.net.cache.AbstractBundler
-
Obtain the timeout delay value.
- getDelayMillis() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.WriteQueue
-
- getDelaySeconds() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.WriteQueue
-
- getDelegate() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperCollection
-
Return the Collection to which all operations should be delegated to.
- getDelegate() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperEntry
-
Return the Map to which all operations should be delegated to.
- getDelegate() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperIterator
-
Return the Iterator to which all operations should be delegated to.
- getDelegate() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperList
-
Return the List to which all operations should be delegated to.
- getDelegate() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperListIterator
-
Return the Iterator to which all operations should be delegated to.
- getDelegate() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperMap
-
Return the Map to which all operations should be delegated to.
- getDelegate() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperSet
-
Return the Set to which all operations should be delegated to.
- getDelegate() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperSortedMap
-
Return the Map to which all operations should be delegated to.
- getDelegate() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperSortedSet
-
Return the SortedSet to which all operations should be delegated to.
- getDelegate() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperCollection
-
Return the Collection to which all operations should be delegated to.
- getDelegate() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperEntry
-
Return the Collection to which all operations should be delegated to.
- getDelegate() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
-
Return the Map to which all operations should be delegated to.
- getDelegate() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperSet
-
Return the Set to which all operations should be delegated to.
- getDelegateSocketProvider() - Method in class com.tangosol.net.TcpDatagramSocketProvider.DefaultDependencies
-
Return the SocketProvider to use in producing the underling sockets
which will be wrapped with DatagramSocket.
- getDelegateSocketProvider() - Method in interface com.tangosol.net.TcpDatagramSocketProvider.Dependencies
-
Return the SocketProvider to use in producing the underling sockets
which will be wrapped with DatagramSocket.
- getDelta() - Method in class com.tangosol.io.pof.PofDeltaCompressor.ChangeTracker
-
Obtain the final delta result as a Binary value.
- getDeltaCompressor(Serializer, DeltaCompressor) - Static method in class com.tangosol.util.ExternalizableHelper
-
Return a DeltaCompressor suitable for compressing/extracting binaries
produced by ExternalizableHelper using the specified serializer.
- getDeltaCompressor() - Static method in class com.tangosol.util.NullImplementation
-
Factory method: Obtain a null implementation of a DeltaCompressor.
- getDemultiplexedSocketProvider(int) - Method in class com.tangosol.coherence.config.builder.SocketProviderBuilder
-
Return a Demultiplexed Socket provider
- getDemultiplexedSocketProvider(XmlElement, int) - Method in class com.tangosol.net.SocketProviderFactory
-
Deprecated.
- getDemultiplexedSocketProvider(String, SocketProviderFactory.Dependencies, int) - Method in class com.tangosol.net.SocketProviderFactory
-
Return a Demultiplexed Socket provider
- getDemultiplexedSocketProvider(SocketProviderBuilder, int) - Method in class com.tangosol.net.SocketProviderFactory
-
Return a Demultiplexed Socket provider
- getDependencies() - Method in class com.tangosol.coherence.config.builder.SocketProviderBuilder
-
Return either an anonymous SocketProviderFactory dependencies for an inlined socket-provider or
the global SocketProviderFactory dependencies initialized from cluster socket-providers definitions.
- getDependencies() - Method in class com.tangosol.config.xml.DefaultProcessingContext
-
- getDependencies() - Method in interface com.tangosol.net.Cluster
-
Retrieve the Cluster configuration.
- getDependencies() - Method in interface com.tangosol.net.Service
-
Return the service's dependencies.
- getDependencies() - Method in class com.tangosol.net.SocketProviderFactory
-
Get SocketProviderDependencies object
- getDependencies() - Method in class com.tangosol.net.WrapperService
-
Return the service's dependencies.
- getDepth() - Method in class com.tangosol.io.pof.LoggingPofHandler
-
Determine the current nested data structure depth within the POF
stream.
- getDerivedName(Class, String) - Static method in class com.tangosol.util.ClassHelper
-
Build the name of a "derived" class based on an existing class and a
"derived" class prefix.
- getDerivedName(String, String) - Static method in class com.tangosol.util.ClassHelper
-
Build the name of a "derived" class based on the name of an existing
class and a "derived" class prefix.
- getDescription() - Method in class com.tangosol.coherence.dslquery.queryplus.CommandsStatementBuilder
-
- getDescription() - Method in class com.tangosol.coherence.dslquery.queryplus.ExtendedLanguageStatementBuilder
-
- getDescription() - Method in class com.tangosol.coherence.dslquery.queryplus.HelpStatementBuilder
-
- getDescription() - Method in class com.tangosol.coherence.dslquery.queryplus.SanityCheckStatementBuilder
-
- getDescription() - Method in class com.tangosol.coherence.dslquery.queryplus.ServicesStatementBuilder
-
- getDescription() - Method in class com.tangosol.coherence.dslquery.queryplus.SetTimeoutStatementBuilder
-
- getDescription() - Method in class com.tangosol.coherence.dslquery.queryplus.TraceStatementBuilder
-
- getDescription() - Method in class com.tangosol.coherence.dslquery.queryplus.WheneverStatementBuilder
-
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.BackupStatementBuilder
-
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.CreateCacheStatementBuilder
-
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.CreateIndexStatementBuilder
-
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.DeleteStatementBuilder
-
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.DropCacheStatementBuilder
-
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.DropIndexStatementBuilder
-
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.InsertStatementBuilder
-
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.persistence.ArchiveSnapshotStatementBuilder
-
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.persistence.CreateSnapshotStatementBuilder
-
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.persistence.ForceRecoveryStatementBuilder
-
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.persistence.ListArchiverStatementBuilder
-
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.persistence.ListServicesStatementBuilder
-
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.persistence.ListSnapshotsStatementBuilder
-
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.persistence.RecoverSnapshotStatementBuilder
-
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.persistence.RemoveSnapshotStatementBuilder
-
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.persistence.ResumeServiceStatementBuilder
-
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.persistence.RetrieveSnapshotStatementBuilder
-
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.persistence.SuspendServiceStatementBuilder
-
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.persistence.ValidateSnapshotStatementBuilder
-
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.QueryRecorderStatementBuilder
-
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.RestoreStatementBuilder
-
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.SelectStatementBuilder
-
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.SourceStatementBuilder
-
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.TruncateCacheStatementBuilder
-
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.UpdateStatementBuilder
-
- getDescription() - Method in interface com.tangosol.coherence.dslquery.StatementBuilder
-
Return a description of the CohQL command suitable for displaying
as help text.
- getDescription() - Method in class com.tangosol.net.cache.AbstractSerializationCache
-
Assemble a human-readable description.
- getDescription() - Method in class com.tangosol.net.cache.CacheEvent
-
Get the event's description.
- getDescription() - Method in class com.tangosol.net.cache.OverflowMap.ExpirableStatus
-
Assemble a human-readable description.
- getDescription() - Method in class com.tangosol.net.cache.OverflowMap.Status
-
Assemble a human-readable description.
- getDescription() - Method in class com.tangosol.net.cache.SerializationCache
-
Assemble a human-readable description.
- getDescription() - Method in class com.tangosol.net.cache.SerializationMap
-
Assemble a human-readable description.
- getDescription() - Method in class com.tangosol.net.cache.SerializationPagedCache
-
Assemble a human-readable description.
- getDescription() - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
-
Assemble a human-readable description.
- getDescription(MBeanInfo) - Method in class com.tangosol.net.management.AnnotatedStandardEmitterMBean
-
Retrieve the description for the MBean from the MBean interface annotation.
- getDescription(MBeanOperationInfo) - Method in class com.tangosol.net.management.AnnotatedStandardEmitterMBean
-
- getDescription(MBeanAttributeInfo) - Method in class com.tangosol.net.management.AnnotatedStandardEmitterMBean
-
Retrieve a description for a particular attribute by finding a
Description
annotation on the getter method for the attribute.
- getDescription(MBeanInfo) - Method in class com.tangosol.net.management.AnnotatedStandardMBean
-
Retrieve the description for the MBean from the MBean interface annotation.
- getDescription(MBeanOperationInfo) - Method in class com.tangosol.net.management.AnnotatedStandardMBean
-
- getDescription(MBeanAttributeInfo) - Method in class com.tangosol.net.management.AnnotatedStandardMBean
-
Retrieve a description for a particular attribute by finding a
Description
annotation on the getter method for the attribute.
- getDescription(Class<?>, MBeanInfo) - Static method in class com.tangosol.net.management.MBeanHelper
-
Retrieve the description for the MBean from the MBean interface annotation.
- getDescription(Class, MBeanAttributeInfo) - Static method in class com.tangosol.net.management.MBeanHelper
-
Retrieve a description for a particular attribute by finding a
Description
annotation on the getter method for the attribute.
- getDescription(Class, MBeanOperationInfo) - Static method in class com.tangosol.net.management.MBeanHelper
-
- getDescription() - Method in class com.tangosol.net.partition.MirroringAssignmentStrategy
-
Return a human-readable description of the state of the partition
assignment.
- getDescription() - Method in class com.tangosol.net.partition.Ownership
-
Return a human-readable description of this Ownership.
- getDescription() - Method in interface com.tangosol.net.partition.PartitionAssignmentStrategy
-
Return a human-readable description of the state of the partition
assignment.
- getDescription() - Method in class com.tangosol.net.partition.PartitionEvent
-
Get the event's description.
- getDescription(int) - Static method in class com.tangosol.net.partition.PartitionEvent
-
Convert an event ID into a human-readable string.
- getDescription() - Method in class com.tangosol.net.partition.PartitionStatistics
-
Return a human-readable description of this statistics object.
- getDescription() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.BackupStrength
-
Return a human-readable description string of this backup-strength.
- getDescription() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
Return a human-readable description of the state of the partition
assignment.
- getDescription() - Method in class com.tangosol.net.partition.VersionedOwnership
-
Return a human-readable description of this Ownership.
- getDescription() - Method in interface com.tangosol.net.ThreadPoolSizingStrategy
-
Return a human-readable description of the state of the
ThreadPoolSizingStrategy.
- getDescription() - Method in class com.tangosol.util.Daemon
-
Format the Daemon attributes into a String for inclusion in the String
returned from the
Daemon.toString()
method.
- getDescription() - Method in class com.tangosol.util.filter.CacheEventFilter
-
Get the filter's description.
- getDescription() - Method in class com.tangosol.util.filter.MapEventFilter
-
Get the filter's description.
- getDescription() - Method in class com.tangosol.util.MapEvent
-
Get the event's description.
- getDescription(int) - Static method in class com.tangosol.util.MapEvent
-
Convert an event ID into a human-readable string.
- getDescription() - Method in class com.tangosol.util.MapListenerSupport.FilterEvent
-
Get the event's description.
- getDescription() - Method in class com.tangosol.util.NullImplementation.NullPartitionAssignmentStrategy
-
Return a human-readable description of the state of the partition
assignment.
- getDescription() - Method in class com.tangosol.util.processor.NumberIncrementor
-
Returns this PropertyProcessor's description.
- getDescription() - Method in class com.tangosol.util.processor.NumberMultiplier
-
Returns this PropertyProcessor's description.
- getDescription() - Method in class com.tangosol.util.processor.PropertyProcessor
-
Returns this PropertyProcessor's description.
- getDescription() - Method in class com.tangosol.util.SafeSortedMap.IndexNode
-
Return a human-readable description of this SkipNode.
- getDescription() - Method in class com.tangosol.util.TaskDaemon
-
Format the Daemon attributes into a String for inclusion in the String
returned from the
Daemon.toString()
method.
- getDescription() - Method in class com.tangosol.util.WrapperConcurrentMap
-
Assemble a human-readable description.
- getDescription() - Method in class com.tangosol.util.WrapperObservableMap
-
Assemble a human-readable description.
- getDesiredState(S, ExecutionContext) - Method in interface com.tangosol.util.fsm.Event
-
- getDesiredState(S, ExecutionContext) - Method in class com.tangosol.util.fsm.Instruction.TransitionTo
-
- getDesiredState(S, ExecutionContext) - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.CoalescedEvent
-
- getDesiredState(S, ExecutionContext) - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.DelayedTransitionTo
-
- getDesiredState(S, ExecutionContext) - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.SubsequentEvent
-
- getDestination(int) - Method in class com.tangosol.net.LoadBalancer
-
Determine one of the AddressPort combinations that the load balancer
balances requests to.
- getDestinationCount() - Method in class com.tangosol.net.LoadBalancer
-
Determine the number of AddressPort combinations that the load balancer
balances requests to.
- getDestructiveBufferInput() - Method in class com.tangosol.io.MultiBufferReadBuffer
-
Return a self-destructing BufferInput over this Buffer.
- getDirectory(ParameterResolver) - Method in class com.tangosol.coherence.config.builder.storemanager.BdbStoreManagerBuilder
-
Return the path name for the root directory that the BDB file manager
uses to store files in.
- getDirectory(ParameterResolver) - Method in class com.tangosol.coherence.config.builder.storemanager.NioFileManagerBuilder
-
Return the path name for the root directory that the manager uses to
store files in.
- getDirectory(ParameterResolver) - Method in interface com.tangosol.coherence.config.scheme.BackupMapConfig
-
Return the root directory where the disk persistence manager stores files.
- getDirectory(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.DistributedScheme.BackupConfig
-
Return the root directory where the disk persistence manager stores files.
- getDirectory() - Method in class com.tangosol.io.nio.MappedStoreManager
-
Obtain the directory to use for MappedBufferManager(s).
- getDirectQuery() - Method in class com.tangosol.coherence.rest.config.QueryConfig
-
Return the direct query.
- getDirectStorageSize() - Method in class com.tangosol.net.partition.PartitionStatistics
-
Return the partition size from partitioned maps.
- getDirEnv() - Method in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
-
Get the Environment Directory.
- getDirLock() - Method in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
-
Get the DirectoryLock held on a temporary Environment.
- getDirParent() - Method in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
-
Get the Parent Directory.
- getDirtyBytesCount() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Get the estimated number of dirty bytes in this POF value hierarchy.
- getDiscoveryInterface() - Method in interface com.tangosol.net.OperationalContext
-
Return the IP associated with the network interface to use for multicast based discovery.
- getDiscoveryTimeToLive() - Method in interface com.tangosol.net.OperationalContext
-
Return the TTL for multicast based discovery.
- getDispatcher() - Method in interface com.tangosol.net.events.Event
-
- getDispatcher() - Method in interface com.tangosol.net.events.partition.cache.Event
-
- getDispatcher() - Method in interface com.tangosol.net.events.partition.Event
-
- getDistance(Member) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.StrengthComparator
-
Return the "distance" of the specified member from the reference
ownership.
- getDistance(Member, Member) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.StrengthComparator
-
Return the "distance" between the specified members.
- getDistinctValues() - Method in class com.tangosol.coherence.dslquery.internal.SelectListMaker
-
Turn the results of tree processing into a DistinctValues aggregator
- getDistributedCache(String, ClassLoader) - Method in class com.tangosol.run.jca.CacheAdapter
-
- getDistributedCacheConfig() - Static method in class com.tangosol.net.CacheFactory
-
Return the default distributed (partitioned) cache configuration.
- getDocumentComment() - Method in class com.tangosol.run.xml.SimpleDocument
-
Get the XML comment that appears outside of the root element.
- getDocumentComment() - Method in interface com.tangosol.run.xml.XmlDocument
-
Get the XML comment that appears outside of the root element.
- getDocumentPreprocessor() - Method in class com.tangosol.config.xml.AbstractNamespaceHandler
-
- getDocumentPreprocessor() - Method in interface com.tangosol.config.xml.NamespaceHandler
-
- getDomainName() - Method in interface com.tangosol.net.management.Registry
-
Domain name for managed beans registered by Coherence clustered services.
- getDomainPartitions() - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
-
- getDomainPartitions() - Method in interface com.tangosol.coherence.dslquery.QueryPlus.Dependencies
-
Return the optional array of domain partition names
to use if loading a GAR file.
- getDouble(String) - Static method in class com.tangosol.coherence.config.Config
-
Return Coherence system property value as a Double.
- getDouble(String, double) - Static method in class com.tangosol.coherence.config.Config
-
Return Coherence system property value as a double.
- getDouble() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Return the double which this PofValue represents.
- getDouble() - Method in interface com.tangosol.io.pof.reflect.PofValue
-
Return the double which this PofValue represents.
- getDouble() - Method in class com.tangosol.run.xml.SimpleValue
-
Get the value as a double.
- getDouble(double) - Method in class com.tangosol.run.xml.SimpleValue
-
Get the value as a double.
- getDouble() - Method in interface com.tangosol.run.xml.XmlValue
-
Get the value as a double.
- getDouble(double) - Method in interface com.tangosol.run.xml.XmlValue
-
Get the value as a double.
- getDoubleArray() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Return the double[] which this PofValue represents.
- getDoubleArray() - Method in interface com.tangosol.io.pof.reflect.PofValue
-
Return the double[] which this PofValue represents.
- getDtdName() - Method in class com.tangosol.run.xml.SimpleDocument
-
Get the public identifier of the DTD (DOCTYPE) for the document.
- getDtdName() - Method in interface com.tangosol.run.xml.XmlDocument
-
Get the public identifier of the DTD (DOCTYPE) for the document.
- getDtdUri() - Method in class com.tangosol.run.xml.SimpleDocument
-
Get the URI of the DTD (DOCTYPE) for the document.
- getDtdUri() - Method in interface com.tangosol.run.xml.XmlDocument
-
Get the URI of the DTD (DOCTYPE) for the document.
- getDuration(String) - Static method in class com.tangosol.coherence.config.Config
-
Return Coherence system property value as a Duration
.
- getDuration(String, Duration) - Static method in class com.tangosol.coherence.config.Config
-
Return Coherence system property value as a Duration
.
- getDuration() - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.DelayedTransitionTo
-
Obtains the amount of time to wait before the transition to the
desired state should occur
- getDuration() - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.ProcessEventLater
-
Obtains the amount of time to wait before the transition to the
desired state should occur.
- getDuration() - Method in interface com.tangosol.util.QueryRecord.PartialResult.Step
-
Get the amount of time (in ms) spent evaluating the filter or
applying an index for this query plan step.
- getDuration() - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.Step
-
Get the amount of time (in ms) spent evaluating the filter or
applying an index for this query plan step.
- getEdition() - Static method in class com.tangosol.net.CacheFactory
-
Returns the edition currently loaded based on the operational
configuration.
- getEdition() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the Coherence product edition.
- getEdition() - Method in interface com.tangosol.net.OperationalContext
-
Get the product edition.
- getEditionName() - Method in interface com.tangosol.net.OperationalContext
-
Get the product edition in a formatted string.
- getEfficiency() - Method in interface com.tangosol.util.QueryRecord.PartialResult.Step
-
- getEfficiency() - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.Step
-
- getElement(String) - Method in class com.tangosol.run.xml.SimpleElement
-
Get a child element.
- getElement(String) - Method in interface com.tangosol.run.xml.XmlElement
-
Get a child element.
- getElement(XmlElement, String) - Static method in class com.tangosol.run.xml.XmlHelper
-
Get a child element for the specified element.
- getElement(XmlElement, String, String) - Static method in class com.tangosol.run.xml.XmlHelper
-
Get a child element of the specified XmlElement that matches
to the specified local name and the specified Namespace URI.
- getElement(int) - Method in class com.tangosol.util.OpenHashSet
-
Expose the indexed element storage to sub-classes in a range-unsafe
manner.
- getElementAdapter() - Method in class com.tangosol.run.xml.CollectionAdapter
-
- getElementCount() - Method in class com.tangosol.io.pof.ValidatingPofHandler.Complex
-
Obtain the total element count.
- getElementList() - Method in class com.tangosol.run.xml.SimpleElement
-
Get the list of all child elements.
- getElementList() - Method in interface com.tangosol.run.xml.XmlElement
-
Get the list of all child elements.
- getElementName() - Method in enum com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy.ActionRule
-
- getElementName() - Method in class com.tangosol.run.xml.IterableAdapter
-
- getElementProcessor(XmlElement) - Method in class com.tangosol.config.xml.AbstractNamespaceHandler
-
- getElementProcessor(String) - Method in class com.tangosol.config.xml.AbstractNamespaceHandler
-
Obtains the
ElementProcessor
registered with the specified
localName (in the namespace).
- getElementProcessor(XmlElement) - Method in interface com.tangosol.config.xml.NamespaceHandler
-
- getElements(XmlElement) - Method in class com.tangosol.run.xml.PropertyAdapter
-
Get an iterator of child elements of the specified XmlElement
that represent values for a property represented by this adapter.
- getElements(String) - Method in class com.tangosol.run.xml.SimpleElement
-
Get an iterator of child elements that have a specific name.
- getElements(String) - Method in interface com.tangosol.run.xml.XmlElement
-
Get an iterator of child elements that have a specific name.
- getElements(XmlElement, String, String) - Static method in class com.tangosol.run.xml.XmlHelper
-
Get an iterator of child elements of the specified XmlElement that
match to the specified local name and the specified Namespace URI.
- getEncodedHash() - Method in class com.tangosol.io.AbstractReadBuffer
-
- getEncodedHash() - Method in interface com.tangosol.util.HashEncoded
-
- getEncoding() - Method in class com.tangosol.run.xml.SimpleDocument
-
Get the encoding string for the XML document.
- getEncoding() - Method in interface com.tangosol.run.xml.XmlDocument
-
Get the encoding string for the XML document.
- getEndingState() - Method in class com.tangosol.util.fsm.Transition
-
- getEntries(int, int, String, PropertySet, String) - Method in class com.tangosol.coherence.rest.CacheResource
-
Return the cache entries that satisfy the given query criteria.
- getEntries(PropertySet) - Method in class com.tangosol.coherence.rest.EntrySetResource
-
- getEntries(UriInfo, int, int, String, PropertySet) - Method in class com.tangosol.coherence.rest.NamedQueryResource
-
Return the cache entries that satisfy criteria defined by
this resource.
- getEntries() - Method in interface com.tangosol.net.events.partition.TransferEvent
-
Return a map of cache names and associated set of read-only
entries
encapsulated in this
TransferEvent
.
- getEntry(MapEvent) - Method in class com.tangosol.net.cache.AbstractEvictionPolicy
-
Return the map entry associated with the given map event.
- getEntry(Object) - Method in class com.tangosol.net.cache.LocalCache
-
Locate an Entry in the hash map based on its key.
- getEntry(Object) - Method in class com.tangosol.net.cache.OldCache
-
Deprecated.
Locate an Entry in the hash map based on its key.
- getEntry() - Method in class com.tangosol.util.ConverterCollections.AbstractConverterEntry
-
Return the underlying Map.Entry.
- getEntry() - Method in class com.tangosol.util.ConverterCollections.ConverterCacheEntry
-
Return the underlying Map.Entry.
- getEntry(Map.Entry<FK, FV>, Converter<FK, TK>, Converter<FV, TV>, Converter<TV, FV>) - Static method in class com.tangosol.util.ConverterCollections
-
Returns an instance of a MapEntry that uses Converters to retrieve
the Entry's data.
- getEntry(Object) - Method in class com.tangosol.util.SafeHashMap
-
Locate an Entry in the hash map based on its key.
- getEntry(Object) - Method in class com.tangosol.util.SafeSortedMap
-
Locate a Map.Entry in this map based on its key.
- getEntry(Object) - Method in class com.tangosol.util.SegmentedHashMap
-
Locate an Entry in the this map based on its key.
- GetEntryAction() - Constructor for class com.tangosol.util.SegmentedHashMap.GetEntryAction
-
- getEntryBlockCount() - Method in class com.tangosol.io.nio.BinaryMap
-
Returns the number of entry blocks.
- getEntryEventsMap(TransactionEvent) - Static method in class com.tangosol.net.events.EventHelper
-
- getEntryEventsMap(UnsolicitedCommitEvent) - Static method in class com.tangosol.net.events.EventHelper
-
- getEntryEventsMap(Set<BinaryEntry>, boolean) - Static method in class com.tangosol.net.events.EventHelper
-
Converts the provided set of
entries
into a map keyed
by
EntryEvent
and with a value of a Set of entries.
- getEntryInternal(Object) - Method in class com.tangosol.net.cache.OldCache
-
Deprecated.
Locate an Entry in the hash map based on its key.
- getEntryInternal(Object) - Method in class com.tangosol.util.SafeHashMap
-
Locate an Entry in the hash map based on its key.
- getEntryInternal(Object) - Method in class com.tangosol.util.SegmentedHashMap
-
Locate an Entry in the hash map based on its key.
- getEntryInternal(Object, boolean) - Method in class com.tangosol.util.SegmentedHashMap
-
Locate an Entry in the hash map based on its key.
- getEntryMap() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.WriteQueue
-
Return a map of items queued to be written.
- getEntryNode() - Method in class com.tangosol.util.SafeSortedMap.SkipNode
-
Return the EntryNode below this one in the skip-list.
- getEntryOrQueryResource(String) - Method in class com.tangosol.coherence.rest.CacheResource
-
Return a REST sub-resource representing either a configured named query
or a single cache entry.
- getEntryProcessor() - Static method in class com.tangosol.util.NullImplementation
-
Factory method: Obtain a null implementation of an EntryProcessor.
- getEntrySet() - Method in interface com.tangosol.net.events.partition.cache.EntryEvent
-
Return the immutable Set of
entries
on which the
action represented by this
EntryEvent
occurred.
- getEntrySet() - Method in interface com.tangosol.net.events.partition.cache.EntryProcessorEvent
-
Return a Set of
entries
being processed by the
entry processor.
- getEntrySet() - Method in interface com.tangosol.net.events.partition.TransactionEvent
-
A set of
entries
enlisted within this
transaction.
- getEntrySet() - Method in interface com.tangosol.net.events.partition.UnsolicitedCommitEvent
-
A set of
entries
observed to have been modified
without being caused by the partitioned service.
- getEntrySet() - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet
-
Return the underlying Entry Set.
- getEntrySet(Collection<Map.Entry<FK, FV>>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Static method in class com.tangosol.util.ConverterCollections
-
Returns a Converter instance of a Set that holds Entry objects for a
ConverterMap.
- getEntrySet(Set, Class, Class) - Static method in class com.tangosol.util.RestrictedCollections
-
Returns a restricted instance of Set that holds Entry objects for a
RestrictedMap.
- getEntrySetResource(String) - Method in class com.tangosol.coherence.rest.CacheResource
-
Return a REST sub-resource representing a set of cache entries.
- getEntrySize() - Method in class com.tangosol.net.cache.SimpleMemoryCalculator
-
Return the size of a map entry.
- getEntrySize() - Method in class com.tangosol.util.SimpleMapIndex.IndexCalculator
-
Return the size of a map entry.
- getEnumeration() - Static method in class com.tangosol.util.NullImplementation
-
Returns an instance of the null enumerator.
- getenv(String) - Static method in class com.tangosol.coherence.config.Config
-
- getEnv(String) - Method in class com.tangosol.coherence.config.EnvironmentVariableResolver.Default
-
- getEnv(String) - Method in interface com.tangosol.coherence.config.EnvironmentVariableResolver
-
Return the value of the specified environment variable.
- getEnv(String, String) - Method in interface com.tangosol.coherence.config.EnvironmentVariableResolver
-
Return the value of the specified environment variable, or the specified
default value if the variable doesn't exist.
- getEnvConfig() - Method in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
-
Get the Environment Configuration.
- getEnvHolder() - Method in class com.tangosol.io.bdb.DatabaseFactory
-
Get the EnvironmentHolder.
- getEnvironment() - Method in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
-
Get underlying Berkeley DB Environment.
- getEnvironment() - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceEnvironment
-
Return the underlying PersistenceEnvironment.
- getEnvironmentContinuation(PersistenceEnvironment<R>) - Method in interface com.tangosol.persistence.SafePersistenceWrappers.FailureContinuationFactory
-
Return a failure continuation to handle unexpected exceptions thrown
by operations against the specified PersistenceEnvironment.
- getEnvironmentInfo(ExtensibleConfigurableCacheFactory, String) - Static method in class com.tangosol.persistence.CachePersistenceHelper
-
- getEraseBundler() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
Obtain the bundler for the "erase" operations.
- getEraseFailures() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
Determine the number of erase() failures.
- getEraseMillis() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
Determine the cumulative time spent on erase() operations.
- getEraseOps() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
Determine the number of erase() operations.
- getErr() - Static method in class com.tangosol.util.Base
-
Obtains the current writer used for tracing.
- getErrorCount() - Method in class com.tangosol.run.xml.SaxParser.ValidationHandler
-
Returns the number of Errors encountered.
- getEscapeChar() - Method in class com.tangosol.util.filter.LikeFilter
-
Obtain the escape character that is used for escaping '%' and '_' in
the pattern or zero if there is no escape.
- getEvent() - Method in class com.tangosol.util.fsm.Instruction.ProcessEvent
-
Obtain the
Event
to process.
- getEvent() - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.ProcessEventLater
-
Obtain the
Event
to process later.
- getEventDispatcherThreadPriority() - Method in interface com.tangosol.net.ServiceDependencies
-
Obtain the priority of the event dispatcher thread.
- getEventInterceptor(String) - Method in interface com.tangosol.net.events.InterceptorRegistry
-
- getEventInterceptorBuilders() - Method in class com.tangosol.coherence.config.CacheConfig
-
- getEventInterceptorBuilders() - Method in class com.tangosol.coherence.config.ResourceMapping
-
- getEventInterceptorBuilders() - Method in class com.tangosol.coherence.config.scheme.AbstractLocalCachingScheme
-
- getEventInterceptorBuilders() - Method in class com.tangosol.coherence.config.scheme.AbstractServiceScheme
-
- getEventInterceptorBuilders() - Method in class com.tangosol.coherence.config.scheme.ClassScheme
-
- getEventInterceptorBuilders() - Method in class com.tangosol.coherence.config.scheme.DistributedScheme
-
- getEventInterceptorBuilders() - Method in interface com.tangosol.coherence.config.scheme.ServiceScheme
-
- getEventInterceptorBuilders() - Method in class com.tangosol.coherence.config.scheme.WrapperCachingScheme
-
- getEventListeners() - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheAsynchronousMapListener
-
Iterable over asynchronous CacheEntryListenerRegistrations
- getEventListeners() - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheSynchronousMapListener
-
- getEventListeners() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheAsynchronousMapListener
-
get JCache registered CacheEntryListenerRegistrations.
- getEventListeners() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheSynchronousMapListener
-
Iterate over synchronous JCache CacheEntry Listener Registrations.
- getEventMask() - Method in class com.tangosol.util.filter.MapEventFilter
-
Obtain the event mask.
- getEventQueue() - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
Obtain this ContinuousQueryCache
's event queue.
- getEventTypes() - Method in interface com.tangosol.net.events.EventDispatcher.InterceptorRegistrationEvent
-
- getEvictionApprover() - Method in interface com.tangosol.net.cache.ConfigurableCacheMap
-
Obtain the registered EvictionApprover.
- getEvictionApprover() - Method in class com.tangosol.net.cache.OldCache
-
Deprecated.
Obtain the registered EvictionApprover.
- getEvictionApprover() - Method in class com.tangosol.net.cache.SerializationCache
-
Obtain the registered EvictionApprover.
- getEvictionApprover() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
-
Obtain the registered EvictionApprover.
- getEvictionPolicy() - Method in interface com.tangosol.net.cache.ConfigurableCacheMap
-
Obtain the current EvictionPolicy used by the cache.
- getEvictionPolicy() - Method in class com.tangosol.net.cache.OldCache
-
Deprecated.
Obtain the current EvictionPolicy used by the cache.
- getEvictionPolicy() - Method in class com.tangosol.net.cache.SerializationCache
-
Obtain the current EvictionPolicy used by the cache.
- getEvictionPolicy() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
-
Obtain the current EvictionPolicy used by the cache.
- getEvictionPolicyBuilder() - Method in class com.tangosol.coherence.config.scheme.AbstractJournalScheme
-
Return the EvictionPolicyBuilder used to build an EvictionPolicy.
- getEvictionPolicyBuilder() - Method in class com.tangosol.coherence.config.scheme.LocalScheme
-
Return the EvictionPolicyBuilder used to build an EvictionPolicy.
- getEvictionType(ParameterResolver) - Method in class com.tangosol.coherence.config.builder.EvictionPolicyBuilder
-
Obtains the EvictionPolicy type.
- getEvictionType() - Method in class com.tangosol.net.cache.OldCache
-
Deprecated.
Determine the current eviction type.
- getEvictionType() - Method in class com.tangosol.net.cache.OldCache.InternalEvictionPolicy
-
Deprecated.
Determine the OldCache eviction type represented by this
InternalEvictionPolicy.
- getEvolvable(int) - Method in interface com.tangosol.io.pof.EvolvableObject
-
Return
Evolvable
object for the specified type id.
- getEvolvableHolder() - Method in interface com.tangosol.io.pof.EvolvableObject
-
Return
EvolvableHolder
that should be used to store information
about evolvable objects that are not known during deserialization.
- getException() - Method in class com.tangosol.net.cache.ContinuousQueryCache.ConverterAsynchronousProcessor
-
- getException() - Method in class com.tangosol.run.xml.SaxParser.ValidationHandler
-
Returns a saved parser exception.
- getException() - Method in class com.tangosol.util.AsynchronousAgent
-
Helper method that returns an exception (if completed exceptionally).
- getExecutionConfirmation(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.queryplus.AbstractQueryPlusStatementBuilder.AbstractStatement
-
- getExecutionConfirmation(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.AbstractStatement
-
- getExecutionConfirmation(ExecutionContext) - Method in interface com.tangosol.coherence.dslquery.Statement
-
Return a string that will be used as a question to confirm execution of
a statement.
- getExecutionConfirmation(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.persistence.ArchiveSnapshotStatementBuilder.ArchiveSnapshotStatement
-
- getExecutionConfirmation(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.persistence.CreateSnapshotStatementBuilder.CreateSnapshotStatement
-
- getExecutionConfirmation(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.persistence.ForceRecoveryStatementBuilder.ForceRecoveryStatement
-
- getExecutionConfirmation(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.persistence.RecoverSnapshotStatementBuilder.RecoverSnapshotStatement
-
- getExecutionConfirmation(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.persistence.RemoveSnapshotStatementBuilder.RemoveSnapshotStatement
-
- getExecutionConfirmation(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.persistence.ResumeServiceStatementBuilder.ResumeServiceStatement
-
- getExecutionConfirmation(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.persistence.RetrieveSnapshotStatementBuilder.RetrieveSnapshotStatement
-
- getExecutionConfirmation(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.persistence.SuspendServiceStatementBuilder.SuspendServiceStatement
-
- getExecutionContext() - Method in class com.tangosol.coherence.dslquery.QueryPlus
-
- getExecutionTimeoutMillis() - Method in class com.tangosol.net.AbstractInvocable
-
Obtain the maximum amount of time this task is allowed to run before
the corresponding service will attempt to stop it.
- getExecutionTimeoutMillis() - Method in class com.tangosol.net.AbstractPriorityTask
-
Obtain the maximum amount of time this task is allowed to run before
the corresponding service will attempt to stop it.
- getExecutionTimeoutMillis() - Method in interface com.tangosol.net.PriorityTask
-
Obtain the maximum amount of time this task is allowed to run before
the corresponding service will attempt to stop it.
- getExecutionTimeoutMillis() - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.DefaultTaskDependencies
-
Return the execution timeout for the task in millisecond.
- getExecutionTimeoutMillis() - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.Task
-
Obtain the maximum amount of time this task is allowed to run before
the corresponding service will attempt to stop it.
- getExecutionTimeoutMillis() - Method in interface com.tangosol.util.fsm.NonBlockingFiniteStateMachine.TaskDependencies
-
Return the execution timeout for the task in millisecond.
- getExpiry() - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
-
Return the number of milliseconds remaining before the specified entry
is scheduled to expire.
- getExpiry() - Method in class com.tangosol.net.cache.OverflowMap.ExpirableStatus
-
Determine the expiry for the entry represented by this Status.
- getExpiry() - Method in class com.tangosol.net.cache.OverflowMap.Status
-
Determine the expiry for the entry represented by this Status.
- getExpiry() - Method in interface com.tangosol.util.BinaryEntry
-
Return the number of milliseconds remaining before the specified entry
is scheduled to expire.
- getExpiry() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventBinaryEntry
-
Return the number of milliseconds remaining before the specified entry
is scheduled to expire.
- getExpiry() - Method in class com.tangosol.util.InvocableMapHelper.RoutingBinaryEntry
-
- getExpiryArray() - Method in class com.tangosol.net.cache.OverflowMap
-
Obtain the array of keys that have an expiration, indexed by expiration
times.
- getExpiryArray() - Method in class com.tangosol.net.cache.SerializationCache
-
Get the Expiry data structure.
- getExpiryDelay(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.AbstractJournalScheme
-
Return the amount of time since the last update that entries
are kept by the cache before being expired.
- getExpiryDelay(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.ExternalScheme
-
Return the amount of time since the last update that entries
are kept by the cache before being expired.
- getExpiryDelay(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.LocalScheme
-
Return the amount of time since the last update that entries
are kept by the cache before being expired.
- getExpiryDelay(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.OverflowScheme
-
Return the amount of time since the last update that entries
are kept by the cache before being expired.
- getExpiryDelay(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
-
Return the amount of time that elements offered to the queue remain
visible to consumers.
- getExpiryDelay() - Method in interface com.tangosol.net.cache.ConfigurableCacheMap
-
Determine the default "time to live" for each individual cache entry.
- getExpiryDelay() - Method in class com.tangosol.net.cache.OldCache
-
Deprecated.
Determine the default "time to live" for each individual cache entry.
- getExpiryDelay() - Method in class com.tangosol.net.cache.OverflowMap
-
Determine the "time to live" for each individual cache entry.
- getExpiryDelay() - Method in class com.tangosol.net.cache.SerializationCache
-
Determine the default "time to live" for each individual cache entry.
- getExpiryDelay() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
-
Determine the default "time to live" for each individual cache entry.
- getExpiryMillis() - Method in interface com.tangosol.net.cache.ConfigurableCacheMap.Entry
-
Determine when the cache entry will expire, if ever.
- getExpiryMillis() - Method in class com.tangosol.net.cache.OldCache.Entry
-
Deprecated.
Determine when the cache entry will expire, if ever.
- getExpiryMillis() - Method in class com.tangosol.net.cache.SerializationCache.EntrySet.Entry
-
Determine when the cache entry will expire, if ever.
- getExpiryMillis() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache.EntrySet.Entry
-
Determine when the cache entry will expire, if ever.
- getExpiryMillis() - Method in class com.tangosol.util.ConverterCollections.ConverterCacheEntry
-
Determine when the cache entry will expire, if ever.
- getExpiryPolicy() - Method in class com.tangosol.coherence.jcache.common.JCacheContext
-
Get ExpiryPolicy
- getExpiryPolicyFactory() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
-
- getExpiryTime() - Method in class com.tangosol.coherence.jcache.common.JCacheEntryMetaInf
-
Gets the time (since the Epoc) in milliseconds when the Cache Entry
associated with this value should be considered expired.
- getExpiryTime() - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheValue
-
Gets the time (since the Epoc) in milliseconds when the Cache Entry
associated with this value should be considered expired.
- getExpiryTime() - Method in class com.tangosol.net.cache.SerializationCache.EntryAttributes
-
Determine the date/time at which the entry expires.
- getExpression() - Method in class com.tangosol.coherence.rest.config.NamedQuery
-
Return the query expression.
- getExpressionParser() - Method in class com.tangosol.config.xml.DefaultProcessingContext
-
- getExpressionParser() - Method in class com.tangosol.config.xml.DocumentProcessor.DefaultDependencies
-
Obtains the ExpressionParser
to use for parsing Expression
s during document processing.
- getExpressionParser() - Method in interface com.tangosol.config.xml.DocumentProcessor.Dependencies
-
Obtains the ExpressionParser
to use for parsing Expression
s during document processing.
- getExpressionParser() - Method in interface com.tangosol.config.xml.ProcessingContext
-
- getExtension(String) - Static method in class com.tangosol.io.FileHelper
-
Gets the extension of a filename.
- getExtensionsMap() - Static method in class com.tangosol.coherence.rest.server.DefaultResourceConfig
-
Construct a map with URL suffix to media type mappings.
- getExternalMap() - Method in class com.tangosol.util.SetMap
-
Return an external map allowing type safe access.
- getExtractor(NodeTerm) - Static method in class com.tangosol.coherence.dslquery.statement.AbstractStatementBuilder
-
Return the AST node that represents the extractor for an index from the
given AST node.
- getExtractor() - Method in class com.tangosol.coherence.rest.util.MvelManipulator
-
Retrieve the underlying ValueExtractor reference.
- getExtractor() - Method in class com.tangosol.coherence.rest.util.PropertySpec
-
Return extractor for this property.
- getExtractor() - Method in class com.tangosol.util.aggregator.GroupAggregator
-
Obtain the underlying ValueExtractor.
- getExtractor() - Method in class com.tangosol.util.comparator.ExtractorComparator
-
Returns the
ValueExtractor
to extract value(s) to be used in comparison.
- getExtractor() - Method in class com.tangosol.util.extractor.CompositeUpdater
-
Retrieve the ValueExtractor part.
- getExtractor() - Method in class com.tangosol.util.extractor.ConditionalExtractor
-
- getExtractor(Map<ValueExtractor<T, E>, MapIndex>, MapIndex) - Method in interface com.tangosol.util.extractor.IndexAwareExtractor
-
Obtain the underlying ValueExtractor that was added to the index map
during the
index creation
.
- getExtractor() - Method in class com.tangosol.util.extractor.KeyExtractor
-
Obtain the underlying ValueExtractor.
- getExtractor() - Method in class com.tangosol.util.processor.PropertyManipulator
-
Retrieve the underlying ValueExtractor reference.
- getExtractor() - Method in interface com.tangosol.util.ValueManipulator
-
Retrieve the underlying ValueExtractor reference.
- getExtractorBuilder() - Method in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
-
- getExtractorDescription() - Method in interface com.tangosol.util.QueryRecord.PartialResult.IndexLookupRecord
-
Get a description of the extractor that was used for the index
lookup.
- getExtractorDescription() - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.IndexLookupRecord
-
Get a description of the extractor that was used for the index
lookup.
- getExtractors() - Method in class com.tangosol.util.extractor.AbstractCompositeExtractor
-
Obtain the ValueExtractor array.
- getFactory() - Method in class com.tangosol.io.bdb.BerkeleyDBBinaryStore
-
Get the DatabaseFactory used to create the underlying Database.
- getFactory(String, ClassLoader) - Method in class com.tangosol.net.ScopedCacheFactoryBuilder
-
- getFactory(String, ClassLoader) - Method in class com.tangosol.net.SingletonCacheFactoryBuilder
-
- getFactory() - Method in interface com.tangosol.net.SocketProvider
-
Return the factory associated with this provider.
- getFactoryManager() - Static method in class com.tangosol.io.bdb.BerkeleyDBBinaryStoreManager
-
Get the DatabaseFactoryManager.
- getFairShare(boolean) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
Return the (primary or backup) fair-share partition load.
- getFairShare() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.UnderloadedFilter
-
Return the fair-share partition load.
- getFairShareBackup() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
Get the number of backup partitions per storage-enabled service member
that this strategy will currently attempt to maintain.
- getFairShareBackup() - Method in interface com.tangosol.net.partition.SimpleStrategyMBean
-
Get the number of backup partitions per storage-enabled service member
that this strategy will currently attempt to maintain.
- getFairSharePrimary() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
Get the number of primary partitions per storage-enabled service member
that this strategy will currently attempt to maintain.
- getFairSharePrimary() - Method in interface com.tangosol.net.partition.SimpleStrategyMBean
-
Get the number of primary partitions per storage-enabled service member
that this strategy will currently attempt to maintain.
- getFields(NodeTerm) - Static method in class com.tangosol.coherence.dslquery.statement.AbstractStatementBuilder
-
Return the AST node that represents the fields to select from the
given AST node.
- getFile(NodeTerm) - Static method in class com.tangosol.coherence.dslquery.statement.AbstractStatementBuilder
-
Return the String that represents the filename from the given AST
node by looking for the "file" term in the AST.
- getFile() - Method in class com.tangosol.io.nio.MappedBufferManager
-
Obtain the RandomAccessFile that the buffer is constructed on.
- getFileName() - Method in class com.tangosol.util.Base.StackFrame
-
- getFiles() - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
-
- getFiles() - Method in interface com.tangosol.coherence.dslquery.QueryPlus.Dependencies
-
Return the list of statement script files that should be executed prior to the
start of the CohQL session.
- getFillLength() - Method in class com.tangosol.io.nio.BinaryMap.Block
-
Get the size of the fill in the block.
- getFilter() - Method in class com.tangosol.coherence.dslquery.statement.SelectStatementBuilder.SelectStatement
-
Return the
Filter
to use to execute this query.
- getFilter() - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
Obtain the
Filter
that this
ContinuousQueryCache
is using to query the
underlying
NamedCache
.
- getFilter() - Method in class com.tangosol.net.topic.Subscriber.Filtered
-
Return the option's filter.
- getFilter() - Method in class com.tangosol.util.ConditionalIndex
-
Get the associated filter.
- getFilter() - Method in class com.tangosol.util.filter.ArrayFilter.WeightedFilter
-
Get the wrapped filter.
- getFilter() - Method in class com.tangosol.util.filter.FilterTrigger
-
Obtain the underlying Filter.
- getFilter() - Method in class com.tangosol.util.filter.InKeySetFilter
-
Obtain the underlying Filter.
- getFilter() - Method in class com.tangosol.util.filter.KeyAssociatedFilter
-
Obtain the wrapped Filter.
- getFilter() - Method in class com.tangosol.util.filter.LimitFilter
-
Obtain the Filter whose results are truncated by this filter.
- getFilter() - Method in class com.tangosol.util.filter.MapEventFilter
-
Obtain the Filter object used to evaluate the event value(s).
- getFilter() - Method in class com.tangosol.util.filter.NotFilter
-
Obtain the Filter whose results are negated by this filter.
- getFilter() - Method in class com.tangosol.util.filter.PartitionedFilter
-
Obtain the wrapped Filter.
- getFilter() - Method in class com.tangosol.util.filter.PriorityFilter
-
Obtain the underlying filter.
- getFilter() - Method in class com.tangosol.util.MapListenerSupport.FilterEvent
-
Return an array of filters that are the cause of this event.
- getFilterBuilder() - Method in class com.tangosol.coherence.config.scheme.ContinuousQueryCacheScheme
-
- getFilterDescription() - Method in interface com.tangosol.util.QueryRecord.PartialResult.Step
-
Get a description of the filter that was associated with this
step during its creation.
- getFilterDescription() - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.Step
-
Get a description of the filter that was associated with this
step during its creation.
- getFilterList() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the list of all filters for the cluster.
- getFilterMap() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the map of filter name to WrapperStreamFactory.
- getFilterMap() - Method in interface com.tangosol.net.OperationalContext
-
Return a Map of network filter factories.
- getFilters() - Method in class com.tangosol.util.filter.ArrayFilter
-
Obtain the Filter array.
- getFilters() - Method in class com.tangosol.util.Listeners
-
Return the array of filters associated with this Listeners object.
- getFilterSet() - Method in class com.tangosol.util.MapListenerSupport
-
Obtain a set of all filters that have associated global listeners.
- getFirst() - Method in class com.tangosol.util.SafeLinkedList
-
Returns the first element in the list, or null if empty.
- getFirstEntry() - Method in class com.tangosol.run.xml.SimpleElement.AttributeMap
-
Return the first entry in the list..
- getFirstIndex() - Method in class com.tangosol.util.AbstractLongArray
-
Determine the first index that exists in the LongArray.
- getFirstIndex() - Method in class com.tangosol.util.AbstractSafeLongArray
-
- getFirstIndex() - Method in class com.tangosol.util.AbstractSparseArray
-
Determine the first index that exists in the LongArray.
- getFirstIndex() - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray
-
- getFirstIndex() - Method in interface com.tangosol.util.LongArray
-
Determine the first index that exists in the LongArray.
- getFirstIndex() - Method in class com.tangosol.util.SimpleLongArray
-
Determine the first index that exists in the LongArray.
- getFirstIndex() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
-
- getFirstMap() - Method in class com.tangosol.util.ChainedMap
-
Get the first (front) map.
- getFirstParameter(ParameterResolver, ParameterList, Class<V>) - Static method in class com.tangosol.coherence.dslquery.function.FunctionBuilders
-
Extract the first parameter from the listParameters argument.
- getFloat(String) - Static method in class com.tangosol.coherence.config.Config
-
Return Coherence system property value as a Float.
- getFloat(String, float) - Static method in class com.tangosol.coherence.config.Config
-
Return Coherence system property value as a float.
- getFloat() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Return the float which this PofValue represents.
- getFloat() - Method in interface com.tangosol.io.pof.reflect.PofValue
-
Return the float which this PofValue represents.
- getFloatArray() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Return the float[] which this PofValue represents.
- getFloatArray() - Method in interface com.tangosol.io.pof.reflect.PofValue
-
Return the float[] which this PofValue represents.
- getFlowControl() - Method in interface com.tangosol.net.topic.Publisher
-
Return the
FlowControl
object governing this publisher.
- getFlowControl() - Method in interface com.tangosol.net.topic.Subscriber
-
Return the
FlowControl
object governing this subscriber.
- getFlushTime() - Method in class com.tangosol.net.cache.OldCache
-
- getForwardEntry(Object) - Method in class com.tangosol.util.ConditionalIndex
-
Get the forward index entry associated with the specified key.
- getForwardEntry(Object) - Method in class com.tangosol.util.SimpleMapIndex
-
Get the forward index entry associated with the specified key.
- getFreeBlockOffset(int) - Method in class com.tangosol.io.nio.BinaryMap
-
Get the first free block in the linked list of free blocks that have
a certain size code.
- getFreeCapacity() - Method in class com.tangosol.io.nio.BinaryMap
-
Determine the free capacity of the map in bytes.
- getFreeListCount() - Method in class com.tangosol.io.nio.BinaryMap
-
Determine the number of free lists (ie the number of size codes).
- getFromInternalCache(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Get the the value for a given key.
- getFromMember() - Method in class com.tangosol.net.partition.PartitionEvent
-
Determine the member that held the partitions prior to the action
represented by this event.
- getFrontEvent() - Method in class com.tangosol.net.cache.OverflowMap.Status
-
For internal use only, return the current event from the front
Map.
- getFrontEvent() - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
-
For internal use only, return the current event from the front
Map.
- getFrontMap() - Method in class com.tangosol.net.cache.CachingMap
-
Obtain the front map reference.
- getFrontMap() - Method in class com.tangosol.net.cache.OverflowMap
-
Returns the front Map.
- getFrontMap() - Method in class com.tangosol.net.cache.SimpleOverflowMap
-
Returns the front Map.
- getFrontMapListener() - Method in class com.tangosol.net.cache.OverflowMap
-
Get the MapListener for the front map.
- getFrontMapListener() - Method in class com.tangosol.net.cache.SimpleOverflowMap
-
Get the MapListener for the front map.
- getFrontPaddingSize() - Method in class com.tangosol.io.MultiByteArrayOutputStream
-
Determine the number of extra bytes of padding that will be allocated
and left blank at the start of each block in front of the data portion.
- getFrontScheme() - Method in class com.tangosol.coherence.config.scheme.AbstractCompositeScheme
-
Return the front scheme.
- getFullStackTrace() - Method in exception com.tangosol.io.pof.PortableException
-
Return an array of Strings containing the full representation of the
stack trace.
- getFullyQualifiedClassNameOf(String) - Static method in class com.tangosol.util.ClassHelper
-
Determines the fully qualified class name of the Coherence-style abbreviated class name.
- getFunction(String) - Method in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
-
Return the function mapped to the given function name or
null if no function mapping exists.
- getFunction() - Method in class com.tangosol.net.topic.Subscriber.Convert
-
Return the option's converter function.
- getFunctor() - Method in class com.tangosol.coherence.dslquery.queryplus.AbstractQueryPlusStatementBuilder.AbstractOPToken
-
Return the functor for this OPToken.
- getFunctor() - Method in class com.tangosol.coherence.dslquery.token.SQLExplainOPToken
-
Get the functor for the new term.
- getFunctor() - Method in class com.tangosol.coherence.dslquery.token.SQLTraceOPToken
-
- getFunctor() - Method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
-
Obtain the functor representation of the Term.
- getFunctor() - Method in class com.tangosol.coherence.dsltools.termtrees.NodeTerm
-
Obtain the functor representation of the Term.
- getFunctor() - Method in class com.tangosol.coherence.dsltools.termtrees.Term
-
Obtain the functor representation of the Term.
- getFutureData() - Method in class com.tangosol.io.AbstractEvolvable
-
Return all the unknown remainder of the data stream from which this
object was deserialized.
- getFutureData() - Method in interface com.tangosol.io.Evolvable
-
Return all the unknown remainder of the data stream from which this
object was deserialized.
- getFutureData() - Method in class com.tangosol.io.SimpleEvolvable
-
Return all the unknown remainder of the data stream from which this
object was deserialized.
- getGarFileName() - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
-
- getGarFileName() - Method in interface com.tangosol.coherence.dslquery.QueryPlus.Dependencies
-
Return the name of the optional GAR file to load
before running QueryPlus.
- getGate() - Method in class com.tangosol.net.cache.OverflowMap
-
Obtain the Gate for managing key-level and Collection-level
operations against the Map, versus Map-level operations themselves.
- getGate() - Method in class com.tangosol.net.cache.SimpleOverflowMap
-
Obtain the Gate for managing key-level and Collection-level
operations against the Map, versus Map-level operations themselves.
- getGenericTypeId(Class) - Method in class com.tangosol.io.pof.SafeConfigurablePofContext
-
For user types that are not registered in the POF configuration used
by this PofContext, determine if the user type can be serialized using
POF, otherwise determine if the user type can be serialized using the
traditional (pre-POF) Coherence Java Serialization format that supports
Java Serializable and ExternalizableLite objects.
- getGetBundler() - Method in class com.tangosol.net.cache.BundlingNamedCache
-
Obtain the bundler for the "get" operations.
- getGetEntryAction() - Method in class com.tangosol.util.SegmentedHashMap
-
Return the registered action for getEntryInternal.
- getGlobalPartitions(PartitionedService) - Static method in class com.tangosol.persistence.CachePersistenceHelper
-
Return a PartitionSet that contains partitions to be used to persist
(meta-)data that is logically "global".
- getGroupAddress() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the multicast group address to listen/publish on.
- getGroupBufferSize() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the preferred size for the multicast datagram socket input buffer
(SO_RCVBUF).
- getGroupBy(NodeTerm) - Static method in class com.tangosol.coherence.dslquery.statement.AbstractStatementBuilder
-
Return the AST node that represents the group by fields from the
given AST node.
- getGroupInterface() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the IP address of the interface (e.g. the NIC) that the MulticastSocket
will open a socket on.
- getGroupListenerPriority() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the priority of the PacketListener daemon thread.
- getGroupPort() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the multicast port number that the cluster will listen/publish on.
- getGroupTimeToLive() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the multicast time-to-live setting for the cluster.
- getGrowthCount() - Method in class com.tangosol.io.nio.BinaryMap
-
Determine the level at which the modulo will increase.
- getGrowthThreshold() - Method in class com.tangosol.io.nio.AbstractBufferManager
-
Determine the level (what number of bytes used) above which the current
ByteBuffer will need to be "resized" upwards.
- getGrowthThreshold() - Method in interface com.tangosol.io.nio.ByteBufferManager
-
Determine the level (what number of bytes used) above which the current
ByteBuffer will need to be "resized" upwards.
- getGuardable() - Method in interface com.tangosol.net.Guardian.GuardContext
-
Return the Guardable for this context.
- getGuardable() - Method in class com.tangosol.net.GuardSupport.Context
-
Return the Guardable for this context.
- getGuardableCount() - Method in class com.tangosol.net.GuardSupport
-
Return the number of Guardables that are registered with this
GuardSupport.
- getGuardContexts() - Method in class com.tangosol.net.GuardSupport
-
Return the array of GuardContext objects for the Guardables managed by
this GuardSupport.
- getGuardian() - Method in interface com.tangosol.net.Guardian.GuardContext
-
Return the Guardian for this context.
- getGuardian() - Method in class com.tangosol.net.GuardSupport.Context
-
Return the Guardian for this context.
- getGuardian() - Method in class com.tangosol.net.GuardSupport
-
Return the Guardian that manages this GuardSupport.
- getGuardRegisterAction() - Method in class com.tangosol.util.Daemon
-
Return the Guardian registration action.
- getGuardTimeoutMillis() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the default Guard timeout.
- getHashCode() - Method in class com.tangosol.run.xml.XmlBean
-
Get the cached hash code.
- getHAStatus() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
The High Availability status for the service.
- getHAStatus() - Method in interface com.tangosol.net.partition.SimpleStrategyMBean
-
The High Availability status for the service.
- getHAStatusCode() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
The High Availability status for the service as an integer.
- getHAStatusCode() - Method in interface com.tangosol.net.partition.SimpleStrategyMBean
-
The High Availability status for the service as an integer.
- getHATarget() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
The High Availability status that this strategy attempts to achieve.
- getHATarget() - Method in interface com.tangosol.net.partition.SimpleStrategyMBean
-
The High Availability status that this strategy attempts to achieve.
- getHead() - Method in class com.tangosol.util.SafeSortedMap.Split
-
Return front of the split.
- getHeadWeight() - Method in class com.tangosol.util.SafeSortedMap.Split
-
- getHighUnitFairShare() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
-
Return the fair share of high-units per partition map.
- getHighUnits(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.AbstractJournalScheme
-
Return the limit of cache size.
- getHighUnits(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.ExternalScheme
-
Return the limit of cache size.
- getHighUnits(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.LocalScheme
-
Return the limit of cache size.
- getHighUnits(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
-
Return the high-units
- getHighUnits() - Method in interface com.tangosol.net.cache.ConfigurableCacheMap
-
Determine the limit of the cache size in units.
- getHighUnits() - Method in class com.tangosol.net.cache.OldCache
-
Deprecated.
Determine the limit of the cache size in units.
- getHighUnits() - Method in class com.tangosol.net.cache.SerializationCache
-
Determine the limit of the cache size in units.
- getHighUnits() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
-
Determine the limit of the cache size in units.
- getHitProbability() - Method in interface com.tangosol.net.cache.CacheStatistics
-
Determine the rough probability (0 <= p <= 1) that the next
invocation will be a hit, based on the statistics collected since the
last reset of the cache statistics.
- getHitProbability() - Method in class com.tangosol.net.cache.OldCache
-
Deprecated.
Determine the rough probability (0 <= p <= 1) that any particular
OldCache.get(java.lang.Object)
invocation will be satisfied by an existing entry in
the cache, based on the statistics collected since the last reset
of the cache statistics.
- getHitProbability() - Method in class com.tangosol.net.cache.SimpleCacheStatistics
-
Determine the rough probability (0 <= p <= 1) that the next
invocation will be a hit, based on the statistics collected since the
last reset of the cache statistics.
- getHitProbability() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.AggregatingCacheStatistics
-
Determine the rough probability (0 <= p <= 1) that the next
invocation will be a hit, based on the statistics collected since the
last reset of the cache statistics.
- getHost() - Method in class com.tangosol.net.ConfigurableAddressProvider.AddressHolder
-
Return the host name.
- getHost() - Method in class com.tangosol.net.LoadBalancer
-
Determine the AddressPort that the load balancer listens on.
- getHostKey() - Method in class com.tangosol.util.filter.KeyAssociatedFilter
-
Obtain the host key that serves as an associated key for all keys that
the wrapped filter will be applied to.
- getHostName() - Static method in class com.tangosol.net.management.MBeanConnector
-
Get the configured host name for the RMI Connector Server.
- getHostnameVerifierBuilder() - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder
-
Get customized HostnameVerifierBuilder
- getHour() - Method in class com.tangosol.io.pof.RawTime
-
Determine the time's hour value.
- getHourOffset() - Method in class com.tangosol.io.pof.RawTime
-
Determine the timezone's hour offset value.
- getHours() - Method in class com.tangosol.io.pof.RawDayTimeInterval
-
Determine the number of hours in the day-time interval.
- getHours() - Method in class com.tangosol.io.pof.RawTimeInterval
-
Determine the number of hours in the time interval.
- getId() - Method in class com.tangosol.coherence.config.builder.SocketProviderBuilder
-
Return the identifier for SocketProvider built by this builder.
- getId() - Method in class com.tangosol.coherence.dsltools.precedence.OPToken
-
Obtain the string representation of this token.
- getId() - Method in interface com.tangosol.net.Member
-
Return a small number that uniquely identifies the Member at this point
in time and does not change for the life of this Member.
- getId() - Method in class com.tangosol.net.MemberEvent
-
Return this event's id.
- getId() - Method in class com.tangosol.net.partition.PartitionEvent
-
Return this event's id.
- getId() - Method in class com.tangosol.net.proxy.RemoteMember
-
Return a small number that uniquely identifies the Member at this point
in time and does not change for the life of this Member.
- getId() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
-
Return the identifier of this store.
- getId() - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistentStore
-
Return the identifier of this store.
- getId() - Method in class com.tangosol.util.MapEvent
-
Return this event's id.
- getId() - Method in class com.tangosol.util.NullImplementation.NullPersistentStore
-
- getId() - Method in class com.tangosol.util.ServiceEvent
-
Return this event's ID.
- getIdentifier() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCache
-
- getIdentifier() - Method in interface com.tangosol.coherence.jcache.CoherenceBasedCache
-
Obtain the internal identifier used for JCache caches.
- getIdentifier() - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
-
- getIdentifier() - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
-
Get unique JCacheIdentifier for cache that these statistics are for.
- getIdentifier() - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
-
- getIdentifier() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
-
- getIdentifier() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
-
- getIdentifier() - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
-
- getIdentifier() - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
-
- getIdentifier() - Method in interface com.tangosol.net.events.EventDispatcher.InterceptorRegistrationEvent
-
- getIdentity(Object) - Method in class com.tangosol.io.pof.PofBufferWriter.ReferenceLibrary
-
Look up an identity for an object.
- getIdentityAsserter() - Method in interface com.tangosol.net.OperationalContext
-
Return an IdentityAsserter that can be used to establish a user's
identity.
- getIdentityManager() - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder
-
Get the SSL identity manager dependencies
- getIdentityTransformer() - Method in interface com.tangosol.net.OperationalContext
-
Return an IdentityTransformer that can be used to transform a Subject
into an identity assertion.
- getIdleThreadCount() - Method in interface com.tangosol.net.ThreadPoolManager
-
Return the idle thread count of the thread pool.
- getIdleTimeout() - Method in class com.tangosol.util.TaskDaemon
-
Determine the length of time that the daemon will live without any
activity before it stops itself.
- getIgnoredAdvice() - Method in interface com.tangosol.net.partition.DistributionManager
-
Return a set of partitions from the previous suggestions that were
ignored or rejected.
- getImplVersion() - Method in class com.tangosol.io.AbstractEvolvable
-
Determine the serialization version supported by the implementing
class.
- getImplVersion() - Method in interface com.tangosol.io.Evolvable
-
Determine the serialization version supported by the implementing
class.
- getImplVersion() - Method in class com.tangosol.io.SimpleEvolvable
-
Determine the serialization version supported by the implementing
class.
- getImplVersion() - Method in class com.tangosol.persistence.AbstractPersistenceManager
-
Return the implementation version of this manager.
- getIn() - Method in class com.tangosol.io.MultiBufferReadBuffer.MultiBufferInput
-
Obtain the underlying BufferOutput.
- getIncidentStartTime() - Method in interface com.tangosol.net.Cluster.MemberTimeoutAction
-
Return the time at which the current outage "incident" was first
detected.
- getIndent() - Method in class com.tangosol.io.pof.LoggingPofHandler
-
Determine the current textual indent for logging, which is based on the
nested data structure depth within the POF stream.
- getIndex() - Method in class com.tangosol.util.AbstractSafeLongArray.SafeIterator
-
- getIndex() - Method in class com.tangosol.util.AbstractSparseArray.Crawler
-
Returns the index of the current value, which is the value returned
by the most recent call to the next
method.
- getIndex() - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray.ConverterLongArrayIterator
-
- getIndex() - Method in class com.tangosol.util.CopyOnWriteLongArray.UnmodifiableIterator
-
Returns the index of the current value, which is the value returned
by the most recent call to the next method.
- getIndex() - Method in interface com.tangosol.util.LongArray.Iterator
-
Returns the index of the current value, which is the value returned
by the most recent call to the next method.
- getIndex() - Method in class com.tangosol.util.SimpleLongArray.Iterator
-
Returns the index of the current value, which is the value returned
by the most recent call to the next method.
- getIndexContents() - Method in class com.tangosol.util.ForwardOnlyMapIndex
-
Get the Map that contains the index contents.
- getIndexContents() - Method in interface com.tangosol.util.MapIndex
-
Get the Map that contains the index contents.
- getIndexContents() - Method in class com.tangosol.util.SimpleMapIndex
-
Get the Map that contains the index contents.
- getIndexDef() - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.IndexLookupRecord
-
Returns the index definition.
- getIndexDescription() - Method in interface com.tangosol.util.QueryRecord.PartialResult.IndexLookupRecord
-
Get a description of the associated index.
- getIndexDescription() - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.IndexLookupRecord
-
Get a description of the associated index.
- getIndexExtentId(long) - Static method in class com.tangosol.persistence.CachePersistenceHelper
-
Return the extent identifier that contains index registration
information for the cache with the given identifier.
- getIndexLookupRecords() - Method in interface com.tangosol.util.QueryRecord.PartialResult.Step
-
Get the recorded information about the index lookups performed
during filter evaluation as part of a query record.
- getIndexLookupRecords() - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.Step
-
Get the recorded information about the index lookups performed
during filter evaluation as part of a query record.
- getIndexMap() - Method in interface com.tangosol.net.BackingMapContext
-
Return a map of indexes defined for the
cache
that
this BackingMapContext is associated with.
- getIndexMap() - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
Get the map of indexes maintained by this cache.
- getIndirectStorageSize() - Method in class com.tangosol.net.partition.PartitionStatistics
-
Return the partition size from non-PartitionAwareBackingMaps.
- getInfo() - Method in interface com.tangosol.net.Service
-
Return the ServiceInfo object for this Service.
- getInfo() - Method in class com.tangosol.net.WrapperService
-
Return the ServiceInfo object for this Service.
- getInheritedUserTypeIdentifier(Class) - Method in class com.tangosol.io.pof.ConfigurablePofContext
-
Helper method for determining the user type identifier associated with
a given class that does not have a direct configured association.
- getInitialSize(ParameterResolver) - Method in class com.tangosol.coherence.config.builder.storemanager.AbstractNioManagerBuilder
-
Return the initial buffer size in bytes.
- getInitialSize(ParameterResolver) - Method in interface com.tangosol.coherence.config.scheme.BackupMapConfig
-
Return the initial buffer size in bytes for off-heap and file-mapped
backup maps.
- getInitialSize(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.DistributedScheme.BackupConfig
-
Return the initial buffer size in bytes for off-heap and file-mapped
backup maps.
- getInitParams() - Method in class com.tangosol.coherence.config.builder.storemanager.BdbStoreManagerBuilder
-
Return the BDB init params needed to construct a BerkeleyDBBinaryStoreManager.
- getInnerScheme() - Method in class com.tangosol.coherence.config.scheme.BackingMapScheme
-
Return the inner scheme.
- getInputStream() - Method in class com.tangosol.io.WrapperInputStream
-
Obtain the underlying InputStream.
- getInputStream(InputStream) - Method in interface com.tangosol.io.WrapperStreamFactory
-
Deprecated.
Requests an InputStream that wraps the passed InputStream.
- getInputStream(InputStream) - Method in class com.tangosol.net.CompressionFilter
-
Deprecated.
Requests an InputStream that wraps the passed InputStream.
- getInputStream() - Method in class com.tangosol.util.Binary
-
Get an InputStream to read the Binary object's contents from.
- getInputStream(DataInput) - Static method in class com.tangosol.util.ExternalizableHelper
-
Get an InputStream for the passed DataInput object.
- getInsertAction() - Method in class com.tangosol.util.SegmentedHashMap
-
Return the registered action for insert.
- getInsertKey(NodeTerm) - Static method in class com.tangosol.coherence.dslquery.statement.AbstractStatementBuilder
-
Return the AST node that represents the key to insert from the
given AST node.
- getInsertValue(NodeTerm) - Static method in class com.tangosol.coherence.dslquery.statement.AbstractStatementBuilder
-
Return the AST node that represents the value to insert from the
given AST node.
- getInstance() - Static method in interface com.tangosol.coherence.config.EnvironmentVariableResolver
-
- getInstance() - Static method in interface com.tangosol.coherence.config.SystemPropertyResolver
-
Return an instance of a
SystemPropertyResolver
discovered by
the
ServiceLoader
, or a default instance if none are discovered.
- getInstance() - Static method in class com.tangosol.net.DefaultCacheServer
-
- getInstance() - Static method in class com.tangosol.util.NullFilter
-
Returns an instance of the null enumerator.
- getInstanceClass() - Method in interface com.tangosol.coherence.config.builder.ParameterizedBuilderRegistry.Registration
-
Obtains the class of instance produced by the builder.
- getInstanceClass() - Method in class com.tangosol.coherence.config.builder.SimpleParameterizedBuilderRegistry.BuilderRegistration
-
- getInstanceClass() - Method in class com.tangosol.coherence.config.builder.SimpleParameterizedBuilderRegistry.RegistryKey
-
Return the class of the instance produced by the builder.
- getInt() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Return the int which this PofValue represents.
- getInt() - Method in interface com.tangosol.io.pof.reflect.PofValue
-
Return the int which this PofValue represents.
- getInt() - Method in class com.tangosol.run.xml.SimpleValue
-
Get the value as an int.
- getInt(int) - Method in class com.tangosol.run.xml.SimpleValue
-
Get the value as an int.
- getInt() - Method in interface com.tangosol.run.xml.XmlValue
-
Get the value as an int.
- getInt(int) - Method in interface com.tangosol.run.xml.XmlValue
-
Get the value as an int.
- getInt() - Method in class com.tangosol.util.AnyEvent
-
Gets the associated value as a java int.
- getIntArray() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Return the int[] which this PofValue represents.
- getIntArray() - Method in interface com.tangosol.io.pof.reflect.PofValue
-
Return the int[] which this PofValue represents.
- getInteger(String) - Static method in class com.tangosol.coherence.config.Config
-
Return Coherence system property value as an Integer.
- getInteger(String, int) - Static method in class com.tangosol.coherence.config.Config
-
Return Coherence system property value as an Integer.
- getInterceptor() - Method in interface com.tangosol.net.events.EventDispatcher.InterceptorRegistrationEvent
-
- getInterceptorRegistry() - Method in interface com.tangosol.net.ConfigurableCacheFactory
-
- getInterceptorRegistry() - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
- getInterceptorRegistry() - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
-
- getInternal(Object) - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
Return the value from the back cache, transforming it in the process if
necessary.
- getInternal(Object, boolean, Map) - Method in class com.tangosol.net.cache.OverflowMap
-
- getInternalCache() - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
Obtain a reference to the internal cache.
- getInternalCache() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Get the representative of the "in-memory" storage for this backing map.
- getInternalConfigurableCache() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Get the map that provides internal storage for this backing map.
- getInternalIterator() - Method in class com.tangosol.util.CopyOnWriteLongArray.UnmodifiableIterator
-
Return the internal Iterator.
- getInternalKeySet() - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
- getInternalKeySet() - Method in class com.tangosol.net.cache.OverflowMap
-
Obtain a set of keys that are represented by this Map.
- getInternalKeySet() - Method in class com.tangosol.net.cache.SerializationMap
-
Obtain a set of keys that are represented by this Map.
- getInternalKeySet() - Method in class com.tangosol.util.AbstractKeySetBasedMap
-
Obtain a set of keys that are represented by this Map.
- getInternalKeySet() - Method in class com.tangosol.util.WrapperObservableMap
-
Obtain a set of keys that are represented by this Map.
- getInternalListener() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Obtain the MapListener that listens to the internal cache and routes
those events to anyone listening to this ReadWriteBackingMap, creating
such a listener if one does not already exist.
- getInternalMap() - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
-
Return the internal map which is set by the backing map manager when
the partitioned flag is true.
- getInternalMap() - Method in class com.tangosol.util.CopyOnWriteMap
-
Return the internal map.
- getInternalMap() - Method in class com.tangosol.util.SetMap
-
Return the internal map allowing any object to be stored.
- getInternalMap() - Method in class com.tangosol.util.SortedBag
-
Return the internal sorted-map holding the bag contents.
- getInternalScheme() - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
-
Return the scheme which the specifies the map used to cache entries.
- getInternalValue(long) - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheValue
-
Gets the internal value with the side-effect of updating the access time
to that which is specified and incrementing the access count.
- getInternalValue() - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheValue
-
Access internal value without updating access expiry.
- getInternalValue() - Method in class com.tangosol.run.xml.SimpleValue
-
Get the internal value of this XmlValue.
- getInternalValueDecoration(Object, int) - Method in interface com.tangosol.net.BackingMapManagerContext
-
Obtain a decoration from the specified value in the internal form.
- getInternalValueDecoration(Object, int) - Method in class com.tangosol.util.NullImplementation.NullBackingMapManagerContext
-
Obtain a decoration from the specified value in the internal form.
- getInvalidationHits() - Method in class com.tangosol.net.cache.CachingMap
-
Determine the rough number of front map invalidation hits since
the cache statistics were last reset.
- getInvalidationMisses() - Method in class com.tangosol.net.cache.CachingMap
-
Determine the rough number of front map invalidation misses since
the cache statistics were last reset.
- getInvalidationStrategy(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.NearScheme
-
Return the invalidation strategy.
- getInvalidationStrategy() - Method in class com.tangosol.net.cache.CachingMap
-
Obtain the invalidation strategy used by this CachingMap.
- getInvocableMap() - Method in class com.tangosol.util.ConverterCollections.ConverterInvocableMap
-
Return the underlying InvocableMap.
- getInvocableMap(InvocableMap<FK, FV>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Static method in class com.tangosol.util.ConverterCollections
-
Returns a Converter instance of InvocableMap.
- getInvocationService() - Method in class com.tangosol.net.WrapperInvocationService
-
Return the wrapped InvocationService.
- getIpMonitorAttempts() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the number of connection attempts that the IpMonitor will use in
determining if IP connectivity exists to other hosts.
- getIpMonitorPriority() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the priority of the IpMonitor daemon thread.
- getIpMonitorTimeoutMillis() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the timeout that the IpMonitor will use in determining if IP
connectivity exists to other hosts.
- getIsDistinct(NodeTerm) - Static method in class com.tangosol.coherence.dslquery.statement.AbstractStatementBuilder
-
Return the boolean that indicates whether distinctness in indicated
in the given AST node.
- getIsolation() - Method in class com.tangosol.run.jca.CacheAdapter.CacheConnectionSpec
-
- getIterable() - Static method in class com.tangosol.util.NullImplementation
-
Returns an instance of the null iterable.
- getIterator() - Method in class com.tangosol.util.ChainedEnumerator
-
Get the current or next enumeration in the list
- getIterator() - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet.ConverterIterator
-
Return the underlying Iterator.
- getIterator(Iterator<F>, Converter<F, T>) - Static method in class com.tangosol.util.ConverterCollections
-
Returns an instance of Iterator that uses a Converter to view an
underlying Iterator.
- getIterator() - Static method in class com.tangosol.util.NullImplementation
-
Returns an instance of the null iterator.
- getJavaTypeId(Object, PofContext) - Static method in class com.tangosol.io.pof.PofHelper
-
Return an identifier that represents the Java type of the specified
object.
- getJlineReader(OutputStream, InputStream, boolean) - Static method in class com.tangosol.coherence.dslquery.QueryPlus
-
Return an instance of BufferedReader if JLine is present.
- getJoiningMember() - Method in interface com.tangosol.net.Service.MemberJoinAction
-
Return the Member that is attempting to join the service.
- getKey() - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheEntry
-
- getKey() - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheEntryEvent
-
- getKey() - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCacheEntryEvent
-
- getKey() - Method in class com.tangosol.coherence.rest.events.SimpleMapEvent
-
Return the key associated with this event.
- getKey() - Method in class com.tangosol.io.nio.BinaryMap.Block
-
Get the Entry key in the block, lazy loading it if necessary.
- getKey() - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
-
Return the key corresponding to this entry.
- getKey() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.ReadLatch
-
Return the key that is being loaded by the refresh-ahead thread.
- getKey() - Method in interface com.tangosol.run.xml.Identifiable
-
Determine the key for this value object
- getKey() - Method in class com.tangosol.util.ConverterCollections.AbstractConverterEntry
- getKey() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventEntry
- getKey() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent
-
Return a key associated with this event.
- getKey() - Method in interface com.tangosol.util.InvocableMap.Entry
-
Return the key corresponding to this entry.
- getKey() - Method in class com.tangosol.util.InvocableMapHelper.RoutingMapTriggerEntry
-
Return the key corresponding to this entry.
- getKey() - Method in class com.tangosol.util.MapEvent
-
Return a key associated with this event.
- getKey() - Method in class com.tangosol.util.MapListenerSupport.FilterEvent
-
Return a key associated with this event.
- getKey() - Method in class com.tangosol.util.PrimitiveSparseArray.PrimitiveNode
-
Return the key
- getKey() - Method in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet.RestrictedEntry
-
Returns the key corresponding to this entry.
- getKey() - Method in class com.tangosol.util.SafeHashMap.Entry
-
Returns the key corresponding to this entry.
- getKey() - Method in class com.tangosol.util.SafeSortedMap.EntryNode
-
Return the key that this node represents.
- getKey() - Method in class com.tangosol.util.SafeSortedMap.EntryNode.MapEntry
- getKey() - Method in class com.tangosol.util.SegmentedHashMap.Entry
-
Returns the key corresponding to this entry.
- getKey() - Method in class com.tangosol.util.SimpleMapEntry
-
Return the key corresponding to this entry.
- getKey() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperEntry
- getKey() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperEntry
- getKeyAdapter() - Method in class com.tangosol.run.xml.MapAdapter
-
- getKeyAssociator() - Method in interface com.tangosol.net.PartitionedService
-
Determine the key associator that this service has been
configured to use.
- getKeyClass() - Method in class com.tangosol.coherence.rest.config.ResourceConfig
-
Determine the class of the cache key.
- getKeyClassName() - Method in class com.tangosol.coherence.config.CacheMapping
-
- getKeyClassName() - Method in class com.tangosol.net.cache.TypeAssertion.WithTypesAssertion
-
Get Key ClassName
- getKeyConverter() - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
-
Get key converter for this.
- getKeyConverter() - Method in class com.tangosol.coherence.rest.config.ResourceConfig
-
Return a KeyConverter instance for this resource.
- getKeyFromInternalConverter() - Method in interface com.tangosol.net.BackingMapManagerContext
-
Return a converter that allows the manager (or a backing map
managed thereby) to convert a key object from its internal form
(as managed by the CacheService) into its "normal" (Object) form.
- getKeyFromInternalConverter() - Method in class com.tangosol.util.NullImplementation.NullBackingMapManagerContext
-
Return a converter that allows the manager (or a backing map
managed thereby) to convert a key object from its internal form
(as managed by the CacheService) into its "normal" (Object) form.
- getKeyHash() - Method in class com.tangosol.io.nio.BinaryMap.Block
-
Get the hash code for the Entry block.
- getKeyLength() - Method in class com.tangosol.io.nio.BinaryMap.Block
-
Get the length of the Entry key in the block.
- getKeyList() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.ReadQueue
-
Return a list of keys in the queue.
- getKeyMap() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.ReadQueue
-
Return a map of keys in the queue.
- getKeyMap() - Method in class com.tangosol.net.cache.SerializationMap
-
Returns the cache of keys that are in the SerializationMap.
- getKeyMask() - Method in class com.tangosol.net.cache.LocalCache
-
ThreadLocal: Get the current key mask for the current thread.
- getKeyOwner(Object) - Method in interface com.tangosol.net.PartitionedService
-
Determine the primary owner of the specified key, as determined by the
combination of the KeyPartitioningStrategy and the
PartitionAssignmentStrategy.
- getKeyPartition(Object) - Method in interface com.tangosol.net.BackingMapManagerContext
-
Determine the partition to which the specified key belongs.
- getKeyPartition(Object) - Method in class com.tangosol.net.partition.BroadKeyPartitioningStrategy
-
Determine the partition to which a particular key should be assigned.
- getKeyPartition(Object) - Method in class com.tangosol.net.partition.DefaultKeyPartitioningStrategy
-
Determine the partition to which a particular key should be assigned.
- getKeyPartition(Object) - Method in interface com.tangosol.net.partition.KeyPartitioningStrategy
-
Determine the partition to which a particular key should be assigned.
- getKeyPartition(Object) - Method in class com.tangosol.util.NullImplementation.NullBackingMapManagerContext
-
Determine the partition to which the specified key belongs.
- getKeyPartitioningStrategy() - Method in interface com.tangosol.net.PartitionedService
-
Determine the strategy for key partitioning that this service has been
configured to use.
- getKeys(String) - Method in class com.tangosol.coherence.rest.CacheResource
-
Return the keys of cache entries that satisfy the given query criteria.
- getKeys(UriInfo) - Method in class com.tangosol.coherence.rest.NamedQueryResource
-
Return the keys for cache entries that satisfy criteria defined by
this resource.
- getKeys() - Method in class com.tangosol.util.filter.InKeySetFilter
-
Obtain the underlying key set.
- getKeys() - Method in class com.tangosol.util.filter.KeyFilter
-
Get the set of keys that are evaluated to true by this filter.
- getKeySet() - Method in class com.tangosol.util.MapListenerSupport
-
Obtain a set of all keys that have associated key listeners.
- getKeystoreDependencies() - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.DefaultManagerDependencies
-
get manager keystore dependencies
- getKeystoreDependencies() - Method in interface com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.ManagerDependencies
-
- getKeyToInternalConverter() - Method in interface com.tangosol.net.BackingMapManagerContext
-
Return a converter that allows the manager (or a backing map
managed thereby) to convert a key object into its internal form
as managed by the CacheService.
- getKeyToInternalConverter() - Method in class com.tangosol.util.NullImplementation.NullBackingMapManagerContext
-
Return a converter that allows the manager (or a backing map
managed thereby) to convert a key object into its internal form
as managed by the CacheService.
- getKeyType() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
-
- getKeyType() - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheMXBean
-
- getKeyType() - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCacheConfiguration
-
- getLastAnalysisContext() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
Return the last AnalysisContext.
- getLastAnalysisTime() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
Get the last time a partition distribution analysis was performed.
- getLastAnalysisTime() - Method in interface com.tangosol.net.partition.SimpleStrategyMBean
-
Get the last time a partition distribution analysis was performed.
- getLastBlockOffset() - Method in class com.tangosol.io.nio.BinaryMap
-
Get the offset of the last block in the buffer.
- getLastChildIndex(int) - Method in class com.tangosol.io.pof.reflect.ComplexPofValue
-
Return index of the last parsed child with an index lower than the
specified one.
- getLastIndex() - Method in class com.tangosol.util.AbstractLongArray
-
Determine the last index that exists in the LongArray.
- getLastIndex() - Method in class com.tangosol.util.AbstractSafeLongArray
-
- getLastIndex() - Method in class com.tangosol.util.AbstractSparseArray
-
Determine the last index that exists in the LongArray.
- getLastIndex() - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray
-
- getLastIndex() - Method in interface com.tangosol.util.LongArray
-
Determine the last index that exists in the LongArray.
- getLastIndex() - Method in class com.tangosol.util.SimpleLongArray
-
Determine the last index that exists in the LongArray.
- getLastIndex() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
-
- getLastOwnershipMembers() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
Return the set of ownership-enabled members present when the analysis was
last considered.
- getLastPosition() - Method in class com.tangosol.io.pof.ValidatingPofHandler.Complex
-
Obtain the last known position, which is the index (or property
number) of the most recent value.
- getLastSafeTimeMillis() - Static method in class com.tangosol.util.Base
-
- getLastTouchMillis() - Method in interface com.tangosol.net.cache.ConfigurableCacheMap.Entry
-
Determine when the cache entry was last touched.
- getLastTouchMillis() - Method in class com.tangosol.net.cache.OldCache.Entry
-
Deprecated.
Determine when the cache entry was last touched.
- getLastTouchMillis() - Method in class com.tangosol.net.cache.SerializationCache.EntrySet.Entry
-
Determine when the cache entry was last touched.
- getLastTouchMillis() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache.EntrySet.Entry
-
Determine when the cache entry was last touched.
- getLastTouchMillis() - Method in class com.tangosol.util.ConverterCollections.ConverterCacheEntry
-
Determine when the cache entry was last touched.
- getLastTransferTime() - Method in class com.tangosol.net.partition.PartitionStatistics
-
Return the time (on the primary owner) at which the partition was last
transferred or restored.
- getLatestOldValue(MapEvent) - Static method in class com.tangosol.net.cache.OverflowMap
-
Obtain the latest old value from the passed event.
- getLatestOldValue() - Method in class com.tangosol.net.cache.OverflowMap.HistoricCacheEvent
-
Obtain the value that needs to be saved if this event represents
a merged sequence of events ending with the eviction of data.
- getLeavingMembers() - Method in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy
-
Return the set of members that are leaving the associated service
- getLedASTName() - Method in class com.tangosol.coherence.dsltools.precedence.OPToken
-
Get led AST Name for this token
- getLegacySocketProvider(XmlElement) - Method in class com.tangosol.net.SocketProviderFactory
-
Deprecated.
- getLength() - Method in class com.tangosol.io.nio.BinaryMap.Block
-
Determine the length of the block.
- getLength() - Method in class com.tangosol.io.pof.reflect.PofArray
-
Return the length of this array.
- getLevel() - Method in class com.tangosol.util.SafeSortedMap.IndexNode
-
Return the index-level that this IndexNode represents.
- getLine() - Method in class com.tangosol.util.Base.StackFrame
-
- getLineNumber() - Method in class com.tangosol.util.Base.StackFrame
-
- getLink() - Method in class com.tangosol.coherence.dsltools.base.BaseTokenStream
-
Answer a BaseTokenStream that can become the target of streaming
- getList() - Method in class com.tangosol.util.ConverterCollections.ConverterList
-
Return the underlying List.
- getList(List<F>, Converter<F, T>, Converter<T, F>) - Static method in class com.tangosol.util.ConverterCollections
-
Returns a Converter instance of List.
- getList() - Method in class com.tangosol.util.ImmutableArrayList
-
Return a java.util.List view of this ImmutableArrayList.
- getList() - Method in class com.tangosol.util.ImmutableMultiList
-
Return a java.util.List view of this ImmutableMultiList.
- getList(List, Class) - Static method in class com.tangosol.util.RestrictedCollections
-
Returns a restricted instance of List.
- getListenerBuilder() - Method in class com.tangosol.coherence.config.scheme.AbstractCachingScheme
-
- getListenerBuilder() - Method in interface com.tangosol.coherence.config.scheme.ObservableCachingScheme
-
- getListenerClassNames() - Method in class com.tangosol.util.Listeners
-
Return a comma separated list of the listener class names.
- getListenerExtentId(long) - Static method in class com.tangosol.persistence.CachePersistenceHelper
-
Return the extent identifier that contains listener registration
information for the cache with the given identifier.
- getListeners(Filter) - Method in class com.tangosol.util.MapListenerSupport
-
Obtain the Listeners object for a given filter.
- getListeners(Object) - Method in class com.tangosol.util.MapListenerSupport
-
Obtain the Listeners object for a given key.
- getListIterator() - Method in class com.tangosol.util.ConverterCollections.ConverterListIterator
-
Return the underlying ListIterator.
- getListIterator(ListIterator<F>, Converter<F, T>, Converter<T, F>) - Static method in class com.tangosol.util.ConverterCollections
-
Returns a Converter instance of ListIterator.
- getListIterator(ListIterator, Class) - Static method in class com.tangosol.util.RestrictedCollections
-
Returns a restricted instance of ListIterator.
- getLoad(int) - Method in interface com.tangosol.net.partition.SimpleAssignmentStrategy.LoadCalculator
-
Return the load for the specified partition.
- getLoad(PartitionSet) - Method in interface com.tangosol.net.partition.SimpleAssignmentStrategy.LoadCalculator
-
Return the load for the specified set of partitions.
- getLoad(int) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.SimpleLoadCalculator
-
Return the load for the specified partition.
- getLoad(PartitionSet) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.SimpleLoadCalculator
-
Return the load for the specified set of partitions.
- getLoadBundler() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
Obtain the bundler for the "load" operations.
- getLoadFailures() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
Determine the number of load() failures.
- getLoadMillis() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
Determine the cumulative time spent on load() operations.
- getLoadOps() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
Determine the number of load() operations.
- getLocalAddress() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the unicast IP address that the cluster member will listen/publish on
or null for default.
- getLocalAddress(Filter) - Static method in class com.tangosol.net.InetAddressHelper
-
Obtain the "best" local host address which matches the supplied filter.
- getLocalAddress() - Method in interface com.tangosol.net.NameService
-
Retrieve the running or configured listening address.
- getLocalBufferSize() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the preferred size for the unicast socket input buffer (SO_RCVBUF).
- getLocalDiscoveryAddress() - Method in interface com.tangosol.net.ClusterDependencies
-
Return the InetAddress on which this member will listen for discovery requests.
- getLocalizedMessage() - Method in exception com.tangosol.util.WrapperException
-
Creates a localized description of this WrapperException
.
- getLocalListenerPriority() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the priority of the "local" PacketListener daemon thread.
- getLocalMember() - Method in class com.tangosol.net.AbstractServiceLoadBalancer
-
Return the Member object representing the local cluster member.
- getLocalMember() - Method in interface com.tangosol.net.Cluster
-
Returns a Member object representing the local (i.e. this JVM)
member of the cluster.
- getLocalMember() - Method in interface com.tangosol.net.events.partition.TransferEvent
-
Return the local
Member
associated with this transfer
operation.
- getLocalMember() - Method in interface com.tangosol.net.OperationalContext
-
Return a Member object representing this process.
- getLocalName() - Method in class com.tangosol.run.xml.QualifiedName
-
- getLocalPort() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the unicast port number that the member will listen on.
- getLocalPort() - Method in class com.tangosol.net.TcpDatagramSocket.Impl
- getLocalPortAutoAdjust() - Method in interface com.tangosol.net.ClusterDependencies
-
Return the maximum unicast port that can be auto-adjusted to.
- getLocalTcpPort() - Method in interface com.tangosol.net.OperationalContext
-
Return the TCP port on which this member is bound.
- getLocalTransaction(NamedCache) - Static method in class com.tangosol.net.CacheFactory
-
Factory method returning an instance of the TransactionMap that is
based on the specified NamedCache and is local to this JVM.
- getLocalXmlName() - Method in class com.tangosol.run.xml.PropertyAdapter
-
Determine the "local" XML element name that will be used to hold the
property value.
- getLock() - Method in class com.tangosol.util.SafeLongArray
-
Return the lock used to protect this LongArray, with the unsafe delegate as its
resource
.
- getLock() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperCollection
-
Return the ReadWriteLock that is used to manage concurrent access
and modifications to the underlying map.
- getLock() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperEntry
-
Return the ReadWriteLock that is used to manage concurrent access
and modifications to the underlying map.
- getLock() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
-
Return the ReadWriteLock that is used to manage concurrent access
and modifications to the underlying map.
- getLockAction() - Method in class com.tangosol.util.SegmentedConcurrentMap
-
Return the registered action for lock().
- getLockCount() - Method in class com.tangosol.util.WrapperConcurrentMap.Lock
-
Return the lock count.
- getLockDelaySeconds() - Method in class com.tangosol.net.cache.SerializationPagedCache
-
Determine the number of seconds to wait for a lock in debug mode.
- getLockDescription(Object) - Method in class com.tangosol.util.WrapperConcurrentMap
-
Make a human-readable description of the information kept about the
passed key.
- getLockDirectory() - Method in class com.tangosol.persistence.AbstractPersistenceManager
-
Return the directory used to store lock files.
- getLockExtentId(long) - Static method in class com.tangosol.persistence.CachePersistenceHelper
-
Return the extent identifier that contains lock registration
information for the cache with the given identifier.
- getLockHolder() - Method in class com.tangosol.util.SegmentedConcurrentMap.LockableEntry
-
Return the holder of this lockable entry, or null if this entry is not
locked.
- getLockMap() - Method in class com.tangosol.net.cache.SerializationPagedCache
-
Obtain the map used for managing key- and map-level locks to ensure
data consistency.
- getLockThread() - Method in class com.tangosol.util.WrapperConcurrentMap.Lock
-
Return the Thread object holding this Lock.
- getLockTypeDescription() - Method in class com.tangosol.util.WrapperConcurrentMap.Lock
-
Return a human readable description of the Lock type.
- getLog() - Static method in class com.tangosol.util.Base
-
Obtains the current writer used for logging.
- getLoggingConfig() - Static method in class com.tangosol.net.CacheFactory
-
Return the configuration info for the logging facility as defined
by the "logging-config" element in the tangosol-coherence.xml
configuration file.
- getLong(String) - Static method in class com.tangosol.coherence.config.Config
-
Return Coherence system property value as a Long.
- getLong(String, long) - Static method in class com.tangosol.coherence.config.Config
-
Return Coherence system property value as a long.
- getLong() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Return the long which this PofValue represents.
- getLong() - Method in interface com.tangosol.io.pof.reflect.PofValue
-
Return the long which this PofValue represents.
- getLong() - Method in class com.tangosol.run.xml.SimpleValue
-
Get the value as a long.
- getLong(long) - Method in class com.tangosol.run.xml.SimpleValue
-
Get the value as a long.
- getLong() - Method in interface com.tangosol.run.xml.XmlValue
-
Get the value as a long.
- getLong(long) - Method in interface com.tangosol.run.xml.XmlValue
-
Get the value as a long.
- getLongArray() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Return the long[] which this PofValue represents.
- getLongArray() - Method in interface com.tangosol.io.pof.reflect.PofValue
-
Return the long[] which this PofValue represents.
- getLongArray(LongArray<F>, Converter<F, T>, Converter<T, F>) - Static method in class com.tangosol.util.ConverterCollections
-
Returns a LongArray storing values with type F
and converting
to type V
as and when required.
- getLostPacketThreshold() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the number of sequential packets which may be lost before declaring a
member paused, and starting to trickle packets.
- getLowerBound() - Method in class com.tangosol.util.filter.BetweenFilter
-
Obtain the lower bound of the range being used to evaluate
values by this BetweenFilter.
- getLowerBound() - Method in class com.tangosol.util.SafeSortedMap.ViewMap
-
Return the lower bound of this ViewMap.
- getLowUnitFairShare() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
-
Return the fair share of low-units per partition map.
- getLowUnits(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.AbstractJournalScheme
-
Return the lowest number of units that a cache is pruned down to when
pruning takes place.
- getLowUnits(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.LocalScheme
-
Return the lowest number of units that a cache is pruned down to when
pruning takes place.
- getLowUnits() - Method in interface com.tangosol.net.cache.ConfigurableCacheMap
-
Determine the point to which the cache will shrink when it prunes.
- getLowUnits() - Method in class com.tangosol.net.cache.OldCache
-
Deprecated.
Determine the point to which the cache will shrink when it prunes.
- getLowUnits() - Method in class com.tangosol.net.cache.SerializationCache
-
Determine the point to which the cache will shrink when it prunes.
- getLowUnits() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
-
Determine the point to which the cache will shrink when it prunes.
- getLruArray() - Method in class com.tangosol.net.cache.SerializationCache
-
Get the LRU data structure.
- getMachineCount() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.BackupStrength
-
Return the site count.
- getMachineId() - Method in interface com.tangosol.net.MemberIdentity
-
Return the Member's machine Id.
- getMachineId() - Method in class com.tangosol.net.proxy.RemoteMember
-
Return the Member's machine Id.
- getMachineName() - Method in interface com.tangosol.net.MemberIdentity
-
Return the configured name for the Machine (such as a host name) in which
this Member resides.
- getMachineName() - Method in class com.tangosol.net.proxy.RemoteMember
-
Return the configured name for the Machine (such as a host name) in which
this Member resides.
- getManagement() - Method in interface com.tangosol.net.Cluster
-
Returns the current management registry.
- getManagementConfig() - Static method in class com.tangosol.net.CacheFactory
-
Return the management framework configuration.
- getManager() - Method in interface com.tangosol.net.BackingMapManagerContext
-
Return the BackingMapManager this object is a context for.
- getManager() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
Return the DistributionManager.
- getManager() - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceManager
-
Return the underlying PersistenceManager.
- getManager() - Method in class com.tangosol.util.NullImplementation.NullBackingMapManagerContext
-
Return the BackingMapManager this object is a context for.
- getManagerContext() - Method in interface com.tangosol.net.BackingMapContext
-
- getManagerContinuation(PersistenceManager<R>) - Method in interface com.tangosol.persistence.SafePersistenceWrappers.FailureContinuationFactory
-
Return a failure continuation to handle unexpected exceptions thrown
by operations against the specified PersistenceManager.
- getMandatoryProperty(String, Type, XmlElement) - Method in class com.tangosol.config.xml.DefaultProcessingContext
-
Obtains the strongly typed value for the property defined at the path relative to the specified
XmlElement
.
- getMandatoryProperty(String, Type, XmlElement) - Method in interface com.tangosol.config.xml.ProcessingContext
-
Obtains the strongly typed value for the property defined at the path relative to the specified
XmlElement
.
- getMap(Map) - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Return the Map which this PofValue represents.
- getMap(Map) - Method in interface com.tangosol.io.pof.reflect.PofValue
-
Return the Map which this PofValue represents.
- getMap() - Method in class com.tangosol.net.cache.MapCacheStore
-
Returns the Map that this CacheStore uses for its storage.
- getMap() - Method in class com.tangosol.net.cache.SeppukuMapListener
-
Returns the front Map invalidated by this listener.
- getMap() - Method in class com.tangosol.util.ConverterCollections.ConverterMap
-
Return the underlying Map.
- getMap(Map<FK, FV>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Static method in class com.tangosol.util.ConverterCollections
-
Returns a Converter instance of Map.
- getMap() - Method in class com.tangosol.util.MapEvent
-
Return an ObservableMap object on which this event has actually
occurred.
- getMap() - Method in class com.tangosol.util.MapSet
-
Obtain the underlying Map for purposes of synchronization or read-only
access; the caller must never directly modify the returned Map.
- getMap() - Static method in class com.tangosol.util.NullImplementation
-
Returns an instance of the NullMap.
- getMap(Map, Class, Class) - Static method in class com.tangosol.util.RestrictedCollections
-
Returns a restricted instance of Map.
- getMap() - Method in class com.tangosol.util.WrapperObservableMap
-
Get the Map that is wrapped by this wrapper.
- getMapArray() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
-
Get the mapping between partition IDs and backing maps.
- getMapEntry() - Method in class com.tangosol.util.SafeSortedMap.EntryNode
-
Return a MapEntry view of this EntryNode, suitable for returning to
the EntrySet iterator.
- getMapEvent() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent
-
Return the underlying MapEvent.
- getMapEvent(ObservableMap, MapEvent, Converter, Converter) - Static method in class com.tangosol.util.ConverterCollections
-
Returns an instance of a MapEvent that uses Converters to retrieve
the event's data.
- getMapEvent(ObservableMap, MapEvent, Converter, Converter, BackingMapManagerContext) - Static method in class com.tangosol.util.ConverterCollections
-
Returns an instance of a MapEvent that uses Converters to retrieve the
event's data, and additionally provides access to the
BackingMapManagerContext.
- getMapEvent() - Method in class com.tangosol.util.MapListenerSupport.FilterEvent
-
Return the wrapped event.
- getMapEventFilter() - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughListenerRegistration
-
- getMapFactories() - Method in class com.tangosol.io.bdb.DatabaseFactoryManager
-
Get the Map of Database factories.
- getMapFilters() - Method in class com.tangosol.net.management.MBeanAccessor.QueryBuilder.ParsedQuery
-
Return a map of key to Filter used to test against the corresponding
key/value within the ObjectName.
- getMapListener() - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughListenerRegistration
-
- getMapListener() - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
Obtain the configured
MapListener
for this
ContinuousQueryCache
.
- getMapListener(ObservableMap, MapListener, Converter, Converter) - Static method in class com.tangosol.util.ConverterCollections
-
Returns a converter listener for the specified listener and Converters.
- getMapListener() - Method in class com.tangosol.util.MapListenerSupport.WrapperListener
-
Return the underlying MapListener.
- getMapListenersRegistry() - Method in class com.tangosol.coherence.config.builder.MapBuilder.Dependencies
-
- getMapListenerSupport() - Method in class com.tangosol.net.cache.AbstractSerializationCache
-
Accessor for the MapListenerSupport for sub-classes.
- getMapListenerSupport() - Method in class com.tangosol.net.cache.OldCache
-
Deprecated.
Accessor for the MapListenerSupport for sub-classes.
- getMapListenerSupport() - Method in class com.tangosol.net.cache.OverflowMap
-
Accessor for the MapListenerSupport for sub-classes.
- getMapListenerSupport() - Method in class com.tangosol.util.ObservableHashMap
-
Accessor for the MapListenerSupport for sub-classes.
- getMapListenerSupport() - Method in class com.tangosol.util.WrapperObservableMap
-
Accessor for the MapListenerSupport for sub-classes.
- getMappingRegistry() - Method in class com.tangosol.coherence.config.CacheConfig
-
- getMappingRegistry() - Method in class com.tangosol.coherence.config.CacheMappingRegistry
-
Deprecated.
- getMarkInternal() - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
-
Obtain the offset of the stream mark.
- getMarshaller(Class, MediaType) - Method in class com.tangosol.coherence.rest.io.MarshallerRegistry
-
Return the marshaller for the specified root class and media type.
- getMarshaller(Class, String) - Method in class com.tangosol.coherence.rest.io.MarshallerRegistry
-
Return the marshaller for the specified root class and media type.
- getMarshallerMap() - Method in class com.tangosol.coherence.rest.config.ResourceConfig
-
Return a map of marshaller classes keyed by media type.
- getMarshallerRegistry() - Method in class com.tangosol.coherence.rest.config.RestConfig
-
Return the configured marshaller registry.
- getMask() - Method in enum com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy.ActionRule
-
- getMaxCapacity() - Method in class com.tangosol.io.nio.AbstractBufferManager
-
Determine the maximum size that the managed buffer can reach.
- getMaxCapacity() - Method in class com.tangosol.io.nio.AbstractStoreManager
-
Determine the maximum size that the managed buffers can reach.
- getMaxCapacity() - Method in interface com.tangosol.io.nio.ByteBufferManager
-
Determine the maximum size that the managed buffer can reach.
- getMaxDecDigits(int) - Static method in class com.tangosol.util.Base
-
Calculate the number of decimal digits needed to display the passed
value.
- getMaxHexDigits(int) - Static method in class com.tangosol.util.Base
-
Calculate the number of hex digits needed to display the passed value.
- getMaximumCapacity() - Method in class com.tangosol.io.AbstractWriteBuffer
-
Determine the maximum number of bytes that the buffer can hold.
- getMaximumCapacity() - Method in class com.tangosol.io.ByteArrayWriteBuffer.Allocator
-
Determine the largest amount of aggregate WriteBuffer capacity
that this factory can provide.
- getMaximumCapacity() - Method in class com.tangosol.io.ByteArrayWriteBuffer
-
Determine the maximum number of bytes that the buffer can hold.
- getMaximumCapacity() - Method in class com.tangosol.io.DelegatingWriteBuffer
-
Determine the maximum number of bytes that the buffer can hold.
- getMaximumCapacity() - Method in class com.tangosol.io.MultiBufferWriteBuffer
-
Determine the maximum number of bytes that the buffer can hold.
- getMaximumCapacity() - Method in interface com.tangosol.io.MultiBufferWriteBuffer.WriteBufferPool
-
Determine the largest amount of aggregate WriteBuffer capacity
that this factory can provide.
- getMaximumCapacity() - Method in interface com.tangosol.io.WriteBuffer
-
Determine the maximum number of bytes that the buffer can hold.
- getMaximumCapacity() - Method in class com.tangosol.util.ExternalizableHelper.Stats
-
Determine the largest amount of aggregate WriteBuffer capacity
that this factory can provide.
- getMaximumPages() - Method in class com.tangosol.net.cache.SerializationPagedCache
-
Determine the maximum number of pages that the cache will manage,
beyond which the oldest pages are destroyed.
- getMaximumPages() - Method in class com.tangosol.net.cache.SerializationPagedCache.PagedBinaryStore
-
Determine the maximum number of pages that the cache will manage,
beyond which the oldest pages are destroyed.
- getMaximumSize(ParameterResolver) - Method in class com.tangosol.coherence.config.builder.storemanager.AbstractNioManagerBuilder
-
Return the maximum buffer size in bytes.
- getMaximumSize(ParameterResolver) - Method in interface com.tangosol.coherence.config.scheme.BackupMapConfig
-
Return the maximum buffer size in bytes for off-heap and file-mapped
backup maps.
- getMaximumSize(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.DistributedScheme.BackupConfig
-
Return the maximum buffer size in bytes for off-heap and file-mapped
backup maps.
- getMaxIncrement() - Method in class com.tangosol.io.nio.AbstractBufferManager
-
- getMaxLevel() - Method in class com.tangosol.util.SafeSortedMap
-
Return the maximum index-level that this map is allowed to reach.
- getMaxLoadFactor() - Method in class com.tangosol.io.nio.BinaryMap
-
Determine the load factor for the map.
- getMaxLoadNodeId() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
Get the node id with the maximum storage size.
- getMaxLoadNodeId() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.JMXPartitionStats
-
Return node ID with maximum node storage size.
- getMaxLoadNodeId() - Method in interface com.tangosol.net.partition.SimpleStrategyMBean
-
Get the node id with the maximum storage size.
- getMaxPartitionSize() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.JMXPartitionStats
-
Return maximum partition storage size.
- getMaxPartitionSizeKB() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
Get the maximum partition storage size.
- getMaxPartitionSizeKB() - Method in interface com.tangosol.net.partition.SimpleStrategyMBean
-
Get the maximum partition storage size.
- getMaxPoolSize() - Method in interface com.tangosol.net.ThreadPoolManager
-
Return the maximum size of the thread pool.
- getMaxResults() - Method in class com.tangosol.coherence.rest.config.NamedQuery
-
Return the max allowed result set size.
- getMaxResults() - Method in class com.tangosol.coherence.rest.config.ResourceConfig
-
Return the max size of result set this resource is allowed to return.
- getMaxStorageSize() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.JMXPartitionStats
-
Return maximum node storage size.
- getMaxStorageSizeKB() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
Get maximum node storage size.
- getMaxStorageSizeKB() - Method in interface com.tangosol.net.partition.SimpleStrategyMBean
-
Get maximum node storage size.
- getMaxWaitMillis(long) - Method in class com.tangosol.util.Daemon
-
If this Daemon is guarded, return the maximum wait time that the Daemon
is allowed to wait for, according to its SLA.
- getMBean() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCache
-
Get JMX Bean associated with Cache.
- getMBean() - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
-
- getMBean() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
-
Get JMX Management Bean.
- getMBean() - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
-
- getMBean() - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
-
- getMBeanDomain() - Method in class com.tangosol.net.management.MBeanAccessor.QueryBuilder
-
The MBean Domain to be used for the query.
- getMBeanInfo(String) - Method in interface com.tangosol.net.management.MBeanServerProxy
-
Return the MBeanInfo for a given MBean.
- getMBeanInfo(String) - Method in class com.tangosol.net.management.WrapperMBeanServerProxy
-
- getMBeanName(String) - Static method in class com.tangosol.persistence.CachePersistenceHelper
-
Obtain the PersistenceManagerMBean name for a given service.
- getMBeanServer() - Method in class com.tangosol.net.management.MBeanReference
-
Return the MbeanServer where the ObjectName is located.
- getMBeanServerProxy() - Method in interface com.tangosol.net.management.Registry
-
Obtain a reference to the MBeanServerProxy for this Registry.
- getMediaType() - Method in class com.tangosol.coherence.rest.util.StaticContent
-
Return media type of this content.
- getMember() - Method in class com.tangosol.net.MemberEvent
-
Return the Member associated with this event.
- getMember() - Method in interface com.tangosol.net.NameService.RequestContext
-
Get the client
Member
that sent the request.
- getMember(int) - Method in interface com.tangosol.net.partition.DistributionManager
-
Return the ownership-enabled service member with the specified
mini-id, or null if the member does not exist.
- getMember(int) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
Return the PartitionedService Member with the specified mini-id.
- getMemberGUIDs() - Method in class com.tangosol.persistence.GUIDHelper.GUIDResolver
-
Return a Map of member id to an array of GUIDs.
- getMemberId(String) - Static method in class com.tangosol.persistence.GUIDHelper
-
Parse the specified GUID and return the originating member-id.
- getMemberIdentity() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the member identity.
- getMemberJoinDelay() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
Return the amount of time in ms to delay the analysis after a member has
joined.
- getMemberList(Member) - Method in class com.tangosol.net.proxy.DefaultProxyServiceLoadBalancer
-
- getMemberList(Member) - Method in interface com.tangosol.net.ServiceLoadBalancer
-
Called by the Service when a new client connects to obtain an
ordered list of Members to which the new client should be redirected.
- getMemberList(Member) - Method in class com.tangosol.net.SimpleServiceLoadBalancer
-
Called by the Service when a new client connects to obtain an
ordered list of Members to which the new client should be redirected.
- getMemberLoad(Member, boolean) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
Return the (primary or backup) partition load of the specified member.
- getMemberName() - Method in interface com.tangosol.net.MemberIdentity
-
Return the configured name for the Member.
- getMemberName() - Method in class com.tangosol.net.proxy.RemoteMember
-
Return the configured name for the Member.
- getMemberSet() - Method in interface com.tangosol.net.Cluster
-
Returns a Set of Member objects, one for each Member of
the cluster.
- getMembersOwningPartition(Map<Integer, Object[]>, String) - Static method in class com.tangosol.persistence.ArchiverHelper
-
Deprecated.
Return the
Set
of members who are aware of a particular
store.
- getMemorySize() - Method in class com.tangosol.coherence.config.unit.Units
-
Return the MemorySize
.
- getMemoryUsage() - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.IndexLookupRecord
-
Returns index memory usage in bytes.
- getMessage() - Method in exception com.tangosol.config.ConfigurationException
- getMessage() - Method in exception com.tangosol.io.pof.PortableException
-
Return the detail message string of this PortableException.
- getMessage() - Method in exception com.tangosol.util.WrapperException
-
Returns the error message string of this WrapperException object.
- getMessageBacklogIncoming() - Method in interface com.tangosol.net.ServiceLoad
-
Return the number of messages that are queued for processing.
- getMessageBacklogOutgoing() - Method in interface com.tangosol.net.ServiceLoad
-
Return the number of messages that are queued for delivery.
- getMetadata() - Method in class com.tangosol.persistence.AbstractPersistenceManager
-
Return metadata for this manager.
- getMetadata(String) - Method in class com.tangosol.persistence.AbstractSnapshotArchiver
-
Internal implementation to retrieve the metadata stored for the archived
snapshot.
- getMetadata(String) - Method in class com.tangosol.persistence.DirectorySnapshotArchiver
-
- getMethodName() - Method in class com.tangosol.util.Base.StackFrame
-
- getMethodName() - Method in class com.tangosol.util.extractor.ReflectionExtractor
-
Determine the name of the method that this extractor is configured to
invoke.
- getMethodName() - Method in class com.tangosol.util.extractor.ReflectionUpdater
-
Determine the name of the method that this extractor is configured to
invoke.
- getMethodName() - Method in class com.tangosol.util.extractor.UniversalExtractor
-
Return the method name that this extractor is configured to invoke.
- getMethodName() - Method in class com.tangosol.util.extractor.UniversalUpdater
-
Determine the name of the method that this extractor is configured to
invoke.
- getMethodName() - Method in class com.tangosol.util.processor.MethodInvocationProcessor
-
Returns the name of the method to invoke.
- getMinCapacity() - Method in class com.tangosol.io.nio.AbstractBufferManager
-
Determine the minimum size that the managed buffer can reach.
- getMinCapacity() - Method in class com.tangosol.io.nio.AbstractStoreManager
-
Determine the minimum size that the managed buffers can reach.
- getMinCapacity() - Method in interface com.tangosol.io.nio.ByteBufferManager
-
Determine the minimum size that the managed buffer can reach.
- getMinLoadFactor() - Method in class com.tangosol.io.nio.BinaryMap
-
Determine the "unload factor" for the map.
- getMinPoolSize() - Method in interface com.tangosol.net.ThreadPoolManager
-
Return the minimum size of the thread pool.
- getMinute() - Method in class com.tangosol.io.pof.RawTime
-
Determine the time's minute value.
- getMinuteOffset() - Method in class com.tangosol.io.pof.RawTime
-
Determine the timezone's minute offset value.
- getMinutes() - Method in class com.tangosol.io.pof.RawDayTimeInterval
-
Determine the number of minutes in the day-time interval.
- getMinutes() - Method in class com.tangosol.io.pof.RawTimeInterval
-
Determine the number of minutes in the time interval.
- getMissCache() - Method in class com.tangosol.net.cache.SimpleOverflowMap
-
Returns the optional miss cache.
- getMissCacheScheme() - Method in class com.tangosol.coherence.config.scheme.OverflowScheme
-
Return the scheme for the cache used to maintain information on cache
misses.
- getMissCacheScheme() - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
-
Return the
Scheme
for the cache used to maintain information on cache
misses.
- getMissedSoftTimeout() - Method in class com.tangosol.net.GuardSupport.Context
-
Return the last missed soft-timeout for this Guardable (that
resulted in a recovery attempt).
- getMissesCache() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Get the optional map used to cache CacheLoader (or CacheStore) misses.
- getMode() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the Mode for the "license type", i.e. evaluation, development or
production use.
- getModificationCount() - Method in class com.tangosol.coherence.jcache.common.JCacheEntryMetaInf
-
Gets the number of times the internal value has been modified (set)
- getModificationCount() - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheValue
-
Gets the number of times the internal value has been modified (set)
- getModificationTime() - Method in class com.tangosol.coherence.jcache.common.JCacheEntryMetaInf
-
Gets the time (since the Epoc) in milliseconds since the internal value
was last modified.
- getModificationTime() - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheValue
-
Gets the time (since the Epoc) in milliseconds since the internal value
was last modified.
- getModulo() - Method in class com.tangosol.io.nio.BinaryMap
-
Determine the current modulo.
- getMonth() - Method in class com.tangosol.io.pof.RawDate
-
Determine the date's month value.
- getMonths() - Method in class com.tangosol.io.pof.RawYearMonthInterval
-
Determine the number of months in the year-month interval.
- getMostRecentTaskTime() - Method in class com.tangosol.util.TaskDaemon
-
Determine when the most recent task was run.
- getMutator() - Method in class com.tangosol.run.xml.PropertyAdapter
-
Obtain the Method object that is used to call the property mutator.
- getMvelParserContext() - Static method in class com.tangosol.coherence.rest.util.RestHelper
-
Return an instance of ParserContext
to be used for evaluation.
- getName() - Method in class com.tangosol.coherence.config.builder.NamedEventInterceptorBuilder
-
- getName() - Method in interface com.tangosol.coherence.config.builder.ParameterizedBuilderRegistry.Registration
-
Obtains the name of the builder.
- getName() - Method in class com.tangosol.coherence.config.builder.SimpleParameterizedBuilderRegistry.BuilderRegistration
-
- getName() - Method in class com.tangosol.coherence.config.builder.SimpleParameterizedBuilderRegistry.RegistryKey
-
Return the builder name.
- getName() - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.ProviderBuilder
-
Referenced provider name
- getName() - Method in class com.tangosol.coherence.config.SchemeMappingRegistry.SchemeMappingKey
-
Return the resource name.
- getName() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCache
-
- getName() - Method in class com.tangosol.coherence.jcache.common.JCacheIdentifier
-
Get the JCache map name
- getName() - Method in class com.tangosol.coherence.rest.config.NamedQuery
-
Return the query name.
- getName() - Method in class com.tangosol.coherence.rest.util.PropertySpec
-
Return the property name.
- getName() - Method in class com.tangosol.io.bdb.BerkeleyDBBinaryStore.DatabaseHolder
-
Get the name of the underlying Database.
- getName(String) - Static method in class com.tangosol.io.FileHelper
-
Gets the name minus the path from a full filename.
- getName() - Method in class com.tangosol.io.pof.PofPrincipal
-
Return the name of this Principal.
- getName() - Method in exception com.tangosol.io.pof.PortableException
-
Return the name of the exception.
- getName() - Method in interface com.tangosol.io.Serializer
-
Return the name of this serializer.
- getName() - Method in class com.tangosol.net.cache.AbstractEvictionPolicy
-
Obtain the name of the eviction policy.
- getName() - Method in interface com.tangosol.net.cache.ConfigurableCacheMap.EvictionPolicy
-
Obtain the name of the eviction policy.
- getName() - Method in interface com.tangosol.net.cache.ConfigurableCacheMap.UnitCalculator
-
Obtain the name of the unit calculator.
- getName() - Method in class com.tangosol.net.cache.OldCache.InternalEvictionPolicy
-
Deprecated.
Obtain the name of the eviction policy.
- getName() - Method in class com.tangosol.net.cache.OldCache.InternalUnitCalculator
-
Deprecated.
Obtain the name of the unit calculator.
- getName() - Method in class com.tangosol.net.cache.SerializationCache.InternalEvictionPolicy
-
Obtain the name of the eviction policy.
- getName() - Method in class com.tangosol.net.cache.SimpleMemoryCalculator
-
Obtain the name of the unit calculator.
- getName() - Method in interface com.tangosol.net.NamedCache
-
- getName() - Method in interface com.tangosol.net.NamedCollection
-
Obtain the name of this NamedCollection.
- getName() - Method in class com.tangosol.net.partition.ObservableSplittingBackingMap
-
Determine the name of the cache for which this PartitionAwareBackingMap
exists.
- getName() - Method in interface com.tangosol.net.partition.PartitionAwareBackingMap
-
Determine the name of the cache for which this PartitionAwareBackingMap
exists.
- getName() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
-
Determine the name of the cache for which this PartitionAwareBackingMap
exists.
- getName() - Method in class com.tangosol.net.partition.ReadWriteSplittingBackingMap
-
Determine the name of the cache for which this PartitionAwareBackingMap
exists.
- getName() - Method in class com.tangosol.net.security.SimpleHandler
-
Return the name of this principal.
- getName() - Method in enum com.tangosol.net.SocketProviderFactory.Dependencies.ProviderType
-
- getName() - Method in class com.tangosol.net.topic.Subscriber.Name
-
Return the group name.
- getName() - Method in class com.tangosol.persistence.AbstractPersistenceManager
-
Return the name of this manager.
- getName() - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceManager
-
Return the name of this manager.
- getName() - Method in class com.tangosol.persistence.Snapshot
-
Return the name of the snapshot.
- getName() - Method in class com.tangosol.run.xml.PropertyAdapter
-
Obtain the name of the property that this PropertyAdapter handles.
- getName() - Method in class com.tangosol.run.xml.QualifiedName
-
Returns the entire qualified name, including the prefix and local name.
- getName() - Method in class com.tangosol.run.xml.SimpleAttribute
-
- getName() - Method in class com.tangosol.run.xml.SimpleElement
-
Get the name of the element.
- getName() - Method in interface com.tangosol.run.xml.XmlAttribute
-
- getName() - Method in class com.tangosol.run.xml.XmlBean.BeanInfo
-
Determine the element name that the XML bean will use when
serializing to XML.
- getName() - Method in interface com.tangosol.run.xml.XmlElement
-
Get the name of the element.
- getName() - Method in class com.tangosol.util.extractor.UniversalExtractor
-
- getName() - Method in interface com.tangosol.util.fsm.ExecutionContext
-
- getName() - Method in interface com.tangosol.util.fsm.FiniteStateMachine
-
- getName() - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine
-
- getName() - Method in class com.tangosol.util.fsm.Transition
-
- getName() - Method in class com.tangosol.util.NullImplementation.NullPersistenceManager
-
Return the name of this manager.
- getName() - Method in class com.tangosol.util.SimpleResourceRegistry.RegistryKey
-
Return the resource name.
- getNamedCache() - Method in interface com.tangosol.net.AsyncNamedCache
-
Return the
NamedCache
instance this
AsyncNamedCache
is
based on.
- getNamedCache(String, ClassLoader) - Method in class com.tangosol.run.jca.CacheAdapter
-
Obtain an instance of a NamedCache.
- getNamedCache(String, ClassLoader, TransactionMap.Validator, boolean) - Method in class com.tangosol.run.jca.CacheAdapter
-
Obtain an instance of a NamedCache.
- getNamedCache() - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
-
Return the underlying NamedCache.
- getNamedCache(NamedCache<FK, FV>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Static method in class com.tangosol.util.ConverterCollections
-
Returns a Converter instance of NamedCache that converts between the raw/from
types to the desired/to types.
- getNamedCacheName() - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCacheConfiguration
-
Obtains the desired mapping of a JCache
Cache
name to an
Coherence
NamedCache
.
- getNamedQuery(String) - Method in class com.tangosol.coherence.rest.config.QueryConfig
-
Return the named query.
- getNameList() - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.NameListDependencies
-
- getNamePattern() - Method in class com.tangosol.coherence.config.ResourceMapping
-
- getNamespaceHandler(String) - Method in class com.tangosol.config.xml.DefaultProcessingContext
-
Obtains the
NamespaceHandler
which is capable of processing the namespace with the specified prefix.
- getNamespaceHandler(URI) - Method in class com.tangosol.config.xml.DefaultProcessingContext
-
Obtains the
NamespaceHandler
that is capable of processing the namespace defined with the specified
URI
.
- getNamespaceHandler(URI) - Method in interface com.tangosol.config.xml.ProcessingContext
-
Obtains the
NamespaceHandler
that is capable of processing the namespace defined with the specified
URI
.
- getNamespaceHandler(String) - Method in interface com.tangosol.config.xml.ProcessingContext
-
Obtains the
NamespaceHandler
which is capable of processing the namespace with the specified prefix.
- getNamespaceHandlers() - Method in class com.tangosol.config.xml.DefaultProcessingContext
-
- getNamespaceHandlers() - Method in interface com.tangosol.config.xml.ProcessingContext
-
- getNamespacePrefix() - Method in class com.tangosol.run.xml.PropertyAdapter
-
Determine the default namespace prefix for the property.
- getNamespacePrefix() - Method in class com.tangosol.run.xml.XmlBean.BeanInfo
-
Obtain the default namespace prefix for this XML bean.
- getNamespacePrefix(XmlElement, String) - Static method in class com.tangosol.run.xml.XmlHelper
-
Retrieve the Namespace prefix for a given URI in a context of the
specified XmlElement.
- getNamespaceURI(String) - Method in class com.tangosol.config.xml.DefaultProcessingContext
-
Obtains the
URI
that is associated with the specified prefix.
- getNamespaceURI(String) - Method in interface com.tangosol.config.xml.ProcessingContext
-
Obtains the
URI
that is associated with the specified prefix.
- getNamespaceUri() - Method in class com.tangosol.run.xml.PropertyAdapter
-
Determine the namespace URI for the property.
- getNamespaceUri() - Method in class com.tangosol.run.xml.XmlBean.BeanInfo
-
Obtain the namespace URI for this XML bean.
- getNamespaceUri(XmlElement, String) - Static method in class com.tangosol.run.xml.XmlHelper
-
Retrieve the Namespace URI for a given prefix in a context of the
specified XmlElement.
- getNameUsing(String) - Method in class com.tangosol.coherence.config.ResourceMapping
-
Determines the name of a resource given a value for the wildcard
(assuming the resource name pattern for the mapping is using a wildcard).
- getNano() - Method in class com.tangosol.io.pof.RawTime
-
Determine the time's nanosecond value.
- getNanos(Date) - Static method in class com.tangosol.io.pof.PofBufferWriter
-
Extract the nanoseconds from the date.
- getNanos() - Method in class com.tangosol.io.pof.RawDayTimeInterval
-
Determine the number of nanoseconds in the day-time interval.
- getNanos() - Method in class com.tangosol.io.pof.RawTimeInterval
-
Determine the number of nanoseconds in the time interval.
- getNavigator() - Method in class com.tangosol.util.extractor.PofExtractor
-
Obtain the POF navigator for this extractor.
- getNest() - Method in class com.tangosol.coherence.dsltools.precedence.NestingOPToken
-
Obtain the NestedBaseTokens that this token will process.
- getNestEnd() - Method in class com.tangosol.coherence.dsltools.base.NestedBaseTokens
-
Obtain the character that ends the nesting.
- getNestStart() - Method in class com.tangosol.coherence.dsltools.base.NestedBaseTokens
-
Obtain the character that begins the nesting.
- getNewEntry() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent
-
Return a Map Entry that represents the state of the Entry after the
change occurred that generated this event.
- getNewEntry() - Method in class com.tangosol.util.MapEvent
-
Return a Map Entry that represents the state of the Entry after the
change occurred that generated this event.
- getNewestGUID(int) - Method in class com.tangosol.persistence.GUIDHelper.GUIDResolver
-
Return the newest GUID for the specified partition.
- getNewestGUIDs(PartitionSet) - Method in class com.tangosol.persistence.GUIDHelper.GUIDResolver
-
Return the list of the newest GUIDs for the specified set of partitions.
- getNewObjectInput(DataInput, ClassLoader) - Static method in class com.tangosol.util.ExternalizableHelper
-
Get a new ObjectInput for the passed DataInput, even if the passed
DataInput is an ObjectInput.
- getNewValue() - Method in class com.tangosol.coherence.rest.events.SimpleMapEvent
-
Return the new value associated with this event.
- getNewValue() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent
-
Return a new value associated with this event.
- getNewValue() - Method in class com.tangosol.util.MapEvent
-
Return a new value associated with this event.
- getNewValue() - Method in class com.tangosol.util.MapListenerSupport.FilterEvent
-
Return a new value associated with this event.
- getNewValueExtractor() - Method in class com.tangosol.util.transformer.ExtractorEventTransformer
-
Return a ValueExtractor used to transfrom the event's NewValue.
- getNext() - Method in class com.tangosol.util.SafeLinkedList.Node
-
- getNext() - Method in class com.tangosol.util.SafeSortedMap.EntryNode
-
Return the next EntryNode in the entry list.
- getNext() - Method in class com.tangosol.util.SafeSortedMap.SkipNode
-
Return the next node in this node-list.
- getNextAddress() - Method in interface com.tangosol.net.AddressProvider
-
- getNextAddress() - Method in class com.tangosol.net.CompositeAddressProvider
-
- getNextAddress() - Method in class com.tangosol.net.CompositeAddressProvider.SingleProvider
-
- getNextAddress() - Method in class com.tangosol.net.CompositeSocketAddressProvider
-
Obtain a next available address to use.
- getNextAddress() - Method in class com.tangosol.net.ConfigurableAddressProvider
-
- getNextAddress() - Method in class com.tangosol.net.RefreshableAddressProvider
-
- getNextAddress() - Method in interface com.tangosol.net.SocketAddressProvider
-
Obtain a next available address to use.
- getNextAddress() - Method in class com.tangosol.util.NullImplementation.NullAddressProvider
-
- getNextAddressInternal() - Method in class com.tangosol.net.RefreshableAddressProvider
-
Obtain the next available address to use.
- getNextBlockOffset() - Method in class com.tangosol.io.nio.BinaryMap.Block
-
Determine the offset of the next Block in the Buffer.
- getNextCheckTime() - Method in class com.tangosol.net.GuardSupport
-
Return the next time at which the Guardables should be checked.
- getNextCompactBlock() - Method in class com.tangosol.io.nio.BinaryMap
-
Determine the next block to compact.
- getNextDestination() - Method in class com.tangosol.net.LoadBalancer
-
Determine the next AddressPort combination to route to.
- getNextDestinationSocket() - Method in class com.tangosol.net.LoadBalancer
-
Open a socket to route to.
- getNextEntry() - Method in class com.tangosol.run.xml.SimpleElement.AttributeMap.Entry
-
Get the next entry in the linked list
- getNextExpiryTime() - Method in interface com.tangosol.net.cache.ConfigurableCacheMap
-
Determine the next expiry time for the cache entries.
- getNextExpiryTime() - Method in class com.tangosol.net.cache.OldCache
-
Deprecated.
Determine the next expiry time for the cache entries.
- getNextExpiryTime() - Method in class com.tangosol.net.cache.SerializationCache
-
Determine the next expiry time for the cache entries.
- getNextExpiryTime() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
-
Determine the next expiry time for the cache entries.
- getNextNodeOffset() - Method in class com.tangosol.io.nio.BinaryMap.Block
-
Determine the offset of the next Block in the linked list.
- getNextPosition() - Method in class com.tangosol.io.pof.ValidatingPofHandler.Complex
-
For complex values with contiguous values, obtain the next
position.
- getNextPosition() - Method in class com.tangosol.io.pof.ValidatingPofHandler.ComplexMap
-
For complex values with contiguous values, obtain the next
position.
- getNextPropertyIndex() - Method in class com.tangosol.io.pof.PofBufferReader.UserTypeReader
-
Return the index of the next property in the POF stream.
- getNextRehashBucket() - Method in class com.tangosol.io.nio.BinaryMap
-
Determine the next bucket to rehash.
- getNextTerm(OPScanner, String, String, String) - Static method in class com.tangosol.coherence.dslquery.internal.PersistenceToolsHelper
-
Return a term for a given scanner representing the specified name.
- getNextValidator() - Method in class com.tangosol.run.jca.SimpleValidator
-
Retrive the next Validator.
- getNextValidator() - Method in interface com.tangosol.util.TransactionMap.Validator
-
Retrive the next Validator.
- getNode(int) - Method in class com.tangosol.util.SafeLinkedList
-
Find and return the specified Node.
- getNonceCounter() - Method in class com.tangosol.util.SortedBag
-
Return the nonce counter used to assign unique element ids.
- getNonPartialIndexes(Map) - Method in class com.tangosol.util.filter.NotFilter
-
Get a Map of the available non-partial indexes from the given Map of all
available indexes.
- getNotificationInfo() - Method in class com.tangosol.net.management.AnnotatedStandardEmitterMBean
-
- getNotificationInfo() - Method in class com.tangosol.net.management.AnnotatedStandardEmitterMBean.SilentEmitter
-
- getNotificationInfo(Class<?>) - Static method in class com.tangosol.net.management.MBeanHelper
-
- getNotificationManager() - Method in interface com.tangosol.net.management.Registry
-
Obtain a reference to the NotificationManager for this Registry.
- getNudASTName() - Method in class com.tangosol.coherence.dsltools.precedence.OPToken
-
Get nud AST Name for this token
- getNullPasswordProviderBuilder() - Static method in class com.tangosol.coherence.config.xml.processor.PasswordProviderBuilderProcessor
-
Rerturns a builder for null password values.
- getNumber() - Method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
-
Obtain the Number representation of the node.
- getNumFactor() - Method in class com.tangosol.util.processor.NumberMultiplier
-
Returns the number to multiply by.
- getNumInc() - Method in class com.tangosol.util.processor.NumberIncrementor
-
Returns the number to increment by.
- getObject() - Method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
-
Obtain the Object representation of the node.
- getObject() - Method in class com.tangosol.util.SafeLinkedList.Node
-
- getObject() - Method in class com.tangosol.util.ThreadLocalObject
-
Get the value of the ThreadLocalObject for the current thread.
- getObjectArray() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Return the Object[] which this PofValue represents.
- getObjectArray() - Method in interface com.tangosol.io.pof.reflect.PofValue
-
Return the Object[] which this PofValue represents.
- getObjectInput(DataInput, ClassLoader, boolean) - Method in interface com.tangosol.io.ObjectStreamFactory
-
Obtain an ObjectInput based on the passed DataInput.
- getObjectInput() - Method in class com.tangosol.io.WrapperObjectInputStream
-
Obtain the underlying object providing the ObjectInput interface that
this object is delegating to.
- getObjectInput(DataInput, ClassLoader, boolean) - Method in class com.tangosol.util.ExternalizableHelper.DefaultObjectStreamFactory
-
Obtain an ObjectInput based on the passed DataInput.
- getObjectInput(DataInput, ClassLoader) - Static method in class com.tangosol.util.ExternalizableHelper
-
Get an ObjectInput for the passed DataInput object.
- getObjectMapper() - Static method in class com.tangosol.coherence.rest.providers.JacksonMapperProvider
-
- getObjectName() - Method in class com.tangosol.net.management.MBeanReference
-
Return the ObjectName of the qualified name.
- getObjectNameFilter() - Method in class com.tangosol.net.management.MBeanAccessor.QueryBuilder.ParsedQuery
-
Return a Filter that can be applied against an ObjectName and
ensures all the Filters within the
map
of filters test successfully (logical AND).
- getObjectOutput(DataOutput) - Method in interface com.tangosol.io.ObjectStreamFactory
-
Obtain an ObjectOutput based on the passed DataOutput.
- getObjectOutput() - Method in class com.tangosol.io.WrapperObjectOutputStream
-
Obtain the underlying object providing the ObjectOutput interface that
this object is delegating to.
- getObjectOutput(DataOutput) - Method in class com.tangosol.util.ExternalizableHelper.DefaultObjectStreamFactory
-
Obtain an ObjectOutput based on the passed DataOutput.
- getObjectOutput(DataOutput) - Static method in class com.tangosol.util.ExternalizableHelper
-
Get an ObjectOutput for the passed DataOutput object.
- getObjectStreamFactory() - Static method in class com.tangosol.util.ExternalizableHelper
-
Return the ObjectStreamFactory used to convert DataInput/Output into
ObjectInput/Output streams.
- getObservableMap() - Method in class com.tangosol.util.ConverterCollections.ConverterMapListener
-
Return the underlying ObservableMap.
- getObservableMap() - Method in class com.tangosol.util.ConverterCollections.ConverterObservableMap
-
Return the underlying ObservableMap.
- getObservableMap(ObservableMap<FK, FV>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Static method in class com.tangosol.util.ConverterCollections
-
Returns a Converter instance of ObservableMap.
- getObservableMap() - Static method in class com.tangosol.util.NullImplementation
-
Returns an instance of the NullObservableMap.
- getObserver() - Method in class com.tangosol.util.SimpleResourceRegistry.RegistryValue
-
Return the lifecycle observer for the registered resource.
- getOffset() - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
-
Determine the current offset of this BufferInput within the
underlying ReadBuffer.
- getOffset() - Method in class com.tangosol.io.AbstractWriteBuffer.AbstractBufferOutput
-
Determine the current offset of this BufferOutput within the
underlying WriteBuffer.
- getOffset() - Method in class com.tangosol.io.nio.BinaryMap.Block
-
Determine the offset of this Block in the Buffer.
- getOffset() - Method in class com.tangosol.io.nio.ByteBufferReadBuffer.ByteBufferInput
-
Determine the current offset of this BufferInput within the
underlying ReadBuffer.
- getOffset() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Return the offset of this value from the beginning of POF stream.
- getOffset() - Method in interface com.tangosol.io.ReadBuffer.BufferInput
-
Determine the current offset of this BufferInput within the
underlying ReadBuffer.
- getOffset() - Method in class com.tangosol.io.SizeEstimatingBufferOutput
-
- getOffset() - Method in class com.tangosol.io.WrapperBufferInput
-
Determine the current offset of this BufferInput within the
underlying ReadBuffer.
- getOffset() - Method in class com.tangosol.io.WrapperBufferOutput
-
Determine the current offset of this BufferOutput within the
underlying WriteBuffer.
- getOffset() - Method in interface com.tangosol.io.WriteBuffer.BufferOutput
-
Determine the current offset of this BufferOutput within the
underlying WriteBuffer.
- getOldEntry() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent
-
Return a Map Entry that represents the state of the Entry before the
change occurred that generated this event.
- getOldEntry() - Method in class com.tangosol.util.MapEvent
-
Return a Map Entry that represents the state of the Entry before the
change occurred that generated this event.
- getOldestActivePage() - Method in class com.tangosol.net.cache.SerializationPagedCache.PagedBinaryStore
-
Obtain the oldest active page.
- getOldestMember() - Method in interface com.tangosol.net.Cluster
-
Returns a Member object representing the senior cluster member.
- getOldestMember() - Method in interface com.tangosol.net.ServiceInfo
-
Return the "most senior" Member that is running this Service.
- getOldValue() - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheEntry
-
Obtains the old value for the entry.
- getOldValue() - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheEntryEvent
-
- getOldValue() - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCacheEntryEvent
-
- getOldValue() - Method in class com.tangosol.coherence.rest.events.SimpleMapEvent
-
Return the old value associated with this event.
- getOldValue() - Method in class com.tangosol.util.AbstractKeyBasedMap.DeferredCacheEvent
-
Return an old value associated with this event.
- getOldValue() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent
-
Return an old value associated with this event.
- getOldValue() - Method in class com.tangosol.util.MapEvent
-
Return an old value associated with this event.
- getOldValue() - Method in class com.tangosol.util.MapListenerSupport.FilterEvent
-
Return an old value associated with this event.
- getOldValueExtractor() - Method in class com.tangosol.util.transformer.ExtractorEventTransformer
-
Return a ValueExtractor used to transfrom the event's OldValue.
- getOpenBundle() - Method in class com.tangosol.net.cache.AbstractBundler
-
Retrieve any Bundle that is currently in the open state.
- getOperationName(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.BundleManager.BundleConfig
-
Return the operation name for which calls performed concurrently
on multiple threads are "bundled" into a functionally analogous
"bulk" operation that takes a collection of arguments instead of
a single one.
- getOperationStatus(String) - Method in class com.tangosol.coherence.dslquery.internal.PersistenceToolsHelper
-
- getOperationStatus() - Method in interface com.tangosol.persistence.PersistenceManagerMBean
-
Return the status of the current operation issued by the persistence coordinator.
- getOperator(String) - Method in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
-
- getOperators() - Method in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
-
Return the set of CohQL Operators characters.
- getOption(int) - Method in class com.tangosol.net.TcpDatagramSocket.Impl
- getOptionalProperty(String, Type, T, XmlElement) - Method in class com.tangosol.config.xml.DefaultProcessingContext
-
Obtains the strongly typed value for the property defined at the path relative to the specified
XmlElement
.
- getOptionalProperty(String, Type, T, XmlElement) - Method in interface com.tangosol.config.xml.ProcessingContext
-
Obtains the strongly typed value for the property defined at the path relative to the specified
XmlElement
.
- getOPToken(String) - Method in class com.tangosol.coherence.dsltools.precedence.PeekOPToken
-
Obtain the
OPToken
that is mapped to
the specified identifier.
- getOrDefault(K, V) - Method in interface com.tangosol.net.AsyncNamedCache
-
Returns the value to which the specified key is mapped, or valueDefault
if this map contains no mapping for the key.
- getOrDefault(Object, V) - Method in interface com.tangosol.util.InvocableMap
-
- getOrDefault(Object, V) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperMap
- getOrDefault(Object, V) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- getOrder() - Method in class com.tangosol.coherence.config.builder.NamedEventInterceptorBuilder
-
- getOrderId() - Method in class com.tangosol.net.AsyncNamedCache.OrderBy
-
Return unit-of-order id.
- getOrderId(V) - Method in class com.tangosol.net.topic.Publisher.OrderBy
-
Return unit-of-order id.
- getOrderId(V) - Method in class com.tangosol.net.topic.Publisher.OrderById
-
- getOrderId(V) - Method in class com.tangosol.net.topic.Publisher.OrderByNone
-
- getOrderId(V) - Method in class com.tangosol.net.topic.Publisher.OrderByThread
-
- getOrderId(V) - Method in class com.tangosol.net.topic.Publisher.OrderByValue
-
- getOriginal() - Method in class com.tangosol.util.DeltaSet
-
Determine what items were in the original set.
- getOriginal() - Method in class com.tangosol.util.SubSet
-
Determine what items were in the original set.
- getOriginalBinaryValue() - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
-
Return a raw original binary value for this entry.
- getOriginalBinaryValue() - Method in interface com.tangosol.util.BinaryEntry
-
Return a raw original binary value for this entry.
- getOriginalBinaryValue() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventBinaryEntry
-
Return a raw original binary value for this entry.
- getOriginalBinaryValue() - Method in class com.tangosol.util.InvocableMapHelper.RoutingBinaryEntry
-
- getOriginalBuffer() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Get the original buffer the changes should be applied to.
- getOriginalException(RuntimeException) - Static method in class com.tangosol.util.Base
-
Unwind the wrapper (runtime) exception to extract the original
- getOriginalException() - Method in exception com.tangosol.util.WrapperException
-
- getOriginalValue() - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
-
Return an original value for this entry.
- getOriginalValue() - Method in interface com.tangosol.util.BinaryEntry
-
Return an original value for this entry.
- getOriginalValue() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventBinaryEntry
-
Return an original value for this entry.
- getOriginalValue() - Method in class com.tangosol.util.InvocableMapHelper.RoutingMapTriggerEntry
-
- getOriginalValue() - Method in interface com.tangosol.util.MapTrigger.Entry
-
Determine the value that existed before the start of the mutating
operation that is being evaluated by the trigger.
- getOriginalValue() - Method in class com.tangosol.util.SimpleMapEntry
-
Determine the value that existed before the start of the mutating
operation that is being evaluated by the trigger.
- getOrphanedPartitions() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
Return the partitions deemed orphaned as a result of a previous
execution of
analyzeOrphans
.
- getOrphanedPartitions() - Method in class com.tangosol.net.PartitionedService.PartitionRecoveryAction
-
Return the set of orphaned partitions.
- getOut() - Method in class com.tangosol.io.MultiBufferWriteBuffer.MultiBufferOutput
-
Obtain the underlying BufferOutput.
- getOut() - Static method in class com.tangosol.util.Base
-
Obtains the current writer used for printing.
- getOutputStream() - Method in class com.tangosol.io.WrapperOutputStream
-
Obtain the underlying OutputStream.
- getOutputStream(OutputStream) - Method in interface com.tangosol.io.WrapperStreamFactory
-
Deprecated.
Requests an OutputStream that wraps the passed OutputStream.
- getOutputStream(OutputStream) - Method in class com.tangosol.net.CompressionFilter
-
Deprecated.
Requests an OutputStream that wraps the passed OutputStream.
- getOutputStream(DataOutput) - Static method in class com.tangosol.util.ExternalizableHelper
-
Get an OutputStream for the passed DataOutput object.
- getOutputStream() - Static method in class com.tangosol.util.NullImplementation
-
Factory method: Obtain a null implementation of a OutputStream.
- getOutputWriter() - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
-
- getOutputWriter() - Method in interface com.tangosol.coherence.dslquery.QueryPlus.Dependencies
-
Return an instance of a
PrintWriter
that should be
used to display query output.
- getOutstandingPacketMaximum() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the maximum allowable flow-control rate measured in packets.
- getOutstandingPacketMinimum() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the minimum allowable flow-control rate measured in packets.
- getOwnedPartitions(Member, int) - Method in interface com.tangosol.net.partition.DistributionManager
-
Return the set of partitions for which the specified member owns the
specified storage index (replica).
- getOwnedPartitions(Member, int) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
Return the set of partitions for which the specified member owns (or
has been assigned by this analysis to own) the specified storage
index.
- getOwnedPartitions(Member) - Method in interface com.tangosol.net.PartitionedService
-
Determine the PartitionSet that is currently owned by a cluster Member.
- getOwner(int) - Method in class com.tangosol.net.partition.Ownership
-
Return the owner id for the specified storage for this partition.
- getOwners() - Method in class com.tangosol.net.partition.Ownership
-
Return an array containing owner ids for this partition.
- getOwners(int[]) - Method in class com.tangosol.net.partition.Ownership
-
Return an array containing owner ids for this partition.
- getOwnership() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.NotOwnedFilter
-
Return the ownership used to evaluate member safety.
- getOwnership() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.SafetyFilter
-
Return the ownership used to evaluate member safety.
- getOwnership() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.StrengthComparator
-
Return the ownership to use in comparing member strength.
- getOwnershipEnabledMembers() - Method in interface com.tangosol.net.PartitionedService
-
Return a Set of Member objects, one for each Member that has registered
this PartitionedService and is partition ownership-enabled.
- getOwnershipLeavingMembers() - Method in interface com.tangosol.net.partition.DistributionManager
-
Return the set of ownership-enabled members in the partitioned
service that are in the process of leaving.
- getOwnershipMembers() - Method in interface com.tangosol.net.partition.DistributionManager
-
Return the set of ownership-enabled members in the partitioned service.
- getOwnershipMembers() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
Return the set of members across which to distribute the partition
ownership.
- getOwnershipMemberSet() - Method in class com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy
-
Return the set of ownership-enabled members in the associated
PartitionedService.
- getOwnershipMembersList() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
Return an array containing the members across which to distribute the
partition ownership, arranged in arbitrary order.
- getOwnershipSenior() - Method in interface com.tangosol.net.PartitionedService
-
Return the senior ownership-enabled member in the service.
- getOwnershipVersion(int) - Method in interface com.tangosol.net.PartitionedService
-
Determine the primary owner's version of the specified partition.
- getOwnerThread() - Method in class com.tangosol.net.cache.OverflowMap.Status
-
Determine the thread that owns the Status object, if the Status
object is processing or committing.
- getOwnerThread() - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
-
Determine the thread that owns the Status object, if the Status
object is processing or committing.
- getPackage(String) - Method in class com.tangosol.coherence.rest.util.PartialObject.PartialClassLoader
- getPackageName(Class) - Static method in class com.tangosol.util.ClassHelper
-
Determine the package name of a class.
- getPackageName(String) - Static method in class com.tangosol.util.ClassHelper
-
Determine the package name from a class (or package) name.
- getPackageResources(String) - Static method in class com.tangosol.util.ClassHelper
-
Load the default package resources for the specified class name.
- getPackageResources(Class) - Static method in class com.tangosol.util.ClassHelper
-
Load the default package resources for the specified class.
- getPackages() - Method in class com.tangosol.coherence.rest.util.PartialObject.PartialClassLoader
- getPacketBundlingAggression() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the aggression factor to use in deferring a packet once it has
reached the average bundle size.
- getPacketBundlingThresholdNanos() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the maximum amount of time to defer a packet while waiting for
additional packets to bundle.
- getPacketMaxLength() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the maximum size, in bytes, of the network packets that
will be sent and received on the local and group sockets.
- getPacketPreferredLength() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the preferred size, in bytes, of the network packets
that will be sent and received on the local sockets.
- getPage(int) - Method in class com.tangosol.net.cache.SerializationPagedCache.PagedBinaryStore
-
Get the BinaryStore for the page specified by the passed page
number.
- getPage() - Method in class com.tangosol.util.filter.LimitFilter
-
Obtain a current page number (zero-based).
- getPageAdvanceTime() - Method in class com.tangosol.net.cache.SerializationPagedCache
-
Determine the time that the next page should be created.
- getPagedBinaryStore() - Method in class com.tangosol.net.cache.SerializationPagedCache
-
Returns the BinaryStore that this map uses for its storage.
- getPagedKeyMap() - Method in class com.tangosol.net.cache.SerializationPagedCache.PagedBinaryStore
-
Obtain the map that manages the mapping from Binary keys to
BinaryStore objects.
- getPageDuration() - Method in class com.tangosol.net.cache.SerializationPagedCache
-
Determine the length of time that the most recently created page is
kept as the current page.
- getPageDurationSeconds(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.PagedExternalScheme
-
Return the length of time that a page in the cache is current.
- getPageLimit(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.PagedExternalScheme
-
Return the maximum number of pages that the cache manages before older
pages are destroyed.
- getPageSize(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
-
Return the binary limit of the size of a page in a topic.
- getPageSize() - Method in class com.tangosol.util.filter.LimitFilter
-
Obtain the page size (expressed as a number of entries per page).
- getParallelAggregator() - Method in interface com.tangosol.util.InvocableMap.ParallelAwareAggregator
-
Deprecated.
Get an aggregator that can take the place of this aggregator in
situations in which the InvocableMap can aggregate in parallel.
- getParameterAnnotation(Method, int, Class<A>) - Static method in class com.tangosol.net.management.MBeanHelper
-
Retrieve an
Annotation
for a parameter to a method.
- getParameterName(MBeanOperationInfo, MBeanParameterInfo, int) - Method in class com.tangosol.net.management.AnnotatedStandardEmitterMBean
-
Retrieve the parameter name for the specified parameter by finding a
Description
annotation on the operation.
- getParameterName(MBeanOperationInfo, MBeanParameterInfo, int) - Method in class com.tangosol.net.management.AnnotatedStandardMBean
-
Retrieve the parameter name for the specified parameter by finding a
Description
annotation on the operation.
- getParameterName(Class, MBeanOperationInfo, MBeanParameterInfo, int) - Static method in class com.tangosol.net.management.MBeanHelper
-
Retrieve the parameter name for the specified parameter by finding a
Description
annotation on the corresponding method.
- getParameterResolver() - Method in class com.tangosol.coherence.config.ResourceMapping
-
Obtains the
ParameterResolver
that is to be used to
resolve
Parameter
s associated with this
ResourceMapping
.
- getParameterResolver(String, ClassLoader, BackingMapManagerContext) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
-
Return the ParameterResolver that has been initialized with the built-in
Coherence parameters.
- getParameterResolver(String, Class<M>, ClassLoader, BackingMapManagerContext) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
-
Return the ParameterResolver that has been initialized with the built-in
Coherence parameters.
- getParameters() - Method in class com.tangosol.util.extractor.ReflectionExtractor
-
Return the array of arguments used to invoke the method.
- getParameters() - Method in class com.tangosol.util.extractor.UniversalExtractor
-
Return the array of arguments used to invoke the method.
- getParameterTypes() - Method in class com.tangosol.coherence.rest.query.AbstractQueryEngine.ParsedQuery
-
Return a map of parameter types keyed by parameter name.
- getParent() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Return the parent of this value.
- getParent() - Method in interface com.tangosol.io.pof.reflect.PofValue
-
Return the parent of this value.
- getParent() - Method in class com.tangosol.run.xml.SimpleValue
-
Get the parent element of this element.
- getParent() - Method in interface com.tangosol.run.xml.XmlValue
-
Get the parent element of this value.
- getParentDirectory() - Method in class com.tangosol.io.bdb.BerkeleyDBBinaryStoreManager
-
Get the configured parent directory.
- getParentParser() - Method in class com.tangosol.io.pof.PofBufferReader
-
If this parser is contextually within a user type, obtain the parser
which created this parser in order to parse the user type.
- getParentParser() - Method in class com.tangosol.io.pof.PofBufferReader.UserTypeReader
-
If this parser is contextually within a user type, obtain the parser
which created this parser in order to parse the user type.
- getParentSpan() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.Entry
-
Return the associated parent Span if any.
- getParentWriter() - Method in class com.tangosol.io.pof.PofBufferWriter
-
If this writer is contextually within a user type, obtain the writer
which created this writer in order to write the user type.
- getParentWriter() - Method in class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
-
If this writer is contextually within a user type, obtain the writer
which created this writer in order to write the user type.
- getParentXmlBean() - Method in class com.tangosol.run.xml.XmlBean
-
Obtain the XmlBean that contains this XmlBean.
- getParser() - Static method in class com.tangosol.run.xml.SaxParser
-
Get an instance of non-validating SAX parser.
- getParseString() - Method in exception com.tangosol.util.FilterBuildingException
-
Answer the String that was being processed when the Exception occurred
- getPartialClass(Class, PropertySet) - Static method in class com.tangosol.coherence.rest.util.PartialObject
-
Return a partial class for the specified source class and property set.
- getPartialClass() - Method in class com.tangosol.coherence.rest.util.PropertySpec
-
Return the partial class for this property.
- getPartialClassLoader() - Static method in class com.tangosol.coherence.rest.util.PartialObject
-
Return a PartialClassLoader corresponding to the Context ClassLoader.
- getPartialClassMap(PartialObject.PartialClassLoader) - Static method in class com.tangosol.coherence.rest.util.PartialObject
-
Return the partial class map corresponding to the PartialClassLoader.
- getPartialConstructorMap(PartialObject.PartialClassLoader) - Static method in class com.tangosol.coherence.rest.util.PartialObject
-
Return the partial constructor map corresponding to the PartialClassLoader.
- getPartialResult() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics.PartitionedCacheStatisticsAggregator
-
- getPartialResult() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics.PartitionedCacheStatisticsClear
-
- getPartialResult() - Method in exception com.tangosol.net.RequestIncompleteException
-
Return a partial execution result that may have been assembled before an
exception occurred.
- getPartialResult() - Method in class com.tangosol.util.aggregator.AbstractAggregator
-
- getPartialResult() - Method in class com.tangosol.util.aggregator.CompositeAggregator
-
- getPartialResult() - Method in class com.tangosol.util.aggregator.Count
-
- getPartialResult() - Method in class com.tangosol.util.aggregator.GroupAggregator
-
- getPartialResult() - Method in class com.tangosol.util.aggregator.PriorityAggregator
-
- getPartialResult() - Method in class com.tangosol.util.aggregator.QueryRecorder
-
- getPartialResult() - Method in class com.tangosol.util.aggregator.ScriptAggregator
-
- getPartialResult() - Method in class com.tangosol.util.aggregator.TopNAggregator
-
- getPartialResult() - Method in interface com.tangosol.util.InvocableMap.StreamingAggregator
-
Return the partial result of the aggregation.
- getPartition() - Method in class com.tangosol.net.partition.PartitionStatistics
-
Return the id of the partition for which these statistics apply.
- getPartition(String) - Static method in class com.tangosol.persistence.GUIDHelper
-
Parse the specified GUID and return the partition-id.
- getPartitionAssignmentStrategy() - Method in interface com.tangosol.net.PartitionedService
-
Determine the strategy for assigning partitions to cluster members that
this service has been configured to use.
- getPartitionAssignmentStrategy() - Static method in class com.tangosol.util.NullImplementation
-
Factory method: Obtain a null implementation of a PartitionAssignmentStrategy.
- getPartitionAwareBackingMap() - Method in class com.tangosol.net.partition.ReadWriteSplittingBackingMap
-
Obtain the PartitionAwareBackingMap that this ReadWriteBackingMap
uses as its backing map.
- getPartitionCache(Object) - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
-
Obtain the backing cache for a particular key.
- getPartitionCacheArray() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
-
Obtain the array of backing caches.
- getPartitionCount() - Method in class com.tangosol.net.partition.PartitionSet
-
Return the number of partitions represented by this PartitionSet.
- getPartitionCount() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
Get the configured number of partitions for the service.
- getPartitionCount() - Method in interface com.tangosol.net.partition.SimpleStrategyMBean
-
Get the configured number of partitions for the service.
- getPartitionCount() - Method in interface com.tangosol.net.PartitionedService
-
Determine the number of partitions that the service has been configured
to "break up" the conceptual "key set" into.
- getPartitionCount(PersistentStore<ReadBuffer>) - Static method in class com.tangosol.persistence.CachePersistenceHelper
-
Return the partition count that has been stored in the specified store.
- getPartitionId() - Method in interface com.tangosol.net.events.partition.TransferEvent
-
Return the ID of the partition being transferred.
- getPartitionId() - Method in interface com.tangosol.net.partition.KeyPartitioningStrategy.PartitionAwareKey
-
Return the partition id that this key should be associated with.
- getPartitionId() - Method in class com.tangosol.net.partition.SimplePartitionKey
-
Return the partition id that this key should be associated with.
- getPartitionKey(int) - Static method in class com.tangosol.net.partition.SimplePartitionKey
-
Factory method for a SimplePartitionKey.
- getPartitionKeys(String, int) - Method in interface com.tangosol.net.BackingMapManagerContext
-
Obtain a collection of keys in the internal format that belong to the
specified partition for the specified backing map.
- getPartitionKeys(String, int) - Method in class com.tangosol.util.NullImplementation.NullBackingMapManagerContext
-
Obtain a collection of keys in the internal format that belong to the
specified partition for the specified backing map.
- getPartitionLoad(int, boolean) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
Return the load (as defined by the appropriate load calculator) for
the specified partition.
- getPartitionMap(int) - Method in class com.tangosol.net.partition.ObservableSplittingBackingMap
-
Obtain a Map view for the data in a specific partition.
- getPartitionMap(PartitionSet) - Method in class com.tangosol.net.partition.ObservableSplittingBackingMap
-
Obtain a Map view for the data in a specific set of partitions.
- getPartitionMap(int) - Method in interface com.tangosol.net.partition.PartitionAwareBackingMap
-
Obtain a Map view for the data in a specific partition.
- getPartitionMap(PartitionSet) - Method in interface com.tangosol.net.partition.PartitionAwareBackingMap
-
Obtain a Map view for the data in a specific set of partitions.
- getPartitionMap(int) - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
-
Obtain a Map view for the data in a specific partition.
- getPartitionMap(PartitionSet) - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
-
Obtain a Map view for the data in a specific set of partitions.
- getPartitionMap(int) - Method in class com.tangosol.net.partition.ReadWriteSplittingBackingMap
-
Obtain a Map view for the data in a specific partition.
- getPartitionMap(PartitionSet) - Method in class com.tangosol.net.partition.ReadWriteSplittingBackingMap
-
Obtain a Map view for the data in a specific set of partitions.
- getPartitionMapType() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
-
Return the uniform type used by each partition map.
- getPartitionOwner(int) - Method in interface com.tangosol.net.PartitionedService
-
Determine the primary owner of the specified partition.
- getPartitionOwnership(int) - Method in interface com.tangosol.net.partition.DistributionManager
-
Return the Ownership information for the specified partition.
- getPartitionOwnership(int) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
Return the Ownership information (or the ownership assigned by this
analysis) for the specified partition.
- getPartitions() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.MapArray
-
Obtain an array of all of the current partition IDs for which
there are backing maps.
- getPartitions(Map<Integer, Object[]>, int) - Static method in class com.tangosol.persistence.GUIDHelper
-
Return a
PartitionSet
with all partitions present in the provided
mapStores
.
- getPartitions() - Method in interface com.tangosol.util.QueryRecord.PartialResult
-
Get the set of partitions associated with this partial result.
- getPartitions() - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult
-
Get the set of partitions associated with this partial result.
- getPartitionSet() - Method in class com.tangosol.net.partition.PartitionEvent
-
Determine the set of partitions represented by this event.
- getPartitionSet() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.MapArray
-
Obtain a PartitionSet containing partition IDs for which there are
backing maps.
- getPartitionSet() - Method in class com.tangosol.util.filter.PartitionedFilter
-
Obtain the PartitionSet that specifies what partitions the wrapped filter
will be applied to.
- getPartitionSplittingBackingMap() - Method in class com.tangosol.net.partition.ObservableSplittingBackingMap
-
Obtain the underlying PartitionSplittingBackingMap.
- getPartitionStats() - Method in interface com.tangosol.net.partition.DistributionManager
-
Return an array of the most recently available partition statistics,
indexed by partition-id.
- getPartitionUnitFactor() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
-
Determine the unit factor for individual partition maps.
- getPassword() - Method in class com.tangosol.net.security.UsernameAndPassword
-
Return the password.
- getPassword() - Method in class com.tangosol.run.jca.CacheAdapter.CacheConnectionSpec
-
- getPasswordProvider() - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.DefaultKeystoreDependencies
-
Get the configured keystore passwordProvider.
- getPasswordProvider() - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.DefaultManagerDependencies
-
Get the configured keystore passwordProvider.
- getPasswordProvider() - Method in interface com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.KeystoreDependencies
-
Get passwordProvider for this Manager.
- getPasswordProvider() - Method in interface com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.ManagerDependencies
-
Get passwordProvider for this Manager.
- getPasswordProviderBuilderForPasswordStr(String) - Static method in class com.tangosol.coherence.config.xml.processor.PasswordProviderBuilderProcessor
-
Generates a ParameterizedBuilder using the DefaultPasswordProvider.class
by passing the string-input to its single-param constructor.
- getPath(File) - Static method in class com.tangosol.io.FileHelper
-
Return the path of a file.
- getPathElements() - Method in class com.tangosol.io.pof.reflect.AbstractPofPath
-
Return a collection of path elements.
- getPathElements() - Method in class com.tangosol.io.pof.reflect.SimplePofPath
-
Return a collection of path elements.
- getPathNoEndSeparator(String) - Static method in class com.tangosol.io.FileHelper
-
Gets the path from a full filename, which excludes the prefix, and also
excluding the final directory separator.
- getPattern() - Method in class com.tangosol.util.filter.LikeFilter
-
Obtain the filter's pattern string.
- getPendingMap() - Method in class com.tangosol.io.AsyncBinaryStore
-
Obtain the map that contains all of the pending store and erase data.
- getPendingMap() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.WriteQueue
-
Obtain a map of entries removed from the queue, but not yet persisted
to the underlying datastore.
- getPermission() - Method in class com.tangosol.net.security.PermissionInfo
-
Return the ClusterPermission object.
- getPermissionsConfig() - Method in class com.tangosol.net.security.DefaultController
-
Obtain the permission configuration descriptor.
- getPersistenceActiveDirectory() - Method in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder.PersistenceEnvironmentInfo
-
- getPersistenceActiveDirectory() - Method in class com.tangosol.persistence.AbstractPersistenceEnvironment
-
Return the directory under which cached data is actively persisted
by the environment.
- getPersistenceActiveDirectory() - Method in interface com.tangosol.persistence.PersistenceEnvironmentInfo
-
Return the directory under which cached data is actively persisted
by the environment.
- getPersistenceActiveSpaceUsed() - Method in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder.PersistenceEnvironmentInfo
-
- getPersistenceActiveSpaceUsed() - Method in class com.tangosol.persistence.AbstractPersistenceEnvironment
-
Return the total size in bytes used by the persistence layer to
persist mutating cache operations.
- getPersistenceActiveSpaceUsed() - Method in interface com.tangosol.persistence.PersistenceEnvironmentInfo
-
Return the total size in bytes used by the persistence layer to
persist mutating cache operations.
- getPersistenceEnvironment() - Method in class com.tangosol.persistence.AbstractPersistenceManager
-
Return the environment that created this manager.
- getPersistenceEnvironment() - Static method in class com.tangosol.util.NullImplementation
-
Factory method: Obtain a null implementation of a PersistenceEnvironment
.
- getPersistenceEnvironment(Class<R>) - Static method in class com.tangosol.util.NullImplementation
-
Factory method: Obtain a null implementation of a PersistenceEnvironment
.
- getPersistenceEnvironmentInfo(String, String) - Method in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder
-
- getPersistenceInfo() - Method in class com.tangosol.persistence.AbstractPersistenceTools
-
- getPersistenceInfo() - Method in class com.tangosol.util.NullImplementation.NullPersistenceManager
-
- getPersistenceManager() - Static method in class com.tangosol.util.NullImplementation
-
Factory method: Obtain a null implementation of a PersistenceManager
.
- getPersistenceManager(Class<R>) - Static method in class com.tangosol.util.NullImplementation
-
Factory method: Obtain a null implementation of a PersistenceManager
.
- getPersistenceMBean(String) - Method in class com.tangosol.coherence.dslquery.internal.PersistenceToolsHelper
-
Return the PersistenceManager MBean name.
- getPersistenceMode() - Method in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder
-
- getPersistenceMode() - Method in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder.PersistenceEnvironmentInfo
-
Return the persistence mode.
- getPersistenceSnapshotDirectory() - Method in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder.PersistenceEnvironmentInfo
-
- getPersistenceSnapshotDirectory() - Method in class com.tangosol.persistence.AbstractPersistenceEnvironment
-
Return the directory under which copies of cached data are persisted
by the environment.
- getPersistenceSnapshotDirectory() - Method in interface com.tangosol.persistence.PersistenceEnvironmentInfo
-
Return the directory under which copies of cached data are persisted
by the environment.
- getPersistenceTools() - Method in class com.tangosol.persistence.AbstractPersistenceManager
-
- getPersistenceTools(String) - Method in class com.tangosol.persistence.AbstractSnapshotArchiver
-
- getPersistenceTools(String) - Method in interface com.tangosol.persistence.SnapshotArchiver
-
Return an instance of PersistenceTools
allowing offline operations
to be performed against the associated PersistenceManager and appropriate
PersistentStore
.
- getPersistenceTools() - Method in class com.tangosol.util.NullImplementation.NullPersistenceManager
-
Return an instance of PersistenceTools
allowing offline operations
to be performed against the associated PersistenceManager and appropriate
PersistentStore
.
- getPersistenceTrashDirectory() - Method in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder.PersistenceEnvironmentInfo
-
- getPersistenceTrashDirectory() - Method in class com.tangosol.persistence.AbstractPersistenceEnvironment
-
Return the directory under which potentially corrupted persisted data
is stored by the environment.
- getPersistenceTrashDirectory() - Method in interface com.tangosol.persistence.PersistenceEnvironmentInfo
-
Return the directory under which potentially corrupted persisted data
is stored by the environment.
- getPersistenceVersion(PersistentStore<ReadBuffer>) - Static method in class com.tangosol.persistence.CachePersistenceHelper
-
Return the persistence version the provided store was written with.
- getPersistentStore() - Static method in class com.tangosol.util.NullImplementation
-
Factory method: Obtain a null implementation of a PersistentStore
.
- getPersistentStore(Class<R>) - Static method in class com.tangosol.util.NullImplementation
-
Factory method: Obtain a null implementation of a PersistentStore
.
- getPersistentStoreMap() - Method in class com.tangosol.persistence.AbstractPersistenceManager
-
Return the map of open PersistentStore instances keyed by their identifiers.
- getPersistentVersionCache() - Method in class com.tangosol.net.cache.VersionedBackingMap
-
Deprecated.
Get the cache of version info for the data stored in the persistent
store behind this backing map (and other related backing maps if this
is backing a distributed cache).
- getPofConfig() - Method in class com.tangosol.io.pof.ConfigurablePofContext
-
Obtain the PofConfig that represents the initialized state of the
ConfigurablePofContext.
- getPofContext() - Method in class com.tangosol.io.pof.PofBufferReader
-
Return the PofContext object used by this PofReader to deserialize user
types from a POF stream.
- getPofContext() - Method in class com.tangosol.io.pof.PofBufferWriter
-
Return the PofContext object used by this PofWriter to serialize user
types to a POF stream.
- getPofContext() - Method in interface com.tangosol.io.pof.PofReader
-
Return the PofContext object used by this PofReader to deserialize user
types from a POF stream.
- getPofContext() - Method in interface com.tangosol.io.pof.PofWriter
-
Return the PofContext object used by this PofWriter to serialize user
types to a POF stream.
- getPofContext() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Return the POF context to use for serialization and deserialization.
- getPofContext() - Static method in class com.tangosol.util.NullImplementation
-
Factory method: Obtain a null implementation of a PofContext.
- getPofHandler() - Method in class com.tangosol.io.pof.PofBufferWriter
-
Return the WritingPofHandler used internally by this PofBufferWriter
to write the POF stream.
- getPofHandler() - Static method in class com.tangosol.util.NullImplementation
-
Factory method: Obtain a null implementation of a PofHandler.
- getPofReader() - Method in class com.tangosol.io.pof.PofInputStream
-
Obtain the underlying PofReader.
- getPofSerializer(int) - Method in class com.tangosol.io.pof.ConfigurablePofContext
-
Return a PofSerializer that can be used to serialize and deserialize an
object of the specified user type to and from a POF stream.
- getPofSerializer(int) - Method in interface com.tangosol.io.pof.PofContext
-
Return a PofSerializer that can be used to serialize and deserialize an
object of the specified user type to and from a POF stream.
- getPofSerializer(int) - Method in class com.tangosol.io.pof.SafeConfigurablePofContext
-
Return a PofSerializer that can be used to serialize and deserialize an
object of the specified user type to and from a POF stream.
- getPofSerializer(int) - Method in class com.tangosol.io.pof.SimplePofContext
-
Return a PofSerializer that can be used to serialize and deserialize an
object of the specified user type to and from a POF stream.
- getPofSerializer(int) - Method in class com.tangosol.util.NullImplementation.NullPofContext
-
Return a PofSerializer that can be used to serialize and deserialize an
object of the specified user type to and from a POF stream.
- getPofTypeId(Class, PofContext) - Static method in class com.tangosol.io.pof.PofHelper
-
Return an identifier that represents the POF type of the specified
class.
- getPofTypeId(PofContext) - Method in class com.tangosol.util.extractor.PofExtractor
-
compute the expected pof type id based on the class.
- getPofWriter() - Method in class com.tangosol.io.pof.PofOutputStream
-
Obtain the underlying PofWriter.
- getPolicyPopulation() - Method in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy
-
Calculate and return the current size of the member set that contributes
to the quorum for this policy domain.
- getPolicyPopulation() - Method in class com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy
-
Calculate and return the current size of the member set that contributes
to the quorum for this policy domain.
- getPoolSize() - Method in interface com.tangosol.net.ThreadPoolManager
-
Return the current size of the thread pool.
- getPort() - Method in class com.tangosol.net.ConfigurableAddressProvider.AddressHolder
-
Return the port number.
- getPort() - Method in interface com.tangosol.net.Member
-
Return the port of the Member's DatagramSocket for
point-to-point communication.
- getPort() - Method in class com.tangosol.net.proxy.RemoteMember
-
Return the port of the Member's DatagramSocket for
point-to-point communication.
- getPort() - Method in class com.tangosol.util.UUID
-
Determine the port portion of the UUID.
- getPortMin() - Method in class com.tangosol.coherence.config.builder.LocalAddressProviderBuilder
-
Return the minimum port number.
- getPortMinOriginal() - Method in class com.tangosol.coherence.config.builder.LocalAddressProviderBuilder
-
Return the minimum port number provided in the constructor.
- getPostFactor() - Method in class com.tangosol.util.processor.NumberMultiplier
-
Returns whether to return the value before it was multiplied.
- getPostFilterKeySetSize() - Method in interface com.tangosol.util.QueryRecord.PartialResult.Step
-
Get the size of the key set remaining after evaluating the
filter or applying an index.
- getPostFilterKeySetSize() - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.Step
-
Get the size of the key set remaining after evaluating the
filter or applying an index.
- getPostInc() - Method in class com.tangosol.util.processor.NumberIncrementor
-
Returns Whether to return the value before it was incremented
("post-increment") or after it is incremented ("pre-increment").
- getPreferredSize(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.BundleManager.BundleConfig
-
Return the bundle size threshold.
- getPreFilterKeySetSize() - Method in interface com.tangosol.util.QueryRecord.PartialResult.Step
-
Get the size of the key set prior to evaluating the filter or
applying an index.
- getPreFilterKeySetSize() - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.Step
-
Get the size of the key set prior to evaluating the filter or
applying an index.
- getPrefix() - Method in class com.tangosol.run.xml.QualifiedName
-
- getPrefixLength(String) - Static method in class com.tangosol.io.FileHelper
-
Returns the length of the filename prefix, such as C:/
or
~/
.
- getPrevBlockOffset() - Method in class com.tangosol.io.nio.BinaryMap.Block
-
Determine the offset of the previous Block in the Buffer.
- getPrevious() - Method in class com.tangosol.util.SafeLinkedList.Node
-
- getPreviousModulo() - Method in class com.tangosol.io.nio.BinaryMap
-
Determine the previous modulo.
- getPreviousPropertyIndex() - Method in class com.tangosol.io.pof.PofBufferReader.UserTypeReader
-
Return the index of the most recent property read or (if it were
missing) requested.
- getPrevNodeOffset() - Method in class com.tangosol.io.nio.BinaryMap.Block
-
Determine the offset of the previous Block in the linked list.
- getPrimaryKey() - Method in class com.tangosol.util.CompositeKey
-
Return the primary key component.
- getPrimaryLoadCalculator() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
Return the LoadCalculator used to calculate the primary partition load.
- getPrimaryOwner() - Method in class com.tangosol.net.partition.Ownership
-
Return the primary owner id for this partition.
- getPrimaryPolicy() - Method in class com.tangosol.net.CompositeActionPolicy
-
Return the primary policy.
- getPrimitive(long) - Method in class com.tangosol.util.PrimitiveSparseArray
-
Return the value stored at the specified index.
- getPrimitiveValue() - Method in class com.tangosol.util.PrimitiveSparseArray.Iterator
-
Returns the current value, which is the same value returned by the
most recent call to the nextPrimitive method, or the most
recent value passed to setPrimitiveValue if
setPrimitiveValue were called after the
nextPrimitive method.
- getPrimitiveValue() - Method in class com.tangosol.util.PrimitiveSparseArray.PrimitiveNode
-
Get the long value for the Node.
- getPrintWriter() - Method in class com.tangosol.io.pof.LoggingPofHandler
-
Obtain the PrintWriter that is used by this LoggingPofHandler.
- getPriority() - Method in class com.tangosol.net.cache.OldCache.Entry
-
Deprecated.
Calculate a cache priority.
- getPriority() - Method in interface com.tangosol.net.MemberIdentity
-
Return the priority (or "weight") of the local Member.
- getPriority() - Method in class com.tangosol.net.proxy.RemoteMember
-
Return the priority (or "weight") of the local Member.
- getProbabilityThresholds() - Method in class com.tangosol.util.SafeSortedMap
-
Return the precomputed array of probability thresholds used by this map to
determine what index levels to build.
- getProblem() - Method in exception com.tangosol.config.ConfigurationException
-
Returns what the problem was.
- getProcessName() - Method in interface com.tangosol.net.MemberIdentity
-
Return the configured name for the Process (such as a JVM) in which this
Member resides.
- getProcessName() - Method in class com.tangosol.net.proxy.RemoteMember
-
Return the configured name for the Process (such as a JVM) in which this
Member resides.
- getProcessor(String...) - Method in class com.tangosol.coherence.rest.util.processor.DefaultProcessorFactory
-
Return a processor instantiated by calling a processor class
constructor.
- getProcessor(String...) - Method in class com.tangosol.coherence.rest.util.processor.NumberIncrementorFactory
-
Returns a processor instance.
- getProcessor(String...) - Method in class com.tangosol.coherence.rest.util.processor.NumberMultiplierFactory
-
Returns a processor instance.
- getProcessor(String...) - Method in interface com.tangosol.coherence.rest.util.processor.ProcessorFactory
-
Returns a processor instance.
- getProcessor(String) - Method in class com.tangosol.coherence.rest.util.processor.ProcessorRegistry
-
Returns a configured processor.
- getProcessor() - Method in class com.tangosol.net.cache.ContinuousQueryCache.ConverterAsynchronousProcessor
-
- getProcessor() - Method in interface com.tangosol.net.events.partition.cache.EntryProcessorEvent
-
- getProcessor() - Method in class com.tangosol.util.processor.AbstractAsynchronousProcessor
-
Obtain the underlying entry processor.
- getProcessor() - Method in class com.tangosol.util.processor.PriorityProcessor
-
Obtain the underlying processor.
- getProcessorClass() - Method in class com.tangosol.coherence.rest.config.ProcessorConfig
-
Determine the class of the processor or its factory.
- getProcessorName() - Method in class com.tangosol.coherence.rest.config.ProcessorConfig
-
Determine the name of the processor.
- getProcessorRegistry() - Method in class com.tangosol.coherence.rest.config.RestConfig
-
Return the configured processor registry.
- getProcessRandom() - Static method in class com.tangosol.util.Base
-
Return a random number assigned to this process.
- getProperties() - Method in class com.tangosol.coherence.jcache.CoherenceBasedCacheManager
-
- getProperties() - Method in class com.tangosol.coherence.rest.util.PropertySet
-
Return the internal property set.
- getProperty(String) - Static method in class com.tangosol.coherence.config.Config
-
- getProperty(String, String) - Static method in class com.tangosol.coherence.config.Config
-
Get a Coherence property value, return default if property lookup fails.
- getProperty(String, Supplier<String>) - Static method in class com.tangosol.coherence.config.Config
-
Get a Coherence property value, returning the value provided by the supplier
if property lookup fails.
- getProperty(String) - Method in class com.tangosol.coherence.config.SystemPropertyResolver.Default
-
- getProperty(String) - Method in interface com.tangosol.coherence.config.SystemPropertyResolver
-
Return the value of the specified system property.
- getProperty(String, String) - Method in interface com.tangosol.coherence.config.SystemPropertyResolver
-
Return the value of the specified system property, or the specified
default value if the property doesn't exist.
- getProperty(String, String) - Method in class com.tangosol.net.LoadBalancer
-
Determine the value of a String option.
- getProperty(String, int) - Method in class com.tangosol.net.LoadBalancer
-
Determine the value of an integer option.
- getProperty(String, boolean) - Method in class com.tangosol.net.LoadBalancer
-
Determine the value of a boolean option.
- getPropertyIndex() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
- getPropertyName() - Method in class com.tangosol.util.extractor.UniversalExtractor
-
Return the property name of this extractor.
- getPropertySet() - Method in class com.tangosol.coherence.rest.util.PropertySpec
-
Return the set of nested properties.
- getPropertyValue(String, Type, XmlElement, boolean) - Method in class com.tangosol.config.xml.DefaultProcessingContext
-
Attempts to resolve the named property of the specified type in the current context and
if required will parse the specified
XmlElement
in order to do so.
- getProtocol() - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder
-
Get the SSL protocol name
- getProvider() - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder
-
Get the SSL provider builder.
- getProviderBuilder() - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.DefaultManagerDependencies
-
get key-store provider builder
- getProviderBuilder() - Method in interface com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.ManagerDependencies
-
- getProviderList() - Method in class com.tangosol.net.CompositeAddressProvider
-
Return the provider list.
- getProviderType(String) - Method in class com.tangosol.net.SocketProviderFactory.DefaultDependencies
-
Get the provider type for the given socket provider id
- getProviderType(String) - Method in interface com.tangosol.net.SocketProviderFactory.Dependencies
-
Get the provider type for the given socket provider id
- getProxy(String, K) - Method in interface com.tangosol.util.Proxyable
-
Return a proxy for a cached value.
- getPruneDelay() - Method in class com.tangosol.util.ThreadLocalObject
-
- getPublisherAckDelayMillis() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the amount of time that the Publisher may delay sending an ACK packet.
- getPublisherCloggedCount() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the maximum number of packets in the send and re-send queues that the
Publisher will tolerate before determining that it is clogged and must
slow down client requests (requests from local non-system threads).
- getPublisherCloggedDelayMillis() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the amount of time that the Publisher will pause a client thread that
is trying to send a message when the Publisher is clogged.
- getPublisherGroupThreshold() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the group threshold which is used to determine whether a packet
will be sent via unicast or multicast.
- getPublisherNackDelayMillis() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the amount of time that the Publisher will delay sending a NACK
packet.
- getPublisherPriority() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the priority of the PacketPublisher daemon thread.
- getPublisherResendDelayMillis() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the minimum amount of time before a packet is resent across the
network if it has not been acknowledged.
- getPublisherResendTimeoutMillis() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the maximum amount of time that the publisher will be resending a
packet before the packet recipient is considered departed.
- getPublisherSocketBufferSize() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the preferred size of the unicast socket output buffer (SO_SNDBUF).
- getPutBundler() - Method in class com.tangosol.net.cache.BundlingNamedCache
-
Obtain the bundler for the "put" operations.
- getQualifiedName() - Method in class com.tangosol.run.xml.SimpleAttribute
-
- getQualifiedName() - Method in class com.tangosol.run.xml.SimpleElement
-
- getQualifiedName() - Method in interface com.tangosol.run.xml.XmlAttribute
-
- getQualifiedName() - Method in interface com.tangosol.run.xml.XmlElement
-
- getQualifiedName(String, String) - Static method in class com.tangosol.util.ClassHelper
-
Build the fully qualified name of a class based on a package name and a
simple class name.
- getQuery() - Method in class com.tangosol.coherence.rest.query.AbstractQueryEngine.ParsedQuery
-
Return the query string with parameter types removed.
- getQuery() - Method in class com.tangosol.net.management.MBeanAccessor.QueryBuilder.ParsedQuery
-
Return the query to reduce the ObjectNames to consider.
- getQueryConfig() - Method in class com.tangosol.coherence.rest.config.ResourceConfig
-
Return the query configuration for this resource.
- getQueryEngine(String) - Method in class com.tangosol.coherence.rest.query.QueryEngineRegistry
-
Return a query engine for the specified name.
- getQueryEngineClass() - Method in class com.tangosol.coherence.rest.config.QueryEngineConfig
-
Determine the class of the query engine.
- getQueryEngineName() - Method in class com.tangosol.coherence.rest.config.NamedQuery
-
Return the name of the query engine responsible to execute this query.
- getQueryEngineName() - Method in class com.tangosol.coherence.rest.config.QueryEngineConfig
-
Determine the name of the query engine.
- getQueryEngineRegistry() - Method in class com.tangosol.coherence.rest.config.RestConfig
-
Return the configured query engine registry.
- getQueryMap() - Method in class com.tangosol.util.ConverterCollections.ConverterQueryMap
-
Return the underlying QueryMap.
- getQueryMap(QueryMap<FK, FV>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Static method in class com.tangosol.util.ConverterCollections
-
Returns a Converter instance of QueryMap.
- getQueryParameters(UriInfo) - Static method in class com.tangosol.coherence.rest.util.RestHelper
-
Return a map containing query parameters from UriInfo instance.
- getQueue() - Method in class com.tangosol.net.LoadBalancer
-
Determine the Queue that Socket connections are placed into.
- getQueueDaemon() - Method in class com.tangosol.io.AsyncBinaryStore
-
- getQueuedLimit() - Method in class com.tangosol.io.AsyncBinaryStore
-
Determine the size, in bytes, of the data that can be queued to be
written asynchronously by the QueueDaemon thread.
- getQueuedLimit() - Method in class com.tangosol.io.AsyncBinaryStoreManager
-
- getQueuedSize() - Method in class com.tangosol.io.AsyncBinaryStore
-
Determine the current number of bytes that are pending being written.
- getQuorumInfo() - Method in class com.tangosol.net.PartitionedService.PartitionRecoveryAction
-
Return the "last good" service membership info.
- getQuorumRules() - Method in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy
-
Return the quorum rules used by this policy.
- getRackCount() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.BackupStrength
-
Return the rack count.
- getRackName() - Method in interface com.tangosol.net.MemberIdentity
-
Return the configured name for the Rack (such as a physical rack, cage or
blade frame) in which this Member resides.
- getRackName() - Method in class com.tangosol.net.proxy.RemoteMember
-
Return the configured name for the Rack (such as a physical rack, cage or
blade frame) in which this Member resides.
- getRandom() - Static method in class com.tangosol.util.Base
-
Obtain a Random object that can be used to get random values.
- getRandom() - Method in class com.tangosol.util.SafeSortedMap
-
Return the random number generator for this map.
- getRandomBinary(int, int) - Static method in class com.tangosol.util.Base
-
Generates a random-length Binary within the length bounds provided
whose contents are random bytes.
- getRandomBinary(int, int, byte...) - Static method in class com.tangosol.util.Base
-
Generates a random-length Binary including abHead
at the head of
the Binary, in addition to random bytes within the length bounds provided.
- getRandomDestination() - Method in class com.tangosol.net.LoadBalancer
-
Determine a random AddressPort combination to route to.
- getRandomString(int, int, boolean) - Static method in class com.tangosol.util.Base
-
Generates a random-length String within the length bounds provided.
- getRawByteArray() - Method in class com.tangosol.io.ByteArrayReadBuffer
-
Obtain the byte array that this ReadBuffer uses.
- getRawByteArray() - Method in class com.tangosol.io.ByteArrayWriteBuffer
-
Obtain the byte array that this WriteBuffer uses.
- getRawDate() - Method in class com.tangosol.io.pof.RawDateTime
-
Obtain the date portion of the raw date-time value.
- getRawOffset() - Method in class com.tangosol.io.ByteArrayReadBuffer
-
- getRawTime() - Method in class com.tangosol.io.pof.RawDateTime
-
Obtain the time portion of the raw date-time value.
- getReadBuffer(int, int) - Method in class com.tangosol.io.AbstractReadBuffer
-
Obtain a ReadBuffer for a portion of this ReadBuffer.
- getReadBuffer() - Method in class com.tangosol.io.AbstractWriteBuffer
-
Get a ReadBuffer object that is a snapshot of this WriteBuffer's data.
- getReadBuffer() - Method in class com.tangosol.io.DelegatingWriteBuffer
-
Get a ReadBuffer object that is a snapshot of this WriteBuffer's data.
- getReadBuffer() - Method in class com.tangosol.io.MultiBufferWriteBuffer
-
Get a ReadBuffer object that is a snapshot of this WriteBuffer's data.
- getReadBuffer() - Method in class com.tangosol.io.nio.ByteBufferWriteBuffer
-
Get a ReadBuffer object that is a snapshot of this WriteBuffer's data.
- getReadBuffer(int, int) - Method in interface com.tangosol.io.ReadBuffer
-
Obtain a ReadBuffer for a portion of this ReadBuffer.
- getReadBuffer() - Method in interface com.tangosol.io.WriteBuffer
-
Get a ReadBuffer object that is a snapshot of this WriteBuffer's data.
- getReader() - Method in class com.tangosol.coherence.dslquery.ExecutionContext
-
- getReader() - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
-
- getReader() - Method in interface com.tangosol.coherence.dslquery.QueryPlus.Dependencies
-
- getReader() - Static method in class com.tangosol.util.NullImplementation
-
Factory method: Obtain a null implementation of a Reader.
- getReadOnlyEntry(Object) - Method in interface com.tangosol.net.BackingMapContext
-
Return an read-only InvocableMap.Entry for the specified key (in its internal
format) from the associated cache.
- getReadQueue() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Get the queue of keys that are yet to be read.
- getReadThread() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Get the refresh-ahead thread.
- getReceiverPriority() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the priority of the PacketReceiver daemon thread.
- getRecentIterator() - Method in class com.tangosol.util.ChainedEnumerator
-
Get the recently used iterator, if any.
- getReconnectInterval() - Method in class com.tangosol.coherence.config.scheme.ContinuousQueryCacheScheme
-
- getReconnectInterval() - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
Return the reconnection interval (in milliseconds).
- getRecoveryMillis() - Method in class com.tangosol.net.GuardSupport.Context
-
Return the recovery interval for this Guardable.
- getRefreshAheadFactor(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
-
Return refresh-ahead-factor used to calculate the "soft-expiration"
time for cache entries.
- getRefreshAheadFactor() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Return the refresh-ahead factor.
- getRefreshFrequency() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
-
- getRegisteredAsynchronousEventListeners() - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
-
Get asynchronous CacheEntryEventListeners.
- getRegisteredAsynchronousEventListeners() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
-
get asynchronous CacheEntryListenerRegistrations
- getRegisteredDbs() - Method in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
-
Get the registered Databases.
- getRegisteredSynchronousEventListeners() - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
-
Get synchronous CacheEntryEventListeners.
- getRegisteredSynchronousEventListeners() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
-
get synchronous CacheEntryListenerRegistrations
- getRegistrationBehavior() - Method in class com.tangosol.coherence.config.builder.NamedEventInterceptorBuilder
-
Returns the behavior upon duplicate registration.
- getRegistrationContext() - Method in class com.tangosol.net.cache.NearCache
-
Obtain the context (tier) used to register a CacheMBean for this cache.
- getRegistryPort() - Static method in class com.tangosol.net.management.MBeanConnector
-
Get the configured registry port for the RMI Connector Server.
- getReifiedTypes(Class<?>, Class<?>) - Static method in class com.tangosol.util.ClassHelper
-
Returns a map of types by type name as defined in
clzDefiningType
.
- getReliableTransport() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the name of the default reliable transport used by this node.
- getRemainingDistributionCount() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
Get the number of distributions (partition transfers) that remain to be
completed before the service achieves the goals set by this strategy.
- getRemainingDistributionCount() - Method in interface com.tangosol.net.partition.SimpleStrategyMBean
-
Get the number of distributions (partition transfers) that remain to be
completed before the service achieves the goals set by this strategy.
- getRemoteCacheScheme() - Method in class com.tangosol.coherence.config.scheme.CacheStoreScheme
-
- getRemoteMember() - Method in interface com.tangosol.net.events.partition.TransferEvent
-
Return the remote
Member
associated with this transfer
operation.
- getRemoveAction() - Method in class com.tangosol.util.SegmentedHashMap
-
Return the registered action for remove().
- getRemoveBundler() - Method in class com.tangosol.net.cache.BundlingNamedCache
-
Obtain the bundler for the "remove" operations.
- getRemoved() - Method in class com.tangosol.util.DeltaSet
-
Determine what items were removed from the delta set.
- getRemoved() - Method in class com.tangosol.util.SubSet
-
Determine what items were removed from the subset.
- getReplicatedCache(String, ClassLoader) - Method in class com.tangosol.run.jca.CacheAdapter
-
- getReplicatedCacheConfig() - Static method in class com.tangosol.net.CacheFactory
-
Return the default replicated cache configuration.
- getRequestCount() - Method in class com.tangosol.net.partition.PartitionStatistics
-
Return the number of requests/second issued for the partition.
- getRequestTimeout(XmlElement) - Static method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Return the request timeout based on the
XmlElement
.
- getRequestTimeout(ServiceScheme) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
-
- getRequestTimeoutMillis() - Method in class com.tangosol.net.AbstractInvocable
-
Obtain the maximum amount of time a calling thread is willing to wait for
a result of the request execution.
- getRequestTimeoutMillis() - Method in class com.tangosol.net.AbstractPriorityTask
-
Obtain the maximum amount of time a calling thread is willing to wait for
a result of the request execution.
- getRequestTimeoutMillis() - Method in interface com.tangosol.net.PriorityTask
-
Obtain the maximum amount of time a calling thread is willing to wait for
a result of the request execution.
- getRequestTimeoutMillis() - Method in interface com.tangosol.net.ServiceDependencies
-
Obtain a default request timeout value.
- getRequestTimeoutMillis() - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.Task
-
Obtain the maximum amount of time a calling thread is willing to wait for
a result of the request execution.
- getResolver(String) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.Manager
-
Return the ParameterResolver
for the given cache.
- getResolver() - Method in class com.tangosol.net.PartitionedService.PartitionRecoveryAction
-
Return the GUID resolver.
- getResource(Class<R>) - Method in class com.tangosol.config.xml.DefaultProcessingContext
-
Attempts to retrieve the resource that was registered with the
specified class.
- getResource(Class<R>, String) - Method in class com.tangosol.config.xml.DefaultProcessingContext
-
Attempts to retrieve the resource that was registered with the
specified class and name.
- getResource(String) - Method in interface com.tangosol.net.Cluster
-
- getResource(Class<R>) - Method in class com.tangosol.util.ChainedResourceResolver
-
Attempts to retrieve the resource that was registered with the
specified class.
- getResource(Class<R>, String) - Method in class com.tangosol.util.ChainedResourceResolver
-
Attempts to retrieve the resource that was registered with the
specified class and name.
- getResource(Class<R>) - Method in class com.tangosol.util.NullImplementation.NullResourceRegistry
-
- getResource(Class<R>, String) - Method in class com.tangosol.util.NullImplementation.NullResourceRegistry
-
- getResource(Class<R>) - Method in interface com.tangosol.util.ResourceResolver
-
Attempts to retrieve the resource that was registered with the
specified class.
- getResource(Class<R>, String) - Method in interface com.tangosol.util.ResourceResolver
-
Attempts to retrieve the resource that was registered with the
specified class and name.
- getResource(Class<R>) - Method in class com.tangosol.util.SimpleResourceRegistry
-
Attempts to retrieve the resource that was registered with the
specified class.
- getResource(Class<R>, String) - Method in class com.tangosol.util.SimpleResourceRegistry
-
Attempts to retrieve the resource that was registered with the
specified class and name.
- getResource() - Method in class com.tangosol.util.SimpleResourceRegistry.RegistryValue
-
Return the registered resource.
- getResourceClass() - Method in class com.tangosol.util.SimpleResourceRegistry.RegistryKey
-
Return the resource class.
- getResourceRegistry() - Method in class com.tangosol.coherence.config.ResourceMapping
-
- getResourceRegistry() - Method in class com.tangosol.coherence.dslquery.ExecutionContext
-
Return the
ResourceRegistry
that may be used to register
ad-hoc resources with this context as a way to maintain state between
different command executions.
- getResourceRegistry() - Method in class com.tangosol.config.xml.DefaultProcessingContext
-
- getResourceRegistry() - Method in class com.tangosol.config.xml.DocumentProcessor.DefaultDependencies
-
- getResourceRegistry() - Method in interface com.tangosol.config.xml.DocumentProcessor.Dependencies
-
- getResourceRegistry() - Method in interface com.tangosol.config.xml.ProcessingContext
-
- getResourceRegistry() - Method in interface com.tangosol.net.Cluster
-
- getResourceRegistry() - Method in interface com.tangosol.net.ConfigurableCacheFactory
-
- getResourceRegistry() - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
- getResourceRegistry() - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.DefaultDependencies
-
- getResourceRegistry() - Method in interface com.tangosol.net.ExtensibleConfigurableCacheFactory.Dependencies
-
- getResourceRegistry() - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
-
- getResourceRegistry() - Method in interface com.tangosol.net.Service
-
- getResourceRegistry() - Method in class com.tangosol.net.WrapperService
-
- getResourceRegistry() - Static method in class com.tangosol.util.NullImplementation
-
- getResources() - Method in class com.tangosol.coherence.rest.config.RestConfig
-
Return a map of configured resources, keyed by cache name or alias.
- getResources(Class, String) - Static method in class com.tangosol.util.ClassHelper
-
Load the named resources for the specified class.
- getResponsiveMemberSet() - Method in interface com.tangosol.net.Cluster.MemberTimeoutAction
-
Return the set of Members that have recently responded to this member.
- getResult() - Method in class com.tangosol.coherence.dslquery.internal.AbstractCoherenceQueryWalker
-
- getResult() - Method in class com.tangosol.coherence.dslquery.statement.DefaultStatementResult
-
- getResult() - Method in interface com.tangosol.coherence.dslquery.StatementResult
-
Return the actual result Object that this StatementResult wraps.
- getResult() - Method in interface com.tangosol.coherence.dsltools.termtrees.TermWalker
-
Return the result of the previous TermTree walk.
- getResult() - Method in class com.tangosol.net.AbstractInvocable
-
Determine the result from the invocation of this object.
- getResult() - Method in class com.tangosol.net.cache.ContinuousQueryCache.ConverterAsynchronousProcessor
-
- getResult() - Method in interface com.tangosol.net.Invocable
-
Determine the result from the invocation of this object.
- getResult() - Method in class com.tangosol.util.AsynchronousAgent
-
- getResultAsEntryProcessor() - Method in class com.tangosol.coherence.dslquery.internal.UpdateSetListMaker
-
Turn the results of tree processing into an InvocableMap.EntryProcessor
that will return the results of the update
- getResults() - Method in class com.tangosol.coherence.dslquery.internal.SelectListMaker
-
Get the resultant Object[] from the tree processing
- getResults() - Method in class com.tangosol.coherence.dslquery.internal.UpdateSetListMaker
-
Get the resultant Object[] from the tree processing
- getResults() - Method in interface com.tangosol.util.QueryRecord
-
Get the list of partial results for this query record.
- getResults() - Method in class com.tangosol.util.SimpleQueryRecord
-
Get the list of partial results for this query record.
- getResultsAsEntryAggregator() - Method in class com.tangosol.coherence.dslquery.internal.SelectListMaker
-
Turn the results of tree processing into an
InvocableMap.EntryAggregator that will perform the aggregation.
- getResultsAsEntryProcessor() - Method in class com.tangosol.coherence.dslquery.internal.SelectListMaker
-
Turn the results of tree processing into an InvocableMap.EntryProcessor
that will return the results of a query
- getResultsAsReduction() - Method in class com.tangosol.coherence.dslquery.internal.SelectListMaker
-
Turn the results of tree processing into an InvocableMap.EntryAggregator
that will return the results of a query.
- getResultsAsValueExtractor() - Method in class com.tangosol.coherence.dslquery.internal.SelectListMaker
-
Turn the results of tree processing into a ValueExtractor
- getRetained() - Method in class com.tangosol.util.SubSet
-
Determine what items were added to the subset.
- getRipeArray() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.WriteQueue
-
Return a
LongArray
indexed by ripe time (when entries become
eligible to be written), and associated to a list of binary keys.
- getRipeMillis() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.Entry
-
Determine when the entry becomes ripe to be persisted.
- getRMIConnectorAttributes() - Static method in class com.tangosol.net.management.MBeanConnector
-
Get the attributes for the RMI Connector Server.
- getRole() - Method in class com.tangosol.coherence.rest.providers.SecurityFilter.Authorizer
-
- getRoleName() - Method in interface com.tangosol.net.MemberIdentity
-
Return the configured role name for the Member.
- getRoleName() - Method in class com.tangosol.net.proxy.RemoteMember
-
Return the configured role name for the Member.
- getRoles() - Method in interface com.tangosol.net.MemberIdentity
-
Return a set of role names for the Member.
- getRollover() - Method in class com.tangosol.util.ThreadLocalObject
-
- getRoot() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Return the root of the hierarchy this value belongs to.
- getRoot() - Method in interface com.tangosol.io.pof.reflect.PofValue
-
Return the root of the hierarchy this value belongs to.
- getRoot() - Method in class com.tangosol.run.xml.SimpleElement
-
Get the root element.
- getRoot() - Method in interface com.tangosol.run.xml.XmlElement
-
Get the root element.
- getRootCause() - Method in exception com.tangosol.util.WrapperException
-
Return the root cause of this exception.
- getRootClass() - Method in class com.tangosol.coherence.rest.io.AbstractMarshaller
-
Return class of the root object this marshaller is for.
- getRoundRobinDestination() - Method in class com.tangosol.net.LoadBalancer
-
Using a round-robin algorithm, determine the next AddressPort
combination to route to.
- getRoutableAddresses(InetAddress, boolean, Collection<InetAddress>, boolean) - Static method in class com.tangosol.net.InetAddressHelper
-
Return the set of addresses from the specified destination addresses which appear to be
routable from addrLocal.
- getRuleMask() - Method in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumRule
-
Return the numeric representation of the actions allowed by this rule.
- getSafeAttribute(String) - Method in class com.tangosol.run.xml.SimpleElement
-
Get an attribute value, and return a temporary value if the attribute
does not exist.
- getSafeAttribute(String) - Method in interface com.tangosol.run.xml.XmlElement
-
Get an attribute value, and return a temporary value if the attribute
does not exist.
- getSafeElement(String) - Method in class com.tangosol.run.xml.SimpleElement
-
Return the specified child element using the same path notation as
supported by findElement, but return a read-only element if the
specified element does not exist.
- getSafeElement(String) - Method in interface com.tangosol.run.xml.XmlElement
-
Return the specified child element using the same path notation as
supported by findElement, but return a read-only element if the
specified element does not exist.
- getSafeTimeMillis() - Static method in class com.tangosol.util.Base
-
Returns a "safe" current time in milliseconds.
- getSampleDuration() - Method in class com.tangosol.net.partition.PartitionStatistics
-
Return the duration (ms) over which data was collected for this sample.
- getSampleStartTime() - Method in class com.tangosol.net.partition.PartitionStatistics
-
Return the time (on the sampling member) at which this data collection
for this sample started.
- getSamplingPeriod() - Method in interface com.tangosol.net.partition.DistributionManager
-
Return the sampling period at which partition statistics are collected.
- getScanner() - Method in class com.tangosol.coherence.dsltools.precedence.OPParser
-
Obtain the OPScanner that backs this parser
- getSchedulingPriority() - Method in class com.tangosol.net.AbstractInvocable
-
Obtain this task's scheduling priority.
- getSchedulingPriority() - Method in class com.tangosol.net.AbstractPriorityTask
-
Obtain this task's scheduling priority.
- getSchedulingPriority() - Method in interface com.tangosol.net.PriorityTask
-
Obtain this task's scheduling priority.
- getSchedulingPriority() - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.Task
-
Obtain this task's scheduling priority.
- getSchemaLocations(XmlElement, String) - Static method in class com.tangosol.run.xml.XmlHelper
-
Retrieve a listing of schema locations
(schemaLocation/noNamespaceSchemaLocation) URL's referenced
in XmlElement and all of its children.
- getSchemeMappingClass() - Method in class com.tangosol.coherence.config.SchemeMappingRegistry.SchemeMappingKey
-
Return the scheme mapping class.
- getSchemeName() - Method in class com.tangosol.coherence.config.ResourceMapping
-
Obtains the name of the caching scheme to be used
that match this
ResourceMapping
.
- getSchemeName() - Method in class com.tangosol.coherence.config.scheme.AbstractScheme
-
Obtains the name of the
Scheme
.
- getSchemeName() - Method in interface com.tangosol.coherence.config.scheme.Scheme
-
Obtains the name of the
Scheme
.
- getSchemeName() - Method in class com.tangosol.coherence.config.scheme.WrapperCachingScheme
-
- getSchemeName() - Method in class com.tangosol.net.DefaultConfigurableCacheFactory.CacheInfo
-
Deprecated.
Obtain the scheme name.
- getScopedResolver(String) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.Manager
-
Return the ScopedParameterResolver
for the given cache.
- getScopedServiceName() - Method in class com.tangosol.coherence.config.scheme.AbstractServiceScheme
-
Return the service name with any scoping applied.
- getScopedServiceName() - Method in interface com.tangosol.coherence.config.scheme.ServiceScheme
-
Return the service name with any scoping applied.
- getScopedServiceName() - Method in class com.tangosol.coherence.config.scheme.WrapperCachingScheme
-
- getScopedServiceName(String) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Apply the scope name prefix to the given service name.
- getScopeName() - Method in interface com.tangosol.coherence.config.builder.ServiceBuilder
-
Return the scope name.
- getScopeName() - Method in class com.tangosol.coherence.config.CacheConfig
-
- getScopeName() - Method in class com.tangosol.coherence.config.scheme.AbstractServiceScheme
-
Return the scope name.
- getScopeName() - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Return the scope name for this ConfigurableCacheFactory.
- getScopeName() - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
-
Return the scope name for this ConfigurableCacheFactory.
- getScopeResolver() - Method in class com.tangosol.net.ScopedCacheFactoryBuilder
-
Obtain the scope resolver for this builder.
- getSecond() - Method in class com.tangosol.io.pof.RawTime
-
Determine the time's second value.
- getSecondaryKey() - Method in class com.tangosol.util.CompositeKey
-
Return the secondary key component.
- getSecondaryPolicy() - Method in class com.tangosol.net.CompositeActionPolicy
-
Return the secondary policy.
- getSecondMap() - Method in class com.tangosol.util.ChainedMap
-
Get the second (back) map.
- getSeconds() - Method in class com.tangosol.io.pof.RawDayTimeInterval
-
Determine the number of seconds in the day-time interval.
- getSeconds() - Method in class com.tangosol.io.pof.RawTimeInterval
-
Determine the number of seconds in the time interval.
- getSecurityConfig() - Static method in class com.tangosol.net.CacheFactory
-
Return the security framework configuration.
- getSegmentForKey(Object) - Method in class com.tangosol.util.SegmentedHashMap
-
Return the Segment object for the specified key.
- getSegmentIndex(int) - Method in class com.tangosol.util.SegmentedHashMap
-
Calculate the segment index for the the specified bucket.
- getSerializedValue() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Return this value's serialized form.
- getSerializedValue() - Method in class com.tangosol.io.pof.reflect.PofSparseArray.NilPofValue
-
Return this value's serialized form.
- getSerializer() - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
-
Return a
Serializer
that is used to serialize/deserialize this
entry.
- getSerializer() - Method in interface com.tangosol.net.Service
-
Return a Serializer used by this Service.
- getSerializer() - Method in class com.tangosol.net.WrapperService
-
Return a Serializer used by this Service.
- getSerializer() - Method in interface com.tangosol.util.BinaryEntry
-
Return a
Serializer
that is used to serialize/deserialize this
entry.
- getSerializer() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventBinaryEntry
-
Return a
Serializer
that is used to serialize/deserialize this
entry.
- getSerializer() - Method in class com.tangosol.util.InvocableMapHelper.RoutingBinaryEntry
-
Return a
Serializer
that is used to serialize/deserialize this
entry.
- getSerializerFactory() - Method in interface com.tangosol.net.ServiceDependencies
-
- getSerializerMap() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the Serializer map.
- getSerializerMap() - Method in interface com.tangosol.net.OperationalContext
-
Return a Map of serializer factories.
- getService() - Method in class com.tangosol.net.AbstractInvocable
-
Obtain the containing InvocationService.
- getService() - Method in class com.tangosol.net.AbstractServiceLoadBalancer
-
Obtain the containing Service.
- getService(String) - Static method in class com.tangosol.net.CacheFactory
-
Return an instance of a service configured by the current
ConfigurableCacheFactory.
- getService(String) - Method in interface com.tangosol.net.Cluster
-
Returns a Service object for the specified service name.
- getService() - Method in class com.tangosol.net.ConfigurableQuorumPolicy.ClusterQuorumPolicy
-
Return the Cluster service.
- getService() - Method in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy
-
Return the Service which this policy applies to.
- getService() - Method in class com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy
-
Return the associated PartitionedService.
- getService() - Method in interface com.tangosol.net.events.partition.PartitionedServiceDispatcher
-
- getService() - Method in class com.tangosol.net.MemberEvent
-
Return the Service that fired the event
- getService() - Method in interface com.tangosol.net.NamedCache
-
- getService() - Method in interface com.tangosol.net.NamedCollection
-
Return the Service that this NamedCollection is a part of.
- getService() - Method in interface com.tangosol.net.partition.DistributionManager
-
Return the partitioned service for which this DistributionManager
coordinates the distribution.
- getService() - Method in class com.tangosol.net.partition.MirroringAssignmentStrategy
-
Return the partitioned service for which this assignment strategy
controls the distribution.
- getService() - Method in class com.tangosol.net.partition.PartitionEvent
-
Determine the partitioned service that this event originates from.
- getService() - Method in class com.tangosol.net.WrapperService
-
Return the wrapped Service.
- getService() - Method in class com.tangosol.util.ServiceEvent
-
Return the Service that fired the event.
- getServiceBanner(Cluster) - Method in class com.tangosol.net.DefaultCacheServer
-
Create a list of running services in the given Cluster.
- getServiceBuilder() - Method in class com.tangosol.coherence.config.scheme.AbstractServiceScheme
-
- getServiceBuilder() - Method in class com.tangosol.coherence.config.scheme.NearScheme
-
- getServiceBuilder() - Method in interface com.tangosol.coherence.config.scheme.ServiceScheme
-
- getServiceBuilder() - Method in class com.tangosol.coherence.config.scheme.WrapperCachingScheme
-
- getServiceConfig(String) - Static method in class com.tangosol.net.CacheFactory
-
Return the configuration for the specified service type.
- getServiceDependencies() - Method in class com.tangosol.coherence.config.scheme.AbstractServiceScheme
-
- getServiceFailurePolicyBuilder() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the service failure policy builder.
- getServiceFilterMap() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain a map of service name to filter list.
- getServiceInfo(String) - Method in interface com.tangosol.net.Cluster
-
Returns a ServiceInfo object for the specified service name.
- getServiceJoinTime(String) - Static method in class com.tangosol.persistence.GUIDHelper
-
Parse the specified GUID and return the service join time.
- getServiceMachineCount() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
Get the number of machines that host storage-enabled nodes running this service.
- getServiceMachineCount() - Method in interface com.tangosol.net.partition.SimpleStrategyMBean
-
Get the number of machines that host storage-enabled nodes running this service.
- getServiceMap() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the service map.
- getServiceMap() - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
-
Return a map of services that were successfully started by this
factory where values are corresponding non-scoped service names.
- getServiceMBean(String, Member) - Method in class com.tangosol.coherence.dslquery.internal.PersistenceToolsHelper
-
Return the Service MBean name.
- getServiceMember(int) - Method in interface com.tangosol.net.ServiceInfo
-
Return the Member with the specified mini-id that is running
this Service.
- getServiceMembers() - Method in interface com.tangosol.net.ServiceInfo
-
Return a Set of Member objects, one for each Member that
has registered this Service.
- getServiceName() - Method in class com.tangosol.coherence.config.scheme.AbstractServiceScheme
-
Return the service name.
- getServiceName() - Method in interface com.tangosol.coherence.config.scheme.ServiceScheme
-
Return the service name.
- getServiceName() - Method in class com.tangosol.coherence.config.scheme.WrapperCachingScheme
-
- getServiceName() - Method in class com.tangosol.net.ClusterPermission
-
Return the service name for this permission object or null
if the permission applies to any service.
- getServiceName() - Method in interface com.tangosol.net.events.partition.cache.PartitionedCacheDispatcher
-
Return the name of the
service
that this
PartitionedCacheDispatcher is associated with.
- getServiceName() - Method in class com.tangosol.net.security.PermissionInfo
-
Return the service name.
- getServiceName() - Method in interface com.tangosol.net.ServiceInfo
-
Return the name of the Service.
- getServiceName() - Method in class com.tangosol.run.jca.CacheAdapter.CacheConnectionSpec
-
- getServiceNames() - Method in interface com.tangosol.net.Cluster
-
Returns an Enumeration of String objects, one for each service that
has been previously registered in the cluster.
- getServiceNodeCount() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
Get the number of storage-enabled nodes running this service.
- getServiceNodeCount() - Method in interface com.tangosol.net.partition.SimpleStrategyMBean
-
Get the number of storage-enabled nodes running this service.
- getServiceRackCount() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
Get the number of racks that host storage-enabled nodes running this service.
- getServiceRackCount() - Method in interface com.tangosol.net.partition.SimpleStrategyMBean
-
Get the number of racks that host storage-enabled nodes running this service.
- getServiceSchemeRegistry() - Method in class com.tangosol.coherence.config.CacheConfig
-
- getServiceSiteCount() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
Get the number of sites that host storage-enabled nodes running this service.
- getServiceSiteCount() - Method in interface com.tangosol.net.partition.SimpleStrategyMBean
-
Get the number of sites that host storage-enabled nodes running this service.
- getServiceType() - Method in class com.tangosol.coherence.config.builder.MapBuilder.Dependencies
-
Return the Service type.
- getServiceType() - Method in class com.tangosol.coherence.config.scheme.AbstractLocalCachingScheme
-
Return the service type.
- getServiceType() - Method in class com.tangosol.coherence.config.scheme.ClassScheme
-
Return the service type.
- getServiceType() - Method in class com.tangosol.coherence.config.scheme.DistributedScheme
-
Return the service type.
- getServiceType() - Method in class com.tangosol.coherence.config.scheme.InvocationScheme
-
Return the service type.
- getServiceType() - Method in class com.tangosol.coherence.config.scheme.OptimisticScheme
-
Return the service type.
- getServiceType() - Method in class com.tangosol.coherence.config.scheme.ProxyScheme
-
Return the service type.
- getServiceType() - Method in class com.tangosol.coherence.config.scheme.RemoteCacheScheme
-
Return the service type.
- getServiceType() - Method in class com.tangosol.coherence.config.scheme.RemoteInvocationScheme
-
Return the service type.
- getServiceType() - Method in class com.tangosol.coherence.config.scheme.ReplicatedScheme
-
Return the service type.
- getServiceType() - Method in interface com.tangosol.coherence.config.scheme.ServiceScheme
-
Return the service type.
- getServiceType() - Method in class com.tangosol.coherence.config.scheme.TransactionalScheme
-
Return the service type.
- getServiceType() - Method in class com.tangosol.coherence.config.scheme.ViewScheme
-
- getServiceType() - Method in class com.tangosol.coherence.config.scheme.WrapperCachingScheme
-
- getServiceType() - Method in interface com.tangosol.net.ServiceInfo
-
Return the type of the Service.
- getServiceType() - Method in class com.tangosol.run.jca.CacheAdapter.CacheConnectionSpec
-
- getServiceVersion(Member) - Method in interface com.tangosol.net.ServiceInfo
-
Return a String with Service version for the specified
service Member.
- getServiceVersion(PersistentStore<ReadBuffer>) - Static method in class com.tangosol.persistence.CachePersistenceHelper
-
- getSet(Set<F>, Converter<F, T>, Converter<T, F>) - Static method in class com.tangosol.util.ConverterCollections
-
Returns an instance of Set that uses a Converter to view an
underlying Set.
- getSet() - Method in class com.tangosol.util.ImmutableArrayList
-
Return a java.util.Set view of this ImmutableArrayList.
- getSet() - Method in class com.tangosol.util.ImmutableMultiList
-
Return a java.util.Set view of this ImmutableMultiList.
- getSet() - Static method in class com.tangosol.util.NullImplementation
-
Returns an instance of the NullSet.
- getSet(Set, Class) - Static method in class com.tangosol.util.RestrictedCollections
-
Returns a restricted instance of Set.
- getSetList(NodeTerm) - Static method in class com.tangosol.coherence.dslquery.statement.AbstractStatementBuilder
-
Return the AST node that represents the list of "Set statements" from the
given AST node.
- getSharedDirectoryPath() - Method in class com.tangosol.persistence.DirectorySnapshotArchiver
-
The shared directory to write archives to.
- getShieldedOutputStream(OutputStream) - Static method in class com.tangosol.util.ExternalizableHelper
-
Get a shielded OutputStream for the passed OutputStream object.
- getShort() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Return the short which this PofValue represents.
- getShort() - Method in interface com.tangosol.io.pof.reflect.PofValue
-
Return the short which this PofValue represents.
- getShortArray() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Return the short[] which this PofValue represents.
- getShortArray() - Method in interface com.tangosol.io.pof.reflect.PofValue
-
Return the short[] which this PofValue represents.
- getShortClassName() - Method in class com.tangosol.util.Base.StackFrame
-
- getShrinkageCount() - Method in class com.tangosol.io.nio.BinaryMap
-
Determine the level at which the modulo will decrease.
- getShrinkageThreshold() - Method in class com.tangosol.io.nio.AbstractBufferManager
-
Determine the level (what number of bytes used) below which the current
ByteBuffer will need to be "resized" downwards.
- getShrinkageThreshold() - Method in interface com.tangosol.io.nio.ByteBufferManager
-
Determine the level (what number of bytes used) below which the current
ByteBuffer will need to be "resized" downwards.
- getShutdownHookOption() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the value of the ShutdownHook setting.
- getSignedPermission() - Method in class com.tangosol.net.security.PermissionInfo
-
Return the encrypted ClusterPermission object.
- getSimpleFactory(Continuation<? super T>) - Static method in class com.tangosol.persistence.SafePersistenceWrappers
-
Return a simple FailureContinuationFactory that uses the specified failure
continuation to handle failures at any layer of the persistence
implementation.
- getSimpleName() - Method in class com.tangosol.coherence.dsltools.base.BaseToken
-
Return the simple class name for this instance.
- getSimpleName(Class) - Static method in class com.tangosol.util.ClassHelper
-
Determine the simple (unqualified) name of a class.
- getSimpleName(String) - Static method in class com.tangosol.util.ClassHelper
-
Determine the simple (unqualified) name of a class.
- getSingletonFactory() - Method in class com.tangosol.net.SingletonCacheFactoryBuilder
-
Return the singleton cache factory.
- getSiteCount() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.BackupStrength
-
Return the site count.
- getSiteName() - Method in interface com.tangosol.net.MemberIdentity
-
Return the configured name for the Site (such as a data center) in which
this Member resides.
- getSiteName() - Method in class com.tangosol.net.proxy.RemoteMember
-
Return the configured name for the Site (such as a data center) in which
this Member resides.
- getSize(Object, Class<?>, Type, Annotation[], MediaType) - Method in class com.tangosol.coherence.rest.providers.EntryWriter
-
- getSize(Object, Class<?>, Type, Annotation[], MediaType) - Method in class com.tangosol.coherence.rest.providers.JsonCollectionWriter
-
- getSize(Object, Class<?>, Type, Annotation[], MediaType) - Method in class com.tangosol.coherence.rest.providers.ObjectWriter
- getSize(Object, Class<?>, Type, Annotation[], MediaType) - Method in class com.tangosol.coherence.rest.providers.XmlCollectionWriter
-
- getSize(Set, Class<?>, Type, Annotation[], MediaType) - Method in class com.tangosol.coherence.rest.providers.XmlKeysWriter
- getSize(Map, Class<?>, Type, Annotation[], MediaType) - Method in class com.tangosol.coherence.rest.providers.XmlMapWriter
-
- getSize() - Method in class com.tangosol.coherence.rest.util.StaticContent
-
Return content size in bytes.
- getSize() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Return the size of the encoded value in bytes.
- getSize() - Method in class com.tangosol.net.cache.OverflowMap
-
Obtain the number of entries in the OverflowMap.
- getSize() - Method in class com.tangosol.net.cache.SerializationPagedCache.WrapperBinaryStore
-
- getSize() - Method in class com.tangosol.util.AbstractLongArray
-
Determine the size of the LongArray.
- getSize() - Method in class com.tangosol.util.AbstractSafeLongArray
-
- getSize() - Method in class com.tangosol.util.AbstractSparseArray
-
Determine the size of the LongArray.
- getSize() - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray
-
- getSize() - Method in interface com.tangosol.util.LongArray
-
Determine the size of the LongArray.
- getSize() - Method in class com.tangosol.util.SimpleLongArray
-
Determine the size of the LongArray.
- getSize() - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.IndexLookupRecord
-
Return index content map size.
- getSize() - Method in class com.tangosol.util.StringTable
-
Determine the number of strings in the table.
- getSize() - Method in class com.tangosol.util.Tree
-
Determine the size of the tree.
- getSize() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
-
- getSizeAction() - Method in class com.tangosol.util.SegmentedConcurrentMap
-
Return the registered action for size().
- getSizeCode() - Method in class com.tangosol.io.nio.BinaryMap.Block
-
Determine the "free block size code" for a block of this size.
- getSizeCounter() - Method in class com.tangosol.util.SafeSortedMap.BaseEntryNode
-
Return the AtomicLong used to track the size of the base entry list.
- getSizeThreshold() - Method in class com.tangosol.net.cache.AbstractBundler
-
Obtain the bundle size threshold value.
- getSnapshotArchiverMap() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the snapshot archiver map.
- getSnapshotArchiverMap() - Method in interface com.tangosol.net.OperationalContext
-
Return a Map of snapshot archiver factories.
- getSnapshotDirectory(ConfigurableCacheFactory, String, String) - Static method in class com.tangosol.coherence.dslquery.internal.PersistenceToolsHelper
-
Return the snapshot directory for a given service and snapshot.
- getSnapshotName() - Method in interface com.tangosol.net.events.partition.TransferEvent.RecoveryTransferEvent
-
Return the name of the snapshot if the partition was recovered from
a snapshot and not active persistence.
- getSnapshotPersistenceTools(File) - Static method in class com.tangosol.persistence.CachePersistenceHelper
-
Return an implementation specific instance of PersistenceTools
for
the given local snapshot directory.
- getSnapshots() - Method in interface com.tangosol.persistence.PersistenceManagerMBean
-
Return a list of snapshots that are available for recovery.
- getSocketProvider(XmlElement) - Method in class com.tangosol.net.SocketProviderFactory
-
Deprecated.
- getSocketProvider(String) - Method in class com.tangosol.net.SocketProviderFactory
-
Return a Socket provider
- getSocketProvider(String, SocketProviderFactory.Dependencies, int) - Method in class com.tangosol.net.SocketProviderFactory
-
Return a Socket provider
- getSocketProviderBuilder() - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder
-
Get delegate socket provider builder
- getSocketProviderFactory() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the SocketProviderFactory associated with the cluster.
- getSocketProviderFactory() - Method in interface com.tangosol.net.OperationalContext
-
Return a SocketProviderFactory.
- getSocketProviderFactory() - Method in class com.tangosol.net.SocketProviderFactory.DefaultDependencies
-
Get the associated SocketProviderFactory for the Dependency object.
- getSocketProviderFactory() - Method in interface com.tangosol.net.SocketProviderFactory.Dependencies
-
Get the associated SocketProviderFactory for the Dependency object.
- getSoftTimeout() - Method in class com.tangosol.net.GuardSupport.Context
-
Return the next soft-timeout for this Guardable.
- getSoftTimeoutMillis() - Method in interface com.tangosol.net.Guardian.GuardContext
-
Return the soft timeout interval for the represented Guardable.
- getSoftTimeoutMillis() - Method in class com.tangosol.net.GuardSupport.Context
-
Return the soft timeout interval for the represented Guardable.
- getSortedMap() - Method in class com.tangosol.util.ConverterCollections.ConverterSortedMap
-
Return the underlying SortedMap.
- getSortedMap(SortedMap<FK, FV>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Static method in class com.tangosol.util.ConverterCollections
-
Returns a Converter instance of SortedMap.
- getSortedMap(SortedMap, Class, Class) - Static method in class com.tangosol.util.RestrictedCollections
-
Returns a restricted instance of SortedMap.
- getSortedSet() - Method in class com.tangosol.util.ConverterCollections.ConverterSortedSet
-
Return the underlying SortedSet.
- getSortedSet(SortedSet<F>, Converter<F, T>, Converter<T, F>) - Static method in class com.tangosol.util.ConverterCollections
-
Returns an instance of SortedSet that uses a Converter to view an
underlying SortedSet.
- getSortedSet() - Method in class com.tangosol.util.ImmutableArrayList
-
Return a java.util.SortedSet view of this ImmutableArrayList.
- getSortedSet(SortedSet, Class) - Static method in class com.tangosol.util.RestrictedCollections
-
Returns a restricted instance of SortedSet.
- getSource() - Method in class com.tangosol.util.SegmentedConcurrentMap.LockableEntry
-
- getSourceAddress() - Method in interface com.tangosol.net.NameService.RequestContext
-
- getSpan(Object) - Method in class com.tangosol.net.partition.BroadKeyPartitioningStrategy
-
Calculate the partition span for a logical group of keys represented by
the specified "base" key.
- getSpan() - Method in class com.tangosol.util.SafeSortedMap
-
Return the span of this map.
- getSpeakerPriority() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the priority of the PacketSpeaker daemon thread.
- getSpeakerVolumeMinimum() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the minimum number of packets which must be ready to be sent in order for
the speaker to be utilized.
- getSplitKey() - Method in class com.tangosol.util.SafeSortedMap.Split
-
- getSqlTokenTable(boolean) - Method in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
-
Return an initialized TokenTable for the full CoherenceQueryLanguage.
- getSSLDependencies(String) - Method in class com.tangosol.net.SocketProviderFactory.DefaultDependencies
-
Get the SSLSocketProvider's dependencies associated with the given socket provider id
- getSSLDependencies(String) - Method in interface com.tangosol.net.SocketProviderFactory.Dependencies
-
Get the SSLSocketProvider's dependencies associated with the given socket provider id
- getSSLSettings() - Method in class com.tangosol.coherence.config.builder.SocketProviderBuilder
-
- getSSLSettings(XmlElement) - Method in class com.tangosol.net.SocketProviderFactory
-
Deprecated.
- getSSLSettings(SocketProvider) - Method in class com.tangosol.net.SocketProviderFactory
-
Return SSLSettings for the specified SocketProvider.
- getSSLSettings(SocketProviderBuilder) - Method in class com.tangosol.net.SocketProviderFactory
-
Return SSLSettings for the specified SocketProviderBuilder.
- getStableBucketArray() - Method in class com.tangosol.util.SafeHashMap
-
Get the bucket array, or if a resize is occurring, wait for the resize
to complete and return the new bucket array.
- getStableBucketArray() - Method in class com.tangosol.util.SegmentedHashMap
-
Get the bucket array, or if a resize is occurring, wait for the resize
to complete and return the new bucket array.
- getStackFrame() - Static method in class com.tangosol.util.Base
-
Get the StackFrame information for the current method.
- getStackFrames() - Static method in class com.tangosol.util.Base
-
Iterate the StackFrame information for all callers, going from the
inside outwards, and starting with the caller of this method.
- getStackTrace() - Static method in class com.tangosol.util.Base
-
Build a stack trace for the current thread.
- getStackTrace(Throwable) - Static method in class com.tangosol.util.Base
-
Build a stack trace for the passed exception that does not include
the exception description itself.
- getState() - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
Obtain the state of the ContinuousQueryCache
.
- getState() - Method in class com.tangosol.net.cache.OverflowMap.Status
-
Determine the state of the Status object.
- getState() - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
-
Determine the state of the Status object.
- getState() - Method in interface com.tangosol.net.Guardian.GuardContext
-
Return the state of the Guardable.
- getState() - Method in class com.tangosol.net.GuardSupport.Context
-
Return the state of the Guardable.
- getState() - Method in class com.tangosol.net.partition.FailoverAccessPolicy
-
Return the current endangered state (one of the STATE_* constants).
- getState() - Method in class com.tangosol.util.Daemon
-
Obtain the state of the daemon.
- getState() - Method in interface com.tangosol.util.fsm.FiniteStateMachine
-
- getState() - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine
-
- getState(String) - Method in class com.tangosol.util.fsm.SimpleModel
-
Obtains the state with the specified name from the
SimpleModel
.
- getStateClass() - Method in class com.tangosol.util.fsm.AnnotationDrivenModel
-
- getStateClass() - Method in interface com.tangosol.util.fsm.Model
-
- getStateClass() - Method in class com.tangosol.util.fsm.SimpleModel
-
- getStateEntryActions() - Method in class com.tangosol.util.fsm.AnnotationDrivenModel
-
- getStateEntryActions() - Method in interface com.tangosol.util.fsm.Model
-
- getStateEntryActions() - Method in class com.tangosol.util.fsm.SimpleModel
-
- getStateExitActions() - Method in class com.tangosol.util.fsm.AnnotationDrivenModel
-
- getStateExitActions() - Method in interface com.tangosol.util.fsm.Model
-
- getStateExitActions() - Method in class com.tangosol.util.fsm.SimpleModel
-
- getStateFrom() - Method in exception com.tangosol.util.fsm.RollbackTransitionException
-
Obtain the state from which the
Transition
was rolled back.
- getStatementBuilder(String) - Method in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
-
- getStatementBuilders() - Method in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
-
- getStatementExecutor() - Method in class com.tangosol.coherence.dslquery.ExecutionContext
-
- getStatementExecutor() - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
-
- getStatementExecutor() - Method in interface com.tangosol.coherence.dslquery.QueryPlus.Dependencies
-
- getStatements() - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
-
- getStatements() - Method in interface com.tangosol.coherence.dslquery.QueryPlus.Dependencies
-
Return the list of statements that should be executed prior to the
start of the CohQL session.
- getStates() - Method in class com.tangosol.util.fsm.AnnotationDrivenModel
-
Obtains the valid states defined by the
Model
.
- getStates() - Method in interface com.tangosol.util.fsm.Model
-
Obtains the valid states defined by the
Model
.
- getStates() - Method in class com.tangosol.util.fsm.SimpleModel
-
Obtains the valid states defined by the
Model
.
- getStateString(int) - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
Return a String description of the provided STATE_*
variables.
- getStateTo() - Method in exception com.tangosol.util.fsm.RollbackTransitionException
-
Obtain the state to which the
Transition
did not occur.
- getStatistics() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCache
-
Get JCache Statistics associated with Cache.
- getStatistics() - Method in class com.tangosol.coherence.jcache.common.JCacheContext
-
Return the statistics for this storage node.
- getStatistics() - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
-
Get JCache statistics.
- getStatistics() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
-
Get JCache statistics
- getStatistics() - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
-
- getStatistics() - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
-
- getStatistics() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistenceSnapshotTools
-
Get the PersistenceStatistics
for a local snapshot by using the
implementation manager and visiting the store.
- getStatistics() - Method in class com.tangosol.util.NullImplementation.NullPersistenceManager
-
- getStatus() - Method in class com.tangosol.net.cache.OverflowMap.Status
-
Determine the enumerated status of the Status object.
- getStatus() - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
-
Determine the enumerated status of the Status object.
- getStatusDescription() - Method in class com.tangosol.net.ConfigurableQuorumPolicy.ClusterQuorumPolicy
-
Return a String that describes the current Quorum state.
- getStatusDescription() - Method in class com.tangosol.net.ConfigurableQuorumPolicy
-
Return a String that describes the current Quorum state.
- getStatusDescription() - Method in class com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy
-
Return a String that describes the current Quorum state.
- getStatusDescription() - Method in class com.tangosol.net.ConfigurableQuorumPolicy.ProxyQuorumPolicy
-
Return a String that describes the current Quorum state.
- getStatusMap() - Method in class com.tangosol.net.cache.OverflowMap
-
Obtain the Map of Status objects for entries managed by this
Overflow Map.
- getStatusMap() - Method in class com.tangosol.net.cache.SimpleOverflowMap
-
Obtain the Map of Status objects for entries managed by this
Overflow Map.
- getSteps() - Method in interface com.tangosol.util.QueryRecord.PartialResult
-
Get the list of steps for this query record partial result in the
order that they occurred.
- getSteps() - Method in interface com.tangosol.util.QueryRecord.PartialResult.Step
-
Return inner nested steps, may be null if not nested.
- getSteps() - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult
-
Get the list of steps for this query record partial result in the
order that they occurred.
- getSteps() - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.Step
-
Return inner nested steps, may be null if not nested.
- getStorageAccessAuthorizer() - Method in class com.tangosol.coherence.config.scheme.BackingMapScheme
-
- getStorageAccessAuthorizer() - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
-
- getStorageAccessAuthorizer(String) - Method in interface com.tangosol.net.BackingMapManager
-
Determine the
StorageAccessAuthorizer
that is used by a
CacheService to secure access to the NamedCache with the specified name.
- getStorageAccessAuthorizer(String) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory.Manager
-
Deprecated.
Determine the
StorageAccessAuthorizer
that is used by a
CacheService to secure access to the NamedCache with the specified name.
- getStorageAccessAuthorizer(String) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory.PartitionedBackingMapManager
-
Deprecated.
Determine the
StorageAccessAuthorizer
that is used by a
CacheService to secure access to the NamedCache with the specified name.
- getStorageAccessAuthorizer(String) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.Manager
-
Determine the
StorageAccessAuthorizer
that is used by a
CacheService to secure access to the NamedCache with the specified name.
- getStorageAccessAuthorizer(String) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.PartitionedBackingMapManager
-
Determine the
StorageAccessAuthorizer
that is used by a
CacheService to secure access to the NamedCache with the specified name.
- getStorageEnabledMembers() - Method in interface com.tangosol.net.DistributedCacheService
-
- getStorageFormat() - Method in class com.tangosol.persistence.AbstractPersistenceManager
-
Return the storage format used by this manager.
- getStorageIndex() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.SafetyFilter
-
Return the storage index at which to evaluate members for safety.
- getStorageScheme(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
-
- getStorageScheme() - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
-
- getStorageSize() - Method in class com.tangosol.net.partition.PartitionStatistics
-
Return the total size (in bytes) of the storage associated with the partition.
- getStorageVersion() - Method in class com.tangosol.persistence.AbstractPersistenceManager
-
Return the version of the storage format used by this manager.
- getStore() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.BinaryEntryStoreWrapper
-
Return the cache store object to which this wrapper delegates.
- getStore() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.CacheStoreWrapper
-
Return the cache store object to which this wrapper delegates.
- getStore() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
Return the cache store object to which this wrapper delegates.
- getStore() - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistentStore
-
Return the underlying PersistentStore.
- getStoreBundler() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
Obtain the bundler for the "store" operations.
- getStoreContinuation(PersistentStore<R>) - Method in interface com.tangosol.persistence.SafePersistenceWrappers.FailureContinuationFactory
-
Return a failure continuation to handle unexpected exceptions thrown
by operations against the specified PersistentStore.
- getStoreFailures() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
Determine the number of store() failures.
- getStoreMillis() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
Determine the cumulative time spent on store() operations.
- getStoreName(ParameterResolver) - Method in class com.tangosol.coherence.config.builder.storemanager.BdbStoreManagerBuilder
-
Specifies the name for a database table that the Berkeley Database JE
store manager uses to store data in.
- getStoreOps() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
Determine the number of store() operations.
- getStrategyName() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
Get name of the PartitionAssignmentStrategy in use.
- getStrategyName() - Method in interface com.tangosol.net.partition.SimpleStrategyMBean
-
Get name of the PartitionAssignmentStrategy in use.
- getStreamFormat(Object) - Static method in class com.tangosol.util.ExternalizableHelper
-
Internal: Select an optimal stream format to use to store the passed
object in a stream (as used by the DefaultSerializer).
- getStrength() - Method in class com.tangosol.util.CacheCollator
-
Returns this Collator's strength property.
- getString() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Return the String which this PofValue represents.
- getString() - Method in interface com.tangosol.io.pof.reflect.PofValue
-
Return the String which this PofValue represents.
- getString() - Method in class com.tangosol.run.xml.SimpleValue
-
Get the value as a String.
- getString(String) - Method in class com.tangosol.run.xml.SimpleValue
-
Get the value as a String.
- getString() - Method in interface com.tangosol.run.xml.XmlValue
-
Get the value as a String.
- getString(String) - Method in interface com.tangosol.run.xml.XmlValue
-
Get the value as a String.
- getString() - Method in class com.tangosol.util.AnyEvent
-
Gets the associated value as a java.lang.String.
- getSubject() - Method in class com.tangosol.net.security.PermissionInfo
-
Return the encryptor subject.
- getSubMappings() - Method in class com.tangosol.coherence.config.ResourceMapping
-
Obtain the list of sub-mappings that this mapping contains
- getSubscriberGroupBuilders() - Method in class com.tangosol.coherence.config.TopicMapping
-
- getSubscriberGroupName(ParameterResolver) - Method in class com.tangosol.coherence.config.builder.SubscriberGroupBuilder
-
Get the subscriber group name.
- getSubscriberGroups() - Method in interface com.tangosol.net.topic.NamedTopic
-
Return the set of
named
subscriber group(s) and statically configured subscriber-group(s).
- getSuggestionCompletionDelay() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
Return the amount of time in ms to delay the analysis after a
distribution suggestion has been made and before it is carried out.
- getSuggestionDelay() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
Return the amount of time in ms to delay the analysis.
- getSupplier() - Method in class com.tangosol.util.processor.MethodInvocationProcessor
-
Returns the supplier that should be used when an entry is not present.
- getSupportedTypes() - Method in interface com.tangosol.net.events.EventDispatcher
-
- getSymbol() - Method in class com.tangosol.coherence.dslquery.operator.BaseOperator
-
Return the symbol to use in CohQL that represents this operator.
- getSynchronousListeners() - Method in class com.tangosol.util.Listeners
-
Get the array of synchronous event listeners.
- getSyntax() - Method in class com.tangosol.coherence.dslquery.queryplus.CommandsStatementBuilder
-
- getSyntax() - Method in class com.tangosol.coherence.dslquery.queryplus.ExtendedLanguageStatementBuilder
-
- getSyntax() - Method in class com.tangosol.coherence.dslquery.queryplus.HelpStatementBuilder
-
- getSyntax() - Method in class com.tangosol.coherence.dslquery.queryplus.SanityCheckStatementBuilder
-
- getSyntax() - Method in class com.tangosol.coherence.dslquery.queryplus.ServicesStatementBuilder
-
- getSyntax() - Method in class com.tangosol.coherence.dslquery.queryplus.SetTimeoutStatementBuilder
-
- getSyntax() - Method in class com.tangosol.coherence.dslquery.queryplus.TraceStatementBuilder
-
- getSyntax() - Method in class com.tangosol.coherence.dslquery.queryplus.WheneverStatementBuilder
-
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.BackupStatementBuilder
-
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.CreateCacheStatementBuilder
-
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.CreateIndexStatementBuilder
-
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.DeleteStatementBuilder
-
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.DropCacheStatementBuilder
-
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.DropIndexStatementBuilder
-
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.InsertStatementBuilder
-
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.persistence.ArchiveSnapshotStatementBuilder
-
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.persistence.CreateSnapshotStatementBuilder
-
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.persistence.ForceRecoveryStatementBuilder
-
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.persistence.ListArchiverStatementBuilder
-
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.persistence.ListServicesStatementBuilder
-
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.persistence.ListSnapshotsStatementBuilder
-
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.persistence.RecoverSnapshotStatementBuilder
-
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.persistence.RemoveSnapshotStatementBuilder
-
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.persistence.ResumeServiceStatementBuilder
-
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.persistence.RetrieveSnapshotStatementBuilder
-
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.persistence.SuspendServiceStatementBuilder
-
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.persistence.ValidateSnapshotStatementBuilder
-
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.QueryRecorderStatementBuilder
-
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.RestoreStatementBuilder
-
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.SelectStatementBuilder
-
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.SourceStatementBuilder
-
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.TruncateCacheStatementBuilder
-
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.UpdateStatementBuilder
-
- getSyntax() - Method in interface com.tangosol.coherence.dslquery.StatementBuilder
-
Return the syntax of the CohQL command.
- getSyntheticEventsMap() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Get the map of keys for which the events should be marked as
synthetic (internal).
- getSyntheticInfo(String) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory.CacheInfo
-
Deprecated.
Generate a synthetic CacheInfo for a cache that has a name suffixed
with the specified string.
- getTail() - Method in class com.tangosol.util.SafeSortedMap.Split
-
Return tail of the split
- getTailWeight() - Method in class com.tangosol.util.SafeSortedMap.Split
-
- getTarget() - Method in class com.tangosol.util.extractor.AbstractExtractor
-
- getTarget() - Method in interface com.tangosol.util.ValueExtractor
-
- getTaskExecutionTime() - Method in class com.tangosol.net.partition.PartitionStatistics
-
Return the total amount of time (in ms) that tasks/requests for this
partition spent executing.
- getTaskHungThresholdMillis() - Method in interface com.tangosol.net.ServiceDependencies
-
Obtain the amount of time that a task can execute before it's considered "hung".
- getTasks() - Method in class com.tangosol.util.TaskDaemon
-
Obtain the pending tasks.
- getTaskTimeoutMillis() - Method in interface com.tangosol.net.ServiceDependencies
-
Obtain the default task timeout value.
- getTaskWaitTime() - Method in class com.tangosol.net.partition.PartitionStatistics
-
Return the total amount of time (in ms) that tasks/requests for this
partition spent waiting before execution.
- getTcpBacklog() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the listener backlog for TCMP's TCP listener.
- getTcpDatagramSocketDependencies(String) - Method in class com.tangosol.net.SocketProviderFactory.DefaultDependencies
-
Get the TcpDatagramSocketProvider's dependencies associated with the given socket provider id
- getTcpDatagramSocketDependencies(String) - Method in interface com.tangosol.net.SocketProviderFactory.Dependencies
-
Get the TcpDatagramSocketProvider's dependencies associated with the given socket provider id
- getTcpDatagramSocketOptions() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the SocketOptions to apply when TCMP runs on a TcpDatagramSocket.
- getTcpRingSocketOptions() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the TcpRing SocketOptions.
- getThread() - Method in interface com.tangosol.net.ServiceMonitor
-
Return the thread used by this ServiceMonitor.
- getThread() - Method in class com.tangosol.net.SimpleServiceMonitor
-
Return the thread used by this ServiceMonitor.
- getThread() - Method in class com.tangosol.util.Daemon.DaemonWorker
-
- getThread() - Method in class com.tangosol.util.Daemon
-
Accessor to obtain the Daemon thread object.
- getThreadContext() - Static method in class com.tangosol.net.GuardSupport
-
Obtain the GuardContext associated with the current thread.
- getThreadContextClassLoader() - Method in class com.tangosol.util.Daemon
-
Determine the configured context ClassLoader for the daemon thread.
- getThreadDecreaseInterval() - Method in interface com.tangosol.net.ThreadPoolManager
-
Return the time interval for dynamically decreasing the size of the thread pool.
- getThreadDump() - Static method in class com.tangosol.net.GuardSupport
-
Get the full thread dump.
- getThreadFactory() - Static method in class com.tangosol.util.Base
-
Return the configured thread factory.
- getThreadIncreaseInterval() - Method in interface com.tangosol.net.ThreadPoolManager
-
Return the time interval for dynamically increasing the size of the thread pool.
- getThreadPriority() - Method in interface com.tangosol.net.ServiceDependencies
-
Obtain the priority of the service thread.
- getThreadThreshold(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.BundleManager.BundleConfig
-
Return the minimum number of threads that must be concurrently
executing individual(non-bundled) requests for the bundler to
switch from a pass-through to a bundling mode.
- getThreadThreshold() - Method in class com.tangosol.net.cache.AbstractBundler
-
Obtains the minimum number of threads that will trigger the bundler to
switch from a pass through to a bundled mode.
- getThreshold() - Method in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumRule
-
Return the size threshold for this rule.
- getTime() - Method in class com.tangosol.run.xml.SimpleValue
-
Get the value as a Time.
- getTime(Time) - Method in class com.tangosol.run.xml.SimpleValue
-
Get the value as a Time.
- getTime() - Method in interface com.tangosol.run.xml.XmlValue
-
Get the value as a Time.
- getTime(Time) - Method in interface com.tangosol.run.xml.XmlValue
-
Get the value as a Time.
- getTimedOutMemberSet() - Method in interface com.tangosol.net.Cluster.MemberTimeoutAction
-
Return the set of Members that have exceeded their timeout.
- getTimeMillis() - Method in interface com.tangosol.net.Cluster
-
Returns the current "cluster time", which is analogous to the
System.currentTimeMillis()
except that the cluster
time is the roughly the same for all Members in the cluster.
- getTimeout() - Method in class com.tangosol.coherence.dslquery.ExecutionContext
-
Obtain the number of mill-seconds to wait for a
Statement
to execute
before timing out.
- getTimeout() - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
-
- getTimeout() - Method in interface com.tangosol.coherence.dslquery.QueryPlus.Dependencies
-
Return the initial value that will be set as the
CohQL statement timeout.
- getTimeout() - Method in class com.tangosol.net.GuardSupport.Context
-
Return the next timeout for this Guardable.
- getTimeout() - Method in class com.tangosol.run.jca.CacheAdapter.CacheConnectionSpec
-
- getTimeoutMillis() - Method in interface com.tangosol.net.Guardian.GuardContext
-
Return the hard timeout interval for the represented Guardable.
- getTimeoutMillis() - Method in class com.tangosol.net.GuardSupport.Context
-
Return the hard timeout interval for the represented Guardable.
- getTimestamp() - Method in interface com.tangosol.net.Member
-
Return the date/time value (in cluster time) that the Member joined.
- getTimestamp() - Method in class com.tangosol.net.proxy.RemoteMember
-
Return the date/time value (in cluster time) that the Member joined.
- getTimestamp() - Method in class com.tangosol.util.UID
-
Determine the date/time value that the UID instance was generated.
- getTimestamp() - Method in class com.tangosol.util.UUID
-
Determine the date/time value that the UUID instance was generated.
- getTimeToLive() - Method in class com.tangosol.net.TcpDatagramSocket.Impl
- getTimeUnit() - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.DelayedTransitionTo
-
- getTimeUnit() - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.ProcessEventLater
-
- getTimeZone(String) - Static method in class com.tangosol.util.Base
-
- getTitle() - Method in class com.tangosol.coherence.dslquery.ExecutionContext
-
Return the String to use for title that heads each result.
- getTitle() - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
-
- getTitle() - Method in interface com.tangosol.coherence.dslquery.QueryPlus.Dependencies
-
Return the String to use for title that heads each result.
- getTokens() - Method in class com.tangosol.coherence.dsltools.base.CompoundBaseToken
-
Return an array of BaseTokens making up the receiver.
- getTokens() - Method in class com.tangosol.coherence.dsltools.base.NestedBaseTokens
-
Return an array of BaseTokens making up the receiver.
- getTokens() - Method in class com.tangosol.coherence.dsltools.base.SequenceBaseToken
-
Return an array of BaseTokens making up the receiver.
- getToMember() - Method in class com.tangosol.net.partition.PartitionEvent
-
Determine the member that holds the partitions after the action
represented by this event.
- getTopAnchor() - Method in class com.tangosol.util.filter.LimitFilter
-
Obtain the top anchor object, which is the last value object
on a previous page.
- getTopic(String, NamedCollection.Option...) - Method in class com.tangosol.net.CoherenceSession
-
- getTopic(String, NamedCollection.Option...) - Method in interface com.tangosol.net.Session
-
- getTopNode() - Method in class com.tangosol.util.SafeSortedMap
-
Return the top index node in the map.
- getTotalAllocationTime() - Static method in class com.tangosol.io.nio.DirectBufferManager
-
Deprecated.
Return the total time spent allocating buffers, copying the previous
content and cleaning up uncollected buffers.
- getTotalGets() - Method in interface com.tangosol.net.cache.CacheStatistics
-
Determine the total number of get() operations since the cache
statistics were last reset.
- getTotalGets() - Method in class com.tangosol.net.cache.SimpleCacheStatistics
-
Determine the total number of get() operations since the cache
statistics were last reset.
- getTotalGets() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.AggregatingCacheStatistics
-
Determine the total number of get() operations since the cache
statistics were last reset.
- getTotalGetsMillis() - Method in interface com.tangosol.net.cache.CacheStatistics
-
Determine the total number of milliseconds spent on get()
operations since the cache statistics were last reset.
- getTotalGetsMillis() - Method in class com.tangosol.net.cache.SimpleCacheStatistics
-
Determine the total number of milliseconds spent on get()
operations since the cache statistics were last reset.
- getTotalGetsMillis() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.AggregatingCacheStatistics
-
Determine the total number of milliseconds spent on get()
operations since the cache statistics were last reset.
- getTotalPageCount() - Method in class com.tangosol.net.cache.SerializationPagedCache.PagedBinaryStore
-
Determine the number of pages that the PagedBinaryStore has
managed in total, including those it is currently managing.
- getTotalPuts() - Method in interface com.tangosol.net.cache.CacheStatistics
-
Determine the total number of put() operations since the cache
statistics were last reset.
- getTotalPuts() - Method in class com.tangosol.net.cache.SimpleCacheStatistics
-
Determine the total number of put() operations since the cache
statistics were last reset.
- getTotalPuts() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.AggregatingCacheStatistics
-
Determine the total number of put() operations since the cache
statistics were last reset.
- getTotalPutsMillis() - Method in interface com.tangosol.net.cache.CacheStatistics
-
Determine the total number of milliseconds spent on put()
operations since the cache statistics were last reset.
- getTotalPutsMillis() - Method in class com.tangosol.net.cache.SimpleCacheStatistics
-
Determine the total number of milliseconds spent on put()
operations since the cache statistics were last reset.
- getTotalPutsMillis() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.AggregatingCacheStatistics
-
Determine the total number of milliseconds spent on put()
operations since the cache statistics were last reset.
- getTotalRegisterListener() - Method in class com.tangosol.net.cache.CachingMap
-
- getTouchCount() - Method in interface com.tangosol.net.cache.ConfigurableCacheMap.Entry
-
Determine the number of times that the cache entry has been
touched (since the touch count was last reset).
- getTouchCount() - Method in class com.tangosol.net.cache.OldCache.Entry
-
Deprecated.
Determine the number of times that the cache entry has been touched.
- getTouchCount() - Method in class com.tangosol.net.cache.SerializationCache.EntryAttributes
-
Determine the absolute order of the entry within in the LRU list.
- getTouchCount() - Method in class com.tangosol.net.cache.SerializationCache.EntrySet.Entry
-
Determine the number of times that the cache entry has been
touched (since the touch count was last reset).
- getTouchCount() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache.EntrySet.Entry
-
Determine the number of times that the cache entry has been
touched (since the touch count was last reset).
- getTouchCount() - Method in class com.tangosol.util.ConverterCollections.ConverterCacheEntry
-
Determine the number of times that the cache entry has been
touched (since the touch count was last reset).
- getTouchCounter() - Method in class com.tangosol.net.cache.SerializationCache
-
Determine the next value from the touch counter.
- getTransactionIsolation() - Method in interface com.tangosol.util.TransactionMap
-
Retrieve this TransactionMap's current transaction isolation level.
- getTransactionTimeout() - Method in interface com.tangosol.util.TransactionMap
-
Retrieve transaction timeout value for this TransactionMap.
- getTransformationState() - Method in class com.tangosol.net.cache.CacheEvent
-
- getTransformer() - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
Obtain the transformer that this ContinuousQueryCache
is using to transform the results from
the underlying cache prior to storing them locally.
- getTransformerBuilder() - Method in class com.tangosol.coherence.config.scheme.ContinuousQueryCacheScheme
-
- getTransientExpression() - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
-
Return the Expression
transient. to use to determine
whether the backing map is transient.
- getTransientVersionCache() - Method in class com.tangosol.net.cache.VersionedBackingMap
-
Deprecated.
Get the cache of version info for the data maintained in this
backing map (and other related backing maps if this is backing a
distributed cache).
- getTransitionCount() - Method in interface com.tangosol.util.fsm.ExecutionContext
-
Obtains the number of successful transitions that have occurred on the
FiniteStateMachine
thus far.
- getTransitionCount() - Method in interface com.tangosol.util.fsm.FiniteStateMachine
-
- getTransitionCount() - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine
-
- getTransitions() - Method in class com.tangosol.util.fsm.AnnotationDrivenModel
-
- getTransitions() - Method in interface com.tangosol.util.fsm.Model
-
- getTransitions() - Method in class com.tangosol.util.fsm.SimpleModel
-
- getTrashDirectory() - Method in class com.tangosol.persistence.AbstractPersistenceManager
-
Return the directory used to store "safe-deleted" persisted data.
- getTrigger() - Method in class com.tangosol.util.MapTriggerListener
-
Obtain the MapTrigger agent represented by this TriggerListener.
- getTriggerExtentId(long) - Static method in class com.tangosol.persistence.CachePersistenceHelper
-
Return the extent identifier that contains trigger registration
information for the cache with the given identifier.
- getTrustManager() - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder
-
Get the SSL trust manager
- getTTL() - Method in class com.tangosol.net.TcpDatagramSocket.Impl
- getType() - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.DefaultKeystoreDependencies
-
Get the configured/defaulted keystore defaults.
- getType() - Method in interface com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.KeystoreDependencies
-
get key-store type, defaults to JKS
- getType() - Method in class com.tangosol.coherence.dsltools.base.LiteralBaseToken
-
Obtain the type code of this token.
- getType() - Method in class com.tangosol.coherence.rest.events.SimpleMapEvent
-
Return the event type.
- getType() - Method in class com.tangosol.io.nio.BinaryMap.Block
-
Determine the current Block type.
- getType() - Method in interface com.tangosol.net.events.Event
-
- getType() - Method in class com.tangosol.run.xml.PropertyAdapter
-
Obtain the type of the property (the class of the object declared as
being returned by the accessor and passed to the mutator).
- getType() - Method in class com.tangosol.run.xml.XmlBean.BeanInfo
-
Get the class of the specific XML bean implementation.
- getType() - Method in class com.tangosol.util.aggregator.QueryRecorder
-
Get the record type for this query recorder.
- getType() - Method in interface com.tangosol.util.QueryRecord
-
Get the
type
that was specified when this query record was created.
- getType() - Method in class com.tangosol.util.SimpleQueryRecord
-
Get the
type
that was specified when this query record was created.
- getTypeCode() - Method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
-
Obtain the typecode for the node.
- getTypedCache(String, TypeAssertion<K, V>) - Static method in class com.tangosol.net.CacheFactory
-
Return an instance of a cache with the given name satisfying the specified
TypeAssertion
.
- getTypedCache(String, ClassLoader, TypeAssertion<K, V>) - Static method in class com.tangosol.net.CacheFactory
-
Return an instance of a cache with the given name satisfying the specified
TypeAssertion
.
- getTypeId() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Obtain the POF type identifier for this value.
- getTypeId() - Method in interface com.tangosol.io.pof.reflect.PofValue
-
Obtain the POF type identifier for this value.
- getTypeIds() - Method in class com.tangosol.io.pof.EvolvableHolder
-
Return type identifiers for all the Evolvables within this holder.
- getTypeMetadata() - Method in class com.tangosol.io.pof.PofAnnotationSerializer
-
Return the TypeMetadata
instance that holds structural information
regarding the class this serializer (de)serializes.
- getUid() - Method in interface com.tangosol.net.Member
-
Return the unique identifier of the Member.
- getUid() - Method in class com.tangosol.net.proxy.RemoteMember
-
Return the unique identifier of the Member.
- getUndecorated() - Method in class com.tangosol.util.ExternalizableHelper.DecoratedMultiBufferReadBuffer
-
Return the undecorated value.
- getUndecorated(Binary) - Static method in class com.tangosol.util.ExternalizableHelper
-
- getUndecorated(ReadBuffer) - Static method in class com.tangosol.util.ExternalizableHelper
-
If the passed ReadBuffer is decorated, extract the original contents
that the decorations were added to, otherwise return the passed Binary
value.
- getUnicastSocketProviderBuilder() - Method in interface com.tangosol.net.ClusterDependencies
-
- getUnicastSocketProviderXml() - Method in interface com.tangosol.net.ClusterDependencies
-
Deprecated.
- getUniformElementType() - Method in class com.tangosol.io.pof.reflect.ComplexPofValue
-
Return the uniform element type (if this is a uniform collection).
- getUniformType() - Method in class com.tangosol.io.pof.ValidatingPofHandler.Complex
-
If the object encoding is using uniform encoding, obtain the type
id of the uniform type.
- getUniformType() - Method in class com.tangosol.io.pof.ValidatingPofHandler.ComplexMap
-
If the object encoding is using uniform encoding, obtain the type
id of the uniform type.
- getUniformType() - Method in class com.tangosol.io.pof.WritingPofHandler.Complex
-
If the object encoding is using uniform encoding, obtain the type
id of the uniform type.
- getUniformType() - Method in class com.tangosol.io.pof.WritingPofHandler.ComplexMap
-
If the object encoding is using uniform encoding, obtain the type
id of the uniform type.
- getUniqueDbName() - Method in class com.tangosol.io.bdb.DatabaseFactory
-
Get a unique (within the Factory) database name.
- getUnitCalculator() - Method in interface com.tangosol.net.cache.ConfigurableCacheMap
-
Obtain the current UnitCalculator used by the cache.
- getUnitCalculator() - Method in class com.tangosol.net.cache.OldCache
-
Deprecated.
Obtain the current UnitCalculator used by the cache.
- getUnitCalculator() - Method in class com.tangosol.net.cache.SerializationCache
-
Obtain the current UnitCalculator used by the cache.
- getUnitCalculator() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
-
Obtain the current UnitCalculator used by the cache.
- getUnitCalculatorBuilder() - Method in class com.tangosol.coherence.config.scheme.AbstractJournalScheme
-
Return the UnitCalculatorBuilder used to build a UnitCalculator.
- getUnitCalculatorBuilder() - Method in class com.tangosol.coherence.config.scheme.ExternalScheme
-
Return the UnitCalculatorBuilder used to build a UnitCalculator.
- getUnitCalculatorBuilder() - Method in class com.tangosol.coherence.config.scheme.LocalScheme
-
Return the UnitCalculatorBuilder used to build a UnitCalculator.
- getUnitCalculatorType(ParameterResolver) - Method in class com.tangosol.coherence.config.builder.UnitCalculatorBuilder
-
- getUnitCalculatorType() - Method in class com.tangosol.net.cache.OldCache
-
Deprecated.
Determine the current unit calculator type.
- getUnitCount() - Method in class com.tangosol.coherence.config.unit.Units
-
Return the unit count.
- getUnitFactor(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.AbstractJournalScheme
-
Return the unit-factor element specifies the factor by which the units,
low-units and high-units properties are adjusted.
- getUnitFactor(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.ExternalScheme
-
Return the unit-factor element specifies the factor by which the units,
low-units and high-units properties are adjusted.
- getUnitFactor(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.LocalScheme
-
Return the unit-factor element specifies the factor by which the units,
low-units and high-units properties are adjusted.
- getUnitFactor() - Method in interface com.tangosol.net.cache.ConfigurableCacheMap
-
Determine the factor by which the Units, LowUnits and HighUnits
properties are adjusted.
- getUnitFactor() - Method in class com.tangosol.net.cache.OldCache
-
Deprecated.
Determine the factor by which the Units, LowUnits and HighUnits
properties are adjusted.
- getUnitFactor() - Method in class com.tangosol.net.cache.SerializationCache
-
Determine the factor by which the Units, LowUnits and HighUnits
properties are adjusted.
- getUnitFactor() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
-
Determine the factor by which the Units, LowUnits and HighUnits
properties are adjusted.
- getUnitOfOrderId() - Method in class com.tangosol.net.cache.ContinuousQueryCache.ConverterAsynchronousProcessor
-
- getUnitOfOrderId() - Method in class com.tangosol.util.aggregator.AbstractAsynchronousAggregator
-
Return a unit-of-order id associated with this aggregator.
- getUnitOfOrderId() - Method in class com.tangosol.util.AsynchronousAgent
-
Return a unit-of-order id associated with this agent.
- getUnitOfOrderId() - Method in class com.tangosol.util.processor.AbstractAsynchronousProcessor
-
Return a unit-of-order id associated with this processor.
- getUnits() - Method in interface com.tangosol.net.cache.ConfigurableCacheMap.Entry
-
Determine the number of cache units used by this Entry.
- getUnits() - Method in interface com.tangosol.net.cache.ConfigurableCacheMap
-
Determine the number of units that the cache currently stores.
- getUnits() - Method in class com.tangosol.net.cache.OldCache.Entry
-
Deprecated.
Determine the number of cache units used by this Entry.
- getUnits() - Method in class com.tangosol.net.cache.OldCache
-
Deprecated.
Determine the number of units that the cache currently stores.
- getUnits() - Method in class com.tangosol.net.cache.SerializationCache.EntryAttributes
-
Determine the number of units of storage used by the entry.
- getUnits() - Method in class com.tangosol.net.cache.SerializationCache.EntrySet.Entry
-
Determine the number of cache units used by this Entry.
- getUnits() - Method in class com.tangosol.net.cache.SerializationCache
-
Determine the number of units that the cache currently stores.
- getUnits() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache.EntrySet.Entry
-
Determine the number of cache units used by this Entry.
- getUnits() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
-
Determine the number of units that the cache currently stores.
- getUnits() - Method in class com.tangosol.util.ConverterCollections.ConverterCacheEntry
-
Determine the number of cache units used by this Entry.
- getUnits() - Method in class com.tangosol.util.SimpleMapIndex
-
Retrieve the size of this index in units (as defined by the
UnitCalculator
).
- getUniversalName(String, String) - Static method in class com.tangosol.run.xml.XmlHelper
-
Return a universal XML element name.
- getUnlockAction() - Method in class com.tangosol.util.SegmentedConcurrentMap
-
Return the registered action for unlock().
- getUnownedPartitions(PartitionSet, int) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
Calculate a subset of the PartitionSet consisting of partitions that are
not owned (primary or backup) by the specified member.
- getUnresolvedPartitions() - Method in class com.tangosol.persistence.GUIDHelper.GUIDResolver
-
Retrieve a PartitionSet containing all partitions that don't have any
corresponding GUIDs.
- getUnsafe() - Static method in class com.tangosol.util.Unsafe
-
Return the singleton
Unsafe
instance.
- getUnsafeReadBuffer() - Method in class com.tangosol.io.AbstractWriteBuffer
-
Get a ReadBuffer object to read data from this buffer.
- getUnsafeReadBuffer() - Method in class com.tangosol.io.ByteArrayWriteBuffer
-
Get a ReadBuffer object to read data from this buffer.
- getUnsafeReadBuffer() - Method in class com.tangosol.io.DelegatingWriteBuffer
-
Get a ReadBuffer object to read data from this buffer.
- getUnsafeReadBuffer() - Method in class com.tangosol.io.MultiBufferWriteBuffer
-
Get a ReadBuffer object to read data from this buffer.
- getUnsafeReadBuffer() - Method in class com.tangosol.io.nio.ByteBufferWriteBuffer
-
Get a ReadBuffer object to read data from this buffer.
- getUnsafeReadBuffer() - Method in interface com.tangosol.io.WriteBuffer
-
Get a ReadBuffer object to read data from this buffer.
- getUnsafeWriteBuffer() - Method in class com.tangosol.io.nio.ByteBufferWriteBuffer
-
Create a "shallow clone" of the ByteBufferWriteBuffer that uses the same
underlying memory but through a different (a duplicate) ByteBuffer.
- getUnsynchronizedKeyEnumerator() - Method in class com.tangosol.util.Tree
-
Get an enumerator of the nodes in the tree.
- getUnsynchronizedKeyEnumerator(Comparable) - Method in class com.tangosol.util.Tree
-
Get an enumerator of the nodes in the tree.
- getUpdatedPartitions() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
Return the set of updated partitions; may be null.
- getUpdater() - Method in class com.tangosol.coherence.rest.util.MvelManipulator
-
Retrieve the underlying ValueUpdater reference.
- getUpdater() - Method in class com.tangosol.util.extractor.CompositeUpdater
-
Retrieve the ValueUpdater part.
- getUpdater() - Method in class com.tangosol.util.processor.PropertyManipulator
-
Retrieve the underlying ValueUpdater reference.
- getUpdater() - Method in interface com.tangosol.util.ValueManipulator
-
Retrieve the underlying ValueUpdater reference.
- getUpperBound() - Method in class com.tangosol.util.filter.BetweenFilter
-
Obtain the upper bound of the range being used to evaluate
values by this BetweenFilter.
- getUpperBound() - Method in class com.tangosol.util.SafeSortedMap.ViewMap
-
Return the upper bound of this ViewMap.
- getUpTimeMillis() - Static method in class com.tangosol.util.Base
-
Return the number of milliseconds which have elapsed since the JVM was
started.
- getURI() - Method in class com.tangosol.coherence.jcache.CoherenceBasedCacheManager
-
- getURL() - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.DefaultKeystoreDependencies
-
Get the configured/defaulted keystore url.
- getURL() - Method in interface com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.KeystoreDependencies
-
get URL
- getUsedCapacity() - Method in class com.tangosol.io.nio.BinaryMap
-
Determine the number of types in the buffer that are in use by Entry
blocks.
- getUserContext() - Method in interface com.tangosol.net.Service
-
Return the user context object associated with this Service.
- getUserContext() - Method in class com.tangosol.net.WrapperService
-
Return the user context object associated with this Service.
- getUsername() - Method in class com.tangosol.net.security.UsernameAndPassword
-
Return the username.
- getUserName() - Method in class com.tangosol.run.jca.CacheAdapter.CacheConnectionSpec
-
- getUserPrincipal() - Method in class com.tangosol.coherence.rest.providers.SecurityFilter.Authorizer
-
- getUserTypeId() - Method in class com.tangosol.io.pof.PofBufferReader
-
Determine the user type that is currently being parsed.
- getUserTypeId() - Method in class com.tangosol.io.pof.PofBufferReader.UserTypeReader
-
Determine the user type that is currently being parsed.
- getUserTypeId() - Method in class com.tangosol.io.pof.PofBufferWriter
-
Determine the user type that is currently being written.
- getUserTypeId() - Method in class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
-
Determine the user type that is currently being written.
- getUserTypeId() - Method in interface com.tangosol.io.pof.PofReader
-
Determine the user type that is currently being parsed.
- getUserTypeId() - Method in interface com.tangosol.io.pof.PofWriter
-
Determine the user type that is currently being written.
- getUserTypeIdentifier(Object) - Method in class com.tangosol.io.pof.ConfigurablePofContext
-
Determine the user type identifier associated with the given object.
- getUserTypeIdentifier(Class) - Method in class com.tangosol.io.pof.ConfigurablePofContext
-
Determine the user type identifier associated with the given class.
- getUserTypeIdentifier(String) - Method in class com.tangosol.io.pof.ConfigurablePofContext
-
Determine the user type identifier associated with the given class
name.
- getUserTypeIdentifier(Object) - Method in interface com.tangosol.io.pof.PofContext
-
Determine the user type identifier associated with the given object.
- getUserTypeIdentifier(Class) - Method in interface com.tangosol.io.pof.PofContext
-
Determine the user type identifier associated with the given class.
- getUserTypeIdentifier(String) - Method in interface com.tangosol.io.pof.PofContext
-
Determine the user type identifier associated with the given class
name.
- getUserTypeIdentifier(Class) - Method in class com.tangosol.io.pof.SafeConfigurablePofContext
-
Determine the user type identifier associated with the given class.
- getUserTypeIdentifier(String) - Method in class com.tangosol.io.pof.SafeConfigurablePofContext
-
Determine the user type identifier associated with the given class
name.
- getUserTypeIdentifier(Object) - Method in class com.tangosol.io.pof.SimplePofContext
-
Determine the user type identifier associated with the given object.
- getUserTypeIdentifier(Class) - Method in class com.tangosol.io.pof.SimplePofContext
-
Determine the user type identifier associated with the given class.
- getUserTypeIdentifier(String) - Method in class com.tangosol.io.pof.SimplePofContext
-
Determine the user type identifier associated with the given class
name.
- getUserTypeIdentifier(Object) - Method in class com.tangosol.util.NullImplementation.NullPofContext
-
Determine the user type identifier associated with the given object.
- getUserTypeIdentifier(Class) - Method in class com.tangosol.util.NullImplementation.NullPofContext
-
Determine the user type identifier associated with the given class.
- getUserTypeIdentifier(String) - Method in class com.tangosol.util.NullImplementation.NullPofContext
-
Determine the user type identifier associated with the given class
name.
- getUserTypeIdentifierInternal(Class) - Method in class com.tangosol.io.pof.ConfigurablePofContext
-
Determine the user type identifier associated with the given class.
- getUserTypeIdentifierInternal(String) - Method in class com.tangosol.io.pof.ConfigurablePofContext
-
Determine the user type identifier associated with the given class
name.
- getValidator() - Method in interface com.tangosol.util.TransactionMap
-
Retrieve the topmost Validator in TransactionMap's validation chain.
- getValue(String, Class<T>) - Method in class com.tangosol.coherence.config.ResourceMapping
-
- getValue(String) - Method in class com.tangosol.coherence.config.ResourceMapping
-
- getValue() - Method in class com.tangosol.coherence.dsltools.base.IdentifierBaseToken
-
Return the string representation of this LeafBaseToken.
- getValue() - Method in class com.tangosol.coherence.dsltools.base.LeafBaseToken
-
Return the string representation of this LeafBaseToken.
- getValue() - Method in class com.tangosol.coherence.dsltools.base.LiteralBaseToken
-
Return the string representation of this LeafBaseToken.
- getValue() - Method in class com.tangosol.coherence.dsltools.base.OperatorBaseToken
-
Return the string representation of this LeafBaseToken.
- getValue() - Method in class com.tangosol.coherence.dsltools.base.PunctuationBaseToken
-
Return the string representation of this LeafBaseToken.
- getValue() - Method in class com.tangosol.coherence.dsltools.precedence.OPToken
-
Get a string value that identifies this token
- getValue() - Method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
-
Obtain the string value for the node.
- getValue() - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheEntry
-
- getValue() - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheEntryEvent
-
Return current value.
- getValue() - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCacheEntryEvent
-
- getValue() - Method in class com.tangosol.coherence.rest.EntryResource
-
Get the entry value.
- getValue(Object) - Method in class com.tangosol.coherence.rest.util.PropertySpec
-
Extract the value of this property from a target object.
- getValue() - Method in class com.tangosol.io.nio.BinaryMap.Block
-
Get the Entry value in the block, lazy loading it if necessary.
- getValue() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Return the deserialized value which this PofValue represents.
- getValue(Class) - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Return the deserialized value which this PofValue represents.
- getValue(int) - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Return the deserialized value which this PofValue represents.
- getValue(int) - Method in class com.tangosol.io.pof.reflect.PofSparseArray.NilPofValue
-
Return the deserialized value which this PofValue represents.
- getValue() - Method in interface com.tangosol.io.pof.reflect.PofValue
-
Return the deserialized value which this PofValue represents.
- getValue(Class) - Method in interface com.tangosol.io.pof.reflect.PofValue
-
Return the deserialized value which this PofValue represents.
- getValue(int) - Method in interface com.tangosol.io.pof.reflect.PofValue
-
Return the deserialized value which this PofValue represents.
- getValue() - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
-
Return the value corresponding to this entry.
- getValue() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.ReadLatch
-
Return the result of the load operation.
- getValue() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache.EntrySet.Entry
-
Returns the value corresponding to this entry.
- getValue() - Method in interface com.tangosol.net.topic.Subscriber.Element
-
Return the received value
- getValue() - Method in class com.tangosol.run.xml.SimpleValue
-
Get the value as an Object.
- getValue() - Method in interface com.tangosol.run.xml.XmlValue
-
Get the value as an Object.
- getValue() - Method in class com.tangosol.util.AbstractKeyBasedMap.EntrySet.Entry
-
Returns the value corresponding to this entry.
- getValue() - Method in class com.tangosol.util.AbstractSafeLongArray.SafeIterator
-
- getValue() - Method in class com.tangosol.util.AbstractSparseArray.Crawler
-
Returns the current value, which is the same value returned by the
most recent call to the next
method, or the most recent
value passed to setValue
if setValue
were called
after the next
method.
- getValue() - Method in class com.tangosol.util.AbstractSparseArray.Node
-
Get the value associated with the node.
- getValue() - Method in class com.tangosol.util.AnyEvent
-
Gets the associated value.
- getValue() - Method in class com.tangosol.util.ConverterCollections.AbstractConverterEntry
- getValue() - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray.ConverterLongArrayIterator
-
- getValue() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventEntry
- getValue() - Method in class com.tangosol.util.CopyOnWriteLongArray.UnmodifiableIterator
-
Returns the current value, which is the same value returned by the
most recent call to the next method, or the most recent
value passed to setValue if setValue were called
after the next method.
- getValue() - Method in class com.tangosol.util.ExternalizableHelper.IntDecoratedObject
-
Return the underlying value.
- getValue() - Method in class com.tangosol.util.filter.ComparisonFilter
-
Get the object to compare the reflection result with.
- getValue() - Method in interface com.tangosol.util.InvocableMap.Entry
-
Return the value corresponding to this entry.
- getValue(V) - Method in interface com.tangosol.util.InvocableMap.Entry
-
Return the value corresponding to this entry, or the specified
defaultValue
, if the entry value is null
.
- getValue() - Method in class com.tangosol.util.InvocableMapHelper.RoutingMapTriggerEntry
-
Return an OriginalValue from the underlying entry.
- getValue() - Method in class com.tangosol.util.InvocableMapHelper.SimpleEntry
-
Returns the value corresponding to this entry.
- getValue() - Method in interface com.tangosol.util.LongArray.Iterator
-
Returns the current value, which is the same value returned by the
most recent call to the next method, or the most recent
value passed to setValue if setValue were called
after the next method.
- getValue() - Method in class com.tangosol.util.PrimitiveSparseArray.PrimitiveNode
-
Get the value associated with the node.
- getValue() - Method in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet.RestrictedEntry
-
Returns the value corresponding to this entry.
- getValue() - Method in class com.tangosol.util.SafeHashMap.Entry
-
Returns the value corresponding to this entry.
- getValue() - Method in class com.tangosol.util.SafeSortedMap.EntryNode
-
Return the value that this node represents.
- getValue() - Method in class com.tangosol.util.SafeSortedMap.EntryNode.MapEntry
- getValue() - Method in class com.tangosol.util.SegmentedHashMap.Entry
-
Returns the value corresponding to this entry.
- getValue() - Method in class com.tangosol.util.SimpleLongArray.Iterator
-
Returns the current value, which is the same value returned by the
most recent call to the next method, or the most recent
value passed to setValue if setValue were called
after the next method.
- getValue() - Method in class com.tangosol.util.SimpleMapEntry
-
Returns the value corresponding to this entry.
- getValue() - Method in class com.tangosol.util.SparseArray.ObjectNode
-
Get the value associated with the node.
- getValue() - Method in class com.tangosol.util.ThreadLocalObject
-
Get the value stored by this instance of ThreadLocalObject.
- getValue() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperEntry
- getValue() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperEntry
- getValueAdapter() - Method in class com.tangosol.run.xml.MapAdapter
-
- getValueBuffer() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Get the raw value buffer.
- getValueClass() - Method in class com.tangosol.coherence.rest.config.ResourceConfig
-
Determine the class of the cached values.
- getValueClassName() - Method in class com.tangosol.coherence.config.CacheMapping
-
- getValueClassName() - Method in class com.tangosol.coherence.config.TopicMapping
-
- getValueClassName() - Method in class com.tangosol.net.cache.TypeAssertion.WithTypesAssertion
-
Get Value ClassName
- getValueClassName() - Method in class com.tangosol.net.ValueTypeAssertion.WithValueTypeAssertion
-
Get Value ClassName
- getValueConverter() - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
-
Get value converter for this.
- getValueExtractor() - Method in class com.tangosol.util.aggregator.AbstractAggregator
-
Determine the ValueExtractor whose values this aggregator is
aggregating.
- getValueExtractor() - Method in class com.tangosol.util.filter.BetweenFilter
-
Obtain the ValueExtractor used by this filter.
- getValueExtractor() - Method in class com.tangosol.util.filter.ExtractorFilter
-
Obtain the ValueExtractor used by this filter.
- getValueExtractor() - Method in class com.tangosol.util.ForwardOnlyMapIndex
-
Obtain the ValueExtractor object that the MapIndex uses to extract
an indexable Object from a value stored in the indexed Map.
- getValueExtractor() - Method in interface com.tangosol.util.MapIndex
-
Obtain the ValueExtractor object that the MapIndex uses to extract
an indexable Object from a value stored in the indexed Map.
- getValueExtractor() - Static method in class com.tangosol.util.NullImplementation
-
Factory method: Obtain a null implementation of a ValueExtractor.
- getValueExtractor() - Method in class com.tangosol.util.SimpleMapIndex
-
Obtain the ValueExtractor object that the MapIndex uses to extract
an indexable Object from a value stored in the indexed Map.
- getValueFromInternalConverter() - Method in interface com.tangosol.net.BackingMapManagerContext
-
Return a converter that allows the manager (or a backing map
managed thereby) to convert a value object from its internal form
(as managed by the CacheService) into its "normal" (Object) form.
- getValueFromInternalConverter() - Method in class com.tangosol.util.NullImplementation.NullBackingMapManagerContext
-
Return a converter that allows the manager (or a backing map
managed thereby) to convert a value object from its internal form
(as managed by the CacheService) into its "normal" (Object) form.
- getValueIndex() - Method in class com.tangosol.util.ImmutableArrayList
-
Create a reverse index from value to position if this List is big
enough to warrant it.
- getValueInternal() - Method in class com.tangosol.util.SafeSortedMap.EntryNode
-
Return the value associated with the Map entry (could be NO_VALUE).
- getValueInternal() - Method in class com.tangosol.util.SegmentedHashMap.Entry
-
Returns the value corresponding to this entry, or NO_VALUE
if this Entry is synthetid.
- getValueLength() - Method in class com.tangosol.io.nio.BinaryMap.Block
-
Get the length of the Entry value in the block.
- getValues(int, int, String, PropertySet, String) - Method in class com.tangosol.coherence.rest.CacheResource
-
Return the cache values (or a subset of their properties) that
satisfy the specified criteria.
- getValues(PropertySet) - Method in class com.tangosol.coherence.rest.EntrySetResource
-
Return the entries' values or a subset of their properties.
- getValues(UriInfo, int, int, String, PropertySet) - Method in class com.tangosol.coherence.rest.NamedQueryResource
-
Return the cache values that satisfy criteria defined by this
resource.
- getValueToInternalConverter() - Method in interface com.tangosol.net.BackingMapManagerContext
-
Return a converter that allows the manager (or a backing map
managed thereby) to convert a value object into its internal form
as managed by the CacheService.
- getValueToInternalConverter() - Method in class com.tangosol.util.NullImplementation.NullBackingMapManagerContext
-
Return a converter that allows the manager (or a backing map
managed thereby) to convert a value object into its internal form
as managed by the CacheService.
- getValueType() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
-
- getValueType() - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheMXBean
-
- getValueType() - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCacheConfiguration
-
- getVariance(SimpleAssignmentStrategy.AnalysisContext, boolean) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
Return the maximum load variance in the partition assignments represented
by the analysis context.
- getVersion() - Method in class com.tangosol.io.pof.reflect.PofUserType
-
Return the data version of this value.
- getVersion() - Method in class com.tangosol.net.partition.VersionedOwnership
-
Return the ownership version.
- getVersion(String) - Static method in class com.tangosol.persistence.GUIDHelper
-
Parse the specified GUID and return the partition-version.
- getVersionCache() - Method in class com.tangosol.net.cache.VersionedNearCache
-
Deprecated.
Obtain the NamedCache object that holds the version data.
- getVersionId() - Method in class com.tangosol.io.pof.PofBufferReader
-
Determine the version identifier of the user type that is currently
being parsed.
- getVersionId() - Method in class com.tangosol.io.pof.PofBufferReader.UserTypeReader
-
Determine the version identifier of the user type that is currently
being parsed.
- getVersionId() - Method in class com.tangosol.io.pof.PofBufferWriter
-
Determine the version identifier of the user type that is currently
being written.
- getVersionId() - Method in class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
-
Determine the version identifier of the user type that is currently
being written.
- getVersionId() - Method in interface com.tangosol.io.pof.PofReader
-
Determine the version identifier of the user type that is currently
being parsed.
- getVersionId() - Method in interface com.tangosol.io.pof.PofWriter
-
Determine the version identifier of the user type that is currently
being written.
- getVersionIndicator() - Method in class com.tangosol.coherence.rest.util.JsonMap
-
- getVersionIndicator() - Method in interface com.tangosol.util.Versionable
-
Get the version indicator for this object.
- getVersionMap() - Method in class com.tangosol.run.jca.SimpleValidator
-
Obtain a map that holds the version objects for resources enlisted
into a transaction.
- getViewMap() - Method in class com.tangosol.util.SafeSortedMap
-
Return a view of the entire map.
- getWaitMillis() - Method in class com.tangosol.util.WrapperConcurrentMap
-
Return the number of milliseconds to continue trying to obtain a lock
in case when the locking is enforced.
- getWeaker() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.BackupStrength
-
Return the next weakest BackupStrength.
- getWellKnownAddresses() - Method in interface com.tangosol.net.ClusterDependencies
-
Obtain the AddressProvider that provides the well known addresses (WKA)
represented by InetSocketAddress objects.
- getWhere(NodeTerm) - Static method in class com.tangosol.coherence.dslquery.statement.AbstractStatementBuilder
-
Return the AST node that represents the where clause from the given AST
node.
- getWildcardMatch(String) - Method in class com.tangosol.coherence.config.ResourceMapping
-
Determines the value the wildcard * declared in the resource name
pattern for the
ResourceMapping
matches.
- getWorker() - Method in class com.tangosol.util.Daemon
-
Accessor to obtain the Daemon worker object.
- getWorkerThreadCount() - Method in interface com.tangosol.net.ServiceDependencies
-
- getWorkerThreadCountMax() - Method in interface com.tangosol.net.ServiceDependencies
-
Obtain the maximum number of background worker threads.
- getWorkerThreadCountMin() - Method in interface com.tangosol.net.ServiceDependencies
-
Obtain the minimum number of background worker threads.
- getWorkerThreadPriority() - Method in interface com.tangosol.net.ServiceDependencies
-
Obtain the priority of the worker threads.
- getWrapper() - Method in exception com.tangosol.util.WrapperException
-
- getWriteBatchFactor(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
-
Return the write-batch-factor element is used to calculate the "soft-ripe"
time for write-behind queue entries.
- getWriteBatchFactor() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Return the write-batch factor.
- getWriteBehindMillis() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Return the number of milliseconds between write-behind writes to the
CacheStore or 0 if write-behind is not enabled.
- getWriteBehindSeconds() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Return the number of seconds between write-behind writes to the
CacheStore or 0 if write-behind is not enabled.
- getWriteBuffer(int) - Method in class com.tangosol.io.AbstractWriteBuffer
-
Obtain a WriteBuffer starting at a particular offset within this
WriteBuffer.
- getWriteBuffer(int, int) - Method in class com.tangosol.io.AbstractWriteBuffer
-
Obtain a WriteBuffer for a portion of this WriteBuffer.
- getWriteBuffer(int) - Method in interface com.tangosol.io.WriteBuffer
-
Obtain a WriteBuffer starting at a particular offset within this
WriteBuffer.
- getWriteBuffer(int, int) - Method in interface com.tangosol.io.WriteBuffer
-
Obtain a WriteBuffer for a portion of this WriteBuffer.
- getWriteDelay(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
-
Return the time interval to defer asynchronous writes to the cache store
for a write-behind queue.
- getWriteDelaySeconds(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
-
Return the write behind delay in seconds.
- getWriteMaxBatchSize(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
-
Return the maximum number of entries to write in a single storeAll
operation.
- getWriteMaxBatchSize() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Get the maximum size of the write-behind batch.
- getWriteQueue() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Get the queue of entries that are yet to be written.
- getWriter() - Method in class com.tangosol.coherence.dslquery.ExecutionContext
-
Return the
PrintWriter
that can be used by commands to display output.
- getWriter() - Static method in class com.tangosol.util.NullImplementation
-
Factory method: Obtain a null implementation of a Writer.
- getWriteRequeueThreshold(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
-
Return the size of the write-behind queue at which additional actions
could be taken.
- getWriteRequeueThreshold() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Return the maximum size of the write-behind queue for which failed
CacheStore write operations are requeued or 0 if write-behind
requeueing is disabled.
- getWriteThread() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Get the write-behind thread.
- getXml() - Method in interface com.tangosol.coherence.config.builder.ServiceBuilder
-
Deprecated.
- getXml() - Method in class com.tangosol.coherence.config.scheme.AbstractServiceScheme
-
Deprecated.
- getXmlConfig() - Method in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
-
Get the XML Configuration.
- getXmlConfig(ClassLoader, URL) - Method in class com.tangosol.net.ScopedCacheFactoryBuilder
-
Return the
XML config
relating to the provided
ClassLoader and URL, or null.
- getXmlDocument(ClassLoader) - Method in class com.tangosol.run.xml.XmlDocumentReference
-
- getXmlDocument() - Method in class com.tangosol.run.xml.XmlDocumentReference
-
- getXmlElement() - Method in class com.tangosol.run.xml.SimpleAttribute
-
- getXmlElement() - Method in interface com.tangosol.run.xml.XmlAttribute
-
- getXmlInitParams(ParameterResolver) - Method in class com.tangosol.coherence.config.builder.storemanager.BdbStoreManagerBuilder
-
Return the BDB init params needed to construct a BerkeleyDBBinaryStoreManager.
- getXmlName() - Method in class com.tangosol.run.xml.PropertyAdapter
-
Return the XML element name used to generate an XML.
- getXmlValue() - Method in class com.tangosol.run.xml.SimpleAttribute
-
- getXmlValue() - Method in interface com.tangosol.run.xml.XmlAttribute
-
- getYear() - Method in class com.tangosol.io.pof.RawDate
-
Determine the date's year value.
- getYears() - Method in class com.tangosol.io.pof.RawYearMonthInterval
-
Determine the number of years in the year-month interval.
- grabBlock(int) - Method in class com.tangosol.io.nio.BinaryMap
-
Grab a block object for the specified offset.
- greater(ValueExtractor<T, ? extends E>, E) - Static method in class com.tangosol.util.Filters
-
Return a filter that tests if the extracted value is greater than the
specified value.
- greaterEqual(ValueExtractor<T, ? extends E>, E) - Static method in class com.tangosol.util.Filters
-
Return a filter that tests if the extracted value is greater than or equal
to the specified value.
- GreaterEqualsFilter<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
"Greater or Equal" condition.
- GreaterEqualsFilter() - Constructor for class com.tangosol.util.filter.GreaterEqualsFilter
-
Default constructor (necessary for the ExternalizableLite interface).
- GreaterEqualsFilter(ValueExtractor<? super T, ? extends E>, E) - Constructor for class com.tangosol.util.filter.GreaterEqualsFilter
-
Construct a GreaterEqualFilter for testing "Greater or Equal"
condition.
- GreaterEqualsFilter(String, E) - Constructor for class com.tangosol.util.filter.GreaterEqualsFilter
-
Construct a GreaterEqualFilter for testing "Greater or Equal"
condition.
- GreaterEqualsOperator - Class in com.tangosol.coherence.dslquery.operator
-
A class representing the conditional greater than or equal to operator.
- GreaterEqualsOperator() - Constructor for class com.tangosol.coherence.dslquery.operator.GreaterEqualsOperator
-
Construct a GreaterEqualsOperator.
- GreaterFilter<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
"Greater" condition.
- GreaterFilter() - Constructor for class com.tangosol.util.filter.GreaterFilter
-
Default constructor (necessary for the ExternalizableLite interface).
- GreaterFilter(ValueExtractor<? super T, ? extends E>, E) - Constructor for class com.tangosol.util.filter.GreaterFilter
-
Construct a GreaterFilter for testing "Greater" condition.
- GreaterFilter(String, E) - Constructor for class com.tangosol.util.filter.GreaterFilter
-
Construct a GreaterFilter for testing "Greater" condition.
- GreaterOperator - Class in com.tangosol.coherence.dslquery.operator
-
A class representing the greater than operator.
- GreaterOperator() - Constructor for class com.tangosol.coherence.dslquery.operator.GreaterOperator
-
Construct a GreaterOperator.
- GroupAggregator<K,V,T,E,R> - Class in com.tangosol.util.aggregator
-
The GroupAggregator provides an ability to split a subset of entries in an
InvocableMap into a collection of non-intersecting subsets and then
aggregate them separately and independently.
- GroupAggregator() - Constructor for class com.tangosol.util.aggregator.GroupAggregator
-
Default constructor (necessary for the ExternalizableLite interface).
- GroupAggregator(ValueExtractor<? super T, ? extends E>, InvocableMap.EntryAggregator<? super K, ? super V, R>, Filter) - Constructor for class com.tangosol.util.aggregator.GroupAggregator
-
Construct a GroupAggregator based on a specified ValueExtractor and
underlying EntryAggregator.
- GroupAggregator.Parallel<K,V,T,E,R> - Class in com.tangosol.util.aggregator
-
- grouping(InvocableMap.EntryAggregator<K, V, R>, String...) - Static method in class com.tangosol.util.Aggregators
-
- grouping(InvocableMap.EntryAggregator<K, V, R>, Filter, String...) - Static method in class com.tangosol.util.Aggregators
-
- grouping(ValueExtractor<? super T, ? extends E>, InvocableMap.EntryAggregator<K, V, R>) - Static method in class com.tangosol.util.Aggregators
-
- grouping(ValueExtractor<? super T, ? extends E>, InvocableMap.EntryAggregator<? super K, ? super V, R>, Filter) - Static method in class com.tangosol.util.Aggregators
-
- groupingBy(ValueExtractor<? super U, ? extends K>) - Static method in class com.tangosol.util.stream.RemoteCollectors
-
Returns a Collector
implementing a "group by" operation on input
elements of type T
, grouping elements according to a
classification function, and returning the results in a Map
.
- groupingBy(ValueExtractor<? super U, ? extends K>, RemoteCollector<? super T, A, D>) - Static method in class com.tangosol.util.stream.RemoteCollectors
-
Returns a Collector
implementing a cascaded "group by" operation
on input elements of type T
, grouping elements according to a
classification function, and then performing a reduction operation on the
values associated with a given key using the specified downstream Collector
.
- groupingBy(ValueExtractor<? super U, ? extends K>, Remote.Supplier<M>, RemoteCollector<? super T, A, D>) - Static method in class com.tangosol.util.stream.RemoteCollectors
-
Returns a Collector
implementing a cascaded "group by" operation
on input elements of type T
, grouping elements according to a
classification function, and then performing a reduction operation on the
values associated with a given key using the specified downstream Collector
.
- groupMembersByRole(Set<Member>) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.ClusterQuorumPolicy
-
Group the specified set of Members by their roles.
- GROUPS_PER_LINE - Static variable in class com.tangosol.io.Base64OutputStream
-
The number of Base64 character groups in one line.
- grow(int) - Method in class com.tangosol.io.ByteArrayWriteBuffer
-
Grow the underlying byte array to at least the specified size.
- grow(int) - Method in class com.tangosol.io.nio.AbstractBufferManager
-
Request that the buffer be grown based on the number of bytes
currently required.
- grow(int) - Method in interface com.tangosol.io.nio.ByteBufferManager
-
Request that the buffer be grown based on the number of bytes
currently required.
- grow() - Method in class com.tangosol.util.Dequeue
-
Increase the capacity of the Dequeue.
- grow() - Method in class com.tangosol.util.SafeHashMap
-
Resize the bucket array, rehashing all Entries.
- grow() - Method in class com.tangosol.util.SegmentedHashMap
-
Resize the bucket array, rehashing all Entries.
- grow(int) - Method in class com.tangosol.util.SegmentedHashMap
-
Resize the bucket array to the specified size, rehashing all Entries.
- guard(Guardable) - Method in interface com.tangosol.net.Guardian
-
Register the specified Guardable based on the Guardian's SLA parameters.
- guard(Guardable, long, float) - Method in interface com.tangosol.net.Guardian
-
Register the specified Guardable with the specified SLA parameters.
- GUARD_RECOVERY - Static variable in class com.tangosol.net.cache.ReadWriteBackingMap
-
The recovery threshold to use for guarded execution of
write-behind/refresh-ahead threads.
- Guardable - Interface in com.tangosol.net
-
A Guardable is a logical execution unit whose lifetime may be guarded by a
Guardian.
- Guardian - Interface in com.tangosol.net
-
A Guardian is responsible for monitoring the registered
Guardable
objects.
- Guardian.GuardContext - Interface in com.tangosol.net
-
A GuardContext represents the lifecycle status of a Guardable.
- GUARDIAN_EARLY_THRESHOLD - Static variable in class com.tangosol.net.GuardSupport
-
The threshold before which than which a guardian considers itself early
in checking its guardables.
- GUARDIAN_LATE_THRESHOLD - Static variable in class com.tangosol.net.GuardSupport
-
The threshold past which a guardian considers itself late in checking
its guardables.
- GUARDIAN_LOG_INTERVAL - Static variable in class com.tangosol.net.GuardSupport
-
The minimum interval at which the Guardian should log thread dumps.
- GUARDIAN_MAX_CHECK_INTERVAL - Static variable in class com.tangosol.net.GuardSupport
-
The maximum interval at which the Guardian thread should call check() to
verify its guardables.
- guardIfNeeded() - Method in class com.tangosol.util.Daemon
-
If this Daemon has a Guardian and SLA policy specified, ensure that it
is registered with its Guardian.
- GuardSupport - Class in com.tangosol.net
-
A concrete implementation of Guardian/Guardable interactions.
- GuardSupport(Guardian) - Constructor for class com.tangosol.net.GuardSupport
-
Construct a GuardSupport for the specified Guardian.
- GuardSupport.Context - Class in com.tangosol.net
-
Base implementation for GuardContext's used by GuardSupport.
- GUIDHelper - Class in com.tangosol.persistence
-
Static helper methods to encode and decode the attributes related to the
storage of a persistent form of a partition.
- GUIDHelper() - Constructor for class com.tangosol.persistence.GUIDHelper
-
- GUIDHelper.GUIDResolver - Class in com.tangosol.persistence
-
Resolver used during a recovery to discover the newest available GUID
for a given partition.
- GUIDResolver(int) - Constructor for class com.tangosol.persistence.GUIDHelper.GUIDResolver
-
Construct a GUIDResolver for the specified partition-count.
- id(int) - Static method in class com.tangosol.net.AsyncNamedCache.OrderBy
-
Return the order that will use the specified unit-of-order for all
async operations, regardless of whether they were invoked from the
same client thread or not.
- id(int) - Static method in class com.tangosol.net.topic.Publisher.OrderBy
-
Return an OrderBy that will ensure ordering of
sent values
across
all threads which share the same id.
- Identifiable - Interface in com.tangosol.run.xml
-
An interface for access to a key of a value object
- IDENTIFIER_NODE - Static variable in class com.tangosol.coherence.dsltools.precedence.OPToken
-
The AST node name for an Identifier Node.
- IdentifierBaseToken - Class in com.tangosol.coherence.dsltools.base
-
IdentifierBaseToken is a token that represents an identifier
- IdentifierBaseToken(String) - Constructor for class com.tangosol.coherence.dsltools.base.IdentifierBaseToken
-
Construct a new IdentifierBaseToken with the given value.
- IdentifierOPToken - Class in com.tangosol.coherence.dsltools.precedence
-
IdentifierOPToken is used to implement identifiers.
- IdentifierOPToken(String) - Constructor for class com.tangosol.coherence.dsltools.precedence.IdentifierOPToken
-
Construct a new IdentifierOPToken with the given parameters.
- IdentifierOPToken(String, String) - Constructor for class com.tangosol.coherence.dsltools.precedence.IdentifierOPToken
-
Construct a new IdentifierOPToken with the given parameters.
- identity() - Static method in class com.tangosol.util.Extractors
-
Returns an extractor that always returns its input argument.
- identity() - Static method in interface com.tangosol.util.function.Remote.DoubleUnaryOperator
-
Returns a unary operator that always returns its input argument.
- identity() - Static method in interface com.tangosol.util.function.Remote.Function
-
Returns a function that always returns its input argument.
- identity() - Static method in interface com.tangosol.util.function.Remote.IntUnaryOperator
-
Returns a unary operator that always returns its input argument.
- identity() - Static method in interface com.tangosol.util.function.Remote.LongUnaryOperator
-
Returns a unary operator that always returns its input argument.
- identity() - Static method in interface com.tangosol.util.function.Remote.UnaryOperator
-
Returns a unary operator that always returns its input argument.
- identity() - Static method in interface com.tangosol.util.ValueExtractor
-
Returns an extractor that always returns its input argument.
- IdentityAsserter - Interface in com.tangosol.net.security
-
IdentityAsserter validates a token in order to establish a user's identity.
- identityCast() - Static method in class com.tangosol.util.Extractors
-
Returns an extractor that casts its input argument.
- identityCast() - Static method in interface com.tangosol.util.ValueExtractor
-
Returns an extractor that casts its input argument.
- IdentityExtractor<T> - Class in com.tangosol.util.extractor
-
Trivial ValueExtractor implementation that does not actually extract
anything from the passed value, but returns the value itself.
- IdentityExtractor() - Constructor for class com.tangosol.util.extractor.IdentityExtractor
-
Default constructor (necessary for the ExternalizableLite interface).
- IdentityHolder() - Constructor for class com.tangosol.io.pof.PofBufferReader.IdentityHolder
-
- IdentityTransformer - Interface in com.tangosol.net.security
-
IdentityTransformer transforms a Subject to a token that asserts identity.
- ImmutableArrayList - Class in com.tangosol.util
-
Implementation of the Collection Framework interface "List" in a read-
only fashion on top of an array data structure.
- ImmutableArrayList(Object[], int, int) - Constructor for class com.tangosol.util.ImmutableArrayList
-
Construct a List from a specified number of items in an array starting at
the specified offset.
- ImmutableArrayList(Object[]) - Constructor for class com.tangosol.util.ImmutableArrayList
-
Construct a List from an array.
- ImmutableArrayList(Collection) - Constructor for class com.tangosol.util.ImmutableArrayList
-
Construct a List containing the elements of the specified Collection.
- ImmutableArrayList() - Constructor for class com.tangosol.util.ImmutableArrayList
-
Default constructor (necessary for the ExternalizableLite interface).
- ImmutableArrayList.ListView - Class in com.tangosol.util
-
ListView exposes the underlying ImmutableArrayList through the
List
interface, maintaining correct
equals() and
hashCode() semantics
- ImmutableArrayList.SetView - Class in com.tangosol.util
-
SetView exposes the underlying ImmutableArrayList through the
Set
interface, maintaining correct
equals() and
hashCode() semantics
- ImmutableArrayList.SortedSetView - Class in com.tangosol.util
-
SetView exposes the underlying ImmutableArrayList through the
SortedSet
interface, maintaining correct
equals() and
hashCode() semantics
- ImmutableMultiList - Class in com.tangosol.util
-
Implementation of the List interface in a read-only fashion based on a
collection of arrays.
- ImmutableMultiList(Object[][]) - Constructor for class com.tangosol.util.ImmutableMultiList
-
Construct a List containing the elements of the specified array of
Object arrays.
- ImmutableMultiList(Collection) - Constructor for class com.tangosol.util.ImmutableMultiList
-
Construct a List containing the elements of the specified Collection of
Object arrays.
- ImmutableMultiList.ListView - Class in com.tangosol.util
-
ListView exposes the underlying ImmutableMultiList through the
List
interface, maintaining correct
equals() and
hashCode() semantics
- ImmutableMultiList.MultiIterator - Class in com.tangosol.util
-
ListIterator implementation based on the ImmutableMultiList.
- ImmutableMultiList.SetView - Class in com.tangosol.util
-
SetView exposes the underlying ImmutableMultiList through the
Set
interface, maintaining correct
equals() and
hashCode() semantics
- Impl() - Constructor for class com.tangosol.net.NonBlockingTcpDatagramSocket.Impl
-
Creates a new Impl.
- Impl(SocketProvider) - Constructor for class com.tangosol.net.NonBlockingTcpDatagramSocket.Impl
-
- Impl() - Constructor for class com.tangosol.net.TcpDatagramSocket.Impl
-
Create a new new Impl.
- Impl(SocketProvider) - Constructor for class com.tangosol.net.TcpDatagramSocket.Impl
-
- implies(Permission) - Method in class com.tangosol.net.ClusterPermission
-
Check if the specified permission's actions are "implied by"
this object's actions.
- in(ValueExtractor<T, ? extends E>, Set<? extends E>) - Static method in class com.tangosol.util.Filters
-
Return a filter that tests if the extracted value is contained in the
specified set.
- in(ValueExtractor<T, ? extends E>, E...) - Static method in class com.tangosol.util.Filters
-
Return a filter that tests if the extracted value is contained in the
specified array.
- incBytesWritten(int) - Method in class com.tangosol.io.WrapperDataOutputStream
-
Increment the count of total number of bytes written to the wrapped
DataOutput object by the specified number of bytes.
- includeMessage(Throwable) - Static method in class com.tangosol.io.nio.ByteBufferOutputStream
-
Provide a "suffix" containing the exception message (if any).
- increment(String, N, boolean) - Static method in class com.tangosol.util.Processors
-
Construct an increment processor that will increment a property
value by a specified amount, returning either the old or the new value
as specified.
- increment(PropertyManipulator, N, boolean) - Static method in class com.tangosol.util.Processors
-
Construct an increment processor that will increment a property
value by a specified amount, returning either the old or the new value
as specified.
- incrementDirtyBytesCount(int) - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Increment the counter representing the estimated number of bytes in the
original buffer that have been modified.
- incrementDirtyValuesCount() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Increment the counter representing the number of values within this POF
hierarchy that have been modified.
- incrementVersion() - Method in class com.tangosol.coherence.rest.util.JsonMap
-
- incrementVersion(Object, Object) - Method in class com.tangosol.net.cache.VersionedNearCache
-
Deprecated.
Increment value's version.
- incrementVersion() - Method in interface com.tangosol.util.Versionable
-
Update the version to the next logical version indicator.
- IndentingWriter - Class in com.tangosol.io
-
An IndentingWriter is used to indent line-based output to an underlying
Writer.
- IndentingWriter(Writer, int) - Constructor for class com.tangosol.io.IndentingWriter
-
Construct an IndentingWriter that indents a certain number of spaces.
- IndentingWriter(Writer, String) - Constructor for class com.tangosol.io.IndentingWriter
-
Construct an IndentingWriter that indents using an indention string.
- indentString(String, String) - Static method in class com.tangosol.util.Base
-
Indent the passed multi-line string.
- indentString(String, String, boolean) - Static method in class com.tangosol.util.Base
-
Textually indent the passed multi-line string.
- IndexAdapter(MapIndex) - Constructor for class com.tangosol.util.InvocableMapHelper.IndexAdapter
-
Construct an IndexAdapter.
- IndexAwareExtractor<T,E> - Interface in com.tangosol.util.extractor
-
IndexAwareExtractor is an extension to the
ValueExtractor
interface
that supports the creation and destruction of an
index
.
- IndexAwareFilter<K,V> - Interface in com.tangosol.util.filter
-
IndexAwareFilter is an extension to the EntryFilter interface that allows
a filter to use a Map index to fully or partially evaluate itself.
- IndexCalculator(BackingMapContext, SimpleMapIndex) - Constructor for class com.tangosol.util.SimpleMapIndex.IndexCalculator
-
Construct an IndexCalculator which allows for conversion of items into
a serialized format.
- IndexLookupRecord() - Constructor for class com.tangosol.util.SimpleQueryRecord.PartialResult.IndexLookupRecord
-
Default constructor (necessary for the ExternalizableLite
interface).
- IndexLookupRecord(ValueExtractor, MapIndex) - Constructor for class com.tangosol.util.SimpleQueryRecord.PartialResult.IndexLookupRecord
-
Construct an IndexLookupRecord.
- IndexLookupRecord(QueryRecord.PartialResult.IndexLookupRecord) - Constructor for class com.tangosol.util.SimpleQueryRecord.PartialResult.IndexLookupRecord
-
Copy constructor for an IndexLookupRecord.
- IndexLookupRecord(String, String, boolean, long, int, String) - Constructor for class com.tangosol.util.SimpleQueryRecord.PartialResult.IndexLookupRecord
-
Construct an IndexLookupRecord.
- IndexNode(int, SafeSortedMap.IndexNode, SafeSortedMap.EntryNode) - Constructor for class com.tangosol.util.SafeSortedMap.IndexNode
-
Create a new IndexNode for the specified index-level.
- indexOf(V) - Method in class com.tangosol.util.AbstractLongArray
-
Return the index in this LongArray of the first occurrence of
the specified element, or NOT_FOUND if this LongArray does not
contain the specified element.
- indexOf(V, long) - Method in class com.tangosol.util.AbstractLongArray
-
Return the index in this LongArray of the first occurrence of
the specified element such that (index is greater or equal to lIndex)
, or
NOT_FOUND if this LongArray does not contain the specified
element.
- indexOf(V) - Method in class com.tangosol.util.AbstractSafeLongArray
-
- indexOf(V, long) - Method in class com.tangosol.util.AbstractSafeLongArray
-
- indexOf(byte) - Method in class com.tangosol.util.Binary
-
Returns the offset within this Binary object of the first occurrence of
the specified byte.
- indexOf(byte, int) - Method in class com.tangosol.util.Binary
-
Returns the offset within this Binary object of the first occurrence of
the specified byte, starting the search at the specified offset.
- indexOf(Binary) - Method in class com.tangosol.util.Binary
-
Returns the offset within this Binary object of the first occurrence of
the specified Binary.
- indexOf(Binary, int) - Method in class com.tangosol.util.Binary
-
Returns the offset within this Binary object of the first occurrence of
the specified Binary, starting the search at the specified offset.
- indexOf(Object) - Method in class com.tangosol.util.CircularArrayList
-
Search for the first occurence of the given argument, testing
for equality using the equals method.
- indexOf(Object) - Method in class com.tangosol.util.ConverterCollections.ConverterList
- indexOf(T) - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray
-
- indexOf(T, long) - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray
-
- indexOf(Object) - Method in class com.tangosol.util.ImmutableArrayList
-
Returns the index in this List of the first occurrence of the specified
element, or -1 if this List does not contain this element.
- indexOf(Object) - Method in class com.tangosol.util.ImmutableMultiList
-
Returns the index in this List of the first occurrence of the specified
element, or -1 if this List does not contain this element.
- indexOf(Object) - Method in class com.tangosol.util.InflatableList
- indexOf(V) - Method in interface com.tangosol.util.LongArray
-
Return the index in this LongArray of the first occurrence of
the specified element, or NOT_FOUND if this LongArray does not
contain the specified element.
- indexOf(V, long) - Method in interface com.tangosol.util.LongArray
-
Return the index in this LongArray of the first occurrence of
the specified element such that (index greater or equal to lIndex), or
NOT_FOUND if this LongArray does not contain the specified element.
- indexOf(Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedList
-
Returns the index in this list of the first occurrence of the
specified element, or -1 if this list does not contain this
element.
- indexOf(Object) - Method in class com.tangosol.util.SafeLinkedList
-
Returns the index in this List of the first occurrence of the specified
element, or -1 if this List does not contain this element.
- indexOf(Object, long) - Method in class com.tangosol.util.SimpleLongArray
-
Return the index in this LongArray of the first occurrence of
the specified element such that (index >= lIndex), or
NOT_FOUND if this LongArray does not contain the specified element.
- indexOf(Object) - Method in class com.tangosol.util.SubList
- indexOf(Object) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperList
- indexOf(V) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
-
- indexOf(V, long) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
-
- indexOfExtension(String) - Static method in class com.tangosol.io.FileHelper
-
Returns the index of the last extension separator character, which is a
dot.
- indexOfLastSeparator(String) - Static method in class com.tangosol.io.FileHelper
-
Returns the index of the last directory separator character.
- indexOfLSB(byte) - Static method in class com.tangosol.util.BitHelper
-
Determine the least significant bit of the passed integral value.
- indexOfLSB(int) - Static method in class com.tangosol.util.BitHelper
-
Determine the least significant bit of the passed integral value.
- indexOfLSB(long) - Static method in class com.tangosol.util.BitHelper
-
Determine the least significant bit of the passed integral value.
- indexOfMSB(byte) - Static method in class com.tangosol.util.BitHelper
-
Determine the most significant bit of the passed integral value.
- indexOfMSB(int) - Static method in class com.tangosol.util.BitHelper
-
Determine the most significant bit of the passed integral value.
- indexOfMSB(long) - Static method in class com.tangosol.util.BitHelper
-
Determine the most significant bit of the passed integral value.
- InetAddressHelper - Class in com.tangosol.net
-
Helper class that encapsulates common InetAddress functionality.
- InetAddressHelper() - Constructor for class com.tangosol.net.InetAddressHelper
-
- InetAddressHelper.RoutableFilter - Class in com.tangosol.net
-
The RoutableFilter evaluates to true for any InetAddress which is
externally routable.
- InetAddressHelper.SubnetMaskFilter - Class in com.tangosol.net
-
SubnetMaskFilter evaluates to true for any address with matches the
pattern for the masked bits
- InetAddressRangeFilterBuilder - Class in com.tangosol.coherence.config.builder
-
InetAddressRangeFilterBuilder defers evaluating configuration parameters
until Filter is instantiated.
- InetAddressRangeFilterBuilder() - Constructor for class com.tangosol.coherence.config.builder.InetAddressRangeFilterBuilder
-
- InetAddressSerializer - Class in com.tangosol.io.pof
-
POF serializer for java.net.InetAddress
.
- InetAddressSerializer() - Constructor for class com.tangosol.io.pof.InetAddressSerializer
-
- InetSocketAddressSerializer - Class in com.tangosol.io.pof
-
POF serializer for java.net.InetSocketAddress
.
- InetSocketAddressSerializer() - Constructor for class com.tangosol.io.pof.InetSocketAddressSerializer
-
- InFilter<T,E> - Class in com.tangosol.util.filter
-
Filter which checks whether the result of a method invocation belongs to a
predefined set of values.
- InFilter() - Constructor for class com.tangosol.util.filter.InFilter
-
Default constructor (necessary for the ExternalizableLite interface).
- InFilter(ValueExtractor<? super T, ? extends E>, Set<? extends E>) - Constructor for class com.tangosol.util.filter.InFilter
-
Construct an InFilter for testing "In" condition.
- InFilter(String, Set<? extends E>) - Constructor for class com.tangosol.util.filter.InFilter
-
Construct an InFilter for testing "In" condition.
- InfixOPToken - Class in com.tangosol.coherence.dsltools.precedence
-
InfixOPToken is used to implement infix operators.
- InfixOPToken(String, int) - Constructor for class com.tangosol.coherence.dsltools.precedence.InfixOPToken
-
Construct a new InfixOPToken with the given parameters.
- InfixOPToken(String, int, String) - Constructor for class com.tangosol.coherence.dsltools.precedence.InfixOPToken
-
Construct a new InfixOPToken with the given parameters.
- InfixOPToken(String, int, String, String) - Constructor for class com.tangosol.coherence.dsltools.precedence.InfixOPToken
-
Construct a new InfixOPToken with the given parameters.
- InfixRightOPToken - Class in com.tangosol.coherence.dsltools.precedence
-
InfixRightOPToken is used to implement infix operators that like to bind
to the right which is typical of exponentiation rules.
- InfixRightOPToken(String, int) - Constructor for class com.tangosol.coherence.dsltools.precedence.InfixRightOPToken
-
Construct a new InfixRightOPToken with the given parameters.
- InfixRightOPToken(String, int, String) - Constructor for class com.tangosol.coherence.dsltools.precedence.InfixRightOPToken
-
Construct a new InfixRightOPToken with the given parameters.
- InflatableCollection - Class in com.tangosol.util
-
A Collection implementation which optimizes memory consumption for
collections that often contain just a single value.
- InflatableCollection() - Constructor for class com.tangosol.util.InflatableCollection
-
- InflatableCollection.InflatedCollection - Interface in com.tangosol.util
-
A marker interface which is used to identify internally inflated
Collections.
- InflatableList - Class in com.tangosol.util
-
A List specialization of InflatableCollection.
- InflatableList() - Constructor for class com.tangosol.util.InflatableList
-
- InflatableSet - Class in com.tangosol.util
-
A Set specialization of InflatableCollection.
- InflatableSet() - Constructor for class com.tangosol.util.InflatableSet
-
- InflaterInputShell(InputStream, Inflater) - Constructor for class com.tangosol.net.CompressionFilter.InflaterInputShell
-
Deprecated.
Create a new input stream with the specified decompressor.
- InflaterInputShell(InputStream, Inflater, int) - Constructor for class com.tangosol.net.CompressionFilter.InflaterInputShell
-
Deprecated.
Create a new input stream with the specified decompressor and
buffer size.
- INFLATION_OVERHEAD - Static variable in class com.tangosol.util.SimpleMapIndex.IndexCalculator
-
The memory cost of inflating an InflatableSet.
- init(String, DatabaseFactory) - Method in class com.tangosol.io.bdb.BerkeleyDBBinaryStore
-
Initialize the BinaryStore.
- init(int) - Method in class com.tangosol.io.nio.BinaryMap.Block
-
Configure the Block object to point to a specific offset within the
Buffer.
- init(BackingMapManagerContext) - Method in class com.tangosol.net.AbstractBackingMapManager
-
Called by a CacheService to indicate to this manager that the manager
is being associated with the CacheService.
- init(InvocationService) - Method in class com.tangosol.net.AbstractInvocable
-
Called by the InvocationService exactly once on this Invocable object
as part of its initialization.
- init(S) - Method in class com.tangosol.net.AbstractServiceLoadBalancer
-
Called by the Service exactly once on this object as part of its
initialization.
- init(Service) - Method in interface com.tangosol.net.ActionPolicy
-
Called when the specified service loads and configures this policy.
- init(BackingMapManagerContext) - Method in interface com.tangosol.net.BackingMapManager
-
Called by a CacheService to indicate to this manager that the manager
is being associated with the CacheService.
- init(Service) - Method in class com.tangosol.net.CompositeActionPolicy
-
Called when the specified service loads and configures this policy.
- init(Service) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.ClusterQuorumPolicy
-
Called when the specified service loads and configures this policy.
- init(Service) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy
-
Called when the specified service loads and configures this policy.
- init(BackingMapManagerContext) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory.Manager
-
Deprecated.
Called by a CacheService to indicate to this manager that the manager
is being associated with the CacheService.
- init(BackingMapManagerContext) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.Manager
-
Called by a CacheService to indicate to this manager that the manager
is being associated with the CacheService.
- init(InvocationService) - Method in interface com.tangosol.net.Invocable
-
Called by the InvocationService exactly once on this Invocable object
as part of its initialization.
- init(PartitionedService) - Method in class com.tangosol.net.partition.BroadKeyPartitioningStrategy
-
Initialize the KeyPartitioningStrategy and bind it to the specified
PartitionedService.
- init(PartitionedService) - Method in class com.tangosol.net.partition.DefaultKeyAssociator
-
Initialize the KeyAssociator and bind it to a PartitionedService.
- init(PartitionedService) - Method in class com.tangosol.net.partition.DefaultKeyPartitioningStrategy
-
Initialize the KeyPartitioningStrategy and bind it to the specified
PartitionedService.
- init(Service) - Method in class com.tangosol.net.partition.FailoverAccessPolicy
-
Called when the specified service loads and configures this policy.
- init(PartitionedService) - Method in interface com.tangosol.net.partition.KeyAssociator
-
Initialize the KeyAssociator and bind it to a PartitionedService.
- init(PartitionedService) - Method in interface com.tangosol.net.partition.KeyPartitioningStrategy
-
Initialize the KeyPartitioningStrategy and bind it to the specified
PartitionedService.
- init(DistributionManager) - Method in class com.tangosol.net.partition.MirroringAssignmentStrategy
-
Initialize the PartitionAssignmentStrategy and bind it to the specified
DistributionManager.
- init(DistributionManager) - Method in interface com.tangosol.net.partition.PartitionAssignmentStrategy
-
Initialize the PartitionAssignmentStrategy and bind it to the specified
DistributionManager.
- init(DistributionManager) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
Initialize the PartitionAssignmentStrategy and bind it to the specified
DistributionManager.
- init(S) - Method in interface com.tangosol.net.ServiceLoadBalancer
-
Called by the Service exactly once on this object as part of its
initialization.
- init(ThreadPoolManager) - Method in interface com.tangosol.net.ThreadPoolSizingStrategy
-
Initialize the ThreadPoolSizingStrategy and bind it to the specified manager.
- init() - Method in class com.tangosol.run.xml.SimpleParser
-
Internal initialization.
- init(Class, String, String[]) - Static method in class com.tangosol.run.xml.XmlBean
-
For backwards compatibility only - loads reflection info.
- init(boolean) - Method in class com.tangosol.util.aggregator.AbstractAggregator
-
Initialize the aggregation result.
- init(boolean) - Method in class com.tangosol.util.aggregator.AbstractBigDecimalAggregator
-
Initialize the aggregation result.
- init(boolean) - Method in class com.tangosol.util.aggregator.AbstractComparableAggregator
-
Initialize the aggregation result.
- init(boolean) - Method in class com.tangosol.util.aggregator.AbstractDoubleAggregator
-
Initialize the aggregation result.
- init(boolean) - Method in class com.tangosol.util.aggregator.AbstractLongAggregator
-
Initialize the aggregation result.
- init(boolean) - Method in class com.tangosol.util.aggregator.DistinctValues
-
Initialize the aggregation result.
- init(boolean) - Method in class com.tangosol.util.aggregator.DoubleAverage
-
Initialize the aggregation result.
- init(boolean) - Method in class com.tangosol.util.aggregator.DoubleMax
-
Initialize the aggregation result.
- init(boolean) - Method in class com.tangosol.util.aggregator.DoubleMin
-
Initialize the aggregation result.
- init(boolean) - Method in class com.tangosol.util.aggregator.DoubleSum
-
Initialize the aggregation result.
- init(boolean) - Method in class com.tangosol.util.aggregator.LongMax
-
Initialize the aggregation result.
- init(boolean) - Method in class com.tangosol.util.aggregator.LongMin
-
Initialize the aggregation result.
- init(boolean) - Method in class com.tangosol.util.aggregator.LongSum
-
Initialize the aggregation result.
- init(boolean) - Method in class com.tangosol.util.aggregator.ReducerAggregator
-
Initialize the aggregation result.
- init(String, String, String, int) - Method in class com.tangosol.util.Base.StackFrame
-
Initialize the fields of the StackFrame object.
- init(XmlElement) - Method in class com.tangosol.util.ExternalizableHelper.SimpleXmlBeanClassCache
-
Initialize the XmlBeanClassCache.
- init(XmlElement) - Method in interface com.tangosol.util.ExternalizableHelper.XmlBeanClassCache
-
Initialize the XmlBeanClassCache.
- init() - Method in class com.tangosol.util.extractor.UniversalExtractor
-
Called in constructor and deserializers.
- init(Service) - Method in class com.tangosol.util.NullImplementation.NullActionPolicy
-
Called when the specified service loads and configures this policy.
- init(DistributionManager) - Method in class com.tangosol.util.NullImplementation.NullPartitionAssignmentStrategy
-
Initialize the PartitionAssignmentStrategy and bind it to the specified
DistributionManager.
- init() - Method in class com.tangosol.util.processor.PropertyManipulator
-
Parse the property name and initialize necessary extractor and updator.
- initBeanInfo() - Method in class com.tangosol.run.xml.XmlBean
-
Initialize the Object, loading the XML Bean design information if
necessary.
- initBlock(int) - Method in class com.tangosol.io.nio.BinaryMap
-
Obtain a Block object for a new block that will be located at the
specified offset in the ByteBuffer.
- initFromArray(Object[], int) - Method in class com.tangosol.util.LiteSet
-
Initialize the contents of this Set from the passed array ao
containing c values.
- initialize() - Method in class com.tangosol.io.pof.ConfigurablePofContext
-
Bind the ConfigurablePofContext to a ClassLoader, resolving all class
names, etc.
- initialize(PortableObject, PofReader) - Method in class com.tangosol.io.pof.PortableObjectSerializer
-
Initialize the specified (newly instantiated) PortableObject instance
using the specified reader.
- initialize() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
Initialize the AnalysisContext.
- initialize() - Method in class com.tangosol.util.SafeSortedMap
-
Initialize the index nodes.
- initialize(Object) - Method in class com.tangosol.util.SimpleMapIndex.IndexCalculator
-
Initialize the calculator based on the type of the specified object
assuming that the indexed values are homogeneous (of the same type).
- initialize(boolean) - Method in class com.tangosol.util.SimpleMapIndex
-
Initialize the index's data structures.
- initializeActions() - Method in class com.tangosol.util.SegmentedConcurrentMap
-
Initialize the EntryAction's for this map.
- initializeActions() - Method in class com.tangosol.util.SegmentedHashMap
-
Initialize the EntryAction's for this map.
- initializeBuckets() - Method in class com.tangosol.io.nio.BinaryMap
-
Create an initial array of hash buckets.
- initializeBundler(ParameterResolver, AbstractBundler, BundleManager.BundleConfig) - Method in class com.tangosol.coherence.config.scheme.BundleManager
-
Initialize the specified bundler using the BundleConfig.
- initializeBundler(AbstractBundler, XmlElement) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Initialize the specified bundler using the "bundle-config" element.
- initializeConfiguredProperties() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
-
Initialize the configurable properties of this cache-map.
- initializeFreeLists() - Method in class com.tangosol.io.nio.BinaryMap
-
Create an array of references to lists of free blocks indexed by size
code.
- initializeFunctionMap() - Method in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
-
Creates the Map holding CohQL functions and populates it
with the default functions available in CohQL.
- initializeLanguage() - Method in class com.tangosol.coherence.dslquery.QueryPlus
-
- initializeOperatorMap() - Method in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
-
Initialize the CohQL operators Map with all of the built-in CohQL
operators and return the Map.
- initialStartServices(long) - Method in class com.tangosol.net.DefaultCacheServer
-
Setup any necessary resources and start all services.
- InitiatorDependenciesProcessor - Class in com.tangosol.coherence.config.xml.processor
-
An
ElementProcessor
that will parse an <initator-config> and
produce an
InitiatorDependencies
.
- InitiatorDependenciesProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.InitiatorDependenciesProcessor
-
- InitParamProcessor - Class in com.tangosol.coherence.config.xml.processor
-
- InitParamProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.InitParamProcessor
-
- InitParamProcessor.CacheRefExpression - Class in com.tangosol.coherence.config.xml.processor
-
An Expression
implementation that represents the use of
a {cache-ref} macro in a Configuration File.
- InitParamProcessor.CollectionRefExpression - Class in com.tangosol.coherence.config.xml.processor
-
An Expression
implementation that represents the use of
a {collection-ref} macro in a Configuration File.
- InitParamProcessor.DataStructureRefExpression<E> - Class in com.tangosol.coherence.config.xml.processor
-
An Expression
implementation that represents the use of
a {cache-ref} macro in a Cache Configuration File.
- InitParamProcessor.SchemeRefExpression - Class in com.tangosol.coherence.config.xml.processor
-
An Expression
implementation that represents the use of
a {scheme-ref} macro in a Cache Configuration File.
- InitParamsProcessor - Class in com.tangosol.coherence.config.xml.processor
-
- InitParamsProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.InitParamsProcessor
-
- initRecycling(int) - Method in class com.tangosol.util.RecyclingLinkedList
-
Initializing the recycling data structures.
- inject(T, ServiceLocator) - Static method in class com.tangosol.coherence.rest.server.InjectionBinder
-
Inject its fields and methods of a given resource and return the resource.
- inject(B, XmlElement) - Method in class com.tangosol.config.xml.DefaultProcessingContext
-
- inject(B, XmlElement) - Method in interface com.tangosol.config.xml.ProcessingContext
-
- Injectable - Annotation Type in com.tangosol.config.annotation
-
Denotes that a Java Bean setter method may be injected with a value.
- InjectionBinder - Class in com.tangosol.coherence.rest.server
-
A binder for REST API dependencies.
- InjectionBinder(boolean) - Constructor for class com.tangosol.coherence.rest.server.InjectionBinder
-
Construct InjectionBinder instance.
- injectScopeNameIntoService(Service) - Method in class com.tangosol.coherence.config.scheme.AbstractServiceScheme
-
Get the wrapped
Service
from the SafeService and invoke setScopeName()
on the wrapped
Service
.
- InKeySetFilter<T> - Class in com.tangosol.util.filter
-
Filter that limits the underlying filter evaluation only to the specified
set of keys.
- InKeySetFilter() - Constructor for class com.tangosol.util.filter.InKeySetFilter
-
Default constructor (necessary for the ExternalizableLite interface).
- InKeySetFilter(Filter<T>, Set<K>) - Constructor for class com.tangosol.util.filter.InKeySetFilter
-
Construct an InFilter for testing "In" condition.
- InOperator - Class in com.tangosol.coherence.dslquery.operator
-
A class representing the "in"operator.
- InOperator() - Constructor for class com.tangosol.coherence.dslquery.operator.InOperator
-
Construct a InOperator.
- InputStreaming - Interface in com.tangosol.io
-
This is the interface represented by the Java InputStream class.
- inRange(Object) - Method in class com.tangosol.util.SafeSortedMap.ViewMap
-
Is the specified key in the range represented by this ViewMap?
- insert(Map.Entry) - Method in class com.tangosol.util.ForwardOnlyMapIndex
-
Update this index in response to a insert operation on a cache.
- insert(Map.Entry<? extends K, ? extends V>) - Method in interface com.tangosol.util.MapIndex
-
Update this index in response to a insert operation on a cache.
- insert(Map.Entry) - Method in class com.tangosol.util.SimpleMapIndex
-
Update this index in response to a insert operation on a cache.
- InsertAction() - Constructor for class com.tangosol.util.SegmentedHashMap.InsertAction
-
- insertIndex(SafeSortedMap.IndexNode, SafeSortedMap.EntryNode, int) - Method in class com.tangosol.util.SafeSortedMap
-
Insert a index nodes for the specified newly inserted EntryNode, up to a
random index-level.
- insertInternal(Map.Entry) - Method in class com.tangosol.util.ConditionalIndex
-
Update this index in response to a insert operation on a cache.
- insertInternal(Map.Entry) - Method in class com.tangosol.util.SimpleMapIndex
-
Update this index in response to a insert operation on a cache.
- InsertStatement(String, Object, Object) - Constructor for class com.tangosol.coherence.dslquery.statement.InsertStatementBuilder.InsertStatement
-
Construct a InsertStatement that will insert the specified
key and value into the specified cache.
- InsertStatementBuilder - Class in com.tangosol.coherence.dslquery.statement
-
- InsertStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.statement.InsertStatementBuilder
-
- InsertStatementBuilder.InsertStatement - Class in com.tangosol.coherence.dslquery.statement
-
Implementation of the CohQL "INSERT" command.
- INSTANCE - Static variable in class com.tangosol.coherence.config.ParameterMacroExpressionParser
-
- INSTANCE - Static variable in class com.tangosol.coherence.config.xml.preprocessor.ExtendPreprocessor
-
- INSTANCE - Static variable in class com.tangosol.coherence.config.xml.preprocessor.SchemeRefPreprocessor
-
- INSTANCE - Static variable in class com.tangosol.coherence.config.xml.preprocessor.SystemPropertyPreprocessor
-
- INSTANCE - Static variable in class com.tangosol.coherence.config.xml.preprocessor.ViewSchemePreprocessor
-
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.operator.AdditionOperator
-
An instance of the AndOperator.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.operator.AndOperator
-
An instance of the AndOperator.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.operator.BetweenOperator
-
An instance of the BetweenOperator.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.operator.ContainsAllOperator
-
An instance of the ContainsAllOperator.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.operator.ContainsAnyOperator
-
An instance of the ContainsAnyOperator.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.operator.ContainsOperator
-
An instance of the ContainsOperator.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.operator.DivisionOperator
-
An instance of the DivisionOperator.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.operator.EqualsOperator
-
An instance of the EqualsOperator.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.operator.GreaterEqualsOperator
-
An instance of the GreaterEqualsOperator.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.operator.GreaterOperator
-
An instance of the GreaterOperator.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.operator.InOperator
-
An instance of the InOperator.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.operator.LessEqualsOperator
-
An instance of the LessEqualsOperator.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.operator.LessOperator
-
An instance of the LessOperator.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.operator.LikeOperator
-
An instance of the LikeOperator.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.operator.MultiplicationOperator
-
An instance of the AndOperator.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.operator.NotEqualsOperator
-
An instance of the NotEqualsOperator.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.operator.OrOperator
-
An instance of the OrOperator.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.operator.SubtractionOperator
-
An instance of the AndOperator.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.operator.XorOperator
-
An instance of the XorOperator.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.BackupStatementBuilder
-
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.CreateCacheStatementBuilder
-
An instance of CreateCacheStatementBuilder.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.CreateIndexStatementBuilder
-
An instance of a CreateIndexStatementBuilder.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.DeleteStatementBuilder
-
An instance of DeleteStatementBuilder.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.DropCacheStatementBuilder
-
An instance of DropCacheStatementBuilder.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.DropIndexStatementBuilder
-
An instance of DropIndexStatementBuilder.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.InsertStatementBuilder
-
An instance of a InsertStatementBuilder.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.persistence.ArchiveSnapshotStatementBuilder
-
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.persistence.CreateSnapshotStatementBuilder
-
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.persistence.ForceRecoveryStatementBuilder
-
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.persistence.ListArchiverStatementBuilder
-
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.persistence.ListServicesStatementBuilder
-
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.persistence.ListSnapshotsStatementBuilder
-
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.persistence.RecoverSnapshotStatementBuilder
-
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.persistence.RemoveSnapshotStatementBuilder
-
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.persistence.ResumeServiceStatementBuilder
-
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.persistence.RetrieveSnapshotStatementBuilder
-
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.persistence.SuspendServiceStatementBuilder
-
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.persistence.ValidateSnapshotStatementBuilder
-
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.RestoreStatementBuilder
-
An instance of a RestoreStatementBuilder.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.SelectStatementBuilder
-
An instance of a SelectStatementBuilder.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.SourceStatementBuilder
-
An instance of a SourceStatementBuilder.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.TruncateCacheStatementBuilder
-
An instance of TruncateCacheStatementBuilder.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.UpdateStatementBuilder
-
An instance of a UpdateStatementBuilder.
- INSTANCE - Static variable in class com.tangosol.coherence.dsltools.precedence.EndOfStatementOPToken
-
- INSTANCE - Static variable in class com.tangosol.coherence.dsltools.precedence.EndOPToken
-
- INSTANCE - Static variable in class com.tangosol.net.cache.BinaryMemoryCalculator
-
Singleton BinaryMemoryCalculator instance.
- INSTANCE - Static variable in class com.tangosol.net.cache.OldCache.InternalUnitCalculator
-
Deprecated.
Singleton instance.
- INSTANCE - Static variable in class com.tangosol.net.cache.SimpleOverflowMap.FrontFilterConverter
-
- INSTANCE - Static variable in class com.tangosol.net.cache.SimpleOverflowMap.HashcodeComparator
-
- INSTANCE - Static variable in class com.tangosol.net.InetAddressHelper.RoutableFilter
-
Singleton instance.
- INSTANCE - Static variable in class com.tangosol.net.security.DefaultIdentityAsserter
-
An instance of the DefaultIdentityAsserter.
- INSTANCE - Static variable in class com.tangosol.net.security.DefaultIdentityTransformer
-
An instance of the DefaultIdentityTransformer.
- INSTANCE - Static variable in class com.tangosol.net.SystemDatagramSocketProvider
-
A default SocketProvider instance.
- INSTANCE - Static variable in class com.tangosol.net.TcpDatagramSocketProvider
-
A default SocketProvider instance.
- INSTANCE - Static variable in class com.tangosol.net.topic.Publisher.FailOnFull
-
Singleton instance.
- INSTANCE - Static variable in class com.tangosol.net.topic.Publisher.OrderByNone
-
The none-order singleton.
- INSTANCE - Static variable in class com.tangosol.net.topic.Publisher.OrderByThread
-
The thread-order singleton.
- INSTANCE - Static variable in class com.tangosol.net.topic.Subscriber.CompleteOnEmpty
-
The CompleteOnEmpty singleton.
- INSTANCE - Static variable in class com.tangosol.persistence.ArchiverHelper.DirectoryFileFilter
-
Deprecated.
Singleton instance.
- INSTANCE - Static variable in class com.tangosol.util.comparator.SafeComparator
-
The trivial SafeComparator.
- INSTANCE() - Static method in class com.tangosol.util.comparator.SafeComparator
-
Return the trivial SafeComparator.
- INSTANCE - Static variable in class com.tangosol.util.DaemonThreadFactory
-
A reuseable DaemonThreadFactory instance.
- INSTANCE - Static variable in class com.tangosol.util.extractor.IdentityExtractor
-
An instance of the IdentityExtractor.
- INSTANCE() - Static method in class com.tangosol.util.extractor.IdentityExtractor
-
Return an instance of the IdentityExtractor.
- INSTANCE - Static variable in class com.tangosol.util.filter.AlwaysFilter
-
An instance of the AlwaysFilter.
- INSTANCE() - Static method in class com.tangosol.util.filter.AlwaysFilter
-
Return an instance of the AlwaysFilter.
- INSTANCE - Static variable in class com.tangosol.util.filter.NeverFilter
-
An instance of the NeverFilter.
- INSTANCE() - Static method in class com.tangosol.util.filter.NeverFilter
-
Return an instance of the NeverFilter.
- INSTANCE - Static variable in class com.tangosol.util.filter.PresentFilter
-
An instance of the PresentFilter.
- INSTANCE() - Static method in class com.tangosol.util.filter.PresentFilter
-
Return an instance of the PresentFilter.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullActionPolicy
-
Singleton instance.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullAddressProvider
-
Singleton instance.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullBackingMapManagerContext
-
Singleton instance.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullCacheStore
-
Singleton instance.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullCollector
-
Singleton (unchecked) instance of a Collector.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullContinuation
-
Singleton instance of a NullContinuation.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullConverter
-
Since the Converter contains no information, only one ever has to
exist.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullDeltaCompressor
-
Singleton instance.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullEntryProcessor
-
Singleton instance.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullEnumerator
-
Since the enumerator contains no information, only one ever has to exist.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullMap
-
Since the Map contains no information, only one ever has to exist.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullObservableMap
-
Since the Map contains no information, only one ever has to exist.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullPartitionAssignmentStrategy
-
Singleton instance.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullPersistenceEnvironment
-
Singleton instance of a NullPersistenceEnvironment.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullPersistenceManager
-
Singleton instance of a NullPersistenceManager.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullPersistentStore
-
Singleton instance of a NullPersistentStore.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullPofContext
-
Singleton instance.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullPofHandler
-
Singleton instance.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullResourceRegistry
-
Singleton instance of a NullResourceRegistry.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullSet
-
Since the set contains no information, only one ever has to exist.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullValueExtractor
-
Since the ValueExtractor contains no information, only one ever has to
exist.
- INSTANCE - Static variable in class com.tangosol.util.processor.PreloadRequest
-
An instance of the PreloadRequest processor.
- INSTANCE() - Static method in class com.tangosol.util.processor.PreloadRequest
-
Return an instance of the PreloadRequest processor.
- INSTANCE - Static variable in class com.tangosol.util.transformer.SemiLiteEventTransformer
-
The SemiLiteEventTransformer singleton.
- INSTANCE_BINARY - Static variable in class com.tangosol.net.cache.OldCache
-
Deprecated.
The UnitCalculator object that measures the bytes used by entries.
- INSTANCE_FIXED - Static variable in class com.tangosol.net.cache.OldCache
-
Deprecated.
The UnitCalculator object that counts each entry as one unit.
- INSTANCE_HYBRID - Static variable in class com.tangosol.net.cache.OldCache
-
Deprecated.
The EvictionPolicy object for the Hybrid eviction algorithm.
- INSTANCE_LFU - Static variable in class com.tangosol.net.cache.OldCache
-
Deprecated.
The EvictionPolicy object for the Least Frequently Used (LFU) eviction
algorithm.
- INSTANCE_LRU - Static variable in class com.tangosol.net.cache.OldCache
-
Deprecated.
The EvictionPolicy object for the Least Recently Used (LRU) eviction
algorithm.
- InstanceBuilder<T> - Class in com.tangosol.coherence.config.builder
-
- InstanceBuilder() - Constructor for class com.tangosol.coherence.config.builder.InstanceBuilder
-
- InstanceBuilder(Class<?>, Object...) - Constructor for class com.tangosol.coherence.config.builder.InstanceBuilder
-
- InstanceBuilder(Expression<String>, Object...) - Constructor for class com.tangosol.coherence.config.builder.InstanceBuilder
-
Constructs a
InstanceBuilder
that will realize an instance of the specifically named class.
- InstanceBuilder(String, Object...) - Constructor for class com.tangosol.coherence.config.builder.InstanceBuilder
-
Constructs a
InstanceBuilder
that will realize an instance of the specifically named class.
- InstanceProcessor - Class in com.tangosol.coherence.config.xml.processor
-
- InstanceProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.InstanceProcessor
-
- instantiate() - Method in class com.tangosol.coherence.config.xml.processor.CustomizableBuilderProcessor
-
Instantiate the required class to inject and return.
- instantiate() - Method in class com.tangosol.coherence.config.xml.processor.ServiceBuilderProcessor
-
Instantiate the required class to inject and return.
- instantiateAddListener() - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
Factory Method: Instantiate a
MapListener
for adding items to the
ContinuousQueryCache
, and (if there are listeners on the
ContinuousQueryCache
) for dispatching inserts and updates.
- instantiateAnalysisContext() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
Factory method.
- instantiateAny(DefaultConfigurableCacheFactory.CacheInfo, XmlElement, BackingMapManagerContext, ClassLoader) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Create an Object using "class-scheme" element.
- instantiateAsyncBinaryStore(BinaryStore) - Method in class com.tangosol.io.AsyncBinaryStoreManager
-
Factory method: Instantiate an AsyncBinaryStore.
- instantiateAsyncBinaryStore(BinaryStore, int) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Construct an AsyncBinaryStore using the specified parameters.
- instantiateAsyncBinaryStoreManager(BinaryStoreManager, int) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Construct an AsyncBinaryStoreManager using the specified parameters.
- instantiateAttribute() - Method in class com.tangosol.run.xml.SimpleElement
-
Instantiate an XmlValue implementation for an attribute value.
- instantiateAttributeMap() - Method in class com.tangosol.run.xml.SimpleElement
-
Instantiate a Map implementation that will support the name to value
map used to hold attributes.
- instantiateBackingMap(String) - Method in interface com.tangosol.net.BackingMapManager
-
Instantiate a [thread safe] Map that should be used by a CacheService
to store cached values for a NamedCache with the specified name.
- instantiateBackingMap(String) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory.Manager
-
Deprecated.
Instantiate a [thread safe] Map that should be used by a CacheService
to store cached values for a NamedCache with the specified name.
- instantiateBackingMap(String) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory.PartitionedBackingMapManager
-
Deprecated.
Instantiate a [thread safe] Map that should be used by a CacheService
to store cached values for a NamedCache with the specified name.
- instantiateBackingMap(String) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.Manager
-
Instantiate a [thread safe] Map that should be used by a CacheService
to store cached values for a NamedCache with the specified name.
- instantiateBackingMap(String) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.PartitionedBackingMapManager
-
Instantiate a [thread safe] Map that should be used by a CacheService
to store cached values for a NamedCache with the specified name.
- instantiateBackingMapManager(int, XmlElement) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Instantiate a BackingMapManager for a given scheme type.
- instantiateBackMapListener(int) - Method in class com.tangosol.net.cache.CachingMap
-
Factory pattern: instantiate back map listener.
- instantiateBackMapListener() - Method in class com.tangosol.net.cache.OverflowMap
-
Factory pattern: Back Map Listener.
- instantiateBackupMap(String) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.Manager
-
Instantiate a [thread safe] Map that should be used by a CacheService
to store cached values for a NamedCache with the specified name.
- instantiateBackupStrength(Set) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
Create a backup strength to be used for distribution among the
specified set of ownership members.
- instantiateBean(String) - Method in class com.tangosol.run.xml.RestrictedStringAdapter
-
Convert a String into an instance of the bean.
- instantiateBinaryStoreManager(XmlElement, ClassLoader, boolean) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Create a BinaryStoreManager using the specified XML configuration.
- instantiateBlock() - Method in class com.tangosol.io.nio.BinaryMap
-
Factory method: Create a Block object.
- instantiateBufferInput() - Method in class com.tangosol.io.AbstractByteArrayReadBuffer
-
Factory method: Instantiate a BufferInput object to read data from the
ReadBuffer.
- instantiateBufferInput() - Method in class com.tangosol.io.AbstractReadBuffer
-
Factory method: Instantiate a BufferInput object to read data from the
ReadBuffer.
- instantiateBufferInput() - Method in class com.tangosol.io.MultiBufferReadBuffer
-
Factory method: Instantiate a BufferInput object to read data from the
ReadBuffer.
- instantiateBufferInput(boolean) - Method in class com.tangosol.io.MultiBufferReadBuffer
-
Factory method: Instantiate a BufferInput object to read data from the
ReadBuffer.
- instantiateBufferInput() - Method in class com.tangosol.io.nio.ByteBufferReadBuffer
-
Factory method: Instantiate a BufferInput object to read data from the
ReadBuffer.
- instantiateBundle() - Method in class com.tangosol.net.cache.AbstractBinaryEntryBundler
-
Instantiate a new Bundle object.
- instantiateBundle() - Method in class com.tangosol.net.cache.AbstractBundler
-
Instantiate a new Bundle object.
- instantiateBundle() - Method in class com.tangosol.net.cache.AbstractEntryBundler
-
Instantiate a new Bundle object.
- instantiateBundle() - Method in class com.tangosol.net.cache.AbstractKeyBundler
-
Instantiate a new Bundle object.
- instantiateBundlingNamedCache(NamedCache, XmlElement) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Create a BundlingNamedCache using the "operation-bundling" element.
- instantiateCacheLoaderCacheStore(CacheLoader) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Factory pattern: Instantiate a CacheLoaderCacheStore wrapper around a
passed CacheLoader.
- instantiateCacheResource(NamedCache, Class, Class, KeyConverter, QueryConfig, int) - Method in class com.tangosol.coherence.rest.DefaultRootResource
-
- instantiateCacheResourceInternal(ResourceConfig) - Method in class com.tangosol.coherence.rest.DefaultRootResource
-
Create an instance of
CacheResource
for the specified resource
configuration.
- instantiateCacheStore(DefaultConfigurableCacheFactory.CacheInfo, XmlElement, BackingMapManagerContext, ClassLoader) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Create a CacheLoader, CacheStore or BinaryEntryStore using the
"cachestore-scheme" element.
- instantiateCacheStoreWrapper(CacheStore) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Factory pattern: Instantiate a StoreWrapper wrapper around the
passed CacheStore.
- instantiateCacheStoreWrapper(BinaryEntryStore) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Factory pattern: Instantiate a StoreWrapper wrapper around the
passed BinaryEntryStore.
- instantiateCacheStoreWrapper(CacheStore) - Method in class com.tangosol.net.cache.VersionedBackingMap
-
Deprecated.
Factory pattern: Instantiate a CacheStore wrapper around the passed
CacheStore.
- instantiateCalculator() - Method in class com.tangosol.util.SimpleMapIndex
-
Factory method used to create a new calculator.
- instantiateClusterPolicy(Map<String, Integer>) - Static method in class com.tangosol.net.ConfigurableQuorumPolicy
-
Instantiate an action policy for the a cluster service.
- instantiateCollection() - Method in class com.tangosol.run.xml.CollectionAdapter
-
- instantiateCollection(Collection<F>, Converter<F, T>, Converter<T, F>) - Method in class com.tangosol.util.ConverterCollections.ConverterCollection
-
Create a Converter Collection.
- instantiateCollection(Collection<F>, Converter<F, T>, Converter<T, F>) - Method in class com.tangosol.util.ConverterCollections.ConverterMap
-
Create a Converter Collection.
- instantiateCollection() - Method in class com.tangosol.util.InflatableCollection
-
Factory method used to create a new Collection.
- instantiateCollection() - Method in class com.tangosol.util.InflatableList
-
Factory method used to create a new Collection.
- instantiateCollection() - Method in class com.tangosol.util.InflatableSet
-
Factory method used to create a new Collection.
- instantiateConditionalRemoveAction() - Method in class com.tangosol.util.SegmentedConcurrentMap
-
Factory for ConditionalRemoveAction
- instantiateContainsValueAction() - Method in class com.tangosol.util.SegmentedHashMap
-
Factory for ContainsValueAction
- instantiateContext(Guardable, long, float) - Method in class com.tangosol.net.GuardSupport
-
- instantiateContext(boolean) - Method in class com.tangosol.util.SegmentedConcurrentMap.SizeAction
-
Instantiate a context appropriate for applying SizeAction to count
the number of entries in the map.
- instantiateContext(Object) - Method in class com.tangosol.util.SegmentedHashMap.ContainsValueAction
-
Instantiate a context appropriate for applying ContainsValueAction
to lookup oValue in the map.
- instantiateControlMap() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Factory pattern: Create the concurrency control map for this backing map.
- instantiateConverterMap(Map<K, V_FRONT>) - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
Provides out-bound conversion (i.e. conversion to values clients expect) of internal values.
- instantiateCrawler(AbstractSparseArray.Node<V>, int, boolean) - Method in class com.tangosol.util.AbstractSparseArray
-
Instantiate a new Crawler at the specified location and direction.
- instantiateCrawler(AbstractSparseArray.Node, int, boolean) - Method in class com.tangosol.util.PrimitiveSparseArray
-
Instantiate a new Crawler at the specified location and direction.
- instantiateDefaultComparator() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
Instantiate a default member Comparator.
- instantiateDiskBackingMap(DefaultConfigurableCacheFactory.CacheInfo, XmlElement, BackingMapManagerContext, ClassLoader) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
- instantiateDocument() - Method in class com.tangosol.run.xml.SimpleParser
-
Factory method to instantiate an XmlDocument implementation.
- instantiateElement(String, Object) - Method in class com.tangosol.run.xml.SimpleElement
-
Instantiate an XmlElement implementation for an element.
- instantiateElementList() - Method in class com.tangosol.run.xml.SimpleElement
-
Instantiate a List implementation that will hold child elements.
- instantiateEntry(Binary, Binary) - Method in class com.tangosol.io.nio.BinaryMap
-
Factory pattern: Instantiate an Entry object.
- instantiateEntry() - Method in class com.tangosol.net.cache.LocalCache
-
Factory method.
- instantiateEntry() - Method in class com.tangosol.net.cache.OldCache
-
Deprecated.
Factory method.
- instantiateEntry(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.EntrySet
-
Factory pattern: instantiate a Map.Entry object for the specified
key.
- instantiateEntry(Object, Object, Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Factory pattern: instantiate a queue entry.
- instantiateEntry(Object, Object, Object, long) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Factory pattern: instantiate a queue entry.
- instantiateEntry(Object, Object) - Method in class com.tangosol.net.cache.SerializationCache.EntrySet
-
Factory pattern.
- instantiateEntry(Object, Object) - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache.EntrySet
-
Factory pattern.
- instantiateEntry(Object, Object) - Method in class com.tangosol.run.xml.SimpleElement.AttributeMap
-
Instantiate an Entry instance.
- instantiateEntry(K, V) - Method in class com.tangosol.util.AbstractKeyBasedMap.EntrySet
-
Factory pattern.
- instantiateEntry() - Method in class com.tangosol.util.ObservableHashMap
-
Factory method.
- instantiateEntry(Object, Object) - Method in class com.tangosol.util.OpenHashMap.EntrySet
-
Factory pattern.
- instantiateEntry(K, V, int) - Method in class com.tangosol.util.SafeHashMap
-
Factory pattern: instantiate initialized Entry object.
- instantiateEntry() - Method in class com.tangosol.util.SafeHashMap
-
Factory pattern: instantiate an un-initialized Entry object.
- instantiateEntry(Object, Object, int) - Method in class com.tangosol.util.SegmentedConcurrentMap
-
Factory for Entry.
- instantiateEntry(Object, Object, int) - Method in class com.tangosol.util.SegmentedHashMap
-
Factory for Entry.
- instantiateEntryAttributes(SerializationCache.EntryAttributes, long, long, int) - Method in class com.tangosol.net.cache.SerializationCache
-
Factory pattern: Construct an attribute holder for an entry.
- instantiateEntryResource(NamedCache, Object, Class) - Method in class com.tangosol.coherence.rest.CacheResource
-
Create an instance of
EntryResource
for the specified resource
configuration.
- instantiateEntrySet() - Method in class com.tangosol.io.nio.BinaryMap
-
Factory pattern.
- instantiateEntrySet() - Method in class com.tangosol.net.cache.OldCache
-
Deprecated.
Factory pattern.
- instantiateEntrySet() - Method in class com.tangosol.net.cache.OverflowMap
-
Factory pattern: Create a Set that represents the entries in the Map.
- instantiateEntrySet() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Factory pattern: instantiate an entry set for this backing map.
- instantiateEntrySet() - Method in class com.tangosol.net.cache.SerializationCache
-
Factory pattern: Create a Set that represents the entries in the Map.
- instantiateEntrySet() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
-
Factory pattern: Create a Set that represents the entries in the Map.
- instantiateEntrySet() - Method in class com.tangosol.run.xml.SimpleElement.AttributeMap
-
Instantiate an Entry Set.
- instantiateEntrySet() - Method in class com.tangosol.util.AbstractKeyBasedMap
-
Factory pattern: Create a Set that represents the entries in the Map.
- instantiateEntrySet() - Method in class com.tangosol.util.AbstractKeySetBasedMap
-
Factory pattern: Create a Set that represents the entries in the Map.
- instantiateEntrySet() - Method in class com.tangosol.util.ChainedMap
-
(Factory pattern) Instantiate an Entry Set or subclass thereof.
- instantiateEntrySet(Collection<Map.Entry<FK, FV>>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet
-
Create a Converter Entry Set.
- instantiateEntrySet(Set<Map.Entry<FK, FV>>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Method in class com.tangosol.util.ConverterCollections.ConverterMap
-
Create a Converter Entry Set.
- instantiateEntrySet() - Method in class com.tangosol.util.OpenHashMap
-
Factory pattern: Create a Set that represents the entries in the Map.
- instantiateEntrySet() - Method in class com.tangosol.util.SafeHashMap
-
Factory pattern.
- instantiateEntrySet() - Method in class com.tangosol.util.SegmentedHashMap
-
Factory for EntrySet
- instantiateEntrySetResource(NamedCache, Set, Class) - Method in class com.tangosol.coherence.rest.CacheResource
-
Create an instance of
EntrySetResource
for the specified resource
configuration.
- instantiateEnvironment(BerkeleyDBBinaryStoreManager) - Method in class com.tangosol.io.bdb.DatabaseFactory
-
Create a EnvironmentHolder within the specified parent directory.
- instantiateEraseBundler() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.BinaryEntryStoreWrapper
-
Create the bundler for the erase operations.
- instantiateEraseBundler() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.CacheStoreWrapper
-
Create the bundler for the erase operations.
- instantiateEraseBundler() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
Create the bundler for the erase operations.
- instantiateEventQueue() - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
Create a self-processing event queue.
- instantiateEventRouter(MapListener<? super K, ? super V_FRONT>, boolean) - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
Factory Method: Instantiate a listener on the internal map that will
direct events to the passed listener, either synchronously or
asynchronously as appropriate.
- instantiateExclusiveClosable() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
-
Return an
AutoCloseable
that will transition this PersistentStore
out of exclusive mode.
- instantiateExplainStep(Filter) - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult
-
Instantiate a new explain step for the given filter and add it to
this result's list of steps.
- instantiateExternalBackingMap(DefaultConfigurableCacheFactory.CacheInfo, XmlElement, BackingMapManagerContext, ClassLoader) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Create a backing Map using the "external-scheme" element.
- instantiateFactory(ClassLoader, XmlElement, XmlElement, String, String) - Method in class com.tangosol.net.ScopedCacheFactoryBuilder
-
- instantiateFakeBinaryStore() - Method in class com.tangosol.net.cache.SerializationPagedCache
-
Factory method: Instantiate a FakeBinaryStore.
- instantiateFlashJournalBackingMap(DefaultConfigurableCacheFactory.CacheInfo, XmlElement, BackingMapManagerContext, ClassLoader) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Create a backing Map using the "flashjournal-scheme" element.
- instantiateForwardIndex() - Method in class com.tangosol.util.ConditionalIndex
-
Instantiate the forward index.
- instantiateForwardIndex() - Method in class com.tangosol.util.ForwardOnlyMapIndex
-
Instantiate the forward index.
- instantiateForwardIndex() - Method in class com.tangosol.util.SimpleMapIndex
-
Instantiate the forward index.
- instantiateFrontMapListener() - Method in class com.tangosol.net.cache.CachingMap
-
Factory pattern: instantiate front map listener.
- instantiateFrontMapListener() - Method in class com.tangosol.net.cache.OverflowMap
-
Factory pattern: Front Map Listener.
- instantiateFrontMapListener() - Method in class com.tangosol.net.cache.SimpleOverflowMap
-
Factory pattern: Front Map Listener.
- instantiateGetEntryAction() - Method in class com.tangosol.util.SegmentedHashMap
-
Factory for GetEntryAction
- instantiateInsertAction() - Method in class com.tangosol.util.SegmentedHashMap
-
Factory for InsertAction
- instantiateInternalCache() - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
Create the internal cache used by the ContinuousQueryCache
.
- instantiateInternalKeySet() - Method in class com.tangosol.net.cache.OverflowMap
-
Factory pattern: Create a read-only Set of keys in the Overflow Map
- instantiateInternalListener() - Method in class com.tangosol.net.cache.LocalCache
-
Factory pattern: Instantiate an internal MapListener to listen to this
cache and report changes to the CacheStore.
- instantiateInternalListener() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Factory pattern: Create a MapListener that listens to the internal
cache and routes those events to anyone listening to this
ReadWriteBackingMap.
- instantiateInternalListener() - Method in class com.tangosol.net.cache.VersionedBackingMap
-
Deprecated.
Factory pattern: Create a MapListener that listens to the internal
cache and routes those events to anyone listening to this
VersionedBackingMap.
- instantiateInternalListener() - Method in class com.tangosol.util.WrapperObservableMap
-
Instantiate a MapListener to listen to the wrapped map.
- instantiateInternalMap(Comparator) - Method in class com.tangosol.util.SortedBag
-
Factory for the sorted internal map to use to hold the bag elements.
- instantiateInverseIndex(boolean, Comparator) - Method in class com.tangosol.util.SimpleMapIndex
-
Instantiate the inverse index.
- instantiateIterator() - Method in class com.tangosol.net.cache.OverflowMap.EntrySet
-
Factory pattern.
- instantiateIterator() - Method in class com.tangosol.util.AbstractKeyBasedMap.EntrySet
-
Factory pattern.
- instantiateIterator() - Method in class com.tangosol.util.AbstractKeyBasedMap.ValuesCollection
-
Factory pattern: Create a values Iterator.
- instantiateIterator(Iterator<F>, Converter<F, T>) - Method in class com.tangosol.util.ConverterCollections.ConverterCollection
-
Create a Converter Iterator.
- instantiateIterator(LongArray.Iterator<F>) - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray
-
Instantiate a new Iterator wrapping the provided iterator.
- instantiateIterator() - Method in class com.tangosol.util.OpenHashMap.EntrySet
-
Factory pattern.
- instantiateIterator() - Method in class com.tangosol.util.SafeHashMap.EntrySet
-
Factory pattern.
- instantiateIterator() - Method in class com.tangosol.util.SegmentedHashMap.EntrySet
-
Factory for EntrySetIterator.
- instantiateKeyIterator() - Method in class com.tangosol.util.AbstractKeySetBasedMap
-
Factory pattern: Create a mutable Iterator over the keys in the Map
- instantiateKeyMap() - Method in class com.tangosol.net.cache.SerializationMap
-
Instantiate a key-map.
- instantiateKeySet() - Method in class com.tangosol.io.nio.BinaryMap
-
Factory pattern.
- instantiateKeySet() - Method in class com.tangosol.net.cache.OldCache
-
Deprecated.
Factory pattern.
- instantiateKeySet() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Factory pattern: instantiate a key set for this backing map.
- instantiateKeySet() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
-
Factory pattern: Create a Set that represents the keys in the Map
- instantiateKeySet() - Method in class com.tangosol.util.AbstractKeyBasedMap
-
Factory pattern: Create a Set that represents the keys in the Map
- instantiateKeySet() - Method in class com.tangosol.util.AbstractKeySetBasedMap
-
Factory pattern: Create a Set that represents the keys in the Map
- instantiateKeySet() - Method in class com.tangosol.util.OpenHashMap
-
Factory pattern: Create a Set that represents the keys in the Map
- instantiateKeySet() - Method in class com.tangosol.util.SafeHashMap
-
Factory pattern.
- instantiateKeySet() - Method in class com.tangosol.util.SegmentedHashMap
-
Factory for KeySet.
- instantiateList(List<F>, Converter<F, T>, Converter<T, F>) - Method in class com.tangosol.util.ConverterCollections.ConverterList
-
Create a Converter List.
- instantiateListIterator(ListIterator<F>, Converter<F, T>, Converter<T, F>) - Method in class com.tangosol.util.ConverterCollections.ConverterList
-
Create a Converter ListIterator.
- instantiateLoadBundler() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.BinaryEntryStoreWrapper
-
Create the bundler for the load operations.
- instantiateLoadBundler() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.CacheStoreWrapper
-
Create the bundler for the load operations.
- instantiateLoadBundler() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
Create the bundler for the load operations.
- instantiateLoadCalculator(boolean) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
Instantiate the load calculator.
- instantiateLoadComparator(boolean) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
Return a comparator for primary or backup partition load.
- instantiateLocalCache(DefaultConfigurableCacheFactory.CacheInfo, XmlElement, BackingMapManagerContext, ClassLoader) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Create a backing Map using the "local-scheme" element.
- instantiateLocalCache(int, int) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Construct a LocalCache using the specified parameters.
- instantiateLock(Object) - Method in class com.tangosol.util.WrapperConcurrentMap
-
Factory pattern.
- instantiateLockAction() - Method in class com.tangosol.util.SegmentedConcurrentMap
-
Factory for LockAction
- instantiateMap() - Method in class com.tangosol.coherence.rest.util.JsonMap
-
- instantiateMap(DefaultConfigurableCacheFactory.CacheInfo, XmlElement, BackingMapManagerContext, ClassLoader) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Create a backing Map using the "class-scheme" element.
- instantiateMap() - Method in class com.tangosol.run.xml.MapAdapter
-
- instantiateMap(Map<FK, FV>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Method in class com.tangosol.util.ConverterCollections.ConverterMap
-
Create a Converter Map.
- instantiateMap(Class) - Method in class com.tangosol.util.CopyOnWriteMap
-
Create a new instance of
Map
based on the provided
Class
.
- instantiateMap() - Method in class com.tangosol.util.MapSet
-
Factory pattern: Provide an underlying Map for this Set implementation
to store its contents in.
- instantiateMap() - Method in class com.tangosol.util.SafeHashSet
-
Factory pattern: Provide an underlying Map for this Set implementation
to store its contents in.
- instantiateMap() - Method in class com.tangosol.util.SegmentedHashSet
-
Factory pattern: Provide an underlying Map for this Set implementation
to store its contents in.
- instantiateMapEvent(int, Object, Object, Object) - Method in class com.tangosol.net.cache.LocalCache
-
Factory pattern: instantiate a new CacheEvent corresponding
to the specified parameters.
- instantiateMapEvent(int, Object, Object, Object) - Method in class com.tangosol.net.cache.OldCache
-
Deprecated.
Factory pattern: instantiate a new MapEvent corresponding
to the specified parameters.
- instantiateMapListener(DefaultConfigurableCacheFactory.CacheInfo, XmlElement, BackingMapManagerContext, ClassLoader) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Create a MapListener using the using the "class-scheme" element.
- instantiateMemberListener() - Method in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy
-
Instantiate a member listener to subscribe to service membership events.
- instantiateModificationSet(int) - Method in class com.tangosol.util.SubSet
-
Instantiate a new modification set containing either removed or
retained items.
- instantiateNamedQueryResource(NamedCache, NamedQuery, int) - Method in class com.tangosol.coherence.rest.CacheResource
-
- instantiateNearCache(Map, NamedCache, int) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Construct an NearCache using the specified parameters.
- instantiateNilValue(int, int) - Method in class com.tangosol.io.pof.reflect.PofSparseArray
-
- instantiateNilValue(int, int) - Method in class com.tangosol.io.pof.reflect.PofUniformSparseArray
-
- instantiateNode(long, V) - Method in class com.tangosol.util.AbstractSparseArray
-
Factory pattern: create a new Node with the specified key and value.
- instantiateNode(long, Long) - Method in class com.tangosol.util.PrimitiveSparseArray
-
Factory pattern: create a new Node with the specified key and value.
- instantiateNode(long, long) - Method in class com.tangosol.util.PrimitiveSparseArray
-
Create a new Node with the specified key and value.
- instantiateNode(Object) - Method in class com.tangosol.util.RecyclingLinkedList
-
Instantiate a Node.
- instantiateNode(Object) - Method in class com.tangosol.util.SafeLinkedList
-
Instantiate a Node.
- instantiateNode(long, V) - Method in class com.tangosol.util.SparseArray
-
Factory pattern: create a new Node with the specified key and value.
- instantiateNotOwnedFilter(Ownership) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
Instantiate and return a NotOwnedFilter with the specified ownership.
- instantiateOpToken() - Method in class com.tangosol.coherence.dslquery.queryplus.AbstractQueryPlusStatementBuilder
-
Return the OPToken for this command.
- instantiateOpToken() - Method in class com.tangosol.coherence.dslquery.queryplus.CommandsStatementBuilder
-
- instantiateOpToken() - Method in class com.tangosol.coherence.dslquery.queryplus.ExtendedLanguageStatementBuilder
-
- instantiateOpToken() - Method in class com.tangosol.coherence.dslquery.queryplus.HelpStatementBuilder
-
- instantiateOpToken() - Method in class com.tangosol.coherence.dslquery.queryplus.SanityCheckStatementBuilder
-
- instantiateOpToken() - Method in class com.tangosol.coherence.dslquery.queryplus.ServicesStatementBuilder
-
- instantiateOpToken() - Method in class com.tangosol.coherence.dslquery.queryplus.SetTimeoutStatementBuilder
-
- instantiateOpToken() - Method in class com.tangosol.coherence.dslquery.queryplus.TraceStatementBuilder
-
- instantiateOpToken() - Method in class com.tangosol.coherence.dslquery.queryplus.WheneverStatementBuilder
-
- instantiateOverflowBackingMap(DefaultConfigurableCacheFactory.CacheInfo, XmlElement, BackingMapManagerContext, ClassLoader, Map) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Create a backing Map using the "overflow-scheme" element.
- instantiateOverflowMap(ObservableMap, Map, boolean) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Construct an OverflowMap using the specified parameters.
- instantiateOverloadedFilter(boolean) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
Instantiate a filter that matches members with an over-load.
- instantiatePagedExternalBackingMap(DefaultConfigurableCacheFactory.CacheInfo, XmlElement, BackingMapManagerContext, ClassLoader) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Create a backing Map using the "paged-external-scheme" element.
- instantiatePagedStore(int) - Method in class com.tangosol.net.cache.SerializationPagedCache
-
Factory method: Instantiate a PagedBinaryStore.
- instantiateParser(Reader) - Method in class com.tangosol.coherence.dslquery.ExecutionContext
-
Instantiate an instance of an
OPParser
to parse
the CohQL statements provided by the specified
Reader
.
- instantiatePartitionedBackingMap(MapBuilder, ParameterResolver, MapBuilder.Dependencies, CachingScheme) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.Manager
-
- instantiatePartitionedCachePolicy(ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumRule[], AddressProvider) - Static method in class com.tangosol.net.ConfigurableQuorumPolicy
-
Instantiate an action policy for a PartitionedCache service.
- instantiatePeriodicTask(Runnable, long) - Method in class com.tangosol.util.TaskDaemon
-
Create a task that will automatically be run on a periodic basis.
- instantiatePersistenceTools(OfflinePersistenceInfo) - Method in class com.tangosol.persistence.AbstractPersistenceManager
-
Factory method to create a PersistenceTools
implementation.
- instantiatePersistenceTools(OfflinePersistenceInfo, String) - Method in class com.tangosol.persistence.AbstractSnapshotArchiver
-
Instantiate an instance of PersistenceTools
relevant to this
archiver and the provided snapshot.
- instantiatePersistenceVisitor(CachePersistenceHelper.Visitor) - Static method in class com.tangosol.persistence.CachePersistenceHelper
-
Instantiate a visitor
for the PersistentStore
backed by the
- instantiatePersistentStore(String) - Method in class com.tangosol.persistence.AbstractPersistenceManager
-
Factory method for PersistentStore implementations managed by this
PersistenceManager.
- instantiatePofValue(PofValue, int, ReadBuffer, PofContext, int, ReadBuffer.BufferInput) - Static method in class com.tangosol.io.pof.reflect.PofValueParser
-
Creates a PofValue instance.
- instantiateProxyPolicy(ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumRule[]) - Static method in class com.tangosol.net.ConfigurableQuorumPolicy
-
Instantiate an action policy for the a proxy service.
- instantiateQueue() - Method in class com.tangosol.net.LoadBalancer
-
Factory method: Create a queue.
- instantiateQueueDaemon() - Method in class com.tangosol.io.AsyncBinaryStore
-
Factory method: Instantiate a QueueDaemon.
- instantiateRamJournalBackingMap(DefaultConfigurableCacheFactory.CacheInfo, XmlElement, BackingMapManagerContext, ClassLoader) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Create a backing Map using the "ramjournal-scheme" element.
- instantiateReadBuffer(int, int) - Method in class com.tangosol.io.AbstractReadBuffer
-
Factory method: Instantiate a ReadBuffer for a portion of this
ReadBuffer.
- instantiateReadBuffer(int, int) - Method in class com.tangosol.io.ByteArrayReadBuffer
-
Factory method: Instantiate a ReadBuffer for a portion of this
ReadBuffer.
- instantiateReadBuffer(int, int) - Method in class com.tangosol.io.MultiBufferReadBuffer
-
Factory method: Instantiate a ReadBuffer for a portion of this
ReadBuffer.
- instantiateReadBuffer(int, int) - Method in class com.tangosol.io.nio.ByteBufferReadBuffer
-
Factory method: Instantiate a ReadBuffer for a portion of this
ReadBuffer.
- instantiateReadBuffer(int, int) - Method in class com.tangosol.util.Binary
-
Factory method: Instantiate a ReadBuffer for a portion of this
ReadBuffer.
- instantiateReadLatch(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Factory pattern: Instantiate a new read latch the given key.
- instantiateReadQueue() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Factory pattern: Instantiate a new ReadQueue object.
- instantiateReadThread() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Factory pattern: Instantiate the refresh-ahead thread.
- instantiateReadWriteBackingMap(BackingMapManagerContext, ObservableMap, Map, CacheLoader, boolean, int, double) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
-
Construct a ReadWriteBackingMap using the specified parameters.
- instantiateReadWriteBackingMap(BackingMapManagerContext, ObservableMap, Map, BinaryEntryStore, boolean, int, double) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
-
Construct a ReadWriteBackingMap using the specified parameters.
- instantiateReadWriteBackingMap(DefaultConfigurableCacheFactory.CacheInfo, XmlElement, BackingMapManagerContext, Map) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Create a ReadWriteBackingMap using the "read-write-backing-map-scheme" element.
- instantiateReadWriteBackingMap(BackingMapManagerContext, ObservableMap, Map, CacheLoader, boolean, int, double) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Construct a ReadWriteBackingMap using the specified parameters.
- instantiateReadWriteBackingMap(BackingMapManagerContext, ObservableMap, Map, BinaryEntryStore, boolean, int, double) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Construct a ReadWriteBackingMap using the specified parameters.
- instantiateReadWriteSplittingBackingMap(BackingMapManagerContext, PartitionAwareBackingMap, Map, CacheLoader, boolean, int, double) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
-
Construct a ReadWriteSplittingBackingMap using the specified parameters.
- instantiateReadWriteSplittingBackingMap(BackingMapManagerContext, PartitionAwareBackingMap, Map, BinaryEntryStore, boolean, int, double) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
-
Construct a ReadWriteSplittingBackingMap using the specified parameters.
- instantiateReadWriteSplittingBackingMap(BackingMapManagerContext, PartitionAwareBackingMap, Map, CacheLoader, boolean, int, double) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Construct a ReadWriteSplittingBackingMap using the specified parameters.
- instantiateReadWriteSplittingBackingMap(BackingMapManagerContext, PartitionAwareBackingMap, Map, BinaryEntryStore, boolean, int, double) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Construct a ReadWriteSplittingBackingMap using the specified parameters.
- instantiateRemoveAction() - Method in class com.tangosol.util.SegmentedConcurrentMap
-
Factory for RemoveAction
- instantiateRemoveAction() - Method in class com.tangosol.util.SegmentedHashMap
-
Factory for RemoveAction
- instantiateRemoveListener() - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
Factory Method: Instantiate a
MapListener
for evicting items from the
ContinuousQueryCache
.
- instantiateRequestHandler(LoadBalancer.Queue) - Method in class com.tangosol.net.LoadBalancer
-
Factory method: Create a RequestHandler.
- instantiateResponseHandler(LoadBalancer.RequestHandler) - Method in class com.tangosol.net.LoadBalancer
-
Factory method: Create a ResponseHandler.
- instantiateRoot(String) - Method in class com.tangosol.run.xml.SaxParser
-
Instantiate an XmlElement implementation for a root element.
- instantiateSafeIterator(boolean, long) - Method in class com.tangosol.util.AbstractSafeLongArray
-
Instantiate a SafeIterator around the specified delegate iterator.
- instantiateSafeIterator(boolean, long) - Method in class com.tangosol.util.ReadHeavyLongArray
-
- instantiateSafetyFilter(Ownership, int) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
Instantiate and return a SafetyFilter with the specified ownership.
- instantiateSerializationCache(BinaryStore, int, ClassLoader) - Method in class com.tangosol.coherence.config.scheme.ExternalScheme
-
Construct an SerializationCache using the specified parameters.
- instantiateSerializationCache(BinaryStore, int, boolean) - Method in class com.tangosol.coherence.config.scheme.ExternalScheme
-
Construct an SerializationCache using the specified parameters.
- instantiateSerializationCache(BinaryStore, int, ClassLoader) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Construct an SerializationCache using the specified parameters.
- instantiateSerializationCache(BinaryStore, int, boolean) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Construct an SerializationCache using the specified parameters.
- instantiateSerializationMap(ParameterResolver, BinaryStore, boolean, ClassLoader, int, int) - Method in class com.tangosol.coherence.config.scheme.ExternalScheme
-
Instantiate a SerializationMap, SerializationCache,
SimpleSerializationMap, or any sub-class thereof.
- instantiateSerializationMap(BinaryStore, ClassLoader) - Method in class com.tangosol.coherence.config.scheme.ExternalScheme
-
Construct an SerializationMap using the specified parameters.
- instantiateSerializationMap(BinaryStore, boolean) - Method in class com.tangosol.coherence.config.scheme.ExternalScheme
-
Construct an SerializationMap using the specified parameters.
- instantiateSerializationMap(BinaryStore, boolean, ClassLoader, int, int, String, XmlElement) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Instantiate a SerializationMap, SerializationCache,
SimpleSerializationMap, or any sub-class thereof.
- instantiateSerializationMap(BinaryStore, ClassLoader) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Construct an SerializationMap using the specified parameters.
- instantiateSerializationMap(BinaryStore, boolean) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Construct an SerializationMap using the specified parameters.
- instantiateSerializationPagedCache(BinaryStoreManager, int, int, ClassLoader) - Method in class com.tangosol.coherence.config.scheme.PagedExternalScheme
-
Construct an SerializationPagedCache using the specified parameters.
- instantiateSerializationPagedCache(BinaryStoreManager, int, int, boolean, boolean) - Method in class com.tangosol.coherence.config.scheme.PagedExternalScheme
-
Construct an SerializationPagedCache using the specified parameters.
- instantiateSerializationPagedCache(BinaryStoreManager, int, int, ClassLoader) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Construct an SerializationPagedCache using the specified parameters.
- instantiateSerializationPagedCache(BinaryStoreManager, int, int, boolean, boolean) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Construct an SerializationPagedCache using the specified parameters.
- instantiateSerializer(XmlElement, int, Class) - Method in class com.tangosol.io.pof.ConfigurablePofContext
-
- instantiateSerializer() - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
Create a
Serializer
appropriate for the mode this cache is operating under
(i.e., binary vs non-binary).
- instantiateSet(Set<F>, Converter<F, T>, Converter<T, F>) - Method in class com.tangosol.util.ConverterCollections.ConverterMap
-
Create a Converter Set.
- instantiateSet() - Method in class com.tangosol.util.LiteSet
-
(Factory pattern) Instantiate a Set object to store items in once
the "lite" threshold has been exceeded.
- instantiateSet() - Method in class com.tangosol.util.SimpleMapIndex
-
Factory method used to create a new set containing the keys associated
with a single value.
- instantiateSimpleOverflowMap(ObservableMap, Map, Map) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Construct a SimpleOverflowMap using the specified parameters.
- instantiateSimpleSerializationMap(BinaryStore, ClassLoader) - Method in class com.tangosol.coherence.config.scheme.ExternalScheme
-
Construct a SimpleSerializationMap using the specified parameters.
- instantiateSimpleSerializationMap(BinaryStore, boolean) - Method in class com.tangosol.coherence.config.scheme.ExternalScheme
-
Construct a SimpleSerializationMap using the specified parameters.
- instantiateSimpleSerializationMap(BinaryStore, ClassLoader) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Construct a SimpleSerializationMap using the specified parameters.
- instantiateSimpleSerializationMap(BinaryStore, boolean) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Construct a SimpleSerializationMap using the specified parameters.
- instantiateSizeAction() - Method in class com.tangosol.util.SegmentedConcurrentMap
-
Factory for SizeAction
- instantiateSortedMap(SortedMap<FK, FV>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Method in class com.tangosol.util.ConverterCollections.ConverterSortedMap
-
Create a Converter SortedMap.
- instantiateSortedSet(SortedSet<F>, Converter<F, T>, Converter<T, F>) - Method in class com.tangosol.util.ConverterCollections.ConverterSortedSet
-
Create a Converter SortedSet.
- instantiateStatus() - Method in class com.tangosol.net.cache.OverflowMap
-
Factory method: Instantiate a Status object.
- instantiateStatus() - Method in class com.tangosol.net.cache.SimpleOverflowMap
-
Factory method: Instantiate a Status object.
- instantiateStoreBundler() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.BinaryEntryStoreWrapper
-
Create the bundler for the store operations.
- instantiateStoreBundler() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.CacheStoreWrapper
-
Create the bundler for the store operations.
- instantiateStoreBundler() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
Create the bundler for the store operations.
- instantiateStrengthComparator(Ownership) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
Instantiate a StrengthComparator for the specified reference ownership.
- instantiateSubclass(String, Class, ClassLoader, Object[], XmlElement) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Construct an instance of the specified class using the specified
parameters.
- instantiateTraceStep(Filter) - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult
-
Instantiate a new trace step for the given filter and add it to
this result's list of steps.
- instantiateUnderloadedFilter(boolean) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
Instantiate a filter that matches members with an under-load.
- instantiateUnlockAction() - Method in class com.tangosol.util.SegmentedConcurrentMap
-
Factory for UnlockAction
- instantiateUnmodifiableIterator(LongArray.Iterator<V>) - Method in class com.tangosol.util.CopyOnWriteLongArray
-
Factory pattern: instantiate an UnmodifiableIterator.
- instantiateValues() - Method in class com.tangosol.util.AbstractKeyBasedMap
-
Factory pattern: Instantiate the values Collection.
- instantiateValues() - Method in class com.tangosol.util.AbstractKeySetBasedMap
-
Factory pattern: Instantiate the values Collection.
- instantiateValuesCollection() - Method in class com.tangosol.io.nio.BinaryMap
-
Factory pattern.
- instantiateValuesCollection() - Method in class com.tangosol.net.cache.OldCache
-
Deprecated.
Factory pattern.
- instantiateValuesCollection() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Factory pattern.
- instantiateValuesCollection() - Method in class com.tangosol.util.SafeHashMap
-
Factory pattern.
- instantiateValuesCollection() - Method in class com.tangosol.util.SegmentedHashMap
-
Factory for ValuesCollection.
- instantiateVersionCacheListener() - Method in class com.tangosol.net.cache.VersionedNearCache
-
Deprecated.
Factory method: Provide a MapListener that listens to the VersionCache
and invalidates local entries accordingly.
- instantiateVersionedBackingMap(DefaultConfigurableCacheFactory.CacheInfo, XmlElement, BackingMapManagerContext, Map) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Create a VersionedBackingMap using the "versioned-backing-map-scheme" element.
- instantiateVersionedBackingMap(BackingMapManagerContext, ObservableMap, Map, CacheStore, boolean, int, double, NamedCache, NamedCache, boolean) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Construct a VersionedBackingMap using the specified parameters.
- instantiateVersionedBackingMap(BackingMapManagerContext, ObservableMap, Map, CacheLoader, NamedCache, NamedCache, boolean) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Construct a VersionedBackingMap using the specified parameters.
- instantiateVersionedNearCache(Map, NamedCache, NamedCache) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Construct an VersionedNearCache using the specified parameters.
- instantiateWorker() - Method in class com.tangosol.util.Daemon
-
Instantiate a DaemonWorker that will be used as a daemon.
- instantiateWrapperStore(BinaryStore) - Method in class com.tangosol.net.cache.SerializationPagedCache
-
Factory method: Instantiate a WrapperBinaryStore.
- instantiateWriteQueue() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Factory pattern: Instantiate a new WriteQueue object.
- instantiateWriteThread() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Factory pattern: Instantiate the write-behind thread.
- Instruction - Interface in com.tangosol.util.fsm
-
- Instruction.ProcessEvent<S extends Enum<S>> - Class in com.tangosol.util.fsm
-
- Instruction.TransitionTo<S extends Enum<S>> - Class in com.tangosol.util.fsm
-
- INT_ARRAY_EMPTY - Static variable in class com.tangosol.io.pof.PofHelper
-
An empty array of ints.
- IntAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.SimpleAdapter.IntAdapter
-
Construct a SimpleAdapter.
- IntArrayAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.PrimitiveArrayAdapter.IntArrayAdapter
-
Construct an IntArrayAdapter.
- intBinaryOperator(Remote.IntBinaryOperator) - Static method in class com.tangosol.util.function.Remote
-
Capture serializable IntBinaryOperator.
- intConsumer(Remote.IntConsumer) - Static method in class com.tangosol.util.function.Remote
-
Capture serializable IntConsumer.
- IntDecoratedObject(Object, int) - Constructor for class com.tangosol.util.ExternalizableHelper.IntDecoratedObject
-
Construct an IntDecorated object with the specified value and decoration.
- INTEGERLITERAL - Static variable in class com.tangosol.coherence.dsltools.base.LiteralBaseToken
-
The numberic code for a integer literal
- INTEGERLITERAL - Static variable in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
-
The numberic code for a integer literal
- Interceptor - Annotation Type in com.tangosol.net.events.annotation
-
Interceptor is an annotation that should be applied to
EventInterceptor
implementations.
- Interceptor.Order - Enum in com.tangosol.net.events.annotation
-
- InterceptorProcessor - Class in com.tangosol.coherence.config.xml.processor
-
- InterceptorProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.InterceptorProcessor
-
Construct an InterceptorProcessor.
- InterceptorRegistry - Interface in com.tangosol.net.events
-
- InterceptorsProcessor - Class in com.tangosol.coherence.config.xml.processor
-
- InterceptorsProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.InterceptorsProcessor
-
- INTERNAL_SERVICE - Static variable in class com.tangosol.net.security.LocalPermission
-
"Service.getInternalService" permission.
- InternalCacheSchemeProcessor - Class in com.tangosol.coherence.config.xml.processor
-
- InternalCacheSchemeProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.InternalCacheSchemeProcessor
-
- InternalConverter<T> - Interface in com.tangosol.coherence.jcache.common
-
Converts values of a specified type to and from an internal representation.
- InternalKeySet() - Constructor for class com.tangosol.net.cache.OverflowMap.InternalKeySet
-
- InternalKeySetIterator() - Constructor for class com.tangosol.net.cache.OverflowMap.InternalKeySet.InternalKeySetIterator
-
Default constructor.
- InternalListener() - Constructor for class com.tangosol.net.cache.LocalCache.InternalListener
-
- InternalListener() - Constructor for class com.tangosol.util.WrapperObservableMap.InternalListener
-
- InternalMapListener(MapListenerSupport, Converter, Converter) - Constructor for class com.tangosol.net.cache.ContinuousQueryCache.InternalMapListener
-
- InternalMapListener() - Constructor for class com.tangosol.net.cache.ReadWriteBackingMap.InternalMapListener
-
- InternalMapListener() - Constructor for class com.tangosol.net.cache.VersionedBackingMap.InternalMapListener
-
Deprecated.
- intersects(PartitionSet) - Method in class com.tangosol.net.partition.PartitionSet
-
Check whether or not the specified partition set intersects with this
set.
- intersects(Object[], Object[]) - Static method in class com.tangosol.persistence.GUIDHelper
-
Return a List of stores (GUIDs) that allows the caller to derive whether
the provided sets are disjoint, intersect or equal.
- intFunction(Remote.IntFunction<R>) - Static method in class com.tangosol.util.function.Remote
-
Capture serializable IntFunction.
- intPredicate(Remote.IntPredicate) - Static method in class com.tangosol.util.function.Remote
-
Capture serializable IntPredicate.
- introduceEventDispatcher(String, EventDispatcher) - Method in interface com.tangosol.net.events.EventDispatcherAwareInterceptor
-
- intSupplier(Remote.IntSupplier) - Static method in class com.tangosol.util.function.Remote
-
Capture serializable IntSupplier.
- intToDoubleFunction(Remote.IntToDoubleFunction) - Static method in class com.tangosol.util.function.Remote
-
Capture serializable IntToDoubleFunction.
- intToLongFunction(Remote.IntToLongFunction) - Static method in class com.tangosol.util.function.Remote
-
Capture serializable IntToLongFunction.
- intUnaryOperator(Remote.IntUnaryOperator) - Static method in class com.tangosol.util.function.Remote
-
Capture serializable IntUnaryOperator.
- intValue() - Method in class com.tangosol.io.pof.RawQuad
-
Returns the value of the specified number as an int
.
- invalidate() - Method in class com.tangosol.util.ConverterCollections.ConverterCollection
-
Drop references to the underlying Collection and the Converters.
- invalidateFront(Object) - Method in class com.tangosol.net.cache.CachingMap
-
Invalidate the key from the front.
- InvalidConfigServiceLoadBalancerBuilder - Class in com.tangosol.coherence.config.builder
-
- InvalidConfigServiceLoadBalancerBuilder(String, XmlElement) - Constructor for class com.tangosol.coherence.config.builder.InvalidConfigServiceLoadBalancerBuilder
-
- inverse(Comparator) - Method in class com.tangosol.coherence.rest.util.ComparatorBuilder
-
Reverse ordering of a given comparator.
- InverseComparator<T> - Class in com.tangosol.util.comparator
-
Comparator that reverses the result of another comparator.
- InverseComparator() - Constructor for class com.tangosol.util.comparator.InverseComparator
-
Default constructor (for ExternalizableLite and PortableObject).
- InverseComparator(Comparator<? super T>) - Constructor for class com.tangosol.util.comparator.InverseComparator
-
Construct an InverseComparator.
- invert() - Method in class com.tangosol.net.partition.PartitionSet
-
Invert all the partitions.
- Invocable - Interface in com.tangosol.net
-
The Invocable object is a cluster-portable object that can be invoked on
any set of remote members and each can optionally register a return value
for the invocation.
- InvocableInOrder - Interface in com.tangosol.net
-
The InvocableInOrder interface allows to control the ordering in which
the results of Invocable tasks are returned back to the caller by the
Invocation service with a thread pool.
- InvocableMap<K,V> - Interface in com.tangosol.util
-
An InvocableMap is a Map against which both entry-targeted processing and
aggregating operations can be invoked.
- InvocableMap.Entry<K,V> - Interface in com.tangosol.util
-
An InvocableMap.Entry contains additional information and exposes
additional operations that the basic Map.Entry does not.
- InvocableMap.EntryAggregator<K,V,R> - Interface in com.tangosol.util
-
An EntryAggregator represents processing that can be directed to occur
against some subset of the entries in an InvocableMap, resulting in a
aggregated result.
- InvocableMap.EntryProcessor<K,V,R> - Interface in com.tangosol.util
-
An invocable agent that operates against the Entry objects within a Map.
- InvocableMap.ParallelAwareAggregator<K,V,P,R> - Interface in com.tangosol.util
-
- InvocableMap.ParallelAwareAggregator.PartialResultAggregator<P> - Interface in com.tangosol.util
-
- InvocableMap.StreamingAggregator<K,V,P,R> - Interface in com.tangosol.util
-
- InvocableMapHelper - Class in com.tangosol.util
-
Helper methods for InvocableMap implementations and Filter related
evaluation.
- InvocableMapHelper() - Constructor for class com.tangosol.util.InvocableMapHelper
-
- InvocableMapHelper.IndexAdapter - Class in com.tangosol.util
-
MapListener implementation that routes the map events into the
corresponding MapIndex calls.
- InvocableMapHelper.RoutingBinaryEntry - Class in com.tangosol.util
-
BinaryEntry wrapper that routes the getValue()/getBinaryValue()
calls onto getOriginalValue()/getOriginalBinaryValue().
- InvocableMapHelper.RoutingMapTriggerEntry - Class in com.tangosol.util
-
MapTrigger.Entry wrapper that routes the getValue() call onto
getOriginalValue().
- InvocableMapHelper.SimpleEntry<K,V> - Class in com.tangosol.util
-
Simple implementation of the InvocableMap.Entry interface.
- invocationCompleted() - Method in interface com.tangosol.net.InvocationObserver
-
This method is called by the
InvocationService
to inform the
InvocationObserver that all service members have either finished
the
Invocable
object execution or are not (or no longer) running
the InvocationService.
- InvocationObserver - Interface in com.tangosol.net
-
The InvocationObserver is an object that asynchronously receives
notification of results from the execution of Invocable objects.
- InvocationScheme - Class in com.tangosol.coherence.config.scheme
-
- InvocationScheme() - Constructor for class com.tangosol.coherence.config.scheme.InvocationScheme
-
- InvocationService - Interface in com.tangosol.net
-
The InvocationService is a Service for delivering executable objects to
cluster members for distributed invocation.
- InvocationServiceProxyProcessor - Class in com.tangosol.coherence.config.xml.processor
-
An
ElementProcessor
that will parse invocation-service-proxy configuration
element tp produce a
DefaultInvocationServiceProxyDependencies
object.
- InvocationServiceProxyProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.InvocationServiceProxyProcessor
-
- invoke(K, EntryProcessor<K, V, T>, Object...) - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
-
- invoke(K, EntryProcessor<K, V, T>, Object...) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
-
- invoke(K, EntryProcessor<K, V, T>, Object...) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
-
- invoke(K, EntryProcessor<K, V, T>, Object...) - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
-
- invoke(K, InvocableMap.EntryProcessor<K, V, R>) - Method in interface com.tangosol.net.AsyncNamedCache
-
Invoke the passed EntryProcessor against the Entry specified by the
passed key asynchronously, returning a
CompletableFuture
that can
be used to obtain the result of the invocation.
- invoke(K, InvocableMap.EntryProcessor<K, V_FRONT, R>) - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
Invoke the passed EntryProcessor against the Entry specified by the
passed key, returning the result of the invocation.
- invoke(K, InvocableMap.EntryProcessor<K, V, R>) - Method in class com.tangosol.net.cache.NearCache
-
Invoke the passed EntryProcessor against the Entry specified by the
passed key, returning the result of the invocation.
- invoke(K, InvocableMap.EntryProcessor<K, V, R>) - Method in class com.tangosol.net.cache.ReadonlyNamedCache
-
Should not be called.
- invoke(K, InvocableMap.EntryProcessor<K, V, R>) - Method in class com.tangosol.net.cache.WrapperNamedCache
-
Invoke the passed EntryProcessor against the Entry specified by the
passed key, returning the result of the invocation.
- invoke(MBeanAccessor.QueryBuilder.ParsedQuery, String, Object[], String[]) - Method in class com.tangosol.net.management.MBeanAccessor
-
- Invoke() - Constructor for class com.tangosol.net.management.MBeanAccessor.Invoke
-
Default constructor.
- Invoke(MBeanAccessor.QueryBuilder.ParsedQuery, String, Object[], String[]) - Constructor for class com.tangosol.net.management.MBeanAccessor.Invoke
-
Create an Invoke object.
- invoke(String, String, Object[], String[]) - Method in interface com.tangosol.net.management.MBeanServerProxy
-
Invoke an operation on the specified MBean.
- invoke(String, String, Object[], String[]) - Method in class com.tangosol.net.management.WrapperMBeanServerProxy
-
- invoke(Object, String, Object[]) - Static method in class com.tangosol.util.ClassHelper
-
Invoke the specified instance method using the passed arguments.
- invoke(Class, Object, String, Object[]) - Static method in class com.tangosol.util.ClassHelper
-
Invoke the specified method using the passed arguments.
- invoke(TK, InvocableMap.EntryProcessor<TK, TV, R>) - Method in class com.tangosol.util.ConverterCollections.ConverterInvocableMap
-
Invoke the passed EntryProcessor against the Entry specified by the
passed key, returning the result of the invocation.
- invoke(TK, InvocableMap.EntryProcessor<TK, TV, R>) - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
-
Invoke the passed EntryProcessor against the Entry specified by the
passed key, returning the result of the invocation.
- invoke(K, InvocableMap.EntryProcessor<K, V, R>) - Method in interface com.tangosol.util.InvocableMap
-
Invoke the passed EntryProcessor against the Entry specified by the
passed key, returning the result of the invocation.
- invokeAll(Set<? extends K>, EntryProcessor<K, V, T>, Object...) - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
-
- invokeAll(Set<? extends K>, EntryProcessor<K, V, T>, Object...) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
-
- invokeAll(Set<? extends K>, EntryProcessor<K, V, T>, Object...) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
-
- invokeAll(Set<? extends K>, EntryProcessor<K, V, T>, Object...) - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
-
- invokeAll(InvocableMap.EntryProcessor<K, V, R>) - Method in interface com.tangosol.net.AsyncNamedCache
-
Invoke the passed EntryProcessor against all the entries asynchronously,
returning a
CompletableFuture
that can be used to obtain the
result of the invocation for each entry.
- invokeAll(Collection<? extends K>, InvocableMap.EntryProcessor<K, V, R>) - Method in interface com.tangosol.net.AsyncNamedCache
-
Invoke the passed EntryProcessor against the entries specified by the
passed keys asynchronously, returning a
CompletableFuture
that
can be used to obtain the result of the invocation for each entry.
- invokeAll(Filter, InvocableMap.EntryProcessor<K, V, R>) - Method in interface com.tangosol.net.AsyncNamedCache
-
Invoke the passed EntryProcessor against the set of entries that are
selected by the given Filter asynchronously, returning a
CompletableFuture
that can be used to obtain the result of the
invocation for each entry.
- invokeAll(InvocableMap.EntryProcessor<K, V, R>, Consumer<? super Map.Entry<? extends K, ? extends R>>) - Method in interface com.tangosol.net.AsyncNamedCache
-
Invoke the passed EntryProcessor against all the entries asynchronously,
returning a
CompletableFuture
that can be used to determine if
the operation completed successfully.
- invokeAll(InvocableMap.EntryProcessor<K, V, R>, BiConsumer<? super K, ? super R>) - Method in interface com.tangosol.net.AsyncNamedCache
-
Invoke the passed EntryProcessor against all the entries asynchronously,
returning a
CompletableFuture
that can be used to determine if
the operation completed successfully.
- invokeAll(Collection<? extends K>, InvocableMap.EntryProcessor<K, V, R>, Consumer<? super Map.Entry<? extends K, ? extends R>>) - Method in interface com.tangosol.net.AsyncNamedCache
-
Invoke the passed EntryProcessor against the entries specified by the
passed keys asynchronously, returning a
CompletableFuture
that
can be used to determine if the operation completed successfully.
- invokeAll(Collection<? extends K>, InvocableMap.EntryProcessor<K, V, R>, BiConsumer<? super K, ? super R>) - Method in interface com.tangosol.net.AsyncNamedCache
-
Invoke the passed EntryProcessor against the entries specified by the
passed keys asynchronously, returning a
CompletableFuture
that
can be used to determine if the operation completed successfully.
- invokeAll(Filter, InvocableMap.EntryProcessor<K, V, R>, Consumer<? super Map.Entry<? extends K, ? extends R>>) - Method in interface com.tangosol.net.AsyncNamedCache
-
Invoke the passed EntryProcessor against the set of entries that are
selected by the given Filter asynchronously, returning a
CompletableFuture
that can be used to determine if the operation
completed successfully.
- invokeAll(Filter, InvocableMap.EntryProcessor<K, V, R>, BiConsumer<? super K, ? super R>) - Method in interface com.tangosol.net.AsyncNamedCache
-
Invoke the passed EntryProcessor against the set of entries that are
selected by the given Filter asynchronously, returning a
CompletableFuture
that can be used to determine if the operation
completed successfully.
- invokeAll(Collection<? extends K>, InvocableMap.EntryProcessor<K, V_FRONT, R>) - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
Invoke the passed EntryProcessor against the entries specified by the
passed keys, returning the result of the invocation for each.
- invokeAll(Filter, InvocableMap.EntryProcessor<K, V_FRONT, R>) - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
Invoke the passed EntryProcessor against the set of entries that are
selected by the given Filter, returning the result of the invocation for
each.
- invokeAll(Collection<? extends K>, InvocableMap.EntryProcessor<K, V, R>) - Method in class com.tangosol.net.cache.NearCache
-
Invoke the passed EntryProcessor against the entries specified by the
passed keys, returning the result of the invocation for each.
- invokeAll(Filter, InvocableMap.EntryProcessor<K, V, R>) - Method in class com.tangosol.net.cache.NearCache
-
Invoke the passed EntryProcessor against the set of entries that are
selected by the given Filter, returning the result of the invocation for
each.
- invokeAll(Collection<? extends K>, InvocableMap.EntryProcessor<K, V, R>) - Method in class com.tangosol.net.cache.ReadonlyNamedCache
-
Should not be called.
- invokeAll(Filter, InvocableMap.EntryProcessor<K, V, R>) - Method in class com.tangosol.net.cache.ReadonlyNamedCache
-
Should not be called.
- invokeAll(Collection<? extends K>, InvocableMap.EntryProcessor<K, V, R>) - Method in class com.tangosol.net.cache.WrapperNamedCache
-
Invoke the passed EntryProcessor against the entries specified by the
passed keys, returning the result of the invocation for each.
- invokeAll(Filter, InvocableMap.EntryProcessor<K, V, R>) - Method in class com.tangosol.net.cache.WrapperNamedCache
-
Invoke the passed EntryProcessor against the set of entries that are
selected by the given Filter, returning the result of the invocation for
each.
- invokeAll(Collection<? extends TK>, InvocableMap.EntryProcessor<TK, TV, R>) - Method in class com.tangosol.util.ConverterCollections.ConverterInvocableMap
-
Invoke the passed EntryProcessor against the entries specified by the
passed keys, returning the result of the invocation for each.
- invokeAll(Filter, InvocableMap.EntryProcessor<TK, TV, R>) - Method in class com.tangosol.util.ConverterCollections.ConverterInvocableMap
-
Invoke the passed EntryProcessor against the set of entries that are
selected by the given Filter, returning the result of the invocation for
each.
- invokeAll(Collection<? extends TK>, InvocableMap.EntryProcessor<TK, TV, R>) - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
-
Invoke the passed EntryProcessor against the entries specified by the
passed keys, returning the result of the invocation for each.
- invokeAll(Filter, InvocableMap.EntryProcessor<TK, TV, R>) - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
-
Invoke the passed EntryProcessor against the set of entries that are
selected by the given Filter, returning the result of the invocation for
each.
- invokeAll(InvocableMap.EntryProcessor<K, V, R>) - Method in interface com.tangosol.util.InvocableMap
-
Invoke the passed EntryProcessor against all the entries, returning the
result of the invocation for each.
- invokeAll(Collection<? extends K>, InvocableMap.EntryProcessor<K, V, R>) - Method in interface com.tangosol.util.InvocableMap
-
Invoke the passed EntryProcessor against the entries specified by the
passed keys, returning the result of the invocation for each.
- invokeAll(Filter, InvocableMap.EntryProcessor<K, V, R>) - Method in interface com.tangosol.util.InvocableMap
-
Invoke the passed EntryProcessor against the set of entries that are
selected by the given Filter, returning the result of the invocation for
each.
- invokeAllAsync(NamedCache<K, V>, Collection<? extends K>, int, InvocableMap.EntryProcessor<K, V, R>, BiConsumer<? super Map<? extends K, ? extends R>, ? super Throwable>...) - Static method in class com.tangosol.util.InvocableMapHelper
-
Invoke the specified EntryProcessor asynchronously.
- invokeAllAsync(NamedCache<K, V>, Collection<? extends K>, ToIntFunction<K>, InvocableMap.EntryProcessor<K, V, R>, BiConsumer<? super Map<? extends K, ? extends R>, ? super Throwable>...) - Static method in class com.tangosol.util.InvocableMapHelper
-
Invoke the specified EntryProcessor asynchronously.
- invokeAllLocked(ConcurrentMap<K, V>, Set<? extends InvocableMap.Entry<K, V>>, InvocableMap.EntryProcessor<K, V, R>) - Static method in class com.tangosol.util.InvocableMapHelper
-
Invoke the passed EntryProcessor against the entries specified by the
passed map and entries.
- invokeAsync(NamedCache<K, V>, K, InvocableMap.EntryProcessor<K, V, R>) - Static method in class com.tangosol.util.InvocableMapHelper
-
- invokeAsync(NamedCache<K, V>, K, int, InvocableMap.EntryProcessor<K, V, R>, BiConsumer<? super R, ? super Throwable>...) - Static method in class com.tangosol.util.InvocableMapHelper
-
Invoke the specified EntryProcessor asynchronously.
- invokeFound(Object, Object, SegmentedHashMap.Entry[], int, SegmentedHashMap.Entry, SegmentedHashMap.Entry) - Method in class com.tangosol.util.SegmentedConcurrentMap.ConditionalRemoveAction
-
Invoke some action, holding the segment lock, when a matching Entry
is found.
- invokeFound(Object, Object, SegmentedHashMap.Entry[], int, SegmentedHashMap.Entry, SegmentedHashMap.Entry) - Method in class com.tangosol.util.SegmentedConcurrentMap.LockAction
-
Invoke some action, holding the segment lock, when a matching Entry
is found.
- invokeFound(Object, Object, SegmentedHashMap.Entry[], int, SegmentedHashMap.Entry, SegmentedHashMap.Entry) - Method in class com.tangosol.util.SegmentedConcurrentMap.RemoveAction
-
Invoke some action, holding the segment lock, when a matching Entry
is found.
- invokeFound(Object, Object, SegmentedHashMap.Entry[], int, SegmentedHashMap.Entry, SegmentedHashMap.Entry) - Method in class com.tangosol.util.SegmentedConcurrentMap.SizeAction
-
Invoke some action, holding the segment lock, when a matching Entry
is found.
- invokeFound(Object, Object, SegmentedHashMap.Entry[], int, SegmentedHashMap.Entry, SegmentedHashMap.Entry) - Method in class com.tangosol.util.SegmentedConcurrentMap.UnlockAction
-
Invoke some action, holding the segment lock, when a matching Entry
is found.
- invokeFound(Object, Object, SegmentedHashMap.Entry[], int, SegmentedHashMap.Entry, SegmentedHashMap.Entry) - Method in class com.tangosol.util.SegmentedHashMap.ContainsValueAction
-
Invoke some action, holding the segment lock, when a matching Entry
is found.
- invokeFound(Object, Object, SegmentedHashMap.Entry[], int, SegmentedHashMap.Entry, SegmentedHashMap.Entry) - Method in interface com.tangosol.util.SegmentedHashMap.EntryAction
-
Invoke some action, holding the segment lock, when a matching Entry
is found.
- invokeFound(Object, Object, SegmentedHashMap.Entry[], int, SegmentedHashMap.Entry, SegmentedHashMap.Entry) - Method in class com.tangosol.util.SegmentedHashMap.EntryActionAdapter
-
Invoke some action, holding the segment lock, when a matching Entry
is found.
- invokeFound(Object, Object, SegmentedHashMap.Entry[], int, SegmentedHashMap.Entry, SegmentedHashMap.Entry) - Method in class com.tangosol.util.SegmentedHashMap.GetEntryAction
-
Invoke some action, holding the segment lock, when a matching Entry
is found.
- invokeFound(Object, Object, SegmentedHashMap.Entry[], int, SegmentedHashMap.Entry, SegmentedHashMap.Entry) - Method in class com.tangosol.util.SegmentedHashMap.InsertAction
-
Invoke some action, holding the segment lock, when a matching Entry
is found.
- invokeFound(Object, Object, SegmentedHashMap.Entry[], int, SegmentedHashMap.Entry, SegmentedHashMap.Entry) - Method in class com.tangosol.util.SegmentedHashMap.RemoveAction
-
Invoke some action, holding the segment lock, when a matching Entry
is found.
- invokeLocked(ConcurrentMap<K, V>, InvocableMap.Entry<K, V>, InvocableMap.EntryProcessor<K, V, R>) - Static method in class com.tangosol.util.InvocableMapHelper
-
Invoke the passed EntryProcessor against the specified Entry.
- invokeNotFound(Object, Object, SegmentedHashMap.Entry[], int) - Method in class com.tangosol.util.SegmentedConcurrentMap.LockAction
-
Invoke some action, holding the segment lock, when no matching Entry
is found.
- invokeNotFound(Object, Object, SegmentedHashMap.Entry[], int) - Method in class com.tangosol.util.SegmentedConcurrentMap.UnlockAction
-
Invoke some action, holding the segment lock, when no matching Entry
is found.
- invokeNotFound(Object, Object, SegmentedHashMap.Entry[], int) - Method in interface com.tangosol.util.SegmentedHashMap.EntryAction
-
Invoke some action, holding the segment lock, when no matching Entry
is found.
- invokeNotFound(Object, Object, SegmentedHashMap.Entry[], int) - Method in class com.tangosol.util.SegmentedHashMap.EntryActionAdapter
-
Invoke some action, holding the segment lock, when no matching Entry
is found.
- invokeNotFound(Object, Object, SegmentedHashMap.Entry[], int) - Method in class com.tangosol.util.SegmentedHashMap.GetEntryAction
-
Invoke some action, holding the segment lock, when no matching Entry
is found.
- invokeNotFound(Object, Object, SegmentedHashMap.Entry[], int) - Method in class com.tangosol.util.SegmentedHashMap.InsertAction
-
Invoke some action, holding the segment lock, when no matching Entry
is found.
- invokeOnAllKeys(Object, boolean, SegmentedHashMap.IterableEntryAction) - Method in class com.tangosol.util.SegmentedHashMap
-
Perform an action on all Entries in the map.
- invokeOnKey(Object, Object, boolean, SegmentedHashMap.EntryAction) - Method in class com.tangosol.util.SegmentedHashMap
-
Perform an action on the specified key.
- invokeOperation(String, String, Object[], String[]) - Method in class com.tangosol.coherence.dslquery.internal.PersistenceToolsHelper
-
Invoke an operation against a PersistenceManagerMBean associated to the
given service name.
- invokeOperation(MBeanServer, String) - Method in class com.tangosol.net.management.MBeanAccessor.Invoke
-
Invoke the operation on the MBean.
- invokeOperationWithWait(String, String, String) - Method in class com.tangosol.coherence.dslquery.internal.PersistenceToolsHelper
-
Issue an operation and wait for the operation to be complete by
polling the "Idle" attribute of the PersistenceCoordinator for the service.
- invokeStatic(Class, String, Object[]) - Static method in class com.tangosol.util.ClassHelper
-
Invoke the specified static method using the passed arguments.
- IO_EXCEPTIONS_LOG_LEVEL - Static variable in class com.tangosol.net.TcpDatagramSocket
-
Debbuging flag for logging an IO exceptions which occur, set to a negative
to disable the logging.
- isActive() - Method in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder
-
Return true if the persistence mode is active.
- isActive() - Method in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder.PersistenceEnvironmentInfo
-
Return whether the persistence mode is active.
- isActive() - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
- isActive() - Method in class com.tangosol.net.cache.NearCache
-
Specifies whether or not the NamedCache is active.
- isActive() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Determine if the backing map is still active.
- isActive() - Method in class com.tangosol.net.cache.WrapperNamedCache
-
Specifies whether or not the Releasable is active.
- isActive() - Method in interface com.tangosol.net.Releasable
-
Specifies whether or not the Releasable is active.
- isActive() - Method in interface com.tangosol.net.topic.Subscriber
-
- isActive() - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
-
Specifies whether or not the Releasable is active.
- isActiveIterator() - Method in class com.tangosol.util.SafeHashMap
-
Determine if there are any active Iterators, which may mean that they
are in the middle of iterating over the Map.
- isActiveIterator() - Method in class com.tangosol.util.SegmentedHashMap
-
Determine if there are any active Iterators, which may mean that they
are in the middle of iterating over the Map.
- isAddressIncluded() - Method in class com.tangosol.util.UUID
-
This is true if the IP address is a real IP address.
- isAggregation() - Method in class com.tangosol.coherence.dslquery.internal.SelectListMaker
-
Test to see if the results of processing resulted in an aggregation.
- isAllInclusive() - Method in interface com.tangosol.util.Streamer
-
- isAllowAutoAdjust() - Method in class com.tangosol.net.cache.AbstractBundler
-
Check whether or not the auto-adjustment is allowed.
- isAllowed(Service, Action) - Method in interface com.tangosol.net.ActionPolicy
-
Evaluate if the specified action is currently allowed by this policy.
- isAllowed(Service, Action) - Method in class com.tangosol.net.CompositeActionPolicy
-
Evaluate if the specified action is currently allowed by this policy.
- isAllowed(Service, Action) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.ClusterQuorumPolicy
-
Evaluate if the specified action is currently allowed by this policy.
- isAllowed(Service, Action) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy
-
Evaluate if the specified action is currently allowed by this policy.
- isAllowed(Service, Action) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.ProxyQuorumPolicy
-
Evaluate if the specified action is currently allowed by this policy.
- isAllowed(Service, Action) - Method in class com.tangosol.net.partition.FailoverAccessPolicy
-
Evaluate if the specified action is currently allowed by this policy.
- isAllowed(Service, Action) - Method in class com.tangosol.util.NullImplementation.NullActionPolicy
-
Evaluate if the specified action is currently allowed by this policy.
- isAllowInconsistencies() - Method in interface com.tangosol.util.InvocableMap.StreamingAggregator
-
- isAnonymous() - Method in class com.tangosol.coherence.config.scheme.AbstractScheme
-
Determines if the
Scheme
is a defined and thus useful name.
- isAnonymous() - Method in interface com.tangosol.coherence.config.scheme.Scheme
-
Determines if the
Scheme
is a defined and thus useful name.
- isAnonymous() - Method in class com.tangosol.coherence.config.scheme.WrapperCachingScheme
-
- isAnonymous() - Method in class com.tangosol.run.xml.PropertyAdapter
-
Determine if this property does not have a designated element name.
- isAnyLocalAddress(InetAddress) - Static method in class com.tangosol.net.InetAddressHelper
-
- isAssignableFrom(Type, Type) - Static method in class com.tangosol.util.fsm.ReflectionHelper
-
Determines if two types are assignment compatible, that is, the type
of y can be assigned to type x.
- isAssignablePrimitive(Class<?>, Class<?>) - Static method in class com.tangosol.coherence.config.builder.ParameterizedBuilderHelper
-
Determines if a primitive type is assignable to a wrapper type.
- isAssignablePrimitive(Class<?>, Class<?>) - Static method in class com.tangosol.util.fsm.ReflectionHelper
-
Determines if a primitive type is assignable to a wrapper type.
- isAsync() - Method in class com.tangosol.io.AsyncBinaryStore
-
Determine if the AsyncBinaryStore is operating in an asynchronous
manner.
- isAsynchronousPageDeactivation() - Method in class com.tangosol.net.cache.SerializationPagedCache
-
Determine if a daemon should evict the items from a deactivated page to
avoid blocking other work from being done.
- isAtom() - Method in class com.tangosol.coherence.dsltools.termtrees.NodeTerm
-
Answer whether the receiver is an Atomic Term.
- isAtom() - Method in class com.tangosol.coherence.dsltools.termtrees.Term
-
Answer whether the receiver is an Atomic Term.
- isAttribute() - Method in class com.tangosol.run.xml.PropertyAdapter
-
Determine if the property is stored in an XML attribute instead of an
XML element.
- isAttribute() - Method in class com.tangosol.run.xml.SimpleValue
-
Determine if this value is an element attribute.
- isAttribute() - Method in interface com.tangosol.run.xml.XmlValue
-
Determine if this value is an element attribute.
- isAutoAdjust(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.BundleManager.BundleConfig
-
Return true if the auto adjustment of the preferred size value
(based on the run-time statistics) is allowed.
- isAutoStart() - Method in class com.tangosol.coherence.config.scheme.AbstractServiceScheme
-
Return true if the service has auto-start enabled.
- isAutoStart() - Method in interface com.tangosol.coherence.config.scheme.ServiceScheme
-
Return true if the service has auto-start enabled.
- isAutoStart() - Method in class com.tangosol.coherence.config.scheme.WrapperCachingScheme
-
- isAvailable() - Method in class com.tangosol.net.cache.OverflowMap.Status
-
Determine if the Status object is available.
- isAvailable() - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
-
Determine if the Status object is available.
- isBackingMapPersistent(String) - Method in interface com.tangosol.net.BackingMapManager
-
Determine if the contents of the Map that is used by a CacheService to
store cached values for a NamedCache with the specified name should be
persisted.
- isBackingMapPersistent(String, boolean) - Method in interface com.tangosol.net.BackingMapManager
-
Determine if the contents of the Map that is used by a CacheService to
store cached values for a NamedCache with the specified name should be
persisted.
- isBackingMapPersistent(String) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory.Manager
-
Deprecated.
Determine if the contents of the Map that is used by a CacheService to
store cached values for a NamedCache with the specified name should be
persisted.
- isBackingMapPersistent(String) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory.PartitionedBackingMapManager
-
Deprecated.
Determine if the contents of the Map that is used by a CacheService to
store cached values for a NamedCache with the specified name should be
persisted.
- isBackingMapPersistent(String) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.Manager
-
Determine if the contents of the Map that is used by a CacheService to
store cached values for a NamedCache with the specified name should be
persisted.
- isBackingMapPersistent(String) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.PartitionedBackingMapManager
-
Determine if the contents of the Map that is used by a CacheService to
store cached values for a NamedCache with the specified name should be
persisted.
- isBackingMapSlidingExpiry(String) - Method in interface com.tangosol.net.BackingMapManager
-
Determine if the Map that is used by a CacheService to store cached values
for a NamedCache with specified name enables the sliding expiry - the
expiry delay being extended by the read operations.
- isBackingMapSlidingExpiry(String) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory.Manager
-
Deprecated.
Determine if the Map that is used by a CacheService to store cached values
for a NamedCache with specified name enables the sliding expiry - the
expiry delay being extended by the read operations.
- isBackingMapSlidingExpiry(String) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory.PartitionedBackingMapManager
-
Deprecated.
Determine if the Map that is used by a CacheService to store cached values
for a NamedCache with specified name enables the sliding expiry - the
expiry delay being extended by the read operations.
- isBackingMapSlidingExpiry(String) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.Manager
-
Determine if the Map that is used by a CacheService to store cached values
for a NamedCache with specified name enables the sliding expiry - the
expiry delay being extended by the read operations.
- isBackingMapSlidingExpiry(String) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.PartitionedBackingMapManager
-
Determine if the Map that is used by a CacheService to store cached values
for a NamedCache with specified name enables the sliding expiry - the
expiry delay being extended by the read operations.
- isBackup() - Method in class com.tangosol.coherence.config.builder.MapBuilder.Dependencies
-
Return true if the map is a backup map.
- isBackupPartitioned(String) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.Manager
-
Return true if the backup map should be partitioned.
- isBackUpToDate() - Method in class com.tangosol.net.cache.OverflowMap.Status
-
Determine if the entry for which this Status exists has the same
value in the front Map as in the back Map.
- isBackUpToDate() - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
-
Determine if the entry for which this Status exists has the same
value in the front Map as in the back Map.
- isBinary() - Method in class com.tangosol.coherence.config.builder.MapBuilder.Dependencies
-
Return true if the map is binary.
- isBinaryMap() - Method in class com.tangosol.net.cache.SerializationMap
-
Determine if the keys and values in this map are known to be all
Binary.
- isBinaryMap() - Method in class com.tangosol.net.cache.SimpleSerializationMap
-
Determine if the keys and values in this map are known to be all
Binary.
- isBinaryNamedCache(NamedCache) - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
- isBinaryNamedCache() - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
Return
true
if the current back cache is configured to use
Binary
values.
- isBinaryOnly() - Method in class com.tangosol.net.cache.BinaryStoreCacheStore
-
Determine if the keys and values in this CacheStore are known to be all
Binary.
- isBlackList() - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.NameListDependencies
-
- isBlind() - Method in class com.tangosol.coherence.config.builder.MapBuilder.Dependencies
-
Return true if the map is in blind mode.
- isBlindPutAllowed() - Method in class com.tangosol.net.cache.CacheStoreMap.ReadWriteMap
-
Determine if the "blind put" optimization is possible.
- isBlindRemoveAllowed() - Method in class com.tangosol.net.cache.CacheStoreMap.ReadWriteMap
-
Determine if the "blind remove" optimization is possible.
- isBlocking() - Method in class com.tangosol.net.TcpDatagramSocketProvider.DefaultDependencies
-
Check if datagram sockets should be blocking
the use of "blocking" datagram sockets is not meant for production
use and this setting should remain undocumented
- isBlocking() - Method in interface com.tangosol.net.TcpDatagramSocketProvider.Dependencies
-
Check if datagram sockets should be blocking
the use of "blocking" datagram sockets is not meant for production
use and this setting should remain undocumented
- isBound() - Method in class com.tangosol.net.TcpDatagramSocket
- isByMember() - Method in interface com.tangosol.util.InvocableMap.StreamingAggregator
-
- isByPartition() - Method in interface com.tangosol.util.InvocableMap.StreamingAggregator
-
- isByteArrayPrivate() - Method in class com.tangosol.io.AbstractByteArrayReadBuffer
-
Determine if the underlying byte[] should be treated as private data.
- isByteArrayPrivate() - Method in class com.tangosol.io.ByteArrayReadBuffer
-
Determine if the underlying byte[] should be treated as private data.
- isByteArrayPrivate() - Method in class com.tangosol.io.ByteArrayWriteBuffer
-
Determine if the underlying byte[] should be treated as private data.
- isByteArrayPrivate() - Method in class com.tangosol.util.Binary
-
Determine if the underlying byte[] should be treated as private data.
- isCacheActive(String, ClassLoader) - Method in interface com.tangosol.net.ConfigurableCacheFactory
-
Validate whether a cache with the given name is active in the context
of the given
ClassLoader
.
- isCacheActive(String, ClassLoader) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Validate whether a cache with the given name is active in the context
of the given
ClassLoader
.
- isCacheActive(String, ClassLoader) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
-
Validate whether a cache with the given name is active in the context
of the given
ClassLoader
.
- isCacheValues() - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
Determine if this ContinuousQueryCache
caches values locally.
- isCanceled() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.ReadLatch
-
Return true if the load operation has been canceled.
- isCancelled() - Method in class com.tangosol.net.cache.ContinuousQueryCache.ConverterAsynchronousProcessor
-
- isCancelled() - Method in class com.tangosol.util.AsynchronousAgent
-
- isCanonicalKeySupported(Map) - Static method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Determine whether the provided map allows reference access to the keys it holds.
- isCanonicallyEquatable(Object) - Method in class com.tangosol.util.extractor.AbstractExtractor
-
- isChanged() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.Entry
-
Specifies whether or not the underlying value has been changed during
BinaryEntryStore operations.
- isCheckPrimingExclusively(boolean) - Method in class com.tangosol.net.cache.CachingMap
-
Return true if we can rely on the server emitting priming events (based
on receiving a at least one priming event from a storage node).
- isCloneRequired() - Method in class com.tangosol.run.xml.DateTimeAdapter
-
- isCloneRequired() - Method in class com.tangosol.run.xml.IterableAdapter
-
- isCloneRequired() - Method in class com.tangosol.run.xml.PropertyAdapter
-
Determine if the property value must be deep-cloned.
- isCloneRequired() - Method in class com.tangosol.run.xml.RestrictedStringAdapter
-
- isCloneRequired() - Method in class com.tangosol.run.xml.SerializableAdapter
-
- isCloneRequired() - Method in class com.tangosol.run.xml.SimpleAdapter.DateAdapter
-
- isCloneRequired() - Method in class com.tangosol.run.xml.SimpleAdapter
-
- isCloneRequired() - Method in class com.tangosol.run.xml.SimpleAdapter.OldDateAdapter
-
- isCloneRequired() - Method in class com.tangosol.run.xml.SimpleAdapter.TimeAdapter
-
- isCloneRequired() - Method in class com.tangosol.run.xml.SimpleAdapter.TimestampAdapter
-
- isCloneRequired() - Method in class com.tangosol.run.xml.XmlElementAdapter
-
- isCloneRequired() - Method in class com.tangosol.run.xml.XmlSerializableAdapter
-
- isClosed() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCache
-
- isClosed() - Method in class com.tangosol.coherence.jcache.CoherenceBasedCacheManager
-
- isClosed() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
-
Return true if the store has been closed.
- isClosed() - Method in class com.tangosol.util.ThreadGateLite
-
Determine if any thread has closed the gate and continues to hold exclusive access.
- isClosed() - Method in class com.tangosol.util.WrapperReentrantGate
-
Determine if any thread has closed the gate and continues to hold exclusive access.
- isClosedByCurrentThread() - Method in class com.tangosol.util.ThreadGateLite
-
Determine if the calling thread has closed the gate and continues
to hold exclusive access.
- isClosedByCurrentThread() - Method in class com.tangosol.util.WrapperReentrantGate
-
Determine if the calling thread has closed the gate and continues
to hold exclusive access.
- isCoherent() - Method in class com.tangosol.net.cache.CachingMap
-
Determine if changes to the back map affect the front map so that data
in the front map stays in sync.
- isCollectStats() - Method in class com.tangosol.net.partition.ObservableSplittingBackingMap
-
Check whether or not statistics are collected by the wrapper.
- isCollectStats() - Method in class com.tangosol.util.WrapperObservableMap
-
Check whether or not statistics are collected by the wrapper.
- isCommentValid(String) - Static method in class com.tangosol.run.xml.XmlHelper
-
Validate the passed comment.
- isCommitting() - Method in class com.tangosol.net.cache.OverflowMap.Status
-
Determine if the Status object represents an Entry that has been
processed and the results of that processing are being committed.
- isCommitting() - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
-
Determine if the Status object represents an Entry that has been
processed and the results of that processing are being committed.
- isCompacting() - Method in class com.tangosol.io.nio.BinaryMap
-
Determine if the map is incrementally compacting.
- isCompareEntry() - Method in class com.tangosol.util.comparator.EntryComparator
-
Check whether or not this EntryComparator pass entries themselves for
comparison to the underlying
compareEntries()
method.
- isCompareKey() - Method in class com.tangosol.util.comparator.EntryComparator
-
Check whether or not this EntryComparator uses entries' keys to pass
for comparison to the underlying Comparator.
- isCompareValue() - Method in class com.tangosol.util.comparator.EntryComparator
-
Check whether or not this EntryComparator uses entries' values to pass
for comparison to the underlying Comparator.
- isCompatibleMethod(Method, int, Type, Type...) - Static method in class com.tangosol.util.fsm.ReflectionHelper
-
Determines if the signature of a
Method
is compatible with the
specified parameters.
- isComplete() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.ReadLatch
-
Return true if the load operation is complete.
- isComplete(Object) - Method in class com.tangosol.util.SegmentedConcurrentMap.SizeAction
-
Return true iff further key evaluations for the given context are
known to be unnecessary.
- isComplete(Object) - Method in class com.tangosol.util.SegmentedHashMap.ContainsValueAction
-
Return true iff further key evaluations for the given context are
known to be unnecessary.
- isComplete(Object) - Method in class com.tangosol.util.SegmentedHashMap.EntryActionAdapter
-
Return true iff further key evaluations for the given context are
known to be unnecessary.
- isComplete(Object) - Method in interface com.tangosol.util.SegmentedHashMap.IterableEntryAction
-
Return true iff further key evaluations for the given context are
known to be unnecessary.
- isCompletedExceptionally() - Method in class com.tangosol.net.cache.ContinuousQueryCache.ConverterAsynchronousProcessor
-
- isCompletedExceptionally() - Method in class com.tangosol.util.AsynchronousAgent
-
Helper method to check if the operation failed.
- isCompound() - Method in class com.tangosol.coherence.dsltools.base.BaseToken
-
Answer whether this token is a compound token.
- isCompound() - Method in class com.tangosol.coherence.dsltools.base.CompoundBaseToken
-
Answer whether this token is a compound token.
- isCompound() - Method in class com.tangosol.coherence.dsltools.base.LeafBaseToken
-
Answer whether this token is a compound token.
- isCompressable() - Method in class com.tangosol.io.pof.WritingPofHandler
-
Determine if the value encoding can be compressed by combining type and
value information in such a way that type information could be lost.
- isConditional() - Method in class com.tangosol.coherence.dslquery.operator.BaseOperator
-
Return true if this operator can be used as a conditional operator.
- isConfigured() - Method in class com.tangosol.net.SocketOptions
-
Return true iff the XmlSocketOptions have been configured with any options.
- isConnected() - Method in class com.tangosol.run.jca.CacheAdapter
-
Return the connection status.
- isContainerContext(ExtensibleConfigurableCacheFactory) - Static method in class com.tangosol.coherence.jcache.common.ContainerHelper
-
Return true if running in a container environment.
- isContainerContext() - Method in class com.tangosol.coherence.jcache.common.ContainerHelper.JCacheLifecycleInterceptor
-
Added for Coherence JCache functional testing.
- isContended() - Method in class com.tangosol.util.SegmentedConcurrentMap.LockableEntry
-
Is there contention (a thread waiting) to lock this Entry?
- isContent() - Method in class com.tangosol.run.xml.SimpleValue
-
Determine if this value is an element's content.
- isContent() - Method in interface com.tangosol.run.xml.XmlValue
-
Determine if this value is an element's content.
- isContiguous() - Method in class com.tangosol.io.pof.ValidatingPofHandler.Complex
-
Determine if the elements are contiguous.
- isConverted() - Method in class com.tangosol.util.filter.InKeySetFilter
-
Check if the underlying key set has been converted.
- isCurrent() - Method in class com.tangosol.net.cache.SerializationPagedCache.WrapperBinaryStore
-
- isCurrentThread() - Method in class com.tangosol.util.Daemon.DaemonWorker
-
- isDebug() - Static method in class com.tangosol.net.cache.SerializationPagedCache
-
Determine the status of the internal debug flag.
- isDecimal(char) - Static method in class com.tangosol.util.Base
-
Returns true if the passed character is a decimal digit.
- isDecorated(ReadBuffer) - Static method in class com.tangosol.util.ExternalizableHelper
-
If the ReadBuffer is the result of serialization by ExternalizableHelper,
determine if the buffer contains decorations.
- isDecorated(ReadBuffer, int) - Static method in class com.tangosol.util.ExternalizableHelper
-
If the ReadBuffer is the result of serialization by ExternalizableHelper,
determine if the buffer contains the specified decoration.
- isDelegateParallel() - Method in class com.tangosol.util.aggregator.GroupAggregator
-
Return true
if the underlying aggregator is a ParallelAwareAggregator.
- isDelegateStreaming() - Method in class com.tangosol.util.aggregator.GroupAggregator
-
Return true
if the underlying aggregator is a StreamingAggregator.
- isDelete() - Method in class com.tangosol.util.MapEvent
-
Determine whether this event is a delete event.
- isDeleted() - Method in class com.tangosol.util.SafeSortedMap.EntryNode
-
Return true iff this EntryNode has been deleted.
- isDestroyed() - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
- isDestroyed() - Method in class com.tangosol.net.cache.NearCache
-
Specifies whether or not the NamedCache has been destroyed.
- isDestroyed() - Method in class com.tangosol.net.cache.WrapperNamedCache
-
Specifies whether or not the NamedCache has been destroyed.
- isDestroyed() - Method in interface com.tangosol.net.NamedCache
-
Specifies whether or not the NamedCache has been destroyed.
- isDestroyed() - Method in interface com.tangosol.net.topic.NamedTopic
-
Specifies whether or not this NamedTopic has been destroyed.
- isDestroyed() - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
-
Specifies whether or not the NamedCache has been destroyed.
- isDirectQueryEnabled() - Method in class com.tangosol.coherence.rest.config.QueryConfig
-
Return true if direct querying is enabled.
- isDirty() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Return true if this value has been modified,
false otherwise.
- isDirty() - Method in class com.tangosol.util.WrapperConcurrentMap.Lock
-
Checks whether or not this Lock object is held by another thread.
- isDiscardable() - Method in class com.tangosol.net.cache.OverflowMap.Status
-
Determine if this Status object can be discarded.
- isDiscardable() - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
-
Determine if this Status object can be discarded.
- isDiscardable() - Method in class com.tangosol.util.WrapperConcurrentMap.Lock
-
Checks whether or not this Lock object is discardable.
- isDiscarded() - Method in class com.tangosol.net.cache.OldCache.Entry
-
Deprecated.
Determine if this entry has already been discarded from the cache.
- isDisposed() - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
-
- isDisposed() - Method in class com.tangosol.net.SimpleServiceMonitor
-
- isDone() - Method in class com.tangosol.io.AsyncBinaryStore.QueueDaemon
-
Determine if the daemon thread should continue processing or should
shut itself down.
- isDone() - Method in class com.tangosol.net.cache.ContinuousQueryCache.ConverterAsynchronousProcessor
-
- isDone() - Method in class com.tangosol.util.AsynchronousAgent
-
- isDormant() - Method in class com.tangosol.io.AsyncBinaryStore.QueueDaemon
-
Determine whether the daemon is dormant or not.
- isElementMatch(XmlElement) - Method in class com.tangosol.run.xml.PropertyAdapter
-
Check whether or not the passed element matches to the property's local
name and Namespace URI.
- isElementMatch(XmlElement, String, String) - Static method in class com.tangosol.run.xml.XmlHelper
-
Check whether or not an element matches to the specified local name
and Namespace URI.
- isEmpty() - Method in class com.tangosol.coherence.config.builder.SimpleParameterizedBuilderRegistry
-
- isEmpty() - Method in interface com.tangosol.coherence.config.ParameterList
-
- isEmpty() - Method in class com.tangosol.coherence.config.ResolvableParameterList
-
- isEmpty() - Method in class com.tangosol.coherence.config.SimpleParameterList
-
- isEmpty() - Method in class com.tangosol.io.nio.BinaryMap
-
Returns true if this map contains no key-value mappings.
- isEmpty() - Method in class com.tangosol.io.pof.EvolvableHolder
-
Return true
if this holder is empty.
- isEmpty() - Method in interface com.tangosol.net.AsyncNamedCache
-
Returns true if this cache contains no key-value mappings.
- isEmpty() - Method in class com.tangosol.net.cache.CachingMap
- isEmpty() - Method in class com.tangosol.net.cache.OldCache
-
Deprecated.
Returns true if this map contains no key-value mappings.
- isEmpty() - Method in class com.tangosol.net.cache.OverflowMap.InternalKeySet
- isEmpty() - Method in class com.tangosol.net.cache.OverflowMap
-
Returns true if this map contains no key-value mappings.
- isEmpty() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.WriteQueue
-
- isEmpty() - Method in class com.tangosol.net.cache.SerializationCache
-
Returns true if this map contains no key-value mappings.
- isEmpty() - Method in class com.tangosol.net.cache.SimpleOverflowMap
-
Returns true if this map contains no key-value mappings.
- isEmpty() - Method in class com.tangosol.net.cache.SimpleSerializationMap
-
Returns true if this map contains no key-value mappings.
- isEmpty() - Method in class com.tangosol.net.LoadBalancer.Queue
-
Determine if the queue is empty.
- isEmpty() - Method in class com.tangosol.net.partition.PartitionSet
-
Check whether or not the partition set is empty.
- isEmpty() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
-
Returns true if this map contains no key-value mappings.
- isEmpty(Map[]) - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
-
Return true iff a subset of the maps that belong to specified partitions
contains no entries.
- isEmpty() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.MaskedPartitionMap
-
Returns true if this map contains no key-value mappings.
- isEmpty(Object) - Method in class com.tangosol.run.xml.ArrayAdapter
-
Determine if the specified value is empty.
- isEmpty(Object) - Method in class com.tangosol.run.xml.CollectionAdapter
-
Determine if the specified value is empty.
- isEmpty(Object) - Method in class com.tangosol.run.xml.MapAdapter
-
Determine if the specified value is empty.
- isEmpty(Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.BooleanArrayAdapter
-
Determine if the specified value is empty.
- isEmpty(Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.ByteArrayAdapter
-
Determine if the specified value is empty.
- isEmpty(Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.CharArrayAdapter
-
Determine if the specified value is empty.
- isEmpty(Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.DoubleArrayAdapter
-
Determine if the specified value is empty.
- isEmpty(Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.FloatArrayAdapter
-
Determine if the specified value is empty.
- isEmpty(Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.IntArrayAdapter
-
Determine if the specified value is empty.
- isEmpty(Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.LongArrayAdapter
-
Determine if the specified value is empty.
- isEmpty(Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.ShortArrayAdapter
-
Determine if the specified value is empty.
- isEmpty(Object) - Method in class com.tangosol.run.xml.PropertyAdapter
-
Determine if the specified value is empty.
- isEmpty() - Method in class com.tangosol.run.xml.SimpleValue
-
Determine if the value is empty.
- isEmpty(XmlElement) - Static method in class com.tangosol.run.xml.XmlHelper
-
Check whether or not this element or any of its children elements
have any content such as values or attributes.
- isEmpty() - Method in interface com.tangosol.run.xml.XmlValue
-
Determine if the value is empty.
- isEmpty() - Method in class com.tangosol.util.AbstractKeyBasedMap.EntrySet
-
Returns true if this Set is empty.
- isEmpty() - Method in class com.tangosol.util.AbstractKeyBasedMap
-
Returns true if this map contains no key-value mappings.
- isEmpty() - Method in class com.tangosol.util.AbstractKeyBasedMap.KeySet
-
Returns true if this Set is empty.
- isEmpty() - Method in class com.tangosol.util.AbstractKeyBasedMap.ValuesCollection
-
Returns true if this Set is empty.
- isEmpty() - Method in class com.tangosol.util.AbstractKeySetBasedMap
-
Returns true if this map contains no key-value mappings.
- isEmpty() - Method in class com.tangosol.util.AbstractLongArray
-
Test for empty LongArray.
- isEmpty() - Method in class com.tangosol.util.AbstractSafeLongArray
-
- isEmpty() - Method in class com.tangosol.util.ChainedCollection
-
- isEmpty() - Method in class com.tangosol.util.CircularArrayList
- isEmpty() - Method in interface com.tangosol.util.ConcurrentMap
-
Returns true if this map contains no key-value mappings.
- isEmpty() - Method in class com.tangosol.util.ConverterCollections.ConverterCollection
- isEmpty() - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet
- isEmpty() - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray
-
- isEmpty() - Method in class com.tangosol.util.ConverterCollections.ConverterMap
- isEmpty() - Method in class com.tangosol.util.CopyOnWriteMap
- isEmpty() - Method in class com.tangosol.util.Dequeue
-
Determines if the dequeue is empty.
- isEmpty() - Method in class com.tangosol.util.Listeners
-
Check if there are no listeners.
- isEmpty() - Method in class com.tangosol.util.LiteSet
-
Determine if this Set is empty.
- isEmpty() - Method in interface com.tangosol.util.LongArray
-
Test for empty LongArray.
- isEmpty() - Method in class com.tangosol.util.MapListenerSupport
-
Checks whether or not this MapListenerSupport object contains
any listeners.
- isEmpty(Filter) - Method in class com.tangosol.util.MapListenerSupport
-
Checks whether or not this MapListenerSupport object contains
any listeners for a given filter.
- isEmpty(Object) - Method in class com.tangosol.util.MapListenerSupport
-
Checks whether or not this MapListenerSupport object contains
any listeners for a given key.
- isEmpty() - Method in class com.tangosol.util.RestrictedCollections.RestrictedCollection
-
Returns true if this Collection contains no elements.
- isEmpty() - Method in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet
-
Returns true if this Collection contains no elements.
- isEmpty() - Method in class com.tangosol.util.RestrictedCollections.RestrictedMap
-
Returns true if this map contains no key-value mappings.
- isEmpty() - Method in class com.tangosol.util.SafeHashMap
-
Returns true if this map contains no key-value mappings.
- isEmpty() - Method in class com.tangosol.util.SegmentedConcurrentMap
-
Returns true if this map contains no key-value mappings.
- isEmpty() - Method in class com.tangosol.util.SegmentedHashMap
-
Returns true if this map contains no key-value mappings.
- isEmpty() - Method in class com.tangosol.util.SetMap
-
- isEmpty() - Method in class com.tangosol.util.SimpleLongArray
-
Test for empty LongArray.
- isEmpty() - Method in class com.tangosol.util.SimpleResourceRegistry
-
Determine if the
ResourceRegistry
is empty (contains no resource registrations).
- isEmpty() - Method in class com.tangosol.util.SortedBag
- isEmpty() - Method in class com.tangosol.util.StringTable
-
Test for empty table.
- isEmpty() - Method in class com.tangosol.util.SubList
- isEmpty() - Method in class com.tangosol.util.SubSet
- isEmpty() - Method in class com.tangosol.util.Tree
-
Test for empty tree.
- isEmpty() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperCollection
- isEmpty() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
-
- isEmpty() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperMap
- isEmpty() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperCollection
- isEmpty() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- isEmptyElement(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.AbstractEmptyElementProcessor
-
- isEmptyIsNull() - Method in class com.tangosol.run.xml.IterableAdapter
-
- isEncodingValid(String) - Static method in class com.tangosol.run.xml.XmlHelper
-
Validate the passed encoding.
- isEnd() - Method in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
-
Test whether the receiver has reached the end of the underlying Reader
- isEnd() - Method in class com.tangosol.coherence.dsltools.base.BaseTokenStream
-
Answer a boolean indication as to whether the stream is at the end
- isEnd() - Method in class com.tangosol.coherence.dsltools.precedence.OPScanner
-
If the Scanner is at the end answer true otherwise answer false.
- isEndOfStatement() - Method in class com.tangosol.coherence.dsltools.precedence.OPScanner
-
If the scanner is at the end of a statement return true.
- isEnteredByCurrentThread() - Method in class com.tangosol.util.ThreadGateLite
-
Determines if the current thread has entered the gate and not yet exited.
- isEnteredByCurrentThread() - Method in class com.tangosol.util.WrapperReentrantGate
-
Determines if the current thread has entered the gate and not yet exited.
- isEntry() - Method in class com.tangosol.io.nio.BinaryMap.Block
-
Determine if the Block is marked as an Entry.
- isEntryExistent() - Method in class com.tangosol.net.cache.OverflowMap.Status
-
Determine if the entry for which this Status exists is present in
the front map or the back map.
- isEntryInBack() - Method in class com.tangosol.net.cache.OverflowMap.Status
-
Determine if the entry for which this Status exists is present in
the back map.
- isEntryInFront() - Method in class com.tangosol.net.cache.OverflowMap.Status
-
Determine if the entry for which this Status exists is present in
the front map.
- isEntryInFront() - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
-
Determine if the entry for which this Status exists is present in
the front map.
- isEphemeral() - Method in class com.tangosol.coherence.config.builder.WrapperSocketAddressProviderBuilder
-
Return the flag indicating that the addresses should be ephemeral.
- isEqual(Object) - Static method in interface com.tangosol.util.function.Remote.Predicate
-
- isEraseAllSupported() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
Determine if the wrapped store supports eraseAll() operations.
- isEraseSupported() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
Determine if the wrapped store supports erase() operations.
- isEraseUnsupported() - Method in class com.tangosol.net.cache.CacheStoreMap.ReadWriteMap
-
Determine if the CacheStore has been determined to be read-only for
erase() operations.
- isError() - Method in class com.tangosol.run.xml.SaxParser.ValidationHandler
-
Returns boolean indicating if an error has occurred.
- isEventDeferred(Object) - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
Called when an event has occurred.
- isEventFabricator() - Method in class com.tangosol.net.partition.ObservableSplittingBackingMap
-
Determine if this ObservableMap has to fabricate events itself.
- isEventFabricator() - Method in class com.tangosol.util.WrapperObservableMap
-
Determine if this ObservableMap has to fabricate events itself.
- isEvictable(ConfigurableCacheMap.Entry) - Method in interface com.tangosol.net.cache.ConfigurableCacheMap.EvictionApprover
-
Get an eviction approval for the specified entry.
- isEvictable() - Method in class com.tangosol.net.cache.OldCache.Entry
-
Deprecated.
Determine if this entry has been marked as being evictable.
- isEvolvable() - Method in class com.tangosol.io.pof.PofBufferWriter
-
Determine if the object to be written is either Evolvable or part of an
Evolvable object.
- isEvolvable() - Method in class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
-
Determine if the object to be written is either Evolvable or part of an
Evolvable object.
- isException() - Method in class com.tangosol.net.cache.AbstractBundler.Bundle
-
Check whether or not this bundle is in the "exception" state -
bundled execution threw an exception and requests have to be
un-bundled.
- isExclusive() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
-
Return true if this store is in exclusive mode.
- isExitWhenProcessingComplete() - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
-
- isExitWhenProcessingComplete() - Method in interface com.tangosol.coherence.dslquery.QueryPlus.Dependencies
-
Return whether the QueryPlus session should exit once all of the statements
added to the statements list have been executed.
- isExpired() - Method in class com.tangosol.net.cache.OldCache.Entry
-
Deprecated.
Determine if the cache entry has expired.
- isExpired() - Method in class com.tangosol.net.cache.OverflowMap.ExpirableStatus
-
Determine if this Status represents an entry that will
automatically expire.
- isExpired() - Method in class com.tangosol.net.cache.OverflowMap.Status
-
Determine if this Status represents an entry that will
automatically expire.
- isExpiredAt(long) - Method in class com.tangosol.coherence.jcache.common.JCacheEntryMetaInf
-
Determines if the Cache Entry associated with this value would be expired
at the specified time
- isExpiredAt(long) - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheValue
-
Determines if the Cache Entry associated with this value would be expired
at the specified time
- isExpiryEnabled(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.OverflowScheme
-
Return the expiry enabled flag.
- isExpiryEnabled() - Method in class com.tangosol.net.cache.OverflowMap
-
Determine if this OverflowMap supports entry expiry.
- isExtendedLanguageEnabled() - Method in class com.tangosol.coherence.dslquery.ExecutionContext
-
Return whether "Extended Language" features are enabled.
- isExtendedLanguageEnabled() - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
-
- isExtendedLanguageEnabled() - Method in interface com.tangosol.coherence.dslquery.QueryPlus.Dependencies
-
Return whether "Extended Language" features are enabled.
- isFederateApplySynthetic(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.BackingMapScheme
-
Return true iff received federated changes should be applied locally as synthetic updates.
- isFederated() - Method in class com.tangosol.coherence.config.CacheMapping
-
Check if this CacheMapping is federated.
- isFinishing() - Method in class com.tangosol.util.TaskDaemon
-
Determine if the daemon will finish those scheduled tasks that are
ripe (presently due to be run) before stopping.
- isFirst() - Method in class com.tangosol.coherence.config.builder.NamedEventInterceptorBuilder
-
- isFlowControlEnabled() - Method in interface com.tangosol.net.ClusterDependencies
-
Determine whether the TCMP flow control is enabled.
- isFlushed() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.WriteQueue
-
Return true iff all contents have been persisted to the underlying store.
- isForeignNamespace(XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.InstanceProcessor
-
Return true if the given element meets the following criteria:
there is a single sub element
the namespace of the sub element is not in the Coherence namespace
- isForName(String) - Method in class com.tangosol.coherence.config.RegExCacheMapping
-
- isForName(String) - Method in class com.tangosol.coherence.config.ResourceMapping
-
Determines if the
ResourceMapping
is for (matches) the specified resource name.
- isForwardIndexSupported() - Method in class com.tangosol.util.SimpleMapIndex
-
Determine whether or not this SimpleMapIndex supports a forward index.
- isFound(Object) - Method in class com.tangosol.util.SegmentedHashMap.ContainsValueAction
-
Return true iff the value was found
- isFree() - Method in class com.tangosol.io.nio.BinaryMap.Block
-
Determine if the Block is marked as free.
- isFrontPutBlind() - Method in class com.tangosol.net.cache.OverflowMap
-
Determine if the front Map is more efficiently updated using putAll.
- isFrontPutBlind() - Method in class com.tangosol.net.cache.SimpleOverflowMap
-
Determine if the front Map is more efficiently updated using putAll.
- isFull() - Method in class com.tangosol.net.partition.PartitionSet
-
Check whether or not the partition set is full.
- isFull() - Method in class com.tangosol.util.Dequeue
-
Determines if the dequeue is full.
- isGenerated() - Method in class com.tangosol.util.UUID
-
This is true if the UUID was generated, and false if it was built.
- isGlobalPartitioningSchemePID(int) - Static method in class com.tangosol.persistence.CachePersistenceHelper
-
Return true iff the specified partition-id is to be used to persist
(meta-)data that is logically "global".
- isGuarded() - Method in class com.tangosol.util.Daemon
-
Return true iff this Daemon's execution is guarded.
- isHeadHeavy() - Method in class com.tangosol.util.SafeSortedMap.Split
-
Return true if the estimated weight of the head of the split is
larger than the tail.
- isHex(char) - Static method in class com.tangosol.util.Base
-
Returns true if the passed character is a hexadecimal digit.
- isIdentifier() - Method in class com.tangosol.coherence.dsltools.base.BaseToken
-
Answer whether this token represents an identifier.
- isIdentifier() - Method in class com.tangosol.coherence.dsltools.base.IdentifierBaseToken
-
Answer whether this token represents an identifier.
- isIdle() - Method in interface com.tangosol.persistence.PersistenceManagerMBean
-
Specifies whether or not the persistence coordinator is idle.
- isIgnoreCase() - Method in class com.tangosol.util.filter.LikeFilter
-
Check whether or not the filter is case incensitive.
- isIgnored(Object) - Method in class com.tangosol.net.cache.LocalCache.KeyMask
-
Check if a key should be ignored.
- isIgnoringCase() - Method in class com.tangosol.coherence.dsltools.precedence.TokenTable
-
Answer wheather the receiver is ignoringCase
- isIncrementalEviction() - Method in class com.tangosol.net.cache.OldCache
-
Deprecated.
Determine if incremental eviction is enabled.
- isInitialDistribution(Member) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
Check if the distribution is in the initial state, when the coordinator
owns all the partitions and there are no backups.
- isInitialized() - Method in class com.tangosol.io.pof.ConfigurablePofContext
-
Determine if the ConfigurablePofContext has completed its
initialization.
- isInnerClass(Class) - Static method in class com.tangosol.net.cache.SimpleMemoryCalculator
-
Return true if a given class is an inner class.
- isInsert() - Method in class com.tangosol.util.MapEvent
-
Determine whether this event is an insert event.
- isInstanceConfigEmpty(XmlElement) - Static method in class com.tangosol.run.xml.XmlHelper
-
Check whether or not the specified configuration defines an instance of a
class.
- isInstanceOf(Object, String) - Static method in class com.tangosol.util.ClassHelper
-
Determine if the passed object is an instance of the specified class.
- isInstanceOf(Object, Class) - Static method in class com.tangosol.util.ClassHelper
-
Determine if the passed object is an instance of the specified class.
- isIntDecorated(ReadBuffer) - Static method in class com.tangosol.util.ExternalizableHelper
-
- isIntDecorated(ByteSequence) - Static method in class com.tangosol.util.ExternalizableHelper
-
Check whether or not the specified ByteSequence is a representation of an
IntDecoratedObject.
- isInterfaceAllowed() - Method in class com.tangosol.io.pof.ConfigurablePofContext
-
Determine if the ConfigurablePofContext supports the configuration of
user types by specifying an interface (instead of a class) for the
Java type.
- isInternal() - Method in class com.tangosol.coherence.config.ResourceMapping
-
Check if this ResourceMapping is for internal resources.
- isInternalKeySetIteratorMutable() - Method in class com.tangosol.net.cache.OverflowMap
-
Determine if this Iterator should remove an iterated item by calling
remove on the internal key Set Iterator, or by calling removeBlind on
the map itself.
- isInternalKeySetIteratorMutable() - Method in class com.tangosol.util.AbstractKeySetBasedMap
-
Determine if this Iterator should remove an iterated item by calling
remove on the internal key Set Iterator, or by calling removeBlind on
the map itself.
- isInternalKeySetIteratorMutable() - Method in class com.tangosol.util.WrapperConcurrentMap
-
Determine if this Iterator should remove an iterated item by calling
remove on the internal key Set Iterator, or by calling removeBlind on
the map itself.
- isInternalKeySetIteratorMutable() - Method in class com.tangosol.util.WrapperObservableMap
-
Determine if this Iterator should remove an iterated item by calling
remove on the internal key Set Iterator, or by calling removeBlind on
the map itself.
- isInternalValueDecorated(Object, int) - Method in interface com.tangosol.net.BackingMapManagerContext
-
Check whether or not the specified value in the internal form is decorated.
- isInternalValueDecorated(Object, int) - Method in class com.tangosol.util.NullImplementation.NullBackingMapManagerContext
-
Check whether or not the specified value in the internal form is decorated.
- isIntrinsicPofType(Class) - Static method in class com.tangosol.io.pof.PofHelper
-
Determine if the given class can be represented as an intrinsic POF
type.
- isIpMonitorEnabled() - Method in interface com.tangosol.net.ClusterDependencies
-
Determine whether the IpMonitor is enabled.
- isJCacheSynthetic(CacheEvent) - Method in class com.tangosol.coherence.jcache.common.NonSyntheticEntryFilter
-
- isJCacheSynthetic(CacheEvent) - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheAsynchronousMapListener.NonSyntheticEntryFilter
-
- isJCacheSynthetic(CacheEvent) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheAsynchronousMapListener.NonSyntheticEntryFilter
-
- isKeyComparator() - Method in class com.tangosol.util.comparator.ChainedComparator
-
Specifies whether this comparator expects to compare keys or values.
- isKeyComparator() - Method in interface com.tangosol.util.comparator.EntryAwareComparator
-
Specifies whether this comparator expects to compare keys or values.
- isKeyComparator() - Method in class com.tangosol.util.comparator.SafeComparator
-
Specifies whether this comparator expects to compare keys or values.
- isKeyComparator(Comparator) - Static method in class com.tangosol.util.comparator.SafeComparator
-
Check whether the specified comparator expects to compare keys or values.
- isKeyConverted() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent
-
Check if the event's key has been converted.
- isKeyExcluded(Object) - Method in class com.tangosol.util.SimpleMapIndex
-
Check if the entry with the given key is excluded from the index.
- isKeyOwned(Object) - Method in interface com.tangosol.net.BackingMapManagerContext
-
Determines whether or not the specified key (in the internal format)
is managed (i.e. controlled) by this service member.
- isKeyOwned(Object) - Method in class com.tangosol.util.NullImplementation.NullBackingMapManagerContext
-
Determines whether or not the specified key (in the internal format)
is managed (i.e. controlled) by this service member.
- isLambdaAllowed() - Method in class com.tangosol.io.pof.ConfigurablePofContext
-
Determine if implicit root lambda class processing is allowed.
- isLeaf() - Method in class com.tangosol.coherence.dsltools.base.BaseToken
-
Answer whether this token is a leaf token.
- isLeaf() - Method in class com.tangosol.coherence.dsltools.base.CompoundBaseToken
-
Answer whether this token is a leaf token.
- isLeaf() - Method in class com.tangosol.coherence.dsltools.base.LeafBaseToken
-
Answer whether this token is a leaf token.
- isLeaf() - Method in class com.tangosol.coherence.dsltools.termtrees.NodeTerm
-
Answer whether the receiver has children.
- isLeaf() - Method in class com.tangosol.coherence.dsltools.termtrees.Term
-
Answer whether the receiver has children.
- isLeaf() - Method in class com.tangosol.util.AbstractSparseArray.Node
-
Determine if this node is a part of a 2-3-4 leaf node
(i.e. at least one null child).
- isLinked() - Method in class com.tangosol.util.AbstractSparseArray.Node
-
Return true iff the node is linked to other nodes.
- isLinkLocalAddress(InetAddress) - Static method in class com.tangosol.net.InetAddressHelper
-
- isLiteral() - Method in class com.tangosol.coherence.dsltools.base.BaseToken
-
Answer whether this token represents a literal.
- isLiteral() - Method in class com.tangosol.coherence.dsltools.base.LiteralBaseToken
-
Answer whether this token represents a literal.
- isLoaded() - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheValue
-
Determine if last update to this LocalValue was a load from an external resource.
- isLocal() - Method in class com.tangosol.net.MemberEvent
-
Check whether a Member object for this event represents the local
member of the cluster.
- isLocalMember(Member) - Method in class com.tangosol.net.AbstractServiceLoadBalancer
-
Check whether the specified Member object represents the local member
of the cluster.
- isLocalPortAutoAdjust() - Method in interface com.tangosol.net.ClusterDependencies
-
Determine whether the unicast listener local port(s) will be automatically
selected if the specified port cannot be bound to (e.g. it is already in use.)
- isLocalStorageEnabled() - Method in interface com.tangosol.net.DistributedCacheService
-
Determine if local storage is enabled on this member.
- isLocked() - Method in class com.tangosol.util.SegmentedConcurrentMap.LockableEntry
-
Is this entry Locked?
- isLockingEnforced() - Method in class com.tangosol.util.WrapperConcurrentMap
-
Obtain the flag indicating whether or not the locking is enforced for
put, remove and clear operations.
- isLogEcho() - Static method in class com.tangosol.util.Base
-
Determine if the log is echoed to the console.
- isLogEnabled(int) - Static method in class com.tangosol.net.CacheFactory
-
Check if a message of the specified severity level will be logged using
the Coherence logging facility.
- isLoopbackAddress(InetAddress) - Static method in class com.tangosol.net.InetAddressHelper
-
- isLowerBoundInclusive() - Method in class com.tangosol.util.filter.BetweenFilter
-
Obtain the flag indicating whether values matching the lower bound
of the range evaluate to true.
- isManagementEnabled() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
-
- isManagementEnabled() - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheMXBean
-
- isManagingTimeout() - Method in interface com.tangosol.coherence.dslquery.Statement
-
Obtain a flag indicating whether this Statement will manage its own
timeout handling.
- isManagingTimeout() - Method in class com.tangosol.coherence.dslquery.statement.SourceStatementBuilder.SourceStatement
-
- isManagingTransientVersion() - Method in class com.tangosol.net.cache.VersionedBackingMap
-
Deprecated.
Determine if this backing map is responsible for keeping the transient
version cache in sync.
- isMaster() - Method in class com.tangosol.net.cache.AbstractBundler.Bundle
-
Check whether or not this is a "master" Bundle.
- isMatch(String, String) - Static method in class com.tangosol.coherence.rest.util.PartialObject
-
Determine if a method represents a property.
- isMatch(String) - Method in class com.tangosol.util.filter.LikeFilter
-
Check the passed String value to see if it matches the pattern that
this filter was constructed with.
- isMatching(QueryRecord.PartialResult) - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult
-
Determine whether or not the given result is capable of being
placed in one-to-one correspondence with this result.
- isMatching(QueryRecord.PartialResult.Step) - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.Step
-
Determine whether or not the given step is capable of being
placed in one-to-one correspondence with this step.
- isMBeanRegistered(String) - Method in interface com.tangosol.net.management.MBeanServerProxy
-
Check whether or not an MBean with the specified name is already registered.
- isMBeanRegistered(String) - Method in class com.tangosol.net.management.WrapperMBeanServerProxy
-
- isMemberLeaving(Member) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
Return true iff the specified member is in the process of leaving.
- isMemorySize() - Method in class com.tangosol.coherence.config.unit.Units
-
Return true if Units contains a MemorySize
.
- isMetadataCompatible(Properties) - Method in class com.tangosol.persistence.AbstractPersistenceManager
-
Determine if the given metadata is compatible with this manager.
- isMetadataCompatible(Properties, int, String, int) - Static method in class com.tangosol.persistence.CachePersistenceHelper
-
Determine if the given metadata in the
Properties
is compatible
with the metadata supplied.
- isMetadataComplete(Properties) - Method in class com.tangosol.persistence.AbstractPersistenceManager
-
Determine if the given metadata in the
Properties
is complete.
- isMetadataComplete(Properties) - Static method in class com.tangosol.persistence.CachePersistenceHelper
-
Determine if the given metadata in the
Properties
is complete.
- isMethodExtractor() - Method in class com.tangosol.util.extractor.UniversalExtractor
-
Return true if this a method extractor.
- isMethodUpdater() - Method in class com.tangosol.util.extractor.UniversalUpdater
-
Return true iff this updater references a setter method.
- isModified() - Method in class com.tangosol.util.DeltaSet
-
Determine if any items were added or removed.
- isModified() - Method in class com.tangosol.util.SubSet
-
Determine if the set has been modified.
- isMonitoring() - Method in interface com.tangosol.net.ServiceMonitor
-
Returns true iff the ServiceMonitor is monitoring a number of
services.
- isMonitoring() - Method in class com.tangosol.net.SimpleServiceMonitor
-
Returns true iff the ServiceMonitor is monitoring a number of
services.
- isMonitorStopped() - Method in class com.tangosol.net.DefaultCacheServer
-
- isMutable() - Method in class com.tangosol.run.xml.SimpleValue
-
Determine if this value can be modified.
- isMutable() - Method in class com.tangosol.run.xml.XmlBean
-
Determine if this value can be modified.
- isMutable() - Method in interface com.tangosol.run.xml.XmlValue
-
Determine if this value can be modified.
- isMutator() - Method in class com.tangosol.util.processor.MethodInvocationProcessor
-
Returns a boolean specifying whether the method mutates the state of a target object.
- isNameMatch(XmlElement, String, String, String) - Static method in class com.tangosol.run.xml.XmlHelper
-
Check whether or not a universal (composite) name matches to the specified
local name and Namespace URI.
- isNameMutable() - Method in class com.tangosol.run.xml.SimpleElement
-
Determine if the name can be changed.
- isNameValid(String) - Static method in class com.tangosol.run.xml.XmlHelper
-
Validate the passed name.
- isNest() - Method in class com.tangosol.coherence.dsltools.base.BaseToken
-
Answer whether this token represents a nested collection of tokens.
- isNest(char) - Method in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
-
Test if the given char is a character that starts nesting/
- isNest() - Method in class com.tangosol.coherence.dsltools.base.NestedBaseTokens
-
Answer whether this token represents a nested collection of tokens.
- isNested() - Method in class com.tangosol.run.xml.IterableAdapter
-
- isNewValueConverted() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent
-
Check if the event's new value has been converted.
- isNotNull(ValueExtractor<T, E>) - Static method in class com.tangosol.util.Filters
-
Return a filter that evaluates to true for non-null values.
- IsNotNullFilter<T,E> - Class in com.tangosol.util.filter
-
Filter which tests the result of a method invocation for inequality to null.
- IsNotNullFilter() - Constructor for class com.tangosol.util.filter.IsNotNullFilter
-
Default constructor (necessary for the ExternalizableLite interface).
- IsNotNullFilter(ValueExtractor<? super T, ? extends E>) - Constructor for class com.tangosol.util.filter.IsNotNullFilter
-
Construct a IsNotNullFilter for testing inequality to null.
- IsNotNullFilter(String) - Constructor for class com.tangosol.util.filter.IsNotNullFilter
-
Construct a IsNotNullFilter for testing inequality to null.
- isNull(ValueExtractor<T, E>) - Static method in class com.tangosol.util.Filters
-
Return a filter that evaluates to true for null values.
- IsNullFilter<T,E> - Class in com.tangosol.util.filter
-
Filter which compares the result of a method invocation with null.
- IsNullFilter() - Constructor for class com.tangosol.util.filter.IsNullFilter
-
Default constructor (necessary for the ExternalizableLite interface).
- IsNullFilter(ValueExtractor<? super T, ? extends E>) - Constructor for class com.tangosol.util.filter.IsNullFilter
-
Construct a IsNullFilter for testing equality to null.
- IsNullFilter(String) - Constructor for class com.tangosol.util.filter.IsNullFilter
-
Construct a IsNullFilter for testing equality to null.
- isNullFirst() - Method in class com.tangosol.util.comparator.SafeComparator
-
Obtain the m_fNullFirst flag.
- isNullValuesAllowed() - Method in class com.tangosol.net.cache.OverflowMap
-
Determine if null values are permitted.
- isNullValuesAllowed() - Method in class com.tangosol.net.cache.SimpleOverflowMap
-
Determine if null values are permitted.
- isNumber() - Method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
-
Answer whether the receiver is an Atomic Term representing a Number.
- isNumber() - Method in class com.tangosol.coherence.dsltools.termtrees.Term
-
Answer whether the receiver is an Atomic Term representing a Number.
- isObserved() - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
Determine if the ContinuousQueryCache
has any listeners that cannot be
served by this Map listening to lite events.
- isOctal(char) - Static method in class com.tangosol.util.Base
-
Returns true if the passed character is an octal digit.
- isOldValueAvailable() - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheEntryEvent
-
- isOldValueAvailable() - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCacheEntryEvent
-
- isOldValueConverted() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent
-
Check if the event's old value has been converted.
- isOnWorkerThread() - Method in class com.tangosol.util.Daemon
-
Indicate if the current execution thread is a child of this daemon.
- isOpen() - Method in class com.tangosol.net.cache.AbstractBundler.Bundle
-
Check whether or not this bundle is open for adding request elements.
- isOperator() - Method in class com.tangosol.coherence.dsltools.base.BaseToken
-
Answer whether this token represents a know operator.
- isOperator() - Method in class com.tangosol.coherence.dsltools.base.OperatorBaseToken
-
Answer whether this token represents a know operator.
- isOptimizeMV() - Method in class com.tangosol.util.SimpleMapIndex
-
Specifies whether an attempt will be made to search the forward map
for an existing reference that is "equal" to the specified mutli-value
and use it instead (if available) to reduce the index memory footprint.
- isOrdered() - Method in class com.tangosol.util.ForwardOnlyMapIndex
-
Determine if the MapIndex orders the contents of the indexed
information.
- isOrdered() - Method in interface com.tangosol.util.MapIndex
-
Determine if the MapIndex orders the contents of the indexed
information.
- isOrdered() - Method in interface com.tangosol.util.QueryRecord.PartialResult.IndexLookupRecord
-
Indicates whether or not the associated index is ordered.
- isOrdered() - Method in class com.tangosol.util.SimpleMapIndex
-
Determine if the MapIndex orders the contents of the indexed
information.
- isOrdered() - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.IndexLookupRecord
-
Indicates whether or not the associated index is ordered.
- isOriginalPresent() - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
-
Determine whether or not the Entry existed before the start of the
mutating operation that is being evaluated by the trigger.
- isOriginalPresent() - Method in class com.tangosol.util.InvocableMapHelper.RoutingMapTriggerEntry
-
- isOriginalPresent() - Method in interface com.tangosol.util.MapTrigger.Entry
-
Determine whether or not the Entry existed before the start of the
mutating operation that is being evaluated by the trigger.
- isOriginalPresent() - Method in class com.tangosol.util.SimpleMapEntry
-
Determine whether or not the Entry existed before the start of the
mutating operation that is being evaluated by the trigger.
- isOwnedByCaller() - Method in class com.tangosol.util.WrapperConcurrentMap.Lock
-
Checks whether or not this Lock object is held by the calling thread.
- isOwnedByCurrentThread() - Method in class com.tangosol.net.cache.OverflowMap.Status
-
Determine if the current thread owns this Status object.
- isOwnedByCurrentThread() - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
-
Determine if the current thread owns this Status object.
- isPageActive(int) - Method in class com.tangosol.net.cache.SerializationPagedCache.PagedBinaryStore
-
Determine if the specified page number is active.
- isParallel() - Method in interface com.tangosol.util.InvocableMap.StreamingAggregator
-
- isParallel() - Method in interface com.tangosol.util.stream.RemotePipeline
-
Return whether this pipeline should be executed in parallel.
- isPartial() - Method in class com.tangosol.coherence.rest.util.PropertySpec
-
Return whether this is a partial property or not.
- isPartial() - Method in class com.tangosol.util.ConditionalIndex
-
Determine if indexed information for any entry in the indexed Map has
been excluded from this index.
- isPartial() - Method in class com.tangosol.util.ForwardOnlyMapIndex
-
Determine if indexed information for any entry in the indexed Map has
been excluded from this index.
- isPartial() - Method in interface com.tangosol.util.MapIndex
-
Determine if indexed information for any entry in the indexed Map has
been excluded from this index.
- isPartial() - Method in class com.tangosol.util.SimpleMapIndex
-
Determine if indexed information for any entry in the indexed Map has
been excluded from this index.
- isPartialNameLegal(String) - Static method in class com.tangosol.util.ClassHelper
-
Determine if a partial name (for example, a prefix, class
name, package name, etc. as accepted by the above methods)
is legal.
- isPartitioned(ParameterResolver, boolean) - Method in class com.tangosol.coherence.config.scheme.BackingMapScheme
-
Return true if the partitioned flag is set explicitly or a journal
map is used.
- isPartitionEndangered(int) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
Return true iff the specified partition is "endangered".
- isPartitionEndangered(Ownership) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
Return true iff the specified ownership is "endangered".
- isPartitionStrong(int) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
Return true iff the ownership of the specified partition is "strong",
as defined by the current BackupStrength.
- isPartitionStrong(Ownership) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
Return true iff the specified ownership is "strong", as defined by the
current BackupStrength.
- isPassivePagedBackup() - Method in class com.tangosol.net.cache.SerializationPagedCache
-
Determine if this is just a passive backup for a paged cache.
- isPending() - Method in class com.tangosol.net.cache.AbstractBundler.Bundle
-
Check whether or not this bundle is in the "pending" state - awaiting
for the execution results.
- isPending() - Method in class com.tangosol.net.ConfigurableAddressProvider.AddressHolder
-
Check whether or not the underlying address has been accepted.
- isPreferJavaTime() - Method in class com.tangosol.io.pof.ConfigurablePofContext
-
Return
true
if
PofReader.readObject(int)
method should
return the appropriate Java 8 date/time type, or
false
if a legacy
date/time types should be returned in order to preserve backwards
compatibility.
- isPreferJavaTime() - Method in interface com.tangosol.io.pof.PofContext
-
Return
true
if
PofReader.readObject(int)
method should
return the appropriate Java 8 date/time type, or
false
if a legacy
date/time types should be returned in order to preserve backwards
compatibility.
- isPreferJavaTime() - Method in class com.tangosol.io.pof.SimplePofContext
-
Return
true
if
PofReader.readObject(int)
method should
return the appropriate Java 8 date/time type, or
false
if a legacy
date/time types should be returned in order to preserve backwards
compatibility.
- isPrefixAllowed() - Method in class com.tangosol.coherence.dsltools.precedence.InfixOPToken
-
Get the flag that control whether the operator can be used as a prefix.
- isPreLoad(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.LocalScheme
-
Return true if a cache pre-loads data from its CacheLoader.
- isPresent() - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
-
Determine if this Entry exists in the Map.
- isPresent() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventBinaryEntry
-
Determine if this Entry exists in the Map.
- isPresent() - Method in interface com.tangosol.util.InvocableMap.Entry
-
Determine if this Entry exists in the Map.
- isPresent() - Method in class com.tangosol.util.InvocableMapHelper.RoutingMapTriggerEntry
-
- isPresent() - Method in class com.tangosol.util.InvocableMapHelper.SimpleEntry
-
Determine if this Entry exists in the Map.
- isPresent() - Method in class com.tangosol.util.SimpleHolder
-
Return true if the contained value is present, false otherwise.
- isPresent() - Method in class com.tangosol.util.SimpleMapEntry
-
Determine if this Entry exists in the Map.
- isPresentOnly() - Method in interface com.tangosol.util.InvocableMap.StreamingAggregator
-
- isPrimary() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.LoadComparator
-
Return true iff the comparator should use the primary load.
- isPrimary() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.UnderloadedFilter
-
Return true iff this Filter compares the primary partition load.
- isPriming() - Method in class com.tangosol.net.cache.CacheEvent
-
Return true iff this event is caused by a priming listener registration.
- isPriming(MapEvent) - Method in class com.tangosol.net.cache.CachingMap
-
Check if the specified event is a "priming" one.
- isPrimingListener(MapListener) - Static method in class com.tangosol.util.MapListenerSupport
-
Check if the given listener is a PrimingListener or if it wraps one.
- isProcessed() - Method in class com.tangosol.net.cache.AbstractBundler.Bundle
-
Check whether or not this bundle is in the "processed" state -
ready to return the result of execution back to the client.
- isProcessing() - Method in class com.tangosol.net.cache.OverflowMap.Status
-
Determine if the Status object represents an Entry that is
currently being processed.
- isProcessing() - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
-
Determine if the Status object represents an Entry that is
currently being processed.
- isPropertyDefined(String, XmlElement) - Method in class com.tangosol.config.xml.DefaultProcessingContext
-
Determines if the specified property is defined at the path relative to the specified
XmlElement
.
- isPropertyDefined(String, XmlElement) - Method in interface com.tangosol.config.xml.ProcessingContext
-
Determines if the specified property is defined at the path relative to the specified
XmlElement
.
- isPropertyExtractor() - Method in class com.tangosol.util.extractor.UniversalExtractor
-
Return true if this is a Property extractor.
- isPublicIdentifierValid(String) - Static method in class com.tangosol.run.xml.XmlHelper
-
Validate the passed public identifier.
- isPunctuation() - Method in class com.tangosol.coherence.dsltools.base.BaseToken
-
Answer whether this token represents a punctuation character.
- isPunctuation(char) - Method in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
-
Test if the given char is a punctuation character.
- isPunctuation() - Method in class com.tangosol.coherence.dsltools.base.PunctuationBaseToken
-
- isPutAllOptimized(Map) - Static method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Determines whether or not the specified Map is optimized for a
putAll()
operation versus a regular
put()
operation.
- isQualifiedNameLegal(String) - Static method in class com.tangosol.util.ClassHelper
-
Determine if the passed string is a legal dot-delimited identifier.
- isQuoteRequired(String) - Static method in class com.tangosol.net.management.MBeanHelper
-
Determine if the string requires quotes.
- isQuoteRequired(String, boolean) - Static method in class com.tangosol.net.management.MBeanHelper
-
Determine if the string requires quotes.
- isReadOnly() - Method in class com.tangosol.coherence.config.scheme.ContinuousQueryCacheScheme
-
- isReadOnly(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
-
Returns true if the cache is read only.
- isReadOnly() - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
-
Check whether this BinaryEntry allows data modification operations.
- isReadOnly() - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
Determine if this ContinuousQueryCache
disallows data modification
operations.
- isReadOnly() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Determine if the backing map should send data changes through the
CacheStore, or should just keep them in memory.
- isReadOnly() - Method in interface com.tangosol.util.BinaryEntry
-
Check whether this BinaryEntry allows data modification operations.
- isReadOnly() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventBinaryEntry
-
Check whether this BinaryEntry allows data modification operations.
- isReadOnly() - Method in class com.tangosol.util.InvocableMapHelper.RoutingBinaryEntry
-
Check whether this BinaryEntry allows data modification operations.
- isReadThrough() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
-
- isReadThrough() - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheMXBean
-
- isReadThrough() - Method in class com.tangosol.coherence.jcache.common.JCacheContext
-
Is read-through enabled.
- isReady() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
-
Return true if the store is ready to accept requests.
- isReceiverNackEnabled() - Method in interface com.tangosol.net.ClusterDependencies
-
Determine whether the PacketReceiver will use negative acknowledgments
(NACK packet requests) to pro-actively respond to known missing packets.
- isReferenceEnabled() - Method in class com.tangosol.io.pof.ConfigurablePofContext
-
Determine if Identity/Reference type support is enabled for this
ConfigurablePofContext.
- isReferenceEnabled() - Method in class com.tangosol.io.pof.PofBufferWriter
-
Determine if reference support is enabled.
- isReferenceEnabled() - Method in class com.tangosol.io.pof.SimplePofContext
-
Determine if Identity/Reference type support is enabled for this
SimplePofContext.
- isRefinementNeeded(SimpleAssignmentStrategy.AnalysisContext, PartitionedService, PartitionedService) - Method in class com.tangosol.net.partition.MirroringAssignmentStrategy
-
Return true iff the partition assignments sync'd from the specified
associated service should be further refined/balanced by the local
assignment strategy.
- isReflectionAllowed(Object) - Static method in class com.tangosol.util.ClassHelper
-
Returns true
if oTarget
is a valid type for reflection operations.
- isRefreshable() - Method in class com.tangosol.coherence.config.builder.ListBasedAddressProviderBuilder
-
Returns true if any of the added addresses has been computed to be a hostname.
- isRefreshAhead() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Determine if the backing map preemptively reads soon-to-be expired entries
on a refresh-ahead thread.
- isRegisterable(Class<?>) - Method in class com.tangosol.coherence.config.xml.processor.DefaultsProcessor
-
- isRegistered(Cache, MBeanServerRegistrationUtility.ObjectNameType) - Static method in class com.tangosol.coherence.jcache.common.MBeanServerRegistrationUtility
-
Checks whether an ObjectName is already registered.
- isRegistered(String) - Method in interface com.tangosol.net.management.Registry
-
Check whether or not the specified name is already registered.
- isRehashing() - Method in class com.tangosol.io.nio.BinaryMap
-
Determine if the map is incrementally rehashing.
- isReleased() - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
- isReleased() - Method in class com.tangosol.net.cache.NearCache
-
Specifies whether or not the NamedCache has been released.
- isReleased() - Method in class com.tangosol.net.cache.WrapperNamedCache
-
Specifies whether or not the NamedCache has been released.
- isReleased() - Method in interface com.tangosol.net.NamedCache
-
Specifies whether or not the NamedCache has been released.
- isReleased() - Method in interface com.tangosol.net.topic.NamedTopic
-
Specifies whether or not this NamedTopic has been released.
- isReleased() - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
-
Specifies whether or not the NamedCache has been released.
- isReported() - Method in class com.tangosol.net.ConfigurableAddressProvider.AddressHolder
-
Check whether or not the underlying address has been reported
as unresolvable.
- isReserved() - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
-
Determine if the Status object is reserved.
- isResolving(DataOutput) - Static method in class com.tangosol.util.ExternalizableHelper
-
Determine whether the passed DataOutput handles ClassLoader resolving.
- isRespondInOrder() - Method in class com.tangosol.net.AbstractInvocable
-
Determine whether this Invocable object has to preserve the order of
responses according to the order of requests.
- isRespondInOrder() - Method in interface com.tangosol.net.InvocableInOrder
-
Determine whether this Invocable object has to preserve the order of
responses according to the order of requests.
- isRetainConsumed(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
-
Determine whether to retain consumed values.
- isRetainsEntries() - Method in interface com.tangosol.util.InvocableMap.StreamingAggregator
-
- isRethrowExceptions() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Determine if exceptions caught during synchronous CacheStore operations
are rethrown to the calling thread; if false, exceptions are logged.
- isRollbackCacheStoreFailures(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
-
Return true if exceptions caught during synchronous cachestore operations
are rethrown to the calling thread (possibly over the network to a remote
member).
- isRoot() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Return true if this instance is the root of the PofValue
hierarchy.
- isRootContext() - Method in class com.tangosol.config.xml.DefaultProcessingContext
-
- isRunning() - Method in class com.tangosol.net.WrapperService
-
Determine whether or not the controllable service is running.
- isRunning() - Method in interface com.tangosol.util.Controllable
-
Determine whether or not the controllable service is running.
- isRunning() - Method in class com.tangosol.util.Daemon
-
Check if the daemon is running (has started and has not stopped).
- isRunningClusterNeeded() - Method in interface com.tangosol.coherence.config.builder.ServiceBuilder
-
Return true if a running cluster is needed before using a service.
- isRunningClusterNeeded() - Method in class com.tangosol.coherence.config.scheme.AbstractLocalCachingScheme
-
Return true if a running cluster is needed before using a service.
- isRunningClusterNeeded() - Method in class com.tangosol.coherence.config.scheme.AbstractServiceScheme
-
Return true if a running cluster is needed before using a service.
- isRunningClusterNeeded() - Method in class com.tangosol.coherence.config.scheme.ClassScheme
-
Return true if a running cluster is needed before using a service.
- isRunningClusterNeeded() - Method in class com.tangosol.coherence.config.scheme.DistributedScheme
-
Return true if a running cluster is needed before using a service.
- isRunningClusterNeeded() - Method in class com.tangosol.coherence.config.scheme.InvocationScheme
-
Return true if a running cluster is needed before using a service.
- isRunningClusterNeeded() - Method in class com.tangosol.coherence.config.scheme.ProxyScheme
-
Return true if a running cluster is needed before using a service.
- isRunningClusterNeeded() - Method in class com.tangosol.coherence.config.scheme.RemoteCacheScheme
-
Return true if a running cluster is needed before using a service.
- isRunningClusterNeeded() - Method in class com.tangosol.coherence.config.scheme.RemoteInvocationScheme
-
Return true if a running cluster is needed before using a service.
- isRunningClusterNeeded() - Method in class com.tangosol.coherence.config.scheme.ReplicatedScheme
-
Return true if a running cluster is needed before using a service.
- isRunningClusterNeeded() - Method in class com.tangosol.coherence.config.scheme.TransactionalScheme
-
Return true if a running cluster is needed before using a service.
- isRunningInContainer() - Method in class com.tangosol.coherence.rest.server.ContainerPassThroughResourceConfig
-
- isRunningInContainer() - Method in class com.tangosol.coherence.rest.server.ContainerResourceConfig
-
- isRunningInContainer() - Method in class com.tangosol.coherence.rest.server.DefaultResourceConfig
-
Return whether REST API is run inside the container (true)
or standalone (false).
- isSanityChecking() - Method in class com.tangosol.coherence.dslquery.ExecutionContext
-
Return whether sanity checking should be enabled when executing commands.
- isSanityChecking() - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
-
- isSanityChecking() - Method in interface com.tangosol.coherence.dslquery.QueryPlus.Dependencies
-
Return whether sanity checking should be enabled when executing statements.
- isSealed(PersistentStore<ReadBuffer>) - Static method in class com.tangosol.persistence.CachePersistenceHelper
-
Return true if the specified store has been sealed.
- isSecure() - Method in class com.tangosol.coherence.rest.providers.SecurityFilter.Authorizer
-
- isSecure() - Method in interface com.tangosol.net.DatagramSocketProvider
-
Return true iff the provider returns sockets which are secured, for instance by TLS.
- isSecure() - Method in class com.tangosol.net.SystemDatagramSocketProvider
-
- isSecure() - Method in class com.tangosol.net.TcpDatagramSocketProvider
-
Return true iff the provider returns sockets which are secured, for instance by TLS.
- isSelectStarQuery(String, NodeTerm) - Method in class com.tangosol.coherence.dslquery.statement.SelectStatementBuilder
-
Return true if this query is of the form "SELECT * FROM cache-name".
- isSerial() - Method in interface com.tangosol.util.InvocableMap.StreamingAggregator
-
- isSerializable(Object) - Static method in class com.tangosol.util.ExternalizableHelper
-
Determine if the resource object can be serialized using the
DefaultSerializer.
- isSerializerCompatible(Service, Service) - Method in class com.tangosol.coherence.config.scheme.CacheStoreScheme
-
Determines whether or not the serializers for the specified services are
compatible.
- isSerializerCompatible(Service, Service) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Determines whether or not the serializers for the specified services are
compatible.
- isSerializerCompatible(Serializer, Serializer) - Static method in class com.tangosol.util.ExternalizableHelper
-
Determines whether or not the specified serializers are compatible.
- isShallowCloneable() - Method in class com.tangosol.io.ByteArrayReadBuffer
-
Determine whether a clone can be made without cloning the byte array.
- isSharedStorage() - Method in class com.tangosol.persistence.GUIDHelper.GUIDResolver
-
Check whether ior not all the partition stores visible by every member.
- isSilent() - Method in class com.tangosol.coherence.dslquery.ExecutionContext
-
Return true if the current query session is running in silent mode.
- isSilent() - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
-
- isSilent() - Method in interface com.tangosol.coherence.dslquery.QueryPlus.Dependencies
-
Return true if the current query session is running in silent mode.
- isSimpleNameLegal(String) - Static method in class com.tangosol.util.ClassHelper
-
Determine if the passed string is a legal simple name.
- isSimpleSequence(List<XmlElement>) - Static method in class com.tangosol.run.xml.XmlHelper
-
Check whether or not the specified list contains only simple elements
with the same names.
- isSiteLocalAddress(InetAddress) - Static method in class com.tangosol.net.InetAddressHelper
-
- isSized() - Method in interface com.tangosol.util.Streamer
-
- isSkippable() - Method in class com.tangosol.io.pof.WritingPofHandler
-
Determine if the value encoding can be skipped.
- isSlidingExpiry(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.BackingMapScheme
-
Return true iff sliding expiry is enabled.
- isSparse() - Method in class com.tangosol.io.pof.WritingPofHandler.Complex
-
Determine if the position information is encoded with the values
of the complex type, and if the Complex type is terminated in the
POF stream with an illegal position (-1).
- isSparse() - Method in class com.tangosol.run.xml.IterableAdapter
-
- isSpeakerEnabled() - Method in interface com.tangosol.net.ClusterDependencies
-
Determine whether the packet speaker is enabled.
- isStartingState(S) - Method in class com.tangosol.util.fsm.Transition
-
Determines if the specified state is one of the possible starting
states for the
Transition
.
- isStatisticsEnabled() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCache
-
Get JCache Statistics status
- isStatisticsEnabled() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
-
- isStatisticsEnabled() - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheMXBean
-
- isStatisticsEnabled() - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
-
- isStatisticsEnabled() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
-
- isStatisticsEnabled() - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
-
- isStatisticsEnabled() - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
-
- isStopOnError() - Method in class com.tangosol.coherence.dslquery.ExecutionContext
-
Return the flag indicating whether CohQL should stop processing multiple
statements if an error occurs (for example when processing a file), or
whether errors should be logged and statement processing continue.
- isStopping() - Method in class com.tangosol.util.Daemon.DaemonWorker
-
- isStopping() - Method in class com.tangosol.util.Daemon
-
Check if the daemon is supposed to stop.
- isStoreAllSupported() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
Determine if the wrapped store supports storeAll() operations.
- isStoreByValue() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
-
- isStoreByValue() - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheMXBean
-
- isStoreByValue() - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCacheConfiguration
-
- isStoreSupported() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
Determine if the wrapped store supports store() operations.
- isStoreUnsupported() - Method in class com.tangosol.net.cache.CacheStoreMap.ReadWriteMap
-
Determine if the CacheStore has been determined to be read-only for
store() operations.
- isStrict() - Method in class com.tangosol.io.nio.BinaryMap
-
Determine if the buffer should be initialized and if blocks should be
cleared when not in use.
- isStrict() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
-
Determine if any access to data in missing partitions is being treated
as an error.
- isStringable() - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.BooleanArrayAdapter
-
- isStringable() - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.ByteArrayAdapter
-
- isStringable() - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.CharArrayAdapter
-
- isStringable() - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter
-
- isStrong(Member, Member) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
Return true iff the specified members are mutually "strong", as
defined by the backup strength.
- isStrong(Member, Ownership) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
Return true iff the specified member is "strong" with respect to the
specified ownership, as defined by the backup strength.
- isStrong(Member, Member) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.BackupStrength
-
Return true iff the specified members are mutually "strong".
- isStrongPossible(Set, Map) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
Return true iff a "strong" balanced distribution is achievable for the
specified set of members, split among a set of categories
(e.g. machine, rack, site).
- isSubclassAllowed() - Method in class com.tangosol.io.pof.ConfigurablePofContext
-
Determine if the ConfigurablePofContext supports the serialization of
an object that is an instance of a sub-class of a configured type,
but not actually an instance of a class of a configured type.
- isSubjectScopingEnabled() - Method in interface com.tangosol.net.OperationalContext
-
Indicates if Subject scoping is enabled.
- isSubscribedTo(String) - Method in interface com.tangosol.net.management.NotificationManager
-
Determine if any subscriptions exist for the specified MBean.
- isSupported(OptionalFeature) - Method in class com.tangosol.coherence.jcache.CoherenceBasedCachingProvider
-
- isSuspect(long) - Method in class com.tangosol.net.GuardSupport.Context
-
Is the Guardable represented by this GuardContext suspect (in danger
of timing out soon).
- isSynthetic() - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
-
Determine if this Entry has been synthetically mutated.
- isSynthetic() - Method in class com.tangosol.net.cache.CacheEvent
-
Return true iff this event is caused by the cache internal processing
such as eviction or loading
- isSynthetic() - Method in class com.tangosol.net.cache.LocalCache.KeyMask
-
Check whether or not the currently performed operation is
internally initiated.
- isSynthetic(MapEvent) - Static method in class com.tangosol.net.cache.OverflowMap
-
Helper method to determine if an event is synthetic.
- isSynthetic() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventBinaryEntry
-
Determine if this Entry has been synthetically mutated.
- isSynthetic() - Method in interface com.tangosol.util.InvocableMap.Entry
-
Determine if this Entry has been synthetically mutated.
- isSynthetic() - Method in class com.tangosol.util.InvocableMapHelper.RoutingMapTriggerEntry
-
- isSynthetic() - Method in class com.tangosol.util.SegmentedConcurrentMap.LockableEntry
-
Is this Entry synthetic?
- isSynthetic() - Method in class com.tangosol.util.SegmentedHashMap.Entry
-
Is this Entry synthetic?
- isSynthetic() - Method in class com.tangosol.util.SimpleMapEntry
-
Determine if this Entry has been synthetically mutated.
- isSynthetic(MapEvent<K, V>) - Static method in class com.tangosol.util.WrapperObservableMap
-
Helper method to determine if an event is synthetic.
- isSyntheticUpdate() - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheValue
-
determine if last update was considered synthetic
- isSystemIdentifierValid(String) - Static method in class com.tangosol.run.xml.XmlHelper
-
Validate the passed system identifier.
- isTcmpEnabled() - Method in interface com.tangosol.net.ClusterDependencies
-
Determine whether the TCMP is enabled.
- isTcpRingEnabled() - Method in interface com.tangosol.net.ClusterDependencies
-
Determine whether the TcpRing is enabled.
- isTemporary() - Method in class com.tangosol.io.bdb.BerkeleyDBBinaryStore.DatabaseHolder
-
Return if the database is temporary.
- isTemporary() - Method in class com.tangosol.io.bdb.BerkeleyDBBinaryStoreManager
-
Return true if this is a manager for temporary stores.
- isTemporary() - Method in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
-
Return true if this is a temporary environment.
- isTimedOut(long) - Method in class com.tangosol.net.GuardSupport.Context
-
Is the Guardable represented by this GuardContext timed out?
- isTraceEnabled() - Method in class com.tangosol.coherence.dslquery.ExecutionContext
-
Return whether trace to display output when executing commands.
- isTraceEnabled() - Method in class com.tangosol.coherence.dslquery.internal.PersistenceToolsHelper
-
Return if trace is enabled.
- isTraceEnabled() - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
-
- isTraceEnabled() - Method in interface com.tangosol.coherence.dslquery.QueryPlus.Dependencies
-
Return whether trace is enabled.
- isTrackingRetained() - Method in class com.tangosol.util.SubSet
-
Determine if the SubSet is tracking retained items versus removed
items.
- isTransferStrong(int, int, Member) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
Return true iff the specified partition transfer would result in a
"strong" ownership, as defined by the current BackupStrength.
- isTransformed() - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
Determine if this ContinuousQueryCache
transforms values.
- isTransformedEvent(MapEvent) - Method in class com.tangosol.util.MapListenerSupport
-
Return true iff the specified event represents a transformed CacheEvent.
- isTransient(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.BackingMapScheme
-
Return true if the backing map is transient.
- isTranslateEvents() - Method in class com.tangosol.util.WrapperObservableMap
-
Check whether or not an event source has to be translated by the wrapper.
- isTypeIdEncoded(int) - Method in class com.tangosol.io.pof.WritingPofHandler
-
Determine if the type should be encoded for the current value.
- isUniform() - Method in class com.tangosol.io.pof.ValidatingPofHandler.Complex
-
Determine if the object encoding within the Complex type is
uniform.
- isUniform() - Method in class com.tangosol.io.pof.ValidatingPofHandler.ComplexMap
-
Determine if the object encoding within the Complex type is
uniform.
- isUniform() - Method in class com.tangosol.io.pof.WritingPofHandler.Complex
-
Determine if the object encoding within the Complex type is
uniform.
- isUniform() - Method in class com.tangosol.io.pof.WritingPofHandler.ComplexMap
-
Determine if the object encoding within the Complex type is
uniform.
- isUniformCollection() - Method in class com.tangosol.io.pof.reflect.ComplexPofValue
-
Return true if this complex value is encoded as one of uniform
collection types.
- isUniformEncoded() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Return true if the buffer contains only the value, without the
type identifier.
- isUpdate() - Method in class com.tangosol.util.MapEvent
-
Determine whether this event is an update event.
- isUpperBoundInclusive() - Method in class com.tangosol.util.filter.BetweenFilter
-
Obtain the flag indicating whether values matching the upper bound
of the range evaluate to true.
- isUserInRole(String) - Method in class com.tangosol.coherence.rest.providers.SecurityFilter.Authorizer
-
- isUserType(Object) - Method in class com.tangosol.io.pof.ConfigurablePofContext
-
Determine if the given object is of a user type known to this
PofContext.
- isUserType(Class) - Method in class com.tangosol.io.pof.ConfigurablePofContext
-
Determine if the given class is a user type known to this PofContext.
- isUserType(String) - Method in class com.tangosol.io.pof.ConfigurablePofContext
-
Determine if the class with the given name is a user type known to this
PofContext.
- isUserType(Object) - Method in interface com.tangosol.io.pof.PofContext
-
Determine if the given object is of a user type known to this
PofContext.
- isUserType(Class) - Method in interface com.tangosol.io.pof.PofContext
-
Determine if the given class is a user type known to this PofContext.
- isUserType(String) - Method in interface com.tangosol.io.pof.PofContext
-
Determine if the class with the given name is a user type known to this
PofContext.
- isUserType(Class) - Method in class com.tangosol.io.pof.SafeConfigurablePofContext
-
Determine if the given class is a user type known to this PofContext.
- isUserType(String) - Method in class com.tangosol.io.pof.SafeConfigurablePofContext
-
Determine if the class with the given name is a user type known to this
PofContext.
- isUserType(Object) - Method in class com.tangosol.io.pof.SimplePofContext
-
Determine if the given object is of a user type known to this
PofContext.
- isUserType(Class) - Method in class com.tangosol.io.pof.SimplePofContext
-
Determine if the given class is a user type known to this PofContext.
- isUserType(String) - Method in class com.tangosol.io.pof.SimplePofContext
-
Determine if the class with the given name is a user type known to this
PofContext.
- isUserType(Object) - Method in class com.tangosol.util.NullImplementation.NullPofContext
-
Determine if the given object is of a user type known to this
PofContext.
- isUserType(Class) - Method in class com.tangosol.util.NullImplementation.NullPofContext
-
Determine if the given class is a user type known to this PofContext.
- isUserType(String) - Method in class com.tangosol.util.NullImplementation.NullPofContext
-
Determine if the class with the given name is a user type known to this
PofContext.
- isUTC() - Method in class com.tangosol.io.pof.RawTime
-
Determine if the time value uses UTC.
- isValid() - Method in class com.tangosol.net.cache.OverflowMap.Status
-
Determine if the Status object is valid.
- isValid() - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
-
Determine if the Status object is valid.
- isValidNumber() - Method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
-
Test whether the value is of a valid number format.
- isValidQName(String) - Method in class com.tangosol.run.xml.QNameAdapter
-
Specifies whether or not the specified QName value is associated with a
known namespace declaration.
- isValueChanged() - Method in interface com.tangosol.util.BinaryEntry
-
Check whether the value of this BinaryEntry is changed.
- isValueLoaded() - Method in interface com.tangosol.util.BinaryEntry
-
Check whether this BinaryEntry is loaded by a "read-through" operation.
- isValueRemoved() - Method in interface com.tangosol.util.BinaryEntry
-
Check whether the value of this BinaryEntry is removed.
- isValuesImmutable() - Method in interface com.tangosol.util.TransactionMap
-
Check whether or not the values stored in this TransactionMap are
known to be immutable.
- isValueUpdated() - Method in interface com.tangosol.util.BinaryEntry
-
Check whether the value of this BinaryEntry is updated.
- isVersionCompatible(int, int, int, int, int) - Method in class com.tangosol.io.WrapperBufferInput.VersionAwareBufferInput
-
Determine whether the sender of the content of this BufferInput
runs a version that supersedes (greater or equal to) the specified
version.
- isVersionCompatible(int, int, int, int, int) - Method in class com.tangosol.io.WrapperBufferOutput.VersionAwareBufferOutput
-
Determine whether all the recipients of the content of this BufferOutput
run versions that supersede (greater or equal to) the specified
version.
- isVersionCompatible(DataInput, int, int, int, int, int) - Static method in class com.tangosol.util.ExternalizableHelper
-
Determine whether the sender of the content (the given DataInput)
runs a version that supersedes (greater or equal to) the specified
version.
- isVersionCompatible(DataOutput, int, int, int, int, int) - Static method in class com.tangosol.util.ExternalizableHelper
-
Determine whether all the recipients of the content (the given DataOutput)
run versions that supersede (greater or equal to) the specified
version.
- isVersioningEnabled() - Method in interface com.tangosol.util.Versionable
-
Return the value specifying if the versioning is enabled.
- isVirtualErase() - Method in class com.tangosol.net.cache.SerializationPagedCache
-
Determine if BinaryStore erase commands will be done only in memory
(to the cached list of keys) and not passsed to the underlying
BinaryStore, thus improving performance and cutting I/O, but
potentially wasting disk space (or whatever resource the paged data are
stored on.)
- isWaitingOnPending() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.WriteQueue
-
Check whether any threads are waiting for the store operation
to complete.
- isWhitespace(char) - Static method in class com.tangosol.run.xml.XmlHelper
-
Test if the specified character is XML whitespace.
- isWLSContainer() - Static method in class com.tangosol.coherence.jcache.common.ContainerHelper
-
Deprecated.
- isWriteable(Class<?>, Type, Annotation[], MediaType) - Method in class com.tangosol.coherence.rest.providers.EntryWriter
-
- isWriteable(Class<?>, Type, Annotation[], MediaType) - Method in class com.tangosol.coherence.rest.providers.JsonCollectionWriter
-
- isWriteable(Class<?>, Type, Annotation[], MediaType) - Method in class com.tangosol.coherence.rest.providers.ObjectWriter
- isWriteable(Class<?>, Type, Annotation[], MediaType) - Method in class com.tangosol.coherence.rest.providers.XmlCollectionWriter
-
- isWriteable(Class<?>, Type, Annotation[], MediaType) - Method in class com.tangosol.coherence.rest.providers.XmlKeysWriter
- isWriteable(Class<?>, Type, Annotation[], MediaType) - Method in class com.tangosol.coherence.rest.providers.XmlMapWriter
-
- isWriteBehind() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Determine if the backing map writes changes on a write-behind thread
through the CacheStore.
- isWriteThrough() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
-
- isWriteThrough() - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheMXBean
-
- isWriteThrough() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Determine if the backing map writes changes immediately through the
CacheStore.
- Iterable(IterableCacheLoader<K, V>) - Constructor for class com.tangosol.net.cache.CacheLoaderCacheStore.Iterable
-
The CacheLoader to delegate to.
- IterableAdapter - Class in com.tangosol.run.xml
-
An IterableAdapter is the base class for any data type that must be
iterated over to serialize/deserialize, such as arrays, collections
and maps.
- IterableAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.IterableAdapter
-
Construct a IterableAdapter.
- IterableCacheLoader<K,V> - Interface in com.tangosol.net.cache
-
A JCache CacheLoader that can iterate its underlying contents.
- iterate(PersistentStore.Visitor<ReadBuffer>) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
-
Iterate the key-value pairs in the persistent store, applying the
specified visitor to each key-value pair.
- iterate(PersistentStore.Visitor<R>) - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistentStore
-
Iterate the key-value pairs in the persistent store, applying the
specified visitor to each key-value pair.
- iterate(PersistentStore.Visitor<R>) - Method in class com.tangosol.util.NullImplementation.NullPersistentStore
-
- iterateBinaryStores() - Method in class com.tangosol.net.cache.SerializationPagedCache
-
Obtain an iterator of all registered (not destroyed) BinaryStore
objects being used by this cache.
- iterateInternal(PersistentStore.Visitor<ReadBuffer>) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
-
Iterate the key-value pairs in the underlying persistent storage,
applying the specified visitor to each key-value pair.
- iterateKeys() - Method in class com.tangosol.net.cache.CacheStoreMap.ReadWriteMap
-
Create an iterator over the keys in this Map.
- iterateKeys() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.EvictingBackupMap
-
Create an iterator over the keys in this Map.
- iterateKeys() - Method in class com.tangosol.net.cache.SimpleOverflowMap
-
Create an iterator over the keys in this Map.
- iterateKeys() - Method in class com.tangosol.net.cache.SimpleSerializationMap
-
Create an iterator over the keys in this Map.
- iterateKeys() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
-
Create an iterator over the keys in this Map.
- iterateKeys(Map[]) - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
-
Create an iterator over the keys in maps that belong to partitions
contained in the specified PartitionSet.
- iterateKeys() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.MaskedPartitionMap
-
Create an iterator over the keys in this Map.
- iterateKeys() - Method in class com.tangosol.util.AbstractKeyBasedMap
-
Create an iterator over the keys in this Map.
- iterateKeys() - Method in class com.tangosol.util.AbstractKeySetBasedMap
-
Create an iterator over the keys in this Map.
- iterateKeys() - Method in class com.tangosol.util.KeyValueArrayMap
-
Create an iterator over the keys in this Map.
- iterateKeys() - Method in class com.tangosol.util.OpenHashMap
-
Create an iterator over the keys in this Map.
- iterator() - Method in class com.tangosol.coherence.config.builder.SimpleParameterizedBuilderRegistry
-
- iterator() - Method in class com.tangosol.coherence.config.CacheMappingRegistry
-
Deprecated.
- iterator() - Method in class com.tangosol.coherence.config.ResolvableParameterList
- iterator() - Method in class com.tangosol.coherence.config.SchemeMappingRegistry
-
- iterator() - Method in class com.tangosol.coherence.config.ServiceSchemeRegistry
- iterator() - Method in class com.tangosol.coherence.config.SimpleParameterList
- iterator() - Method in class com.tangosol.coherence.dsltools.termtrees.Term
-
- iterator() - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheEntryEventFilteringIterable
-
- iterator() - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
-
- iterator() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
-
- iterator() - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
-
- iterator() - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
-
- iterator() - Method in class com.tangosol.coherence.rest.util.PropertySet
-
Return an iterator for this property set.
- iterator() - Method in class com.tangosol.io.nio.BinaryMap.EntrySet
-
Returns an iterator over the elements contained in this collection.
- iterator() - Method in class com.tangosol.io.nio.BinaryMap.KeySet
-
Obtain an iterator over the keys in the Map.
- iterator() - Method in class com.tangosol.io.nio.BinaryMap.ValuesCollection
-
Obtain an iterator over the values in the Map.
- iterator() - Method in class com.tangosol.net.cache.OldCache.EntrySet
-
Deprecated.
Returns an iterator over the elements contained in this collection.
- iterator() - Method in class com.tangosol.net.cache.OverflowMap.InternalKeySet
- iterator() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.EntrySet
-
Returns an iterator over the elements contained in this collection.
- iterator() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.KeySet
-
Returns an iterator over the elements contained in this collection.
- iterator() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.ValuesCollection
-
Obtain an iterator over the values in the Map.
- iterator() - Method in class com.tangosol.net.CompositeAddressProvider
-
Returns an iterator over the elements contained in this collection.
- iterator() - Method in class com.tangosol.net.ConfigurableAddressProvider
-
Returns an iterator over the elements contained in this collection.
- iterator() - Method in class com.tangosol.run.xml.SimpleElement.AttributeMap.EntrySet
-
- iterator() - Method in class com.tangosol.util.AbstractKeyBasedMap.EntrySet
-
Returns an iterator over the elements contained in this collection.
- iterator() - Method in class com.tangosol.util.AbstractKeyBasedMap.KeySet
-
Returns an iterator over the elements contained in this collection.
- iterator() - Method in class com.tangosol.util.AbstractKeyBasedMap.ValuesCollection
-
Returns an iterator over the elements contained in this collection.
- iterator() - Method in class com.tangosol.util.AbstractSafeLongArray
-
- iterator(long) - Method in class com.tangosol.util.AbstractSafeLongArray
-
- iterator() - Method in class com.tangosol.util.AbstractSparseArray
-
Obtain a LongArray.Iterator of the contents of the LongArray.
- iterator(long) - Method in class com.tangosol.util.AbstractSparseArray
-
Obtain a LongArray.Iterator of the contents of the LongArray, starting
at a particular index such that the first call to next
will
set the location of the iterator at the first existent index that is
greater than or equal to the specified index, or will throw a
NoSuchElementException if there is no such existent index.
- iterator() - Method in class com.tangosol.util.ChainedCollection
-
- iterator() - Method in class com.tangosol.util.ChainedMap.EntrySet
-
Returns an iterator over the elements contained in this collection.
- iterator() - Method in class com.tangosol.util.ConverterCollections.ConverterCollection
- iterator() - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet
- iterator() - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray
-
- iterator(long) - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray
-
- iterator() - Method in class com.tangosol.util.CopyOnWriteLongArray
-
Obtain a LongArray.Iterator of the contents of the LongArray in
order of increasing indices.
- iterator(long) - Method in class com.tangosol.util.CopyOnWriteLongArray
-
Obtain a LongArray.Iterator of the contents of the LongArray in
order of increasing indices, starting at a particular index such
that the first call to next will set the location of
the iterator at the first existent index that is greater than or
equal to the specified index, or will throw a
NoSuchElementException if there is no such existent index.
- iterator() - Method in class com.tangosol.util.CopyOnWriteMap.EntrySet
- iterator() - Method in class com.tangosol.util.CopyOnWriteMap.KeySet
- iterator() - Method in class com.tangosol.util.DeltaSet
-
Returns an Iterator over the elements contained in this Collection.
- iterator() - Method in class com.tangosol.util.ImmutableArrayList
-
Returns an iterator over the elements in this list in proper
sequence.
- iterator() - Method in class com.tangosol.util.ImmutableMultiList
-
Returns an iterator over the elements in this list in proper
sequence.
- iterator() - Method in class com.tangosol.util.InflatableCollection
- iterator() - Method in class com.tangosol.util.LiteSet
-
Returns an Iterator over the elements in this Set.
- iterator() - Method in interface com.tangosol.util.LongArray
-
Obtain a LongArray.Iterator of the contents of the LongArray in
order of increasing indices.
- iterator(long) - Method in interface com.tangosol.util.LongArray
-
Obtain a LongArray.Iterator of the contents of the LongArray in
order of increasing indices, starting at a particular index such
that the first call to next will set the location of
the iterator at the first existent index that is greater than or
equal to the specified index, or will throw a
NoSuchElementException if there is no such existent index.
- iterator() - Method in class com.tangosol.util.MapSet
-
Returns an iterator over the elements in this Set.
- iterator() - Method in class com.tangosol.util.NullImplementation.NullEnumerator
-
Returns an Iterator instance with no values to enumerate.
- iterator() - Method in class com.tangosol.util.NullImplementation.NullSet
-
Returns an Iterator over the elements contained in this Collection.
- iterator() - Method in class com.tangosol.util.OpenHashSet
- iterator() - Method in class com.tangosol.util.PrimitiveSparseArray
-
Obtain a LongArray.Iterator of the contents of the LongArray.
- iterator(long) - Method in class com.tangosol.util.PrimitiveSparseArray
-
Obtain a LongArray.Iterator of the contents of the LongArray, starting
at a particular index such that the first call to next
will
set the location of the iterator at the first existent index that is
greater than or equal to the specified index, or will throw a
NoSuchElementException if there is no such existent index.
- Iterator(AbstractSparseArray.Node, int, boolean) - Constructor for class com.tangosol.util.PrimitiveSparseArray.Iterator
-
Instantiate a new PrimitiveIterator at the specified location and
direction.
- iterator() - Method in class com.tangosol.util.RestrictedCollections.RestrictedCollection
-
Returns an Iterator over the elements contained in this Collection.
- iterator() - Method in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet
-
Returns an Iterator over the elements contained in this Collection.
- iterator() - Method in class com.tangosol.util.SafeHashMap.EntrySet
-
Returns an iterator over the elements contained in this collection.
- iterator() - Method in class com.tangosol.util.SafeHashMap.KeySet
-
Obtain an iterator over the keys in the Map.
- iterator() - Method in class com.tangosol.util.SafeHashMap.ValuesCollection
-
Obtain an iterator over the values in the Map.
- iterator() - Method in class com.tangosol.util.SafeSortedMap.ViewMap.EntrySet
- iterator() - Method in class com.tangosol.util.SegmentedHashMap.EntrySet
-
Returns an iterator over the elements contained in this collection.
- iterator() - Method in class com.tangosol.util.SegmentedHashMap.KeySet
-
Obtain an iterator over the keys in the Map.
- iterator() - Method in class com.tangosol.util.SegmentedHashMap.ValuesCollection
-
Obtain an iterator over the values in the Map.
- iterator() - Method in class com.tangosol.util.SimpleLongArray
-
Obtain a LongArray.Iterator of the contents of the LongArray.
- iterator(long) - Method in class com.tangosol.util.SimpleLongArray
-
Obtain a LongArray.Iterator of the contents of the LongArray, starting
at a particular index such that the first call to next will
set the location of the iterator at the first existent index that is
greater than or equal to the specified index, or will throw a
NoSuchElementException if there is no such existent index.
- Iterator(int, boolean) - Constructor for class com.tangosol.util.SimpleLongArray.Iterator
-
Construct an iterator that will iterate over the SimpleLongArray
starting with the specified index.
- iterator() - Method in class com.tangosol.util.SortedBag
- iterator() - Method in interface com.tangosol.util.stream.RemoteDoubleStream
-
- iterator() - Method in interface com.tangosol.util.stream.RemoteIntStream
-
- iterator() - Method in interface com.tangosol.util.stream.RemoteLongStream
-
- iterator() - Method in class com.tangosol.util.SubList
- iterator() - Method in class com.tangosol.util.SubSet
- iterator() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperCollection
- iterator() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
-
- iterator(long) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
-
- iterator() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperCollection
- iterator() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperEntrySet
- iteratorActivated(Iterator) - Method in class com.tangosol.util.SafeHashMap
-
Register the activation of an Iterator.
- iteratorActivated(Iterator) - Method in class com.tangosol.util.SegmentedHashMap
-
Register the activation of an Iterator.
- iteratorDeactivated(Iterator) - Method in class com.tangosol.util.SafeHashMap
-
Unregister the (formerly active) Iterator.
- IteratorEnumerator - Class in com.tangosol.util
-
Provide a implementation of an enumerator based on data from an Iterator.
- IteratorEnumerator(Iterator) - Constructor for class com.tangosol.util.IteratorEnumerator
-
Construct the enumerator based on an Iterator.
- m_aabArray - Variable in class com.tangosol.io.MultiByteArrayInputStream
-
The array of byte arrays.
- m_aAdapter - Variable in class com.tangosol.run.xml.XmlBean.BeanInfo
-
The property adapters for the XML bean.
- m_aAddrPortDest - Variable in class com.tangosol.net.LoadBalancer
-
The AddressPort combinations that the load balancer will balance to.
- m_aAggregator - Variable in class com.tangosol.util.aggregator.CompositeAggregator
-
The underlying EntryAggregator array.
- m_ab - Variable in class com.tangosol.io.AbstractByteArrayReadBuffer
-
The byte array that holds the binary data.
- m_ab - Variable in class com.tangosol.io.ByteArrayWriteBuffer
-
The byte array that holds the binary data.
- m_ab - Variable in class com.tangosol.io.MultiByteArrayInputStream
-
The current byte array.
- m_ab - Variable in class com.tangosol.io.MultiByteArrayOutputStream
-
The current block of output.
- m_abAccum - Variable in class com.tangosol.io.Base64OutputStream
-
Accumulated bytes.
- m_abBuf - Variable in class com.tangosol.net.LoadBalancer.SocketHandler
-
The buffer to use for reading from a stream.
- m_abGroup - Variable in class com.tangosol.io.Base64InputStream
-
Group of bytes (stored as ints 0..255).
- m_acache - Variable in class com.tangosol.net.partition.ObservableSplittingBackingCache
-
A cached array of the backing ConfigurableCacheMap instances.
- m_achBuf - Variable in class com.tangosol.io.AbstractWriteBuffer
-
- m_achGroup - Variable in class com.tangosol.io.Base64OutputStream
-
An array that is used to send 4 characters at a time to the underlying
Writer object.
- m_aClzByTypeId - Variable in class com.tangosol.io.pof.ConfigurablePofContext.PofConfig
-
An array of WeakReferences to user type classes, indexed by type identifier.
- m_aComparator - Variable in class com.tangosol.util.comparator.ChainedComparator
-
The Comparator array.
- m_actionConditionalRemove - Variable in class com.tangosol.util.SegmentedConcurrentMap
-
The singleton action for conditional remove.
- m_actionContainsValue - Variable in class com.tangosol.util.SegmentedHashMap
-
The singleton action for containsValue support.
- m_actionGetEntry - Variable in class com.tangosol.util.SegmentedHashMap
-
The singleton action for getEntryInternal support.
- m_actionInsert - Variable in class com.tangosol.util.SegmentedHashMap
-
The singleton action for insert support.
- m_actionLock - Variable in class com.tangosol.util.SegmentedConcurrentMap
-
The action for lock() support.
- m_actionRemove - Variable in class com.tangosol.util.SegmentedHashMap
-
The singleton action for remove support.
- m_actionSize - Variable in class com.tangosol.util.SegmentedConcurrentMap
-
The singleton action for size support.
- m_actionUnlock - Variable in class com.tangosol.util.SegmentedConcurrentMap
-
The action for unlock() support.
- m_address - Variable in class com.tangosol.net.CompositeAddressProvider.SingleProvider
-
The single address that this AddressProvider represents.
- m_addrportHost - Variable in class com.tangosol.net.LoadBalancer
-
The AddressPort combination that the load balancer will listen on.
- m_advancer - Variable in class com.tangosol.util.PagedIterator
-
The underlying Advancer.
- m_aeBucket - Variable in class com.tangosol.util.SafeHashMap
-
The array of hash buckets.
- m_aeBucket - Variable in class com.tangosol.util.SegmentedHashMap
-
The array of hash buckets.
- m_aExtractor - Variable in class com.tangosol.util.extractor.AbstractCompositeExtractor
-
The ValueExtractor array.
- m_aFilter - Variable in class com.tangosol.util.filter.ArrayFilter
-
The Filter array.
- m_aflProbabilityThresholds - Variable in class com.tangosol.util.SafeSortedMap
-
The array of pre-computed probability thresholds for each level.
- m_aggregator - Variable in class com.tangosol.util.aggregator.AbstractAsynchronousAggregator
-
The underlying aggregator.
- m_aggregator - Variable in class com.tangosol.util.aggregator.GroupAggregator
-
The underlying EntryAggregator.
- m_aggregatorRegistry - Variable in class com.tangosol.coherence.rest.CacheResource
-
Aggregator registry that is used to map the given aggregator name to
an EntryAggregator instance.
- m_aggregatorRegistry - Variable in class com.tangosol.coherence.rest.EntrySetResource
-
Aggregator registry that is used to map the given aggregator name to
an EntryAggregator instance.
- m_aggregatorRegistry - Variable in class com.tangosol.coherence.rest.NamedQueryResource
-
Aggregator registry that is used to map the given aggregator name to
an EntryAggregator instance.
- m_aGuardContext - Variable in class com.tangosol.net.GuardSupport
-
Array of GuardContexts for the registered Guardables.
- m_aiOwner - Variable in class com.tangosol.net.partition.Ownership
-
An array of member ids representing the partition ownership.
- m_anodeRecycled - Variable in class com.tangosol.util.RecyclingLinkedList
-
The Nodes to recycle.
- m_aoArgs - Variable in class com.tangosol.util.AbstractScript
-
The arguments to be passed to the script during evaluation.
- m_aoArgs - Variable in class com.tangosol.util.processor.MethodInvocationProcessor
-
Method arguments.
- m_aoData - Variable in class com.tangosol.util.CircularArrayList
-
The array into which the elements of the list are stored.
- m_aoItem - Variable in class com.tangosol.util.SimpleEnumerator
-
Array of items to enumerate.
- m_aoKey - Variable in class com.tangosol.util.KeyValueArrayMap
-
The array containing map keys.
- m_aoParam - Variable in class com.tangosol.util.extractor.ReflectionExtractor
-
The parameter array.
- m_aoParam - Variable in class com.tangosol.util.extractor.UniversalExtractor
-
The parameter array.
- m_aoResults - Variable in class com.tangosol.coherence.dslquery.internal.UpdateSetListMaker
-
The results of the classification
- m_aoValue - Variable in class com.tangosol.util.KeyValueArrayMap
-
The array containing map values.
- m_aOwners - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
The ownership array for this analysis context.
- m_aOwnershipMembers - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
An array of the ownership members to include in the distribution,
arranged in arbitrary order.
- m_aParallelResults - Variable in class com.tangosol.util.aggregator.CompositeAggregator
-
An array of partial results for each aggregator.
- m_apprvrEvict - Variable in class com.tangosol.net.cache.OldCache
-
Deprecated.
The EvictionApprover.
- m_apprvrEvict - Variable in class com.tangosol.net.cache.SerializationCache
-
The EvictionApprover.
- m_apprvrEvict - Variable in class com.tangosol.net.partition.ObservableSplittingBackingCache
-
An optional EvictionApprover registered with this cache.
- m_apRecovery - Variable in class com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy
-
The recovery address-provider.
- m_apRefresh - Variable in class com.tangosol.net.RefreshableAddressProvider
-
The address provider to be refreshed.
- m_aProcessor - Variable in class com.tangosol.util.processor.CompositeProcessor
-
The underlying entry processor array.
- m_aResults - Variable in class com.tangosol.coherence.dslquery.internal.SelectListMaker
-
The results of the classification
- m_arguments - Variable in class com.tangosol.net.management.MBeanAccessor.Invoke
-
The arguments to the operation.
- m_arrayExpiry - Variable in class com.tangosol.net.cache.OldCache
-
Deprecated.
Array of set of keys, indexed by the time of expiry.
- m_arrayRefs - Variable in class com.tangosol.io.pof.PofBufferReader
-
Lazily-constructed mapping of identities to references.
- m_arrayRefs - Variable in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Lazily-constructed mapping of identities to references.
- m_aRules - Variable in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy
-
The array of quorum rules.
- m_aSegment - Variable in class com.tangosol.util.SegmentedHashMap
-
An array of the control-structures for the Map's segments.
- m_aserByTypeId - Variable in class com.tangosol.io.pof.ConfigurablePofContext.PofConfig
-
An array of PofSerializer objects, indexed by type identifier.
- m_asGUIDNewest - Variable in class com.tangosol.persistence.GUIDHelper.GUIDResolver
-
The resolved list of the newest GUIDs, indexed by partition-id.
- m_asStackRemote - Variable in exception com.tangosol.io.pof.PortableException
-
A raw representation of the remote stack trace for this exception.
- m_atomicLocks - Variable in class com.tangosol.util.SegmentedHashMap
-
The "segment-locks".
- m_atomicNonce - Variable in class com.tangosol.util.SortedBag
-
The nonce used to increment the unique element ids.
- m_atomicSize - Variable in class com.tangosol.util.SafeSortedMap.BaseEntryNode
-
AtomicCounter used to hold the size of the base entry list.
- m_atomicTerm - Variable in class com.tangosol.coherence.dslquery.internal.AbstractCoherenceQueryWalker
-
The AtomicTerm that was last processed
- m_atomicUpdaterNext - Static variable in class com.tangosol.util.SafeSortedMap.EntryNode
-
AtomicUpdater for the casNext operation.
- m_atomicUpdaterNext - Static variable in class com.tangosol.util.SafeSortedMap.SkipNode
-
AtomicUpdater for the casNext operation.
- m_atomicUpdaterTopNode - Static variable in class com.tangosol.util.SafeSortedMap
-
AtomicUpdater for the casTopNode operation.
- m_atomicUpdaterValue - Static variable in class com.tangosol.util.SafeSortedMap.EntryNode
-
AtomicUpdater for the casValue operation.
- m_atomicUpdaterValue - Static variable in class com.tangosol.util.SegmentedConcurrentMap
-
AtomicUpdater for the entry value.
- m_binContent - Variable in class com.tangosol.coherence.rest.util.StaticContent
-
- m_binFutureData - Variable in class com.tangosol.io.SimpleEvolvable
-
Future data.
- m_binKey - Variable in class com.tangosol.net.cache.BackingMapBinaryEntry
-
The Binary key.
- m_binValue - Variable in class com.tangosol.net.cache.BackingMapBinaryEntry
-
The Binary value.
- m_binValueOrig - Variable in class com.tangosol.net.cache.BackingMapBinaryEntry
-
The original Binary value.
- m_bldr - Variable in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder
-
- m_bldrExtractor - Variable in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
-
- m_buf - Variable in class com.tangosol.io.DelegatingWriteBuffer
-
The WriteBuffer to delegate to; the "containing" WriteBuffer.
- m_buf - Variable in class com.tangosol.io.nio.ByteBufferInputStream
-
The ByteBuffer object from which data is read.
- m_buf - Variable in class com.tangosol.io.nio.ByteBufferReadBuffer.ByteBufferInput
-
The ByteBuffer object from which data is read.
- m_bufUnsafe - Variable in class com.tangosol.io.ByteArrayWriteBuffer
-
- m_bufValue - Variable in class com.tangosol.util.ExternalizableHelper.DecoratedMultiBufferReadBuffer
-
The undecorated value.
- m_builder - Variable in class com.tangosol.coherence.config.builder.ServiceLoadBalancerBuilder
-
Customized ServiceLoadBalancerBuilder.
- m_cAccum - Variable in class com.tangosol.io.Base64OutputStream
-
The number of bytes accumulated (0, 1, 2 or 3).
- m_cache - Variable in class com.tangosol.coherence.jcache.localcache.LocalCacheAsynchronousMapListener
-
Listener for this JCache.
- m_cache - Variable in class com.tangosol.coherence.rest.CacheResource
-
NamedCache wrapped by this resource.
- m_cache - Variable in class com.tangosol.coherence.rest.EntryResource
-
NamedCache which stores the referenced entry.
- m_cache - Variable in class com.tangosol.coherence.rest.EntrySetResource
-
Cache which stores the referenced entries.
- m_cache - Variable in class com.tangosol.coherence.rest.NamedQueryResource
-
NamedCache wrapped by this resource.
- m_cache - Variable in class com.tangosol.net.partition.AbstractPartitionedIterator
-
The cache to query from.
- m_cacheFactory - Variable in class com.tangosol.coherence.dslquery.ExecutionContext
-
- m_cacheSource - Variable in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheAsynchronousMapListener
-
- m_calculator - Variable in class com.tangosol.net.cache.OldCache
-
Deprecated.
The external unit calculator.
- m_calculator - Variable in class com.tangosol.net.cache.SerializationCache
-
The unit calculator to use to limit size of the cache.
- m_calculator - Variable in class com.tangosol.net.partition.ObservableSplittingBackingCache
-
The unit calculator.
- m_calculator - Variable in class com.tangosol.util.SimpleMapIndex.IndexCalculator
-
- m_calculator - Variable in class com.tangosol.util.SimpleMapIndex
-
UnitCalculator used to estimate the cost of a value.
- m_calculatorBackup - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
The backup LoadCalculator.
- m_calculatorPrimary - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
The primary LoadCalculator.
- m_cAverageBundleSize - Variable in class com.tangosol.net.cache.AbstractBundler.Statistics
-
An average bundle size for this Bundler.
- m_cAverageBurstDuration - Variable in class com.tangosol.net.cache.AbstractBundler.Statistics
-
An average time for bundled request processing (burst).
- m_cAverageThreadWaitDuration - Variable in class com.tangosol.net.cache.AbstractBundler.Statistics
-
An average thread waiting time caused by under-filled bundle.
- m_cAvgTouch - Variable in class com.tangosol.net.cache.OldCache
-
Deprecated.
For a prune cycle, this value is the average number of touches that an
entry should have.
- m_cb - Variable in class com.tangosol.io.AbstractByteArrayReadBuffer
-
Number of bytes in the byte array that belong to this ReadBuffer object.
- m_cb - Variable in class com.tangosol.io.ByteArrayWriteBuffer.Allocator
-
The capacity of the ByteArrayWriteBuffer instances to allocate.
- m_cb - Variable in class com.tangosol.io.ByteArrayWriteBuffer
-
Number of bytes in the byte array that have been written by this
WriteBuffer.
- m_cb - Variable in class com.tangosol.io.DelegatingWriteBuffer
-
Length in bytes of this WriteBuffer.
- m_cb - Variable in class com.tangosol.io.SizeEstimatingBufferOutput
-
The byte count.
- m_cBackupActual - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
The number of backup storages to maintain.
- m_cBarred - Variable in class com.tangosol.util.ThreadGateLite.Bar
-
- m_cbAveragePartition - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.JMXPartitionStats
-
The average partition storage size in bytes.
- m_cbAverageStorage - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.JMXPartitionStats
-
The average node storage size in bytes.
- m_cbBlock - Variable in class com.tangosol.io.MultiByteArrayOutputStream
-
The max size of each block.
- m_cbFixed - Variable in class com.tangosol.util.SimpleMapIndex.IndexCalculator
-
- m_cBlocks - Variable in class com.tangosol.io.MultiByteArrayOutputStream
-
The number of flushed blocks.
- m_cbMax - Variable in class com.tangosol.io.ByteArrayWriteBuffer
-
Number of bytes that the byte array can be grown to.
- m_cbMax - Variable in class com.tangosol.io.DelegatingWriteBuffer
-
Maximum number of bytes in this WriteBuffer.
- m_cbMaxPartition - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.JMXPartitionStats
-
The maximum partition storage size in bytes.
- m_cbMaxStorage - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.JMXPartitionStats
-
The maximum node storage size in bytes.
- m_cbPadBack - Variable in class com.tangosol.io.MultiByteArrayOutputStream
-
The number of additional bytes to allocate and leave free at the back
(end) of each block
- m_cbPadFront - Variable in class com.tangosol.io.MultiByteArrayOutputStream
-
The number of additional bytes to allocate and leave free at the front
(start) of each block
- m_cbStorageDirect - Variable in class com.tangosol.net.partition.PartitionStatistics
-
The portion of the partition size that is obtained directly from
partitioned
maps (in bytes).
- m_cbStorageIndirect - Variable in class com.tangosol.net.partition.PartitionStatistics
-
The portion of the partition size that cannot be obtained directly and
has to be adjusted upon each cache entry update (in bytes).
- m_cBundleCountSnapshot - Variable in class com.tangosol.net.cache.AbstractBundler.Statistics
-
Snapshot for a total number of processed bundled.
- m_cBundleSizeSnapshot - Variable in class com.tangosol.net.cache.AbstractBundler.Statistics
-
Snapshot for a total size of processed bundled.
- m_cBurstDurationSnapshot - Variable in class com.tangosol.net.cache.AbstractBundler.Statistics
-
Snapshot for a burst duration.
- m_cCacheHits - Variable in class com.tangosol.net.cache.SimpleCacheStatistics
-
The rough (ie unsynchronized) number of calls that could be answered
from the front or the back and were answered by data in the front map.
- m_cCacheMisses - Variable in class com.tangosol.net.cache.SimpleCacheStatistics
-
The rough (ie unsynchronized) number of calls that could be answered
from the front or the back and were answered by data in the back map.
- m_cCachePrunes - Variable in class com.tangosol.net.cache.SimpleCacheStatistics
-
Total number of evictions triggered based on the size of the cache
since the last statistics reset.
- m_cCachePrunesMillis - Variable in class com.tangosol.net.cache.SimpleCacheStatistics
-
Total number of milliseconds used for prune operations since the last
statistics reset.
- m_cCachePuts - Variable in class com.tangosol.net.cache.SimpleCacheStatistics
-
Total number of put operations since the last statistics reset.
- m_cCapacity - Variable in class com.tangosol.util.SafeHashMap
-
The capacity of the hash map (the point at which it must resize), 1 <= n.
- m_ccf - Variable in class com.tangosol.net.SimpleServiceMonitor
-
- m_ccfSingleton - Variable in class com.tangosol.net.SingletonCacheFactoryBuilder
-
- m_cContend - Variable in class com.tangosol.util.SegmentedConcurrentMap.LockableEntry
-
The number of threads that are waiting to lock this Entry.
- m_cCurUnits - Variable in class com.tangosol.net.cache.OldCache
-
Deprecated.
The current number of units in the cache.
- m_cCurUnits - Variable in class com.tangosol.net.cache.SerializationCache
-
Current number of units to in the cache.
- m_cDbId - Variable in class com.tangosol.io.bdb.DatabaseFactory
-
Counter used to generate unique Database names for this Environment.
- m_cDefaultSoftTimeoutMillis - Variable in class com.tangosol.net.GuardSupport.Context
-
The default soft-timeout interval to use for the represented Guardable.
- m_cDefaultTimeoutMillis - Variable in class com.tangosol.net.GuardSupport.Context
-
The default timeout interval to use for the represented Guardable.
- m_cDelay - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
- m_cElements - Variable in class com.tangosol.util.CircularArrayList
-
The size of the list (the number of elements it contains).
- m_cEntries - Variable in class com.tangosol.util.SafeHashMap
-
The number of entries stored in the hash map, 0 <= n.
- m_cEraseFailures - Variable in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
The number of Erase failures.
- m_cEraseMillis - Variable in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
The cumulative time spent on Erase operations.
- m_cEraseOps - Variable in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
The number of Erase operations.
- m_cExecutionTime - Variable in class com.tangosol.net.partition.PartitionStatistics
-
The total amount of time (in ms) that tasks/requests were executing.
- m_cExpiryDelay - Variable in class com.tangosol.net.cache.OldCache
-
Deprecated.
The number of milliseconds that a value will live in the cache.
- m_cExpiryDelayMillis - Variable in class com.tangosol.net.partition.ObservableSplittingBackingCache
-
The expiry delay.
- m_cFairShare - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.UnderloadedFilter
-
The cached fair-share load.
- m_cFairShareBackup - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
The fair-share backup partition load.
- m_cFairSharePrimary - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
The fair-share primary partition load.
- m_cGuardable - Variable in class com.tangosol.net.GuardSupport
-
The number of registered Guardables.
- m_chCurrent - Variable in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
-
The current working char.
- m_cHighUnitFairShare - Variable in class com.tangosol.net.partition.ObservableSplittingBackingCache
-
The fair share of high units for each partition map.
- m_cHighUnits - Variable in class com.tangosol.net.partition.ObservableSplittingBackingCache
-
High units is the number of units that triggers eviction.
- m_cHighUnitsCalibrated - Variable in class com.tangosol.net.partition.ObservableSplittingBackingCache
-
- m_cHitsMillis - Variable in class com.tangosol.net.cache.SimpleCacheStatistics
-
Total number of milliseconds used for get operations that were hits
since the last statistics reset.
- m_cLimitMillis - Variable in class com.tangosol.net.partition.FailoverAccessPolicy
-
The amount of time after being in an endangered state after which the
quorum policy makes a maximal effort to hold client requests.
- m_cLineGroups - Variable in class com.tangosol.io.Base64OutputStream
-
The number of groups left to write in the current line.
- m_cLoadFailures - Variable in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
The number of Load failures.
- m_cLoadMillis - Variable in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
The cumulative time spent on Load operations.
- m_cLoadOps - Variable in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
The number of Load operations.
- m_cLock - Variable in class com.tangosol.util.SegmentedConcurrentMap.LockableEntry
-
The lock count (number of times the "lock()" was called by the
locking thread).
- m_cLogMissingIdx - Variable in class com.tangosol.util.SimpleMapIndex
-
The number of "missing inverse index" messages that have been logged.
- m_cLowUnitFairShare - Variable in class com.tangosol.net.partition.ObservableSplittingBackingCache
-
The fair share of low units for each partition map.
- m_cLowUnits - Variable in class com.tangosol.net.partition.ObservableSplittingBackingCache
-
Low units is the number of units to evict down to.
- m_cLowUnitsCalibrated - Variable in class com.tangosol.net.partition.ObservableSplittingBackingCache
-
- m_cluster - Variable in class com.tangosol.coherence.dslquery.ExecutionContext
-
The
Cluster
to use to access services.
- m_clz - Variable in class com.tangosol.util.RestrictedCollections.RestrictedCollection
-
The class of Objects stored in the Collection.
- m_clz - Variable in class com.tangosol.util.RestrictedCollections.RestrictedListIterator
-
The class of Objects stored in the ListIterator.
- m_clzBean - Variable in class com.tangosol.run.xml.XmlBean.BeanInfo
-
The class of the specific XML bean.
- m_clzKey - Variable in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
-
The type of keys for Cache
s.
- m_clzKey - Variable in class com.tangosol.coherence.rest.CacheResource
-
Key class for the entries stored in the wrapped cache.
- m_clzKey - Variable in class com.tangosol.coherence.rest.DefaultKeyConverter
-
Key class.
- m_clzKey - Variable in class com.tangosol.util.RestrictedCollections.RestrictedMap
-
The class of key stored in the Map.
- m_clzPartialClass - Variable in class com.tangosol.coherence.rest.util.PropertySpec
-
Property class (only for partial properties).
- m_clzPartitionMap - Variable in class com.tangosol.net.partition.ObservableSplittingBackingCache
-
- m_clzType - Variable in class com.tangosol.run.xml.PropertyAdapter
-
The type of the property.
- m_clzVal - Variable in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet
-
The class of value stored in the Map.
- m_clzVal - Variable in class com.tangosol.util.RestrictedCollections.RestrictedMap
-
The class of value stored in the Map.
- m_clzValue - Variable in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
-
The type of values for Cache
s.
- m_clzValue - Variable in class com.tangosol.coherence.rest.CacheResource
-
Value class for the entries stored in the wrapped cache.
- m_clzValue - Variable in class com.tangosol.coherence.rest.EntryResource
-
Class of the referenced entry's value.
- m_clzValue - Variable in class com.tangosol.coherence.rest.EntrySetResource
-
Class of the referenced entries' values.
- m_cMaxDelayMillis - Variable in class com.tangosol.net.partition.FailoverAccessPolicy
-
The maximum amount of time (in ms) that a request could be delayed by
this quorum policy.
- m_cMaxResults - Variable in class com.tangosol.coherence.rest.CacheResource
-
Size of the result set this resource is allowed to return.
- m_cMaxResults - Variable in class com.tangosol.coherence.rest.NamedQueryResource
-
Maximum size of the result set this resource is allowed to return.
- m_cMaxSize - Variable in class com.tangosol.util.aggregator.TopNAggregator.PartialResult
-
The maximum size of this partial result.
- m_cMaxUnits - Variable in class com.tangosol.net.cache.OldCache
-
Deprecated.
The number of units to allow the cache to grow to before pruning.
- m_cMaxUnits - Variable in class com.tangosol.net.cache.SerializationCache
-
Maximum number of units to manage in the cache.
- m_cMillis - Variable in class com.tangosol.util.SimpleQueryRecord.PartialResult.Step
-
The execution time in milliseconds.
- m_cMillisLastStart - Variable in class com.tangosol.persistence.AbstractSnapshotArchiver
-
The start time of the last operation.
- m_cMillisMax - Variable in class com.tangosol.persistence.AbstractSnapshotArchiver
-
The maxiumum time in millis to archive or retrieve a snapshot store.
- m_cMillisMin - Variable in class com.tangosol.persistence.AbstractSnapshotArchiver
-
The minimum time in millis to archive or retrieve a snapshot store.
- m_cMillisTotal - Variable in class com.tangosol.persistence.AbstractSnapshotArchiver
-
The total time in millis taken to archive or retrieve snapshot stores.
- m_cMissesMillis - Variable in class com.tangosol.net.cache.SimpleCacheStatistics
-
Total number of milliseconds used for get operations that were misses
since the last statistics reset.
- m_cNameSuffix - Variable in class com.tangosol.util.DaemonThreadFactory
-
The thread name counter.
- m_cNodes - Variable in class com.tangosol.util.SafeLinkedList
-
The size of the List.
- m_coffset - Variable in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
-
Offset of the current character.
- m_col - Variable in class com.tangosol.util.ConverterCollections.ConverterCollection
-
The underlying Collection.
- m_col - Variable in class com.tangosol.util.RestrictedCollections.RestrictedCollection
-
The underlying Collection.
- m_colDelegate - Variable in class com.tangosol.util.WrapperCollections.AbstractWrapperCollection
-
The Collection to which this wrapper delegates.
- m_colDelegate - Variable in class com.tangosol.util.WrapperCollections.ConcurrentWrapperCollection
-
The Collection to which this wrapper delegates.
- m_collValues - Variable in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
-
The values collection.
- m_colRegisteredDbs - Variable in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
-
Databases to close prior to deleting the Environment.
- m_colValues - Variable in class com.tangosol.io.nio.BinaryMap
-
The collection of values backed by this map.
- m_colValues - Variable in class com.tangosol.util.SafeHashMap
-
The collection of values backed by this map.
- m_colValues - Variable in class com.tangosol.util.SegmentedHashMap
-
The collection of values backed by this map.
- m_comparator - Variable in class com.tangosol.util.aggregator.AbstractComparableAggregator
-
The comparator to use for comparing extracted values.
- m_comparator - Variable in class com.tangosol.util.aggregator.TopNAggregator
-
The Comparator used to order the extracted values.
- m_comparator - Variable in class com.tangosol.util.comparator.SafeComparator
-
The wrapped Comparator.
- m_comparator - Variable in class com.tangosol.util.extractor.ComparisonValueExtractor
-
An underlying Comparator object (optional).
- m_comparator - Variable in class com.tangosol.util.SafeSortedMap
-
The comparator used to sort this map.
- m_comparator - Variable in class com.tangosol.util.SimpleMapIndex
-
Comparator used to sort the index.
- m_comparator - Variable in class com.tangosol.util.SortedBag
-
The comparator used to compare logical elements.
- m_comparator_copy - Variable in class com.tangosol.util.aggregator.TopNAggregator.PartialResult
-
The comparator used to compare logical elements.
- m_complex - Variable in class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
-
The Complex value that corresponds to the user type that is being
written.
- m_compressor - Variable in class com.tangosol.util.ExternalizableHelper.FormatAwareCompressor
-
The wrapped DeltaCompressor.
- m_config - Variable in class com.tangosol.coherence.rest.DefaultRootResource
-
REST configuration.
- m_configuration - Variable in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCache
-
- m_contentionObserver - Variable in class com.tangosol.util.SegmentedConcurrentMap
-
The ContentionObserver; may be null.
- m_context - Variable in class com.tangosol.net.DefaultConfigurableCacheFactory.PartitionedBackingMapManager
-
Deprecated.
The BackingMapManagerContext to pass to the enclosed backing maps.
- m_context - Variable in class com.tangosol.util.ConverterCollections.ConverterMapEvent
-
The BackingMapManagerContext to use for extracting binary values.
- m_control - Variable in class com.tangosol.util.AsynchronousAgent
-
The underlying FlowControl; could be null if the "automatic flow control"
is turned on.
- m_conv - Variable in class com.tangosol.util.ConverterCollections.ConverterEnumerator
-
Converter to convert each item.
- m_convDown - Variable in class com.tangosol.util.ConverterCollections.ConverterCollection
-
The Converter from this Collection to the underlying Collection.
- m_convDown - Variable in class com.tangosol.util.ConverterCollections.ConverterListIterator
-
The Converter from this ListIterator to the underlying
ListIterator.
- m_converter - Variable in class com.tangosol.util.SimpleMapIndex.IndexCalculator
-
- m_converterFromBinary - Variable in class com.tangosol.net.cache.ContinuousQueryCache
-
- m_converterToBinary - Variable in class com.tangosol.net.cache.ContinuousQueryCache
-
- m_convKey - Variable in class com.tangosol.util.ConverterCollections.ConverterMapEvent
-
The Converter to view the underlying MapEvent's key.
- m_convKey - Variable in class com.tangosol.util.ConverterCollections.ConverterMapListener
-
The Converter to view an underlying CacheEvent's key.
- m_convKeyDown - Variable in class com.tangosol.util.ConverterCollections.ConverterEntrySet
-
The Converter used to pass keys down to the Entry Set.
- m_convKeyDown - Variable in class com.tangosol.util.ConverterCollections.ConverterMap
-
The Converter used to pass keys down to the Map.
- m_convKeyUp - Variable in class com.tangosol.util.ConverterCollections.ConverterEntry
-
The Converter used to view the Entry's key.
- m_convKeyUp - Variable in class com.tangosol.util.ConverterCollections.ConverterEntrySet
-
The Converter used to view keys stored in the Entry Set.
- m_convKeyUp - Variable in class com.tangosol.util.ConverterCollections.ConverterMap
-
The Converter used to view keys stored in the Map.
- m_convUp - Variable in class com.tangosol.util.ConverterCollections.ConverterCollection
-
The Converter from the underlying Collection to this Collection.
- m_convUp - Variable in class com.tangosol.util.ConverterCollections.ConverterListIterator
-
The Converter from the underlying ListIterator to this
ListIterator.
- m_convVal - Variable in class com.tangosol.util.ConverterCollections.ConverterMapEvent
-
The Converter to view the underlying MapEvent's value.
- m_convVal - Variable in class com.tangosol.util.ConverterCollections.ConverterMapListener
-
The Converter to view an underlying CacheEvent's value.
- m_convValDown - Variable in class com.tangosol.util.ConverterCollections.ConverterEntry
-
The Converter used to store the Entry's value.
- m_convValDown - Variable in class com.tangosol.util.ConverterCollections.ConverterEntrySet
-
The Converter used to pass values down to the Entry Set.
- m_convValDown - Variable in class com.tangosol.util.ConverterCollections.ConverterMap
-
The Converter used to pass keys down to the Map.
- m_convValUp - Variable in class com.tangosol.util.ConverterCollections.ConverterEntry
-
The Converter used to view the Entry's value.
- m_convValUp - Variable in class com.tangosol.util.ConverterCollections.ConverterEntrySet
-
The Converter used to view values stored in the Entry Set.
- m_convValUp - Variable in class com.tangosol.util.ConverterCollections.ConverterMap
-
The Converter used to view values stored in the Map.
- m_count - Variable in class com.tangosol.util.aggregator.AbstractBigDecimalAggregator
-
The count of processed entries.
- m_count - Variable in class com.tangosol.util.aggregator.AbstractComparableAggregator
-
The count of processed entries.
- m_count - Variable in class com.tangosol.util.aggregator.AbstractDoubleAggregator
-
The count of processed entries.
- m_count - Variable in class com.tangosol.util.aggregator.AbstractLongAggregator
-
The count of processed entries.
- m_countThreads - Variable in class com.tangosol.net.cache.AbstractBundler
-
A counter for the total number of threads that have started any bundle
related execution.
- m_cPartitions - Variable in class com.tangosol.persistence.GUIDHelper.GUIDResolver
-
The partition-count.
- m_cPruneUnits - Variable in class com.tangosol.net.cache.OldCache
-
Deprecated.
The number of units to prune the cache down to.
- m_cPruneUnits - Variable in class com.tangosol.net.cache.SerializationCache
-
The number of units to prune the cache down to.
- m_cPutsMillis - Variable in class com.tangosol.net.cache.SimpleCacheStatistics
-
Total number of milliseconds used for put operations since the last
statistics reset.
- m_cReads - Variable in class com.tangosol.util.ReadHeavyLongArray
-
The (dirty) total number of reads.
- m_cReadTrigger - Variable in class com.tangosol.util.ReadHeavyLongArray
-
The read count at which to trigger a switch to a lock-free delegate.
- m_cReconnectMillis - Variable in class com.tangosol.coherence.config.scheme.ContinuousQueryCacheScheme
-
- m_cReconnectMillis - Variable in class com.tangosol.net.cache.ContinuousQueryCache
-
The interval (in milliseconds) that indicates how often the
ContinuousQueryCache
should attempt to synchronize its content with the
underlying cache in case the connection is severed.
- m_cRecoveryMillis - Variable in class com.tangosol.net.GuardSupport.Context
-
The amount of time to allow for recovery
- m_cRecycleMax - Variable in class com.tangosol.util.RecyclingLinkedList
-
The maximum number of Nodes to recycle.
- m_cRecycleNodes - Variable in class com.tangosol.util.RecyclingLinkedList
-
The current number of Nodes being recycle.
- m_cRequests - Variable in class com.tangosol.net.partition.PartitionStatistics
-
The number of requests on this partition during the sampling period.
- m_cResults - Variable in class com.tangosol.util.aggregator.TopNAggregator
-
The maximum number of results to include in the aggregation result.
- m_cSampleMillis - Variable in class com.tangosol.net.partition.PartitionStatistics
-
The sample duration (in ms).
- m_cSegmentCapacity - Variable in class com.tangosol.util.SegmentedHashMap
-
The capacity of each segment (the point at which we should resize).
- m_cSize - Variable in class com.tangosol.util.KeyValueArrayMap
-
The number of map entries.
- m_cStoreEntries - Variable in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
The total number of entries written in Store operations.
- m_cStoreFailures - Variable in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
The number of Store failures.
- m_cStoreMillis - Variable in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
The cumulative time spent on Store operations.
- m_cStoreOps - Variable in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
The number of Store operations.
- m_cThreadWaitSnapshot - Variable in class com.tangosol.net.cache.AbstractBundler.Statistics
-
Snapshot for a combined thread waiting time.
- m_cThresholdMillis - Variable in class com.tangosol.net.partition.FailoverAccessPolicy
-
The amount of time after being in an endangered state before the quorum
policy should start to hold client requests.
- m_cTimeoutMillis - Variable in class com.tangosol.net.GuardSupport.Context
-
The timeout interval to use for the represented Guardable.
- m_ctorFromString - Variable in class com.tangosol.coherence.rest.DefaultKeyConverter
-
Constructor to use for conversion from string.
- m_ctx - Variable in class com.tangosol.io.pof.PofBufferReader
-
The PofContext to use to realize user data types as Java objects.
- m_ctx - Variable in class com.tangosol.io.pof.PofBufferWriter
-
The PofContext used by this PofBufferWriter to serialize user types.
- m_ctx - Variable in class com.tangosol.net.cache.BackingMapBinaryEntry
-
The backing map context.
- m_ctx - Variable in class com.tangosol.util.SimpleMapIndex
-
The
context
associated with this index.
- m_ctxLast - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
The last analysis context.
- m_cUnits - Variable in class com.tangosol.util.SimpleMapIndex
-
The size footprint of the index, in units (as defined by the UnitCalculator).
- m_current - Variable in class com.tangosol.coherence.dsltools.precedence.OPScanner
-
The current BaseTokens from data
- m_current - Variable in class com.tangosol.util.SafeLinkedList
-
The Node at the "cached position" in the List.
- m_currentToken - Variable in class com.tangosol.coherence.dsltools.precedence.OPScanner
-
The current OPToken translated from current
- m_cWaitMillis - Variable in class com.tangosol.net.SimpleServiceMonitor
-
The number of milliseconds between checking the status of the services.
- m_cWaitMillis - Variable in class com.tangosol.util.WrapperConcurrentMap
-
The number of milliseconds to continue trying to obtain a lock
in case when the locking is enforced.
- m_cWaitTime - Variable in class com.tangosol.net.partition.PartitionStatistics
-
The total amount of time (in ms) that tasks/requests spent waiting.
- m_daemonRequest - Variable in class com.tangosol.net.LoadBalancer.ResponseHandler
-
The RequestHandler that this ResponseHandler belongs to.
- m_daemonResponse - Variable in class com.tangosol.net.LoadBalancer.RequestHandler
-
The ResponseHandler that handles the server-to-client response
routing corresponding to requests routed client-to-server by this
daemon.
- m_data - Variable in class com.tangosol.coherence.dsltools.precedence.OPScanner
-
The source of BaseTokens to process
- m_db - Variable in class com.tangosol.io.bdb.BerkeleyDBBinaryStore.DatabaseHolder
-
The underlying Database Handle.
- m_db - Variable in class com.tangosol.io.bdb.BerkeleyDBBinaryStore
-
The Database handle.
- m_dbConfig - Variable in class com.tangosol.io.bdb.DatabaseFactory
-
Configuration to use when creating new Databases.
- m_decResult - Variable in class com.tangosol.util.aggregator.AbstractBigDecimalAggregator
-
The running result value.
- m_delegateSocketProvider - Variable in class com.tangosol.net.TcpDatagramSocketProvider.DefaultDependencies
-
Underlying TCP socket provider
- m_Dependencies - Variable in class com.tangosol.net.SocketProviderFactory
-
Dependencies
- m_dependencies - Variable in class com.tangosol.net.TcpDatagramSocketProvider
-
TcpDatagramSocketProvider Dependencies
- m_dflPruneLevel - Variable in class com.tangosol.net.cache.OldCache
-
Deprecated.
The percentage of the total number of units that will remain after the
cache manager prunes the cache (i.e. this is the "low water mark"
value); this value is in the range 0.0 to 1.0.
- m_dflResult - Variable in class com.tangosol.util.aggregator.AbstractDoubleAggregator
-
The running result value.
- m_dir - Variable in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder.DirectoryLock
-
Directory to lock.
- m_dirEnv - Variable in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
-
Environment directory.
- m_dirLock - Variable in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
-
Lock held on the directory associated with the Environment.
- m_dirParent - Variable in class com.tangosol.io.bdb.BerkeleyDBBinaryStoreManager
-
Parent directory for creating Environments.
- m_dirParent - Variable in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
-
Configuration setting for parent directory.
- m_dPreviousSizeThreshold - Variable in class com.tangosol.net.cache.AbstractBundler
-
The previous bundle size threshold value.
- m_element - Variable in class com.tangosol.run.xml.SimpleElement.ElementIterator
-
- m_eNext - Variable in class com.tangosol.util.SafeHashMap.Entry
-
The next entry in the linked list (an open hashing implementation).
- m_eNext - Variable in class com.tangosol.util.SegmentedHashMap.Entry
-
The next entry in the linked list (an open hashing implementation).
- m_entry - Variable in class com.tangosol.util.ConverterCollections.AbstractConverterEntry
-
The underlying entry.
- m_entry - Variable in class com.tangosol.util.InvocableMapHelper.RoutingMapTriggerEntry
-
The underlying entry.
- m_entry - Variable in class com.tangosol.util.processor.SingleEntryAsynchronousProcessor
-
The result of entry processor invocation.
- m_entry - Variable in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet.RestrictedEntry
-
- m_entryNew - Variable in class com.tangosol.util.ConverterCollections.ConverterMapEvent
-
Cached new entry.
- m_entryOld - Variable in class com.tangosol.util.ConverterCollections.ConverterMapEvent
-
Cached old entry.
- m_env - Variable in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
-
Berkeley DB Environment for managing Databases.
- m_env - Variable in class com.tangosol.persistence.AbstractPersistenceManager
-
The environment that created this AbstractPersistenceManager.
- m_envConfig - Variable in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
-
Berkeley DB Environment Configuration.
- m_envHolder - Variable in class com.tangosol.io.bdb.DatabaseFactory
-
Holder for Environment used to create Databases.
- m_eraseBundler - Variable in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
The bundler for erase() operations.
- m_eReason - Variable in class com.tangosol.util.aggregator.AsynchronousAggregator
-
Reason for the failed operation.
- m_eReason - Variable in class com.tangosol.util.processor.AsynchronousProcessor
-
Reason for the failed operation.
- m_eReason - Variable in class com.tangosol.util.processor.SingleEntryAsynchronousProcessor
-
Reason for the failed operation.
- m_event - Variable in class com.tangosol.util.ConverterCollections.ConverterMapEvent
-
The underlying MapEvent.
- m_eventQueue - Variable in class com.tangosol.net.cache.ContinuousQueryCache
-
The event queue for this ContinuousQueryCache
.
- m_executor - Variable in class com.tangosol.coherence.dslquery.ExecutionContext
-
- m_executor - Variable in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
-
- m_extractor - Variable in class com.tangosol.coherence.rest.util.MvelManipulator
-
The underlying ValueExtractor.
- m_extractor - Variable in class com.tangosol.coherence.rest.util.PropertySpec
-
An extractor that can extract value of this property from a target
object.
- m_extractor - Variable in class com.tangosol.util.aggregator.GroupAggregator
-
The underlying ValueExtractor.
- m_extractor - Variable in class com.tangosol.util.aggregator.TopNAggregator
-
The ValueExtractor used by this aggregator.
- m_extractor - Variable in class com.tangosol.util.extractor.CompositeUpdater
-
The ValueExtractor part.
- m_extractor - Variable in class com.tangosol.util.extractor.ConditionalExtractor
-
The underlying extractor.
- m_extractor - Variable in class com.tangosol.util.extractor.DeserializationAccelerator
-
The underlying extractor.
- m_extractor - Variable in class com.tangosol.util.extractor.KeyExtractor
-
The underlying ValueExtractor.
- m_extractor - Variable in class com.tangosol.util.filter.ExtractorFilter
-
The ValueExtractor used by this filter.
- m_extractor - Variable in class com.tangosol.util.filter.ValueChangeEventFilter
-
- m_extractor - Variable in class com.tangosol.util.processor.ExtractorProcessor
-
The underlying value extractor.
- m_extractor - Variable in class com.tangosol.util.processor.PropertyManipulator
-
The underlying ValueExtractor.
- m_extractor - Variable in class com.tangosol.util.SimpleMapIndex
-
ValueExtractor object that this MapIndex uses to extract an indexable
property value from a [converted] value stored in the resource map.
- m_fActivated - Variable in class com.tangosol.net.ExtensibleConfigurableCacheFactory
-
Indicates whether this factory has been activated.
- m_fActive - Variable in class com.tangosol.util.AbstractKeyBasedMap.DeferredCacheEvent
-
Whether the DeferredCacheEvent is in an active or inactive state.
- m_factory - Variable in class com.tangosol.io.bdb.BerkeleyDBBinaryStore
-
Factory used to create this Database.
- m_factoryCacheLoader - Variable in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
-
The Factory
for the CacheLoader
.
- m_factoryCacheWriter - Variable in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
-
The Factory
for the CacheWriter
.
- m_factoryExpiryPolicy - Variable in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
-
The Factory
for the ExpiryPolicy
.
- m_fAddStorageMBeanAttributes - Variable in class com.tangosol.net.management.MBeanAccessor.GetAttributes
-
Provide a way to disable management over rest assumption that
we want storage mbean attributes when processing a back tier cache.
- m_fAttribute - Variable in class com.tangosol.run.xml.PropertyAdapter
-
True if the property is stored in an attribute instead of an XML
element.
- m_fBlind - Variable in class com.tangosol.net.cache.CacheStoreMap.ReadWriteMap
-
True means that put() and remove() can return null, regardless of
the presence of an old value.
- m_fBlocking - Variable in class com.tangosol.net.TcpDatagramSocketProvider.DefaultDependencies
-
Specifies if the provider is to produce blocking datagram sockets.
- m_fBreakLines - Variable in class com.tangosol.io.Base64OutputStream
-
True if lines are to be broken by BASE64_LF;
- m_fByMember - Variable in class com.tangosol.net.partition.AbstractPartitionedIterator
-
Differentiates between by-member and by-partition iteration.
- m_fCacheValues - Variable in class com.tangosol.net.cache.ContinuousQueryCache
-
The option of whether or not to locally cache values.
- m_fCircular - Variable in class com.tangosol.net.RefreshableAddressProvider.CircularIterator
-
Whether this Iterator is currently in a circular mode.
- m_fClosed - Variable in class com.tangosol.io.Base64InputStream
-
True after close is invoked.
- m_fClosed - Variable in class com.tangosol.io.Base64OutputStream
-
True after close is invoked.
- m_fClosed - Variable in class com.tangosol.io.MultiByteArrayOutputStream
-
True after close is invoked.
- m_fContainer - Variable in class com.tangosol.coherence.rest.server.InjectionBinder
-
The flag specifying whether REST API is run inside the container (true)
or standalone (false).
- m_fDeepClone - Variable in class com.tangosol.run.xml.XmlBean.BeanInfo
-
Specifies whether the XML bean requires a deep clone.
- m_fDeferredEvent - Variable in class com.tangosol.util.WrapperObservableMap
-
Specifies whether or not fabricated events could be deferred.
- m_fDestroyed - Variable in class com.tangosol.net.cache.NearCache
-
True if {#link destroy()} has been called on this cache.
- m_fDestructive - Variable in class com.tangosol.io.MultiBufferReadBuffer.MultiBufferInput
-
True if the BufferInput set to self-destruct.
- m_fDestructive - Variable in class com.tangosol.io.MultiByteArrayInputStream
-
True iff the array will be null'd out as it is traversed.
- m_fDisposed - Variable in class com.tangosol.net.ExtensibleConfigurableCacheFactory
-
Indicates whether this factory has been disposed.
- m_fDisposed - Variable in class com.tangosol.net.SimpleServiceMonitor
-
- m_fDynamic - Variable in class com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy
-
If set to true, indicates a dynamic active recovery strategy.
- m_fEmptyIsNull - Variable in class com.tangosol.run.xml.IterableAdapter
-
Empty-is-null option: Empty iterable values are not stored in the
serialized form of the XmlBean nor in the XML form of the XmlBean.
- m_fEnforceLocking - Variable in class com.tangosol.util.WrapperConcurrentMap
-
Flag indicating whether or not the locking is enforced for put, remove
and clear operations.
- m_fEOF - Variable in class com.tangosol.io.Base64InputStream
-
True after eof is determined.
- m_fEOF - Variable in class com.tangosol.io.MultiByteArrayInputStream
-
True after eof is determined.
- m_fEraseAllSupported - Variable in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
Flag that determines whether or not EraseAll operations are supported
by the wrapped store.
- m_fEraseSupported - Variable in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
Flag that determines whether or not Erase operations are supported by
the wrapped store.
- m_fEraseUnsupported - Variable in class com.tangosol.net.cache.CacheStoreMap.ReadWriteMap
-
True means that a call to the CacheStore erase() method is assumed
to be unsupported.
- m_fEvolvable - Variable in class com.tangosol.io.pof.PofBufferWriter
-
Indicate if the object to be written is either Evolvable or part of an
Evolvable object.
- m_fExact - Variable in class com.tangosol.net.management.MBeanAccessor.QueryBuilder
-
Whether to construct a query without a wildcard suffix (exact) or
with.
- m_fExhausted - Variable in class com.tangosol.net.CompositeAddressProvider.SingleProvider
-
Is this AddressProvider exhausted?
- m_fExitWhenProcessingComplete - Variable in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
-
A flag indicating whether a CohQL session should be exited when the list of
statements has been executed.
- m_fExtended - Variable in class com.tangosol.coherence.dslquery.queryplus.ExtendedLanguageStatementBuilder.ExtendedLanguageQueryPlusStatement
-
Flag indicating whether this command turns trace on or off.
- m_fExtendedLanguage - Variable in class com.tangosol.coherence.dslquery.ExecutionContext
-
Flag that controls whether we except Map, and List as literals.
- m_fExtendedLanguage - Variable in class com.tangosol.coherence.dslquery.internal.AbstractCoherenceQueryWalker
-
Flag that controls whether we except Map, and List as literals.
- m_fExtendedLanguage - Variable in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
-
Flag that controls whether we except Map, and List as literals.
- m_fFederated - Variable in class com.tangosol.coherence.config.CacheMapping
-
- m_fForward - Variable in class com.tangosol.util.SimpleEnumerator
-
Iterator direction.
- m_fForwardIndex - Variable in class com.tangosol.util.extractor.ConditionalExtractor
-
Specifies whether or not this extractor will create a
ConditionalIndex
that supports a forward index.
- m_fForwardIndex - Variable in class com.tangosol.util.SimpleMapIndex
-
Specifies whether or not this MapIndex supports a forward index.
- m_filter - Variable in class com.tangosol.net.cache.CachingMap.FrontMapListener
-
The filter associated with this listener.
- m_filter - Variable in class com.tangosol.net.cache.ContinuousQueryCache
-
The filter that represents the subset of information from the
underlying
NamedCache
that this
ContinuousQueryCache
represents.
- m_filter - Variable in class com.tangosol.net.management.MBeanAccessor.GetAttributes
-
MBean Attribute filter.
- m_filter - Variable in class com.tangosol.net.management.ObjectNameExcludeFilter
-
The underlying filter.
- m_filter - Variable in class com.tangosol.net.partition.AbstractPartitionedIterator
-
The filter to query with.
- m_filter - Variable in class com.tangosol.util.aggregator.GroupAggregator
-
The Filter object representing the "having" clause of this "group by"
aggregator.
- m_filter - Variable in class com.tangosol.util.extractor.ConditionalExtractor
-
The filter used by this extractor.
- m_filter - Variable in class com.tangosol.util.filter.FilterTrigger
-
The underlying filter.
- m_filter - Variable in class com.tangosol.util.filter.MapEventFilter
-
The event value(s) filter.
- m_filter - Variable in class com.tangosol.util.processor.ConditionalProcessor
-
The underlying filter.
- m_filter - Variable in class com.tangosol.util.processor.ConditionalPut
-
The underlying filter.
- m_filter - Variable in class com.tangosol.util.processor.ConditionalPutAll
-
The underlying filter.
- m_filter - Variable in class com.tangosol.util.processor.ConditionalRemove
-
The underlying filter.
- m_filterAdd - Variable in class com.tangosol.net.cache.ContinuousQueryCache
-
The
MapEventFilter
that uses the
ContinuousQueryCache's
filter to
select events that would add elements to this cache's contents.
- m_filterRemove - Variable in class com.tangosol.net.cache.ContinuousQueryCache
-
The
MapEventFilter
that uses the
ContinuousQueryCache's
filter to
select events that would remove elements from this cache's contents.
- m_fImmutableValues - Variable in class com.tangosol.util.SimpleMapIndex
-
Specifies whether or not the index is based on the immutable values (e.g. keys).
- m_fIncrementalEvict - Variable in class com.tangosol.net.cache.OldCache
-
Deprecated.
Specifies whether or not this cache will incrementally evict.
- m_fInit - Variable in class com.tangosol.util.aggregator.CompositeAggregator
-
Flag specifying whether this aggregator has been initialized.
- m_fInit - Variable in class com.tangosol.util.aggregator.GroupAggregator
-
Flag specifying whether this aggregator has been initialized.
- m_fInitialized - Variable in class com.tangosol.util.SafeSortedMap.ViewMap.EntryIterator
-
Has this iterator been initialized yet?
- m_fInsert - Variable in class com.tangosol.util.processor.VersionedPut
-
Specifies whether or not an insert is allowed.
- m_fInsert - Variable in class com.tangosol.util.processor.VersionedPutAll
-
Specifies whether or not an insert is allowed.
- m_fInterfaceAllowed - Variable in class com.tangosol.io.pof.ConfigurablePofContext.PofConfig
-
True iff an interface name is acceptable in the configuration as
the class of a user type.
- m_fIsEnd - Variable in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
-
The flag set when end of file is detected.
- m_fKeysOnly - Variable in class com.tangosol.net.partition.PartitionedIterator
-
Differentiates between a key iterator (true) and an entry iterator
(false).
- m_fLazy - Variable in class com.tangosol.util.extractor.DeserializationAccelerator
-
The "lazy" flag.
- m_flGrowthRate - Variable in class com.tangosol.util.SafeHashMap
-
The rate of growth as a fraction of the current number of buckets,
0 < n, such that the hash map grows to bucketCount * (1 + growthRate)
- m_flGrowthRate - Variable in class com.tangosol.util.SegmentedHashMap
-
The rate of growth as a fraction of the current number of buckets,
0 < n, such that the hash map grows to bucketcount * (1 + growth-rate).
- m_flHeadWeight - Variable in class com.tangosol.util.SafeSortedMap.Split
-
The estimated weight of the head portion of the split, expressed as
a ratio of the size of the headMap to the size of the underlying
SafeSortedMap.
- m_fListeners - Variable in class com.tangosol.net.cache.ContinuousQueryCache
-
Keeps track of whether the ContinuousQueryCache
has listeners that
require this cache to cache values.
- m_flLoadFactor - Variable in class com.tangosol.util.SafeHashMap
-
The determining factor for the hash map capacity given a certain number
of buckets, such that capacity = bucketCount * loadFactor.
- m_flLoadFactor - Variable in class com.tangosol.util.SegmentedHashMap
-
The determining factor for the hash map capacity given a certain number
of buckets, such that capacity = bucketcount * loadfactor.
- m_flPctRecover - Variable in class com.tangosol.net.GuardSupport.Context
-
Percentage of the timeout after which to attempt recovery of the
Guardable.
- m_fManagementEnabled - Variable in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
-
Is JMX management enabled?
- m_fMutator - Variable in class com.tangosol.util.processor.MethodInvocationProcessor
-
A flag specifying whether the method mutates the state of a target object.
- m_fNewValue - Variable in class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventEntry
-
Determines whether this entry represents the old or new value.
- m_fNext - Variable in class com.tangosol.util.FilterEnumerator
-
Is there a next item which passed the test?
- m_fNullFirst - Variable in class com.tangosol.util.comparator.SafeComparator
-
Flag specifying if nulls should be sorted as less (first) or greater
(last) than all non-null elements.
- m_fOptimizeGetTime - Variable in class com.tangosol.net.cache.OldCache
-
Deprecated.
- m_fOptimizeMV - Variable in class com.tangosol.util.extractor.ConditionalExtractor
-
For an indexed value that is a multi-value (Collection or array) this flag
specifies whether an attempt should be made to search the forward map
for an existing reference that is "equal" to the specified multi-value
and use it instead (if available) to reduce the index memory footprint.
- m_fOrdered - Variable in class com.tangosol.util.SimpleMapIndex
-
Specifies whether or not this MapIndex orders the contents of the
indexed information.
- m_fParallel - Variable in class com.tangosol.util.aggregator.AbstractAggregator
-
Set to true if this aggregator realizes that it is going to be used in
parallel.
- m_fParallel - Variable in class com.tangosol.util.aggregator.CompositeAggregator
-
Flag specifying whether parallel optimizations can be used.
- m_fParallel - Variable in class com.tangosol.util.aggregator.GroupAggregator
-
Flag specifying whether parallel optimizations can be used.
- m_fParallel - Variable in class com.tangosol.util.aggregator.TopNAggregator
-
True iff this aggregator is to be used in parallel.
- m_fPreferJavaTime - Variable in class com.tangosol.io.pof.ConfigurablePofContext.PofConfig
-
True if Java 8 date/time types (java.time.*) should be preferred over
legacy types.
- m_fPreferJavaTime - Variable in class com.tangosol.io.pof.SimplePofContext
-
True if Java 8 date/time types (java.time.*) should be preferred over
legacy types.
- m_fPrefixAllowed - Variable in class com.tangosol.coherence.dsltools.precedence.InfixOPToken
-
Flag that control whether the operator can be used as a prefix.
- m_fPreserveOrder - Variable in class com.tangosol.util.filter.ArrayFilter
-
Flag indicating whether or not the filter order should be preserved.
- m_fPrev - Variable in class com.tangosol.util.FilterEnumerator
-
Is there a previous item which passed the test and can be removed?
- m_fPrimary - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.LoadComparator
-
Flag for primary or backup load comparison.
- m_fPrimary - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.UnderloadedFilter
-
True iff this filter represents primary partition load.
- m_fPriming - Variable in class com.tangosol.net.cache.CacheEvent
-
Flag indicating whether or not the event is a priming event (NearCache).
- m_fRandom - Variable in class com.tangosol.net.partition.AbstractPartitionedIterator
-
An option to randomize the order of iteration to avoid harmonics in a
clustered environment.
- m_fReadOnly - Variable in class com.tangosol.coherence.config.scheme.ContinuousQueryCacheScheme
-
- m_fReadOnly - Variable in class com.tangosol.net.cache.ContinuousQueryCache
-
The option to disallow modifications through this ContinuousQueryCache
interface.
- m_fReadThrough - Variable in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
-
Is "read-through" enabled?
- m_fReferenceEnabled - Variable in class com.tangosol.io.pof.ConfigurablePofContext.PofConfig
-
True iff POF Identity/Reference type support is enabled.
- m_fReferenceEnabled - Variable in class com.tangosol.io.pof.SimplePofContext
-
True if POF Identity/Reference type support is enabled.
- m_fRefresh - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
True if JMXPartitionStats should be updated.
- m_fRefreshContext - Variable in class com.tangosol.net.cache.ReadWriteBackingMap.ReadThread
-
- m_fRefreshContext - Variable in class com.tangosol.net.cache.ReadWriteBackingMap.WriteThread
-
- m_fReleased - Variable in class com.tangosol.persistence.AbstractPersistenceManager
-
Whether this PersistenceManager has been released.
- m_fResolve - Variable in class com.tangosol.net.ConfigurableAddressProvider
-
Deprecated.
- m_fRetained - Variable in class com.tangosol.util.SubSet
-
Toggles between whether the modifications are removed or retained.
- m_fReturn - Variable in class com.tangosol.util.processor.ConditionalPut
-
Specifies whether or not a return value is required.
- m_fReturn - Variable in class com.tangosol.util.processor.ConditionalRemove
-
Specifies whether or not a return value is required.
- m_fReturn - Variable in class com.tangosol.util.processor.VersionedPut
-
Specifies whether or not a return value is required.
- m_fReturn - Variable in class com.tangosol.util.processor.VersionedPutAll
-
Specifies whether or not a return value is required.
- m_fRoundRobin - Variable in class com.tangosol.net.LoadBalancer
-
Toggles between random and round-robin load balancing.
- m_fRValueExpected - Variable in class com.tangosol.coherence.dslquery.internal.UpdateSetListMaker
-
Flag that controls the path behaviors for lvalues and rvalues.
- m_fSafe - Variable in class com.tangosol.net.ConfigurableAddressProvider
-
Specifies if the provider is only to return resolved addresses.
- m_fSanity - Variable in class com.tangosol.coherence.dslquery.ExecutionContext
-
A flag that enables sanity checking.
- m_fSanity - Variable in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
-
A flag that enables sanity checking.
- m_fServicesStarted - Variable in class com.tangosol.net.DefaultCacheServer
-
Flag that indicates whether this instance of DefaultCacheServer has
called start on the associated services.
- m_fSharedStorage - Variable in class com.tangosol.persistence.GUIDHelper.GUIDResolver
-
Specifies whether or not the storage is shared.
- m_fShutdown - Variable in class com.tangosol.net.DefaultCacheServer
-
Flag that indicates whether of not the shutdown was initiated.
- m_fSilent - Variable in class com.tangosol.coherence.dslquery.ExecutionContext
-
A flag indicating whether the query session is running in silent mode.
- m_fSilent - Variable in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
-
A flag indicating whether the query session is running in silent mode.
- m_fSparse - Variable in class com.tangosol.run.xml.IterableAdapter
-
Sparse array storage option.
- m_fSplitCollection - Variable in class com.tangosol.util.SimpleMapIndex
-
If a value extracted by the ValueExtractor is a Collection, this
property specifies whether or not it should be treated as a Collection
of contained attributes or indexed as a single composite attribute.
- m_fStarted - Variable in class com.tangosol.net.SimpleServiceMonitor
-
- m_fStatisticsEnabled - Variable in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
-
Are statistics enabled?
- m_fStopOnError - Variable in class com.tangosol.coherence.dslquery.ExecutionContext
-
A flag indicating when true that CohQL should stop processing multiple
statements if an error occurs (for example when processing a file), or
when false that errors will be logged and statement processing will continue.
- m_fStopOnError - Variable in class com.tangosol.coherence.dslquery.queryplus.WheneverStatementBuilder.WheneverQueryPlusStatement
-
The QueryPlus error action.
- m_fStoreAllSupported - Variable in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
Flag that determines whether or not StoreAll operations are supported
by the wrapped store.
- m_fStoreByValue - Variable in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
-
Is store-by-reference enabled?
- m_fStoreSupported - Variable in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
Flag that determines whether or not Store operations are supported by
the wrapped store.
- m_fStoreUnsupported - Variable in class com.tangosol.net.cache.CacheStoreMap.ReadWriteMap
-
True means that a call to the CacheStore store() method is assumed
to be unsupported.
- m_fStreaming - Variable in class com.tangosol.util.aggregator.CompositeAggregator
-
Flag specifying whether streaming optimizations can be used.
- m_fStreaming - Variable in class com.tangosol.util.aggregator.GroupAggregator
-
Flag specifying whether streaming optimizations can be used.
- m_fstreamLocked - Variable in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder.DirectoryLock
-
The FileStream which the actual lock is held on.
- m_fStrict - Variable in class com.tangosol.net.cache.ReadonlyNamedCache
-
Specifies whether or not the "read-only" nature of this NamedCache
is strictly enforced.
- m_fStrict - Variable in class com.tangosol.util.WrapperCollections.ConcurrentWrapperEntrySet
-
Determines whether or not all of the Entry methods are protected;
if set to true, then all Entry methods are protected.
- m_fStrict - Variable in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
-
Determines whether or not all of the Entry methods are protected;
if set to true, then all Entry methods are protected.
- m_fSubclassAllowed - Variable in class com.tangosol.io.pof.ConfigurablePofContext.PofConfig
-
True iff serialization of sub-classes is explicitly enabled.
- m_fSynthetic - Variable in class com.tangosol.net.cache.BackingMapBinaryEntry
-
Whether this update is synthetic.
- m_fSynthetic - Variable in class com.tangosol.net.cache.CacheEvent
-
Flag indicating whether or not the event is synthetic.
- m_fTemporary - Variable in class com.tangosol.io.bdb.BerkeleyDBBinaryStore.DatabaseHolder
-
Flag indicating if the database is temporary.
- m_fTemporary - Variable in class com.tangosol.io.bdb.BerkeleyDBBinaryStoreManager
-
Flag indicating if this store manages temporary data.
- m_fTemporary - Variable in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
-
Flag indicating if this is a temporary environment.
- m_fTrace - Variable in class com.tangosol.coherence.dslquery.ExecutionContext
-
Flag that indicates tracing mode.
- m_fTrace - Variable in class com.tangosol.coherence.dslquery.queryplus.TraceStatementBuilder.TraceQueryPlusStatement
-
Flag indicating whether this command turns trace on or off.
- m_fTraceEnabled - Variable in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
-
Flag that indicates tracing mode.
- m_fTranslateEvents - Variable in class com.tangosol.util.WrapperObservableMap
-
Specifies whether or not events are translated by this wrapper.
- m_fUseIs - Variable in class com.tangosol.util.processor.PropertyManipulator
-
The getter prefix flag.
- m_fUserTypeBegin - Variable in class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
-
True iff the type and version identifier of the user type was
written to the POF stream.
- m_fUserTypeEnd - Variable in class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
-
True iff the user type was written to the POF stream.
- m_fValidate - Variable in class com.tangosol.run.xml.SimpleParser
-
If true, validate XML if it contains an XSD reference
- m_fWriteThrough - Variable in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
-
Is "write-through" enabled?
- m_gateLockAll - Variable in class com.tangosol.util.SegmentedConcurrentMap
-
The Gate controlling LOCK_ALL access for this map.
- m_gateMap - Variable in class com.tangosol.util.WrapperConcurrentMap
-
The ThreadGate object for the entire map.
- m_guardian - Variable in class com.tangosol.net.GuardSupport
-
The Guardian that is managing this GuardSupport.
- m_handler - Variable in class com.tangosol.io.pof.PofBufferWriter
-
The WritingPofHandler used to write a POF stream.
- m_head - Variable in class com.tangosol.util.AbstractSparseArray
-
The first node of the tree (or null if the tree is empty).
- m_head - Variable in class com.tangosol.util.SafeLinkedList
-
The first Node in the List (or null if empty).
- m_iArray - Variable in class com.tangosol.io.MultiByteArrayInputStream
-
The index of the current byte array.
- m_iArrayMarked - Variable in class com.tangosol.io.MultiByteArrayInputStream
-
The index of the marked byte array.
- m_iFirst - Variable in class com.tangosol.util.CircularArrayList
-
The offset to the first element.
- m_iItem - Variable in class com.tangosol.util.SimpleEnumerator
-
Iterator position: next item to return.
- m_iKey - Variable in class com.tangosol.util.KeyValueArrayMap
-
The index into the key array of the first key.
- m_iLast - Variable in class com.tangosol.net.ConfigurableAddressProvider
-
Index of the last returned address.
- m_iLast - Variable in class com.tangosol.util.CircularArrayList
-
The offset to one past the last element.
- m_impl - Variable in class com.tangosol.net.TcpDatagramSocket
-
- m_in - Variable in class com.tangosol.io.pof.PofBufferReader
-
The BufferInput containing the POF stream.
- m_in - Variable in class com.tangosol.io.WrapperDataInputStream
-
The underlying DataInput object to use.
- m_index - Variable in class com.tangosol.util.SimpleMapIndex.IndexCalculator
-
The container index.
- m_iNextDestination - Variable in class com.tangosol.net.LoadBalancer
-
Round-robin index.
- m_iNextIter - Variable in class com.tangosol.util.ChainedEnumerator
-
The next Iterator (index into the m_listIter) to iterate.
- m_info - Variable in class com.tangosol.net.DefaultConfigurableCacheFactory.PartitionedBackingMapManager
-
Deprecated.
The CacheInfo for the enclosed backing maps.
- m_infoBean - Variable in class com.tangosol.run.xml.PropertyAdapter
-
The BeanInfo object that contains this PropertyAdapter.
- m_infoQuorum - Variable in class com.tangosol.net.PartitionedService.PartitionRecoveryAction
-
The "last good" service membership.
- m_iOrderId - Variable in class com.tangosol.util.AsynchronousAgent
-
A unit-of-order id associated with this agent.
- m_iPos - Variable in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
-
The current position in the underlying Reader.
- m_iPos - Variable in class com.tangosol.util.SafeLinkedList
-
The "cached position" in the List.
- m_iPrevProp - Variable in class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
-
The index of the last property written to the POF stream or -1 if
the first property has yet to be written.
- m_iProp - Variable in class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
-
The index of the user type being written.
- m_iStartPos - Variable in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
-
The saved start position for a token.
- m_iStore - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.SafetyFilter
-
The storage index at which to evaluate members for safety.
- m_iter - Variable in class com.tangosol.util.ConverterCollections.ConverterEntrySet.ConverterIterator
-
The underlying Iterator.
- m_iter - Variable in class com.tangosol.util.ConverterCollections.ConverterEnumerator
-
Iterator of Objects to convert.
- m_iter - Variable in class com.tangosol.util.ConverterCollections.ConverterListIterator
-
The underlying ListIterator.
- m_iter - Variable in class com.tangosol.util.FilterEnumerator
-
Objects to filter/enumerate.
- m_iter - Variable in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet.RestrictedIterator
-
- m_iter - Variable in class com.tangosol.util.RestrictedCollections.RestrictedListIterator
-
The underlying ListIterator.
- m_iterAddr - Variable in class com.tangosol.net.ConfigurableAddressProvider
-
An address iterator for the previously resolved address.
- m_iterAddress - Variable in class com.tangosol.net.CompositeAddressProvider.AddressIterator
-
The iterator of Addresses from the current provider.
- m_iterator - Variable in class com.tangosol.net.RefreshableAddressProvider.CircularIterator
-
The iterator used to implement the AddressProvider interface.
- m_iterator - Variable in class com.tangosol.run.xml.SimpleElement.ElementIterator
-
- m_iteratorInternal - Variable in class com.tangosol.util.CopyOnWriteLongArray.UnmodifiableIterator
-
The internal Iterator
- m_iterCurrent - Variable in class com.tangosol.util.ChainedEnumerator
-
The current Iterator.
- m_iterEvict - Variable in class com.tangosol.net.cache.OldCache
-
Deprecated.
For deferred eviction, iterator of entries to evict.
- m_iterInternal - Variable in class com.tangosol.net.CompositeAddressProvider
-
The default iterator used to implement the AddressProvider interface.
- m_iterKeys - Variable in class com.tangosol.net.cache.OverflowMap.EntrySet.EntrySetIterator
-
Key iterator.
- m_iterKeys - Variable in class com.tangosol.util.AbstractKeyBasedMap.EntrySet.EntrySetIterator
-
Key iterator.
- m_iterKeys - Variable in class com.tangosol.util.AbstractKeyBasedMap.ValuesCollection.ValuesIterator
-
A key iterator.
- m_iterPage - Variable in class com.tangosol.util.PagedIterator
-
An Iterator for the current page.
- m_iterProvider - Variable in class com.tangosol.net.CompositeAddressProvider.AddressIterator
-
The iterator of AddressProviders.
- m_iValue - Variable in class com.tangosol.util.KeyValueArrayMap
-
The index into the value array of the first value.
- m_keyConverter - Variable in class com.tangosol.coherence.rest.CacheResource
-
Key converter.
- m_laClass - Variable in class com.tangosol.io.pof.SimplePofContext
-
A LongArray of user types, indexed by type identifier.
- m_language - Variable in class com.tangosol.coherence.dslquery.ExecutionContext
-
- m_laSerializer - Variable in class com.tangosol.io.pof.SimplePofContext
-
A LongArray of PofSerializer objects, indexed by type identifier.
- m_ldtCompleted - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
The timestamp of when the analysis represented by this context was
completed, or 0 if it is not yet complete.
- m_ldtConnectionTimestamp - Variable in class com.tangosol.net.cache.ContinuousQueryCache
-
The timestamp when the synchronization was last attempted.
- m_ldtEndangered - Variable in class com.tangosol.net.partition.FailoverAccessPolicy
-
The time at which the service most recently became endangered (or 0 if
the service is in the "safe" state).
- m_ldtExpiry - Variable in class com.tangosol.net.cache.BackingMapBinaryEntry
-
- m_ldtLastMissedSoftTimeout - Variable in class com.tangosol.net.GuardSupport.Context
-
The soft-timeout stamp that was violated, resulting in a recovery
attempt.
- m_ldtLastRefresh - Variable in class com.tangosol.net.RefreshableAddressProvider
-
The last timestamp when the address list was refreshed.
- m_ldtLastReport - Variable in class com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy
-
The last time disallowed actions were reported.
- m_ldtLastTransfer - Variable in class com.tangosol.net.partition.PartitionStatistics
-
The time at this this partition was last transferred.
- m_ldtLogMissingIdx - Variable in class com.tangosol.util.SimpleMapIndex
-
The time at which the most recent logging of "missing inverse index"
messages started.
- m_ldtNextCheck - Variable in class com.tangosol.net.GuardSupport
-
The next time at which the Guardables should be checked.
- m_ldtSampleStart - Variable in class com.tangosol.net.partition.PartitionStatistics
-
The sample start time.
- m_ldtSoftTimeout - Variable in class com.tangosol.net.GuardSupport.Context
-
The next soft-timeout for the Guardable
- m_ldtTimeout - Variable in class com.tangosol.net.GuardSupport.Context
-
The next timeout for the Guardable.
- m_lIndexLast - Variable in class com.tangosol.util.AbstractSafeLongArray.SafeIterator
-
The index associated with the last returned value
- m_lineNumber - Variable in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
-
The current line number.
- m_list - Variable in class com.tangosol.net.LoadBalancer.Queue
-
A list of items that have been queued.
- m_listBindVars - Variable in class com.tangosol.coherence.dslquery.internal.AbstractCoherenceQueryWalker
-
The current indexed list of bind variables.
- m_listBlock - Variable in class com.tangosol.io.MultiByteArrayOutputStream
-
The list of blocks.
- m_listBundle - Variable in class com.tangosol.net.cache.AbstractBundler
-
A pool of Bundle objects.
- m_listCache - Variable in class com.tangosol.net.RefreshableAddressProvider
-
The cached addresses.
- m_listener - Variable in class com.tangosol.net.cache.ContinuousQueryCache.EventRouter
-
The MapListener to route to.
- m_listenerAdd - Variable in class com.tangosol.net.cache.ContinuousQueryCache
-
The
listener
that gets information about what should be in this cache.
- m_listenerDeactivation - Variable in class com.tangosol.net.cache.CachingMap
-
The NamedCache deactivation listener.
- m_listenerDeactivation - Variable in class com.tangosol.net.cache.ContinuousQueryCache
-
The NamedCacheDeactivationListener
.
- m_listenerInternal - Variable in class com.tangosol.util.WrapperObservableMap
-
The MapListener used to listen to the wrapped ObservableMap.
- m_listenerRemove - Variable in class com.tangosol.net.cache.ContinuousQueryCache
-
The
listener
that gets information about what should be thrown out of
this cache.
- m_listenersCached - Variable in class com.tangosol.util.MapListenerSupport
-
A cached set of Listeners.
- m_listenerService - Variable in class com.tangosol.net.cache.ContinuousQueryCache
-
- m_listenerSupport - Variable in class com.tangosol.net.cache.ContinuousQueryCache
-
- m_listenerSupport - Variable in class com.tangosol.net.cache.OldCache
-
Deprecated.
The MapListenerSupport object.
- m_listenerSupport - Variable in class com.tangosol.net.cache.ReadWriteBackingMap
-
MapListenerSupport object.
- m_listenerSupport - Variable in class com.tangosol.util.ObservableHashMap
-
The MapListenerSupport object.
- m_listenerSupport - Variable in class com.tangosol.util.WrapperObservableMap
-
The event listeners.
- m_listFiles - Variable in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
-
A list of statement script files to execute when the CohQL session starts.
- m_listHandler - Variable in class com.tangosol.net.LoadBalancer
-
The list of RequestHandler daemons.
- m_listHolders - Variable in class com.tangosol.net.ConfigurableAddressProvider
-
A read-only list of ProvidedAddress objects.
- m_listIter - Variable in class com.tangosol.util.ChainedEnumerator
-
The Iterators.
- m_listListenerConfigurations - Variable in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
-
The CacheEntryListenerConfiguration
s.
- m_listResultEntries - Variable in class com.tangosol.util.processor.AsynchronousProcessor
-
List of result value entries.
- m_listStatements - Variable in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
-
A list of statements to execute when the CohQL session starts.
- m_listSteps - Variable in class com.tangosol.util.SimpleQueryRecord.PartialResult
-
The map of steps.
- m_listSubSteps - Variable in class com.tangosol.util.SimpleQueryRecord.PartialResult.Step
-
The list of child steps.
- m_lLastPrune - Variable in class com.tangosol.net.cache.OldCache
-
Deprecated.
The last time that a prune was run.
- m_lNextFlush - Variable in class com.tangosol.net.cache.OldCache
-
Deprecated.
The time before which a expired-entries flush will not be performed.
- m_loadBundler - Variable in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
The bundler for load() operations.
- m_loader - Variable in class com.tangosol.io.WrapperDataInputStream
-
The class loader used to resolve deserialized classes.
- m_loader - Variable in class com.tangosol.net.cache.CacheLoaderCacheStore
-
The CacheLoader to delegate to.
- m_loader - Variable in class com.tangosol.net.cache.ContinuousQueryCache
-
The
ClassLoader
to use when de-serializing/serializing keys and values.
- m_loader - Variable in class com.tangosol.net.DefaultConfigurableCacheFactory.PartitionedBackingMapManager
-
Deprecated.
The ClassLoader to pass to the enclosed backing maps.
- m_loadLocal - Variable in class com.tangosol.net.proxy.DefaultProxyServiceLoadBalancer
-
The ServiceLoad associated with the "local" Member.
- m_lock - Variable in class com.tangosol.util.WrapperCollections.ConcurrentWrapperCollection
-
The read/write lock for concurrency control.
- m_lock - Variable in class com.tangosol.util.WrapperCollections.ConcurrentWrapperEntry
-
The read/write lock for concurrency control.
- m_lock - Variable in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
-
The read/write lock for concurrency control.
- m_lockDir - Variable in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder.DirectoryLock
-
The actual FileLock.
- m_lockExclusive - Variable in class com.tangosol.util.WrapperCollections.ConcurrentWrapperCollection
-
The exclusive lock for performing read/write operations.
- m_lockExclusive - Variable in class com.tangosol.util.WrapperCollections.ConcurrentWrapperEntry
-
The exclusive lock for performing read/write operations.
- m_lockExclusive - Variable in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
-
The exclusive lock for performing read/write operations.
- m_lockFile - Variable in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
-
The FileLock used to prevent concurrent access to the data
directory underlying this persistent store.
- m_lockRead - Variable in class com.tangosol.util.ReadHeavyLongArray
-
The mutable read lock.
- m_lockShared - Variable in class com.tangosol.util.WrapperCollections.ConcurrentWrapperCollection
-
The shared lock for performing read operations.
- m_lockShared - Variable in class com.tangosol.util.WrapperCollections.ConcurrentWrapperEntry
-
The shared lock for performing read operations.
- m_lockShared - Variable in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
-
The shared lock for performing read operations.
- m_lResult - Variable in class com.tangosol.util.aggregator.AbstractLongAggregator
-
The running result value.
- m_lValue - Variable in class com.tangosol.util.PrimitiveSparseArray.PrimitiveNode
-
The Node's value.
- m_manager - Variable in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCache
-
- m_manager - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
The DistributionManager.
- m_managerActive - Variable in class com.tangosol.persistence.AbstractPersistenceEnvironment
-
This singleton active manager.
- m_manipulator - Variable in class com.tangosol.util.processor.PropertyProcessor
-
The property value manipulator.
- m_map - Variable in class com.tangosol.util.aggregator.ReducerAggregator
-
The resulting map of reduced values.
- m_map - Variable in class com.tangosol.util.ConverterCollections.ConverterMap
-
The underlying Map.
- m_map - Variable in class com.tangosol.util.ConverterCollections.ConverterMapListener
-
The converting Map the will be the source of converted events.
- m_map - Variable in class com.tangosol.util.InvocableMapHelper.SimpleEntry
-
The map.
- m_map - Variable in class com.tangosol.util.MapSet
-
The underlying Map.
- m_map - Variable in class com.tangosol.util.processor.ConditionalPutAll
-
Specifies the map of new values.
- m_map - Variable in class com.tangosol.util.processor.VersionedPutAll
-
Specifies the map of new values.
- m_map - Variable in class com.tangosol.util.RestrictedCollections.RestrictedMap
-
The underlying Map.
- m_map - Variable in class com.tangosol.util.SortedBag
-
The internal sorted map holding the bag contents.
- m_map - Variable in class com.tangosol.util.WrapperObservableMap
-
The (wrapped) map containing all the resources.
- m_mapAttribute - Variable in class com.tangosol.net.DefaultConfigurableCacheFactory.CacheInfo
-
Deprecated.
Map of scheme attributes.
- m_mapAttributes - Variable in class com.tangosol.net.management.MBeanAccessor.SetAttributes
-
The AttributeList to be updated.
- m_mapBack - Variable in class com.tangosol.net.cache.SimpleOverflowMap
-
The "back" map, which the front overflows to.
- m_mapBackingMap - Variable in class com.tangosol.net.DefaultConfigurableCacheFactory.Manager
-
Deprecated.
The map of backing maps keyed by corresponding cache names.
- m_mapBackingMapListeners - Variable in class com.tangosol.net.DefaultConfigurableCacheFactory.Manager
-
Deprecated.
The map of backing map listeners keyed by the corresponding backing
map references.
- m_mapByLoader - Variable in class com.tangosol.net.ScopedCacheFactoryBuilder
-
Mapping used to associate class loaders with the cache factories that are
configured on them.
- m_mapClassNameByTypeId - Variable in class com.tangosol.io.pof.ConfigurablePofContext.PofConfig
-
Once initialized, this references a thread-safe Map that contains
mappings from POF type identifiers (wrapped as Integer objects) to
Java class names.
- m_mapConcurrent - Variable in class com.tangosol.util.ConverterCollections.ConverterNamedCache
-
A Converter ConcurrentMap around the underlying NamedCache.
- m_mapConfigByLoader - Variable in class com.tangosol.net.ScopedCacheFactoryBuilder
-
Mapping used to associate class loaders with specific configuration elements.
- m_mapDatagramSocketProvider - Variable in class com.tangosol.net.SocketProviderFactory
-
A map of instantiated datagram socket providers, key'd by id.
- m_mapDelegate - Variable in class com.tangosol.util.WrapperCollections.AbstractWrapperMap
-
The Map to which this wrapper delegates.
- m_mapDelegate - Variable in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
-
The Map to which this wrapper delegates.
- m_mapEvolvable - Variable in class com.tangosol.io.pof.EvolvableHolder
-
Map of Evolvable objects, keyed by type id.
- m_mapFactories - Variable in class com.tangosol.io.bdb.DatabaseFactoryManager
-
Map of DatabaseFactory objects keyed by XmlElement configuration.
- m_mapFilters - Variable in class com.tangosol.net.management.MBeanAccessor.QueryBuilder
-
A map of ObjectName key to Filter.
- m_mapFilters - Variable in class com.tangosol.net.management.MBeanAccessor.QueryBuilder.ParsedQuery
-
A map of ObjectName key to Filter.
- m_mapFirst - Variable in class com.tangosol.util.ChainedMap
-
The first map.
- m_mapForward - Variable in class com.tangosol.util.SimpleMapIndex
-
Map that contains the index values (forward index).
- m_mapFront - Variable in class com.tangosol.net.cache.SimpleOverflowMap
-
The "front" map, which is size-limited.
- m_mapFunctions - Variable in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
-
The map of CohQL functions.
- m_mapHead - Variable in class com.tangosol.util.SafeSortedMap.Split
-
The headMap.
- m_mapIdentities - Variable in class com.tangosol.io.pof.PofBufferWriter.ReferenceLibrary
-
A map from objects that can be referenced to their Integer
identities.
- m_mapIndex - Variable in class com.tangosol.net.cache.ContinuousQueryCache
-
The map of indexes maintained by this cache.
- m_mapInverse - Variable in class com.tangosol.util.SimpleMapIndex
-
Map that contains the index contents (inverse index).
- m_mapInvocable - Variable in class com.tangosol.util.ConverterCollections.ConverterNamedCache
-
A Converter InvocableMap around the underlying NamedCache.
- m_mapKeyListeners - Variable in class com.tangosol.util.MapListenerSupport
-
The collections of MapListener objects that have signed up for key based
notifications from an ObservableMap implementation keyed by the
corresponding key objects.
- m_mapListener - Variable in class com.tangosol.net.cache.ContinuousQueryCache
-
The optional
MapListener
that may be provided during
ContinuousQueryCache
construction.
- m_mapListeners - Variable in class com.tangosol.util.MapListenerSupport
-
The collections of MapListener objects that have signed up for
notifications from an ObservableMap implementation keyed by the
corresponding Filter objects.
- m_mapLoad - Variable in class com.tangosol.net.SimpleServiceLoadBalancer
-
A Map of ServiceLoad objects keyed by their associated Member.
- m_mapLocal - Variable in class com.tangosol.net.cache.ContinuousQueryCache
-
- m_mapLock - Variable in class com.tangosol.util.WrapperConcurrentMap
-
The map containing all the locks.
- m_mapMember - Variable in class com.tangosol.net.SimpleServiceLoadBalancer
-
A SortedMap of List of Member objects keyed by their associated
ServiceLoad.
- m_mapMiss - Variable in class com.tangosol.net.cache.SimpleOverflowMap
-
The miss cache; may be null.
- m_mapNamedQueries - Variable in class com.tangosol.coherence.rest.config.QueryConfig
-
Named query mappings.
- m_mapOperators - Variable in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
-
The map of CohQL operators.
- m_mapOuter - Variable in class com.tangosol.net.partition.ObservableSplittingBackingCache.CapacityAwareMap
-
The ObservableSplittingBackingMap used to call prepareUpdate.
- m_mapOwnedPartitions - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
The map of member ownership information for this analysis context.
- m_mapParsedQuery - Variable in class com.tangosol.coherence.rest.query.AbstractQueryEngine
-
Map of cached ParsedQuery instances, keyed by their corresponding
final query string.
- m_mapProperties - Variable in class com.tangosol.coherence.rest.util.PartialObject
-
Property values for this object.
- m_mapProvider - Variable in class com.tangosol.net.SocketProviderFactory.DefaultDependencies
-
A map of provider types, key'd by id.
- m_mapQuery - Variable in class com.tangosol.util.ConverterCollections.ConverterNamedCache
-
A Converter QueryMap around the underlying NamedCache.
- m_mapQueryEngines - Variable in class com.tangosol.coherence.rest.query.QueryEngineRegistry
-
A map of registered QueryEngines, keyed by engine names.
- m_mapQuorumByRole - Variable in class com.tangosol.net.ConfigurableQuorumPolicy.ClusterQuorumPolicy
-
The cluster membership quorum map, keyed by role name.
- m_mapResolved - Variable in class com.tangosol.persistence.GUIDHelper.GUIDResolver
-
The resolved map of members to the associated set of partitions.
- m_mapResults - Variable in class com.tangosol.util.aggregator.GroupAggregator
-
A map of partial results to aggregate.
- m_mapSecond - Variable in class com.tangosol.util.ChainedMap
-
The second map.
- m_mapServices - Variable in class com.tangosol.net.ExtensibleConfigurableCacheFactory
-
Map used to hold references to services that are ensured by this
factory where values are non-scoped service names.
- m_mapServices - Variable in class com.tangosol.net.SimpleServiceMonitor
-
A map of
Service
s to be monitored with values being non-scoped service names.
- m_mapSocketProvider - Variable in class com.tangosol.net.SocketProviderFactory
-
A map of instantiated socket providers, key'd by id.
- m_mapSSLDependencies - Variable in class com.tangosol.net.SocketProviderFactory.DefaultDependencies
-
A map of SSL provider dependencies, key'd by id.
- m_mapSSLDependenciesBuilder - Variable in class com.tangosol.net.SocketProviderFactory.DefaultDependencies
-
A map of SSL provider dependencies builder, key'd by id.
- m_mapStandardKeyListeners - Variable in class com.tangosol.util.MapListenerSupport
-
The subset of standard (not lite) key listeners.
- m_mapStandardListeners - Variable in class com.tangosol.util.MapListenerSupport
-
The subset of standard (not lite) global listeners.
- m_mapStatementBuilders - Variable in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
-
The map of CohQL query builders.
- m_mapSteps - Variable in class com.tangosol.util.SimpleQueryRecord.PartialResult.AbstractRecordableStep
-
The Map of child steps.
- m_mapSuggestLast - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
The Map containing the last distribution suggested by this strategy.
- m_mapSyncReq - Variable in class com.tangosol.net.cache.ContinuousQueryCache
-
While the ContinuousQueryCache
is configuring or re-configuring its
listeners and content, any events that are received must be logged to
ensure that the corresponding content is in sync.
- m_mapTail - Variable in class com.tangosol.util.SafeSortedMap.Split
-
The tailMap.
- m_mapTCPDatagramDependencies - Variable in class com.tangosol.net.SocketProviderFactory.DefaultDependencies
-
A map of TCP Datagram provider dependencies, key'd by id.
- m_mapTemp - Variable in class com.tangosol.net.cache.OverflowMap.EntrySet.EntrySetIterator
-
Map to use with getInternal() in order to determine differences
between null values and non-present values.
- m_mapTypeId - Variable in class com.tangosol.io.pof.SimplePofContext
-
A Map that contains mappings from a registered user type into type
identifier.
- m_mapTypeIdByClass - Variable in class com.tangosol.io.pof.ConfigurablePofContext.PofConfig
-
Once initialized, this references a thread-safe Map that contains
mappings from Java classes to POF type identifiers (wrapped as
Integer objects).
- m_mapTypeIdByClassName - Variable in class com.tangosol.io.pof.ConfigurablePofContext.PofConfig
-
Once initialized, this references a thread-safe Map that contains
mappings from Java class names to POF type identifiers (wrapped as
Integer objects).
- m_mapVersion - Variable in class com.tangosol.run.jca.SimpleValidator
-
The map that holds version objects for enlisted resources.
- m_mapView - Variable in class com.tangosol.util.SafeSortedMap
-
The default ViewMap (over the entire map's range).
- m_marshallerRegistry - Variable in class com.tangosol.coherence.rest.CacheResource
-
Marshaller registry to obtain marshallers from.
- m_marshallerRegistry - Variable in class com.tangosol.coherence.rest.EntryResource
-
Marshaller registry to obtain marshallers from.
- m_marshallerRegistry - Variable in class com.tangosol.coherence.rest.providers.JsonCollectionWriter
-
Marshaller registry to obtain element marshallers from.
- m_marshallerRegistry - Variable in class com.tangosol.coherence.rest.providers.XmlCollectionWriter
-
Marshaller registry to obtain element marshallers from.
- m_marshallerRegistry - Variable in class com.tangosol.coherence.rest.providers.XmlKeysWriter
-
Marshaller registry to obtain element marshallers from.
- m_marshallerRegistry - Variable in class com.tangosol.coherence.rest.providers.XmlMapWriter
-
Marshaller registry to obtain element marshallers from.
- m_memberFrom - Variable in class com.tangosol.net.partition.PartitionEvent
-
The "from" member for events that represent transfer from a member.
- m_memberTo - Variable in class com.tangosol.net.partition.PartitionEvent
-
The "to" member for events that represent transfer to a member.
- m_methFromString - Variable in class com.tangosol.coherence.rest.DefaultKeyConverter
-
Static method to use for conversion from string.
- m_methodClone - Variable in class com.tangosol.run.xml.PropertyAdapter
-
The "public Object clone()" method for the property type, if available.
- m_methodFactory - Variable in class com.tangosol.run.xml.RestrictedStringAdapter
-
The factory method.
- m_methodGet - Variable in class com.tangosol.run.xml.PropertyAdapter
-
The property "accessor" method.
- m_methodSet - Variable in class com.tangosol.run.xml.PropertyAdapter
-
The property "mutator" method.
- m_nAction - Variable in class com.tangosol.util.filter.FilterTrigger
-
The action code.
- m_nAdvanceFrequency - Variable in class com.tangosol.net.TcpDatagramSocketProvider.DefaultDependencies
-
The TcpDatagramSocket advance frequency.
- m_namedBindVars - Variable in class com.tangosol.coherence.dslquery.internal.AbstractCoherenceQueryWalker
-
The current named bind variables.
- m_namedCache - Variable in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCache
-
- m_nAverageThroughput - Variable in class com.tangosol.net.cache.AbstractBundler.Statistics
-
An average bundled request throughput in size units per millisecond
(total bundle size over total processing time)
- m_nBeanId - Variable in class com.tangosol.run.xml.XmlBean.BeanInfo
-
Serialization ID for the XmlBean class.
- m_nBindingPower - Variable in class com.tangosol.coherence.dsltools.precedence.OPToken
-
The power that this token binds, typically to the left.
- m_nCalculatorType - Variable in class com.tangosol.net.cache.OldCache
-
Deprecated.
The type of unit calculator employed by the cache; one of the
UNIT_CALCULATOR_* enumerated values.
- m_nCallCount - Variable in class com.tangosol.coherence.dslquery.internal.SelectListMaker
-
The count of classifications that are calls
tree of Objects is built
- m_nDataVersion - Variable in class com.tangosol.io.SimpleEvolvable
-
Data version.
- m_nEfficiency - Variable in class com.tangosol.util.SimpleQueryRecord.PartialResult.Step
-
The estimated cost.
- m_nEvictionType - Variable in class com.tangosol.net.cache.OldCache
-
Deprecated.
The type of eviction policy employed by the cache; one of the
EVICTION_POLICY_* enumerated values.
- m_nHash - Variable in class com.tangosol.util.SafeHashMap.Entry
-
The key's hash code.
- m_nHash - Variable in class com.tangosol.util.SegmentedHashMap.Entry
-
The key's hash code.
- m_nId - Variable in class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
-
The identity of the object to encode, or -1 if the identity
shouldn't be encoded in the POF stream
- m_nId - Variable in class com.tangosol.net.partition.PartitionEvent
-
The event's id.
- m_nId - Variable in class com.tangosol.util.MapEvent
-
The event's id.
- m_nImplVersion - Variable in class com.tangosol.io.SimpleEvolvable
-
Implementation version.
- m_nLastSentTime - Variable in class com.tangosol.util.transformer.SamplingEventTransformer
-
The last time an event was sent.
- m_nLevel - Variable in class com.tangosol.util.SafeSortedMap.IndexNode
-
The level of this IndexNode
- m_nLevelMax - Variable in class com.tangosol.util.SafeSortedMap
-
The maximum number of index levels to use for this map.
- m_nMask - Variable in class com.tangosol.util.filter.MapEventFilter
-
The event mask.
- m_nMaskSynthetic - Variable in class com.tangosol.util.filter.CacheEventFilter
-
Bitmask that selects whether to include synthetic, natural, or all events.
- m_nMaxLoadId - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.JMXPartitionStats
-
The node ID with maximum node storage size in bytes.
- m_nodeBelow - Variable in class com.tangosol.util.SafeSortedMap.SkipNode
-
The SkipNode "below" this one in the node lattice.
- m_nodeEntry - Variable in class com.tangosol.util.SafeSortedMap.SkipNode
-
The EntryNode indexed by this node in the lattice.
- m_nodeNext - Variable in class com.tangosol.util.SafeLinkedList.Node
-
The next Node in the List.
- m_nodeNext - Variable in class com.tangosol.util.SafeSortedMap.EntryNode
-
The next SkipNode in the list.
- m_nodeNext - Variable in class com.tangosol.util.SafeSortedMap.SkipNode
-
The SkipNode "below" this one in the node lattice.
- m_nodeNext - Variable in class com.tangosol.util.SafeSortedMap.ViewMap.EntryIterator
-
The next node in the iteration, or null.
- m_nodePrev - Variable in class com.tangosol.util.SafeLinkedList.Node
-
The previous Node in the List.
- m_nodeTop - Variable in class com.tangosol.util.SafeSortedMap
-
The top index node.
- m_nOptimizationPlan - Variable in class com.tangosol.util.MapListenerSupport
-
The optimization plan which indicates the fastest way to put together a
set of listeners.
- m_nPartition - Variable in class com.tangosol.net.partition.PartitionStatistics
-
The partition ID.
- m_nPartition - Variable in class com.tangosol.net.partition.SimplePartitionKey
-
The partition id.
- m_nPort - Variable in class com.tangosol.net.ConfigurableAddressProvider.AddressHolder
-
The configured port.
- m_nRuleMask - Variable in class com.tangosol.coherence.config.builder.ActionPolicyBuilder.QuorumRule
-
Action policy rule mask.
- m_nSamplingInterval - Variable in class com.tangosol.util.transformer.SamplingEventTransformer
-
The sampling interval to use.
- m_nSizeIn - Variable in class com.tangosol.util.SimpleQueryRecord.PartialResult.Step
-
The pre-execution key set size.
- m_nSizeOut - Variable in class com.tangosol.util.SimpleQueryRecord.PartialResult.Step
-
The post-execution key set size.
- m_nSpan - Variable in class com.tangosol.util.SafeSortedMap
-
The span of the map.
- m_nState - Variable in class com.tangosol.net.cache.ContinuousQueryCache
-
State of the ContinuousQueryCache
.
- m_nState - Variable in class com.tangosol.net.GuardSupport.Context
-
The current state of the Context.
- m_nState - Variable in class com.tangosol.net.partition.FailoverAccessPolicy
-
One of the STATE_* constants representing the current quorum state.
- m_nState - Variable in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
-
The state of the PersistenceStore.
- m_nState - Variable in class com.tangosol.run.xml.SimpleElement.ElementIterator
-
- m_nStrategyCurrent - Variable in class com.tangosol.net.cache.CachingMap
-
The current invalidation strategy, which at times could be different
from the target strategy.
- m_nStrategyTarget - Variable in class com.tangosol.net.cache.CachingMap
-
The invalidation strategy that this map is to use.
- m_nStrength - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.BackupStrength
-
The strength (one of the *_SAFE constants).
- m_nStyle - Variable in class com.tangosol.util.comparator.EntryComparator
-
Comparison style utilized by this EntryComparator.
- m_nTarget - Variable in class com.tangosol.util.extractor.AbstractExtractor
-
- m_nThreshold - Variable in class com.tangosol.coherence.config.builder.ActionPolicyBuilder.QuorumRule
-
Action policy threshold which is always non-negative.
- m_nType - Variable in class com.tangosol.io.pof.reflect.AbstractPofValue
-
POF type identifer of this value.
- m_nTypeId - Variable in class com.tangosol.io.pof.ExternalizableLitePofSerializer
-
The type identifier of the user type to serialize and deserialize.
- m_nTypeId - Variable in class com.tangosol.io.pof.ExternalizablePofSerializer
-
The type identifier of the user type to serialize and deserialize.
- m_nTypeId - Variable in class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
-
The type identifier of the user type that is being written.
- m_nTypeId - Variable in class com.tangosol.io.pof.PortableObjectSerializer
-
The type identifier of the user type to serialize and deserialize.
- m_nTypeId - Variable in class com.tangosol.io.pof.PortableTypeSerializer
-
The type identifier of the user type to serialize and deserialize.
- m_nTypeId - Variable in class com.tangosol.io.pof.XmlSerializablePofSerializer
-
The type identifier of the user type to serialize and deserialize.
- m_nUnitFactor - Variable in class com.tangosol.net.cache.OldCache
-
Deprecated.
The unit factor.
- m_nUnitFactor - Variable in class com.tangosol.net.cache.SerializationCache
-
The unit factor.
- m_nUnitFactor - Variable in class com.tangosol.net.partition.ObservableSplittingBackingCache
-
The unit factor.
- m_nVersion - Variable in class com.tangosol.io.pof.reflect.PofUserType
-
The data version of this value.
- m_nVersion - Variable in class com.tangosol.net.partition.VersionedOwnership
-
The ownership version.
- m_nVersionId - Variable in class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
-
The version identifier of the user type that is being written.
- m_object - Variable in class com.tangosol.util.SafeLinkedList.Node
-
The value stored in the Node.
- m_oCurr - Variable in class com.tangosol.util.PagedIterator
-
Currently "Active" object.
- m_oExpr - Variable in class com.tangosol.coherence.rest.util.extractor.MvelExtractor
-
Compiled expression.
- m_oExpr - Variable in class com.tangosol.coherence.rest.util.updater.MvelUpdater
-
Compiled expression.
- m_of - Variable in class com.tangosol.io.AbstractByteArrayReadBuffer
-
Offset into the byte array at which the binary data is located.
- m_of - Variable in class com.tangosol.io.MultiByteArrayInputStream
-
The current offset in the current byte array.
- m_of - Variable in class com.tangosol.io.MultiByteArrayOutputStream
-
The offset into the current block of output.
- m_ofbGroup - Variable in class com.tangosol.io.Base64InputStream
-
The offset in the group of bytes.
- m_ofLimit - Variable in class com.tangosol.util.SimpleEnumerator
-
Iterator end position (beyond last).
- m_ofMarked - Variable in class com.tangosol.io.MultiByteArrayInputStream
-
The marked offset in the marked byte array.
- m_ofStart - Variable in class com.tangosol.io.DelegatingWriteBuffer
-
Offset into the containing WriteBuffer where this WriteBuffer starts.
- m_ofWrite - Variable in class com.tangosol.io.AbstractWriteBuffer.AbstractBufferOutput
-
Current write offset within the containing WriteBuffer.
- m_oIterActive - Variable in class com.tangosol.util.SafeHashMap
-
A holder for active Iterator(s): either WeakReference(<Iterator>) or
WeakHashMap(<Iterator>, null)
- m_oIterActive - Variable in class com.tangosol.util.SegmentedHashMap
-
A holder for active Iterator(s): either WeakReference(<Iterator>) or
WeakHashMap(<Iterator> null)
- m_oKey - Variable in class com.tangosol.coherence.rest.EntryResource
-
Referenced entry's key.
- m_oKey - Variable in class com.tangosol.net.cache.BackingMapBinaryEntry
-
Lazily converted key in Object format.
- m_oKey - Variable in class com.tangosol.util.MapEvent
-
A key.
- m_oKey - Variable in class com.tangosol.util.SafeHashMap.Entry
-
The key.
- m_oKey - Variable in class com.tangosol.util.SafeSortedMap.EntryNode
-
The key represented by this Node.
- m_oKey - Variable in class com.tangosol.util.SegmentedHashMap.Entry
-
The key.
- m_oKey - Variable in class com.tangosol.util.SimpleMapEntry
-
The key.
- m_oKeyLower - Variable in class com.tangosol.util.SafeSortedMap.ViewMap
-
The key that this ViewMap is (inclusively) lower-bounded by, or null
for no lower-bound.
- m_oKeyUp - Variable in class com.tangosol.util.ConverterCollections.AbstractConverterEntry
-
Cached converted key.
- m_oKeyUpper - Variable in class com.tangosol.util.SafeSortedMap.ViewMap
-
The key that this ViewMap is (exclusively) upper-bounded by, or null
for no upper-bound
- m_oLockHolder - Variable in class com.tangosol.util.SegmentedConcurrentMap.LockableEntry
-
The lock holder object.
- m_oNext - Variable in class com.tangosol.util.FilterEnumerator
-
The next item which passed the test.
- m_oOrigValue - Variable in class com.tangosol.util.SimpleMapEntry
-
The original value.
- m_oResult - Variable in class com.tangosol.coherence.dslquery.internal.AbstractCoherenceQueryWalker
-
An Object that is the result of each classified dispatch as the
tree of Objects is built
- m_oResult - Variable in class com.tangosol.util.aggregator.AbstractComparableAggregator
-
The running result value.
- m_out - Variable in class com.tangosol.io.DelegatingWriteBuffer.DelegatingBufferOutput
-
The BufferOutput to delegate to.
- m_out - Variable in class com.tangosol.io.pof.PofBufferWriter
-
The BufferOutput object that the PofBufferWriter writes to.
- m_out - Variable in class com.tangosol.io.WrapperOutputStream
-
The underlying OutputStream object to use.
- m_oValue - Variable in class com.tangosol.io.pof.reflect.AbstractPofValue
-
Deserialized representation of this value.
- m_oValue - Variable in class com.tangosol.net.cache.BackingMapBinaryEntry
-
Lazily converted value in Object format.
- m_oValue - Variable in class com.tangosol.util.InflatableCollection
-
Holds NO_VALUE, a single value, or an InflatedCollection of values.
- m_oValue - Variable in class com.tangosol.util.processor.VersionedPut
-
Specifies the new value to update an entry with.
- m_oValue - Variable in class com.tangosol.util.SafeHashMap.Entry
-
The value.
- m_oValue - Variable in class com.tangosol.util.SafeSortedMap.EntryNode
-
The value represented by this EntryNode.
- m_oValue - Variable in class com.tangosol.util.SafeSortedMap.EntryNode.MapEntry
-
The cached entry value.
- m_oValue - Variable in class com.tangosol.util.SegmentedHashMap.Entry
-
The value.
- m_oValue - Variable in class com.tangosol.util.SimpleMapEntry
-
The value.
- m_oValue - Variable in class com.tangosol.util.SparseArray.ObjectNode
-
The Node's value.
- m_oValueLatestOld - Variable in class com.tangosol.net.cache.OverflowMap.HistoricCacheEvent
-
A previous value, but the most recent of the previous values.
- m_oValueNew - Variable in class com.tangosol.util.MapEvent
-
A new value.
- m_oValueOld - Variable in class com.tangosol.util.MapEvent
-
A previous value.
- m_oValueOrig - Variable in class com.tangosol.net.cache.BackingMapBinaryEntry
-
Lazily converted original value in Object format.
- m_oValueUp - Variable in class com.tangosol.util.ConverterCollections.AbstractConverterEntry
-
Cached converted value.
- m_owners - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.NotOwnedFilter
-
The ownership
- m_owners - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.SafetyFilter
-
The ownership.
- m_owners - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.StrengthComparator
-
The ownership.
- m_partsOrphan - Variable in class com.tangosol.net.PartitionedService.PartitionRecoveryAction
-
The set of orphaned partitions.
- m_partsOrphaned - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
- m_partsUnresolved - Variable in class com.tangosol.persistence.GUIDHelper.GUIDResolver
-
The PartitionSet containing partitions that don't have corresponding GUIDs.
- m_partsUpdated - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
The set of partitions that have been updated in this analysis context;
may be null.
- m_policy - Variable in class com.tangosol.net.cache.OldCache
-
Deprecated.
The eviction policy; for eviction type EVICTION_POLICY_EXTERNAL.
- m_policy - Variable in class com.tangosol.net.partition.ObservableSplittingBackingCache
-
The eviction policy.
- m_pool - Variable in class com.tangosol.persistence.AbstractPersistenceEnvironment
-
An optional DaemonPool used to execute tasks.
- m_pool - Variable in class com.tangosol.persistence.AbstractPersistenceManager
-
An optional DaemonPool used to execute tasks.
- m_predicate - Variable in class com.tangosol.util.filter.PredicateFilter
-
The
Predicate
for filtering extracted values.
- m_processor - Variable in class com.tangosol.util.processor.ConditionalProcessor
-
The underlying entry processor.
- m_processorRegistry - Variable in class com.tangosol.coherence.rest.CacheResource
-
a processor registry that is used to map the given processor name to
an EntryProcessor instance.
- m_processorRegistry - Variable in class com.tangosol.coherence.rest.EntryResource
-
a processor registry that is used to map the given processor name to
an EntryProcessor instance.
- m_processorRegistry - Variable in class com.tangosol.coherence.rest.EntrySetResource
-
a processor registry that is used to map the given processor name to
an EntryProcessor instance.
- m_processorRegistry - Variable in class com.tangosol.coherence.rest.NamedQueryResource
-
a processor registry that is used to map the given processor name to
an EntryProcessor instance.
- m_propertySet - Variable in class com.tangosol.coherence.rest.util.PropertySpec
-
A set of nested properties.
- m_propOptions - Variable in class com.tangosol.net.LoadBalancer
-
The optional settings that the load balancer will use.
- m_providerCurrent - Variable in class com.tangosol.net.CompositeAddressProvider.AddressIterator
-
The current AddressProvider.
- m_providerFactory - Variable in class com.tangosol.net.SocketProviderFactory.DefaultDependencies
-
SocketProviderFactory referencing this Dependency object.
- m_query - Variable in class com.tangosol.coherence.rest.NamedQueryResource
-
Named query responsible to filter cache entries.
- m_query - Variable in class com.tangosol.net.management.MBeanAccessor.GetAttributes
-
The query used to reduce the MBeans.
- m_query - Variable in class com.tangosol.net.management.MBeanAccessor.Invoke
-
The query used to reduce the MBeans.
- m_query - Variable in class com.tangosol.net.management.MBeanAccessor.SetAttributes
-
The ParsedQuery to be used to query the MBeans.
- m_queryConfig - Variable in class com.tangosol.coherence.rest.CacheResource
-
Query configuration for this resource.
- m_queryEngineRegistry - Variable in class com.tangosol.coherence.rest.CacheResource
-
Query engine registry to obtain query engines from.
- m_queue - Variable in class com.tangosol.net.LoadBalancer
-
The queue of pending requests.
- m_queue - Variable in class com.tangosol.net.LoadBalancer.RequestHandler
-
The Queue that this RequestHandler listens to connections (Socket)
on.
- m_random - Variable in class com.tangosol.net.LoadBalancer
-
Random number generator.
- m_random - Variable in class com.tangosol.util.SafeSortedMap
-
The random-number generator for the map.
- m_reader - Variable in class com.tangosol.coherence.dslquery.ExecutionContext
-
The reader to use to get user input.
- m_reader - Variable in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
-
- m_reader - Variable in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
-
The underlying Reader holding the characters being tokenized.
- m_reader - Variable in class com.tangosol.io.Base64InputStream
-
The Reader object from which the Base64 encoded data is read.
- m_recordType - Variable in class com.tangosol.coherence.dslquery.statement.QueryRecorderStatementBuilder
-
The type of query recorder that this builder builds.
- m_refs - Variable in class com.tangosol.io.pof.PofBufferWriter
-
If references are used, then this is the ReferenceLibrary.
- m_registry - Variable in class com.tangosol.coherence.rest.NamedQueryResource
-
Query engine registry.
- m_registry - Variable in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
- m_resolver - Variable in class com.tangosol.net.PartitionedService.PartitionRecoveryAction
-
The GUID resolver.
- m_ruleCurrent - Variable in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy
-
The current state.
- m_sActive - Variable in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder
-
The active directory used by persistence.
- m_sAlias - Variable in class com.tangosol.coherence.dslquery.internal.AbstractCoherenceQueryWalker
-
The alias of the cache name being used.
- m_sApplicationName - Variable in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
-
An optional application name to use.
- m_sBaseQuery - Variable in class com.tangosol.net.management.MBeanAccessor.QueryBuilder
-
The base MBean query to be used in the query.
- m_sCacheName - Variable in class com.tangosol.coherence.dslquery.FilterBuilder
-
The cache name this FilterBuilder is building
Filter
s to query
against.
- m_sCacheName - Variable in class com.tangosol.coherence.dslquery.internal.SelectListMaker
-
The name of the cache that the select list is being built for
- m_sCacheName - Variable in class com.tangosol.net.DefaultConfigurableCacheFactory.CacheInfo
-
Deprecated.
The cache name.
- m_sCluster - Variable in class com.tangosol.net.management.MBeanAccessor.QueryBuilder
-
The cluster name to be used in the query.
- m_scopeResolver - Variable in class com.tangosol.net.ScopedCacheFactoryBuilder
-
Scope resolver used to resolve scope name upon CCF construction.
- m_sDbName - Variable in class com.tangosol.io.bdb.BerkeleyDBBinaryStore.DatabaseHolder
-
The name of the underlying Database.
- m_sDbName - Variable in class com.tangosol.io.bdb.BerkeleyDBBinaryStoreManager
-
Database name, used for persistent stores.
- m_sDomainPartitions - Variable in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
-
A comma delimited list of domain partition names.
- m_sElement - Variable in class com.tangosol.run.xml.IterableAdapter
-
Name used for each element of the array when formatted into XML.
- m_sElementName - Variable in class com.tangosol.coherence.config.xml.processor.BackingMapSchemeProcessor
-
- m_service - Variable in class com.tangosol.net.AbstractServiceLoadBalancer
-
The containing Service.
- m_service - Variable in class com.tangosol.net.cache.WrapperNamedCache
-
The CacheService this NamedCache is a part of.
- m_service - Variable in class com.tangosol.net.ConfigurableQuorumPolicy.ClusterQuorumPolicy
-
The cluster service.
- m_service - Variable in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy
-
The Service that this policy applies to.
- m_service - Variable in class com.tangosol.net.partition.DefaultKeyAssociator
-
The PartitionedService that this DefaultKeyAssociator is bound to.
- m_service - Variable in class com.tangosol.net.partition.DefaultKeyPartitioningStrategy
-
The PartitionedService that this strategy is bound to.
- m_service - Variable in class com.tangosol.net.partition.FailoverAccessPolicy
-
The PartitionedService that this quorum policy is bound to.
- m_service - Variable in class com.tangosol.net.partition.MirroringAssignmentStrategy
-
The associated service that this strategy attempts to co-locate
partitions with.
- m_service - Variable in class com.tangosol.net.WrapperService
-
The (wrapped) Service.
- m_serviceDependencies - Variable in class com.tangosol.coherence.config.scheme.AbstractServiceScheme
-
- m_serviceLocator - Variable in class com.tangosol.coherence.rest.CacheResource
-
The ServiceLocator for this resource.
- m_serviceLocator - Variable in class com.tangosol.coherence.rest.DefaultRootResource
-
- m_serviceMon - Variable in class com.tangosol.net.DefaultCacheServer
-
The ServiceMonitor used to monitor services.
- m_session - Variable in class com.tangosol.coherence.rest.DefaultRootResource
-
Coherence session.
- m_session - Variable in class com.tangosol.net.CoherenceSession
-
The underlying
Session
to which this implementation will
delegate requests.
- m_set - Variable in class com.tangosol.io.nio.BinaryMap
-
The set of entries backed by this map.
- m_set - Variable in class com.tangosol.util.aggregator.DistinctValues
-
The resulting set of distinct values.
- m_set - Variable in class com.tangosol.util.ConverterCollections.ConverterEntrySet
-
The underlying Entry Set (or Collection of Map Entry objects).
- m_set - Variable in class com.tangosol.util.ConverterCollections.ConverterMap
-
The Entry Set.
- m_set - Variable in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet
-
The underlying Entry Set.
- m_set - Variable in class com.tangosol.util.RestrictedCollections.RestrictedMap
-
The Entry Set.
- m_setEntries - Variable in class com.tangosol.util.aggregator.CompositeAggregator
-
A set of accumulated entries to aggregate.
- m_setEntries - Variable in class com.tangosol.util.ChainedMap
-
The entry set.
- m_setEntries - Variable in class com.tangosol.util.EntrySetMap
-
The underlying set of Entry objects.
- m_setEntries - Variable in class com.tangosol.util.SafeHashMap
-
The set of entries backed by this map.
- m_setEntries - Variable in class com.tangosol.util.SegmentedHashMap
-
The set of entries backed by this map.
- m_setEntries - Variable in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
-
The entry set.
- m_setIndexLookupRecords - Variable in class com.tangosol.util.SimpleQueryRecord.PartialResult.Step
-
The set of index lookup records.
- m_setKeyExcluded - Variable in class com.tangosol.util.SimpleMapIndex
-
A set of keys for the entries, which could not be included in the index.
- m_setKeys - Variable in class com.tangosol.coherence.rest.EntrySetResource
-
Referenced entries' keys.
- m_setKeys - Variable in class com.tangosol.io.nio.BinaryMap
-
The set of keys backed by this map.
- m_setKeys - Variable in class com.tangosol.util.filter.KeyFilter
-
The keys that are evaluated to true by this filter.
- m_setKeys - Variable in class com.tangosol.util.SafeHashMap
-
The set of keys backed by this map.
- m_setKeys - Variable in class com.tangosol.util.SegmentedHashMap
-
The set of keys backed by this map.
- m_setKeys - Variable in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
-
The key set.
- m_setLeaving - Variable in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy
-
The set of leaving members.
- m_setMachines - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.BackupStrength
-
The set of machine names.
- m_setManager - Variable in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
A Set of BackingMapManager instances registered by this factory.
- m_setManager - Variable in class com.tangosol.net.ExtensibleConfigurableCacheFactory
-
A Set of BackingMapManager instances registered by this factory.
- m_setMod - Variable in class com.tangosol.util.SubSet
-
The removed or retained items.
- m_setOperators - Variable in class com.tangosol.coherence.dsltools.precedence.OPScanner
-
The set of valid operators used by this scanner
- m_setOrig - Variable in class com.tangosol.util.SubSet
-
The underlying set (assumed immutable).
- m_setOwnershipMembers - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
The set of ownership members to include in the distribution.
- m_setOwnersLast - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
The Set of ownership-enabled members at the time of the last analysis.
- m_setPartitions - Variable in class com.tangosol.net.partition.PartitionEvent
-
The set of affected partitions.
- m_setPids - Variable in class com.tangosol.net.partition.AbstractPartitionedIterator
-
The remaining set of partitions to iterate.
- m_setProperties - Variable in class com.tangosol.coherence.rest.util.PropertySet
-
Property set.
- m_setRacks - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.BackupStrength
-
The set of rack names.
- m_setSites - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.BackupStrength
-
The set of site names.
- m_sExpr - Variable in class com.tangosol.coherence.rest.util.extractor.MvelExtractor
-
The MVEL expression to evaluate.
- m_sExpr - Variable in class com.tangosol.coherence.rest.util.MvelManipulator
-
The MVEL expression to evaluate.
- m_sExpr - Variable in class com.tangosol.coherence.rest.util.updater.MvelUpdater
-
The MVEL expression to evaluate.
- m_sFilter - Variable in class com.tangosol.util.SimpleQueryRecord.PartialResult.Step
-
The filter description.
- m_sGarFileName - Variable in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
-
The name of an optional GAR file to load.
- m_sHost - Variable in class com.tangosol.net.ConfigurableAddressProvider.AddressHolder
-
The configured address, either hostname or IP address.
- m_signature - Variable in class com.tangosol.net.management.MBeanAccessor.Invoke
-
The signature of the operation.
- m_size - Variable in class com.tangosol.util.AbstractSparseArray
-
The number of nodes in the tree.
- m_sJCacheName - Variable in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCache
-
- m_sLanguage - Variable in class com.tangosol.util.AbstractScript
-
The language the script is written.
- m_sLedASTName - Variable in class com.tangosol.coherence.dsltools.precedence.OPToken
-
A functor for building ast for led method.
- m_sLockText - Variable in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder.DirectoryLock
-
Text to include in the lock file.
- m_sMBeanDomainName - Variable in class com.tangosol.net.management.MBeanAccessor.QueryBuilder
-
The MBean domain name to be used in the query.
- m_sMediaType - Variable in class com.tangosol.coherence.rest.util.StaticContent
-
- m_sMemberKey - Variable in class com.tangosol.net.management.MBeanAccessor.QueryBuilder
-
The member key to be used in the query.
- m_sMessage - Variable in exception com.tangosol.io.pof.PortableException
-
The exception's message.
- m_sMethod - Variable in class com.tangosol.util.extractor.ReflectionExtractor
-
The name of the method to invoke.
- m_sMethod - Variable in class com.tangosol.util.extractor.ReflectionUpdater
-
The name of the method to invoke.
- m_sMethodName - Variable in class com.tangosol.util.processor.MethodInvocationProcessor
-
The name of the method to invoke.
- m_sMode - Variable in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder
-
The mode used by persistence; either active or on-demand.
- m_sName - Variable in class com.tangosol.coherence.rest.util.PropertySpec
-
Property name.
- m_sName - Variable in class com.tangosol.io.pof.PofPrincipal
-
The name of the identity represented by this Principal.
- m_sName - Variable in exception com.tangosol.io.pof.PortableException
-
The exception's name.
- m_sName - Variable in class com.tangosol.net.cache.ContinuousQueryCache
-
- m_sName - Variable in class com.tangosol.net.cache.WrapperNamedCache
-
The name of the cache.
- m_sName - Variable in class com.tangosol.run.xml.PropertyAdapter
-
The property name.
- m_sName - Variable in class com.tangosol.run.xml.SimpleElement.ElementIterator
-
- m_sName - Variable in class com.tangosol.run.xml.XmlBean.BeanInfo
-
The XML element name for the XML bean.
- m_sName - Variable in class com.tangosol.util.AbstractScript
-
The name of the script object to execute.
- m_sName - Variable in class com.tangosol.util.extractor.UniversalExtractor
-
A method or property name.
- m_sName - Variable in class com.tangosol.util.extractor.UniversalUpdater
-
A method name, or a property name.
- m_sName - Variable in class com.tangosol.util.processor.PropertyManipulator
-
The property name, never null.
- m_sNameCanon - Variable in class com.tangosol.util.extractor.AbstractExtractor
-
Canonical name for this extractor.
- m_sNameCanon - Variable in class com.tangosol.util.extractor.UniversalExtractor
-
Canonical name for this extractor.
- m_sNamePrefix - Variable in class com.tangosol.util.DaemonThreadFactory
-
The prefix to use for unnammed threads produced by the factory.
- m_sNests - Variable in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
-
The characters used to begin nesting.
- m_sNmsPrefix - Variable in class com.tangosol.run.xml.PropertyAdapter
-
The namespace prefix for this property.
- m_sNmsPrefix - Variable in class com.tangosol.run.xml.XmlBean.BeanInfo
-
Namespace prefix.
- m_sNmsUri - Variable in class com.tangosol.run.xml.PropertyAdapter
-
The namespace URI for this property.
- m_sNmsUri - Variable in class com.tangosol.run.xml.XmlBean.BeanInfo
-
Namespace URI.
- m_sNudASTName - Variable in class com.tangosol.coherence.dsltools.precedence.OPToken
-
A functor for building ast for nud method.
- m_socketClient - Variable in class com.tangosol.net.LoadBalancer.ResponseHandler
-
The Socket to write the response to.
- m_socketServer - Variable in class com.tangosol.net.LoadBalancer.ResponseHandler
-
The Socket to read the response from.
- m_sOperationName - Variable in class com.tangosol.net.management.MBeanAccessor.Invoke
-
The the name of the operation to be invoked.
- m_sPrefixToSuppress - Variable in class com.tangosol.coherence.dslquery.internal.PropertyBuilder
-
Prefix string that should be suppressed.
- m_sPunctuation - Variable in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
-
The characters used for punctuation.
- m_sQuery - Variable in class com.tangosol.net.management.MBeanAccessor.QueryBuilder.ParsedQuery
-
A query that can be passed to the MBeanServer to reduce the MBeans.
- m_sRuleElementName - Variable in class com.tangosol.coherence.config.builder.ActionPolicyBuilder.QuorumRule
-
A rule element name to be used to construct ConfigurationException
description if it throws at instantiation time.
- m_sSchemeName - Variable in class com.tangosol.net.DefaultConfigurableCacheFactory.CacheInfo
-
Deprecated.
The corresponding scheme name.
- m_sService - Variable in class com.tangosol.net.management.MBeanAccessor.QueryBuilder
-
The service name to be used in the query.
- m_sService - Variable in class com.tangosol.net.partition.MirroringAssignmentStrategy
-
The name of the associated service.
- m_sSnapshot - Variable in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder
-
The snapshot directory used by persistence.
- m_state - Variable in class com.tangosol.util.SimpleMapIndex.IndexCalculator
-
- m_stats - Variable in class com.tangosol.net.cache.OldCache
-
Deprecated.
The CacheStatistics object maintained by this cache.
- m_stats - Variable in class com.tangosol.net.cache.SimpleOverflowMap
-
The CacheStatistics object maintained by this cache.
- m_stats - Variable in class com.tangosol.util.WrapperObservableMap
-
The CacheStatistics object maintained by this wrapper.
- m_statsPartition - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
The JMXPartitionStats that hold the last updated jmx attributes.
- m_sTitle - Variable in class com.tangosol.coherence.dslquery.ExecutionContext
-
String to use for Title that heads each result displayed.
- m_sTitle - Variable in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
-
String to use for Title that heads each result displayed.
- m_store - Variable in class com.tangosol.net.cache.CacheStoreMap.ReadWriteMap
-
The CacheStore to delegate all Map operations to.
- m_store - Variable in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
Store that holds cache references scoped by class loader and optionally,
if configured, Subject.
- m_storeBundler - Variable in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
The bundler for store() operations.
- m_sTrash - Variable in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder
-
The trash directory used by persistence.
- m_strength - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
The backup strength for the resiliency of the resulting distribution.
- m_sUnnests - Variable in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
-
The characters used to end nesting.
- m_supplier - Variable in class com.tangosol.util.processor.MethodInvocationProcessor
-
The supplier that should be used to create the entry value if this
processor is invoked on an entry that is not present in the cache.
- m_supplierOrderId - Variable in class com.tangosol.net.AsyncNamedCache.OrderBy
-
A function that should be used to determine order id.
- m_sValue - Variable in class com.tangosol.coherence.dsltools.precedence.OPToken
-
The string value of the literal.
- m_sXml - Variable in class com.tangosol.run.xml.PropertyAdapter
-
The XML element name used to store this property.
- m_tail - Variable in class com.tangosol.util.SafeLinkedList
-
The last Node in the List (or null if empty).
- m_term - Variable in class com.tangosol.coherence.dslquery.FilterBuilder
-
The Term that is the AST that encodes the Filter to be made.
- m_term - Variable in class com.tangosol.coherence.dslquery.internal.SelectListMaker
-
The Term that is the AST that encodes select list
- m_term - Variable in class com.tangosol.coherence.dslquery.internal.UpdateSetListMaker
-
The Term that is the AST that encodes select list
- m_test - Variable in class com.tangosol.util.FilterEnumerator
-
Test to perform on each item.
- m_thread - Variable in class com.tangosol.net.SimpleServiceMonitor
-
The
Thread
we are using for monitoring the services periodically.
- m_threadRunning - Variable in class com.tangosol.net.LoadBalancer
-
The Thread that the load balancer is started on.
- m_threadShutdown - Variable in class com.tangosol.net.DefaultCacheServer
-
Shutdown hook thread.
- m_threadShutdownHook - Variable in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
-
Shutdown hook for closing environment.
- m_timeout - Variable in class com.tangosol.coherence.dslquery.ExecutionContext
-
The number of milli-seconds to wait for a
Statement
to execute
before timing out.
- m_timeout - Variable in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
-
The timeout value to use for CohQL statement execution.
- m_tlContext - Static variable in class com.tangosol.net.GuardSupport
-
ThreadLocal containing the GuardContext associated with the
current thread.
- m_token - Variable in class com.tangosol.run.xml.SimpleParser
-
The "current" token being evaluated.
- m_tokenBuffer - Variable in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
-
The temporary buffer used to build the String representing a token.
- m_tokenTable - Variable in class com.tangosol.coherence.dsltools.precedence.OPScanner
-
The TokenTable that defines the translation from BaseTokens to OPTokens
- m_tokenTableExtendedSQL - Variable in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
-
The extended TokenTable for the full language that resembles SQL.
- m_tokenTableForFilter - Variable in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
-
The TokenTable for Filters.
- m_tokenTableSQL - Variable in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
-
The TokenTable for the full language that resembles SQL.
- m_toker - Variable in class com.tangosol.run.xml.SimpleParser
-
The lexical tokenizer.
- m_transformer - Variable in class com.tangosol.net.cache.ContinuousQueryCache
-
The transformer that should be used to convert values from the
underlying cache.
- m_transformState - Variable in class com.tangosol.net.cache.CacheEvent
-
The transformation state for this event.
- m_tree - Variable in class com.tangosol.util.Tree
-
The delgate tree.
- m_updater - Variable in class com.tangosol.coherence.rest.util.MvelManipulator
-
The underlying ValueUpdater.
- m_updater - Variable in class com.tangosol.util.extractor.CompositeUpdater
-
The ValueUpdater part.
- m_updater - Variable in class com.tangosol.util.processor.PropertyManipulator
-
The underlying ValueUpdater.
- m_updater - Variable in class com.tangosol.util.processor.UpdaterProcessor
-
The underlying ValueUpdater.
- m_value - Variable in class com.tangosol.util.filter.ComparisonFilter
-
The value to compare to.
- m_value - Variable in class com.tangosol.util.processor.ConditionalPut
-
Specifies the new value to update an entry with.
- m_value - Variable in class com.tangosol.util.processor.UpdaterProcessor
-
A value to update the entry's value with.
- m_valueLast - Variable in class com.tangosol.util.AbstractSafeLongArray.SafeIterator
-
The last value returned from the iterator.
- m_writer - Variable in class com.tangosol.coherence.dslquery.ExecutionContext
-
The
PrintWriter
that can be used by commands to display output.
- m_writer - Variable in class com.tangosol.io.Base64OutputStream
-
The Writer object to which the Base64 encoded data is written.
- m_writerNested - Variable in class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
-
The currently open nested writer, if any.
- m_xml - Variable in class com.tangosol.net.SocketOptions
-
The configuration.
- m_xmlConfig - Variable in class com.tangosol.io.bdb.BerkeleyDBBinaryStoreManager
-
Stored configuration for this Manager.
- m_xmlConfig - Variable in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
-
Configuration.
- m_xmlElement - Variable in class com.tangosol.coherence.config.builder.ActionPolicyBuilder.QuorumRule
-
An optional xml configuration element to be used in ConfigurationException.
- m_xmlScheme - Variable in class com.tangosol.net.DefaultConfigurableCacheFactory.PartitionedBackingMapManager
-
Deprecated.
The xml configuration for the enclosed backing maps.
- MACHINE_SAFE - Static variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.BackupStrength
-
Machine-safety (members are on different machines).
- MACHINES - Static variable in class com.tangosol.net.ConfigurableQuorumPolicy.ClusterQuorumPolicy
-
The role prefix to use for the "timeout-machine-quorum".
- main(String[]) - Static method in class com.tangosol.coherence.dslquery.QueryPlus
-
The main application for CohQL statement processing.
- main(String[]) - Static method in class com.tangosol.io.DebugDataOutputStream
-
Command line test.
- main(String[]) - Static method in class com.tangosol.io.nio.BinaryMap
-
Debugging support: Command line test.
- main(String[]) - Static method in class com.tangosol.io.pof.PofBufferWriter
-
- main(String[]) - Static method in class com.tangosol.io.pof.PofParser
-
Unit test:
java PofParser <hex string>
- main(String[]) - Static method in class com.tangosol.net.cache.BinaryMemoryCalculator
-
Unit test.
- main(String[]) - Static method in class com.tangosol.net.cache.SimpleMemoryCalculator
-
Unit test.
- main(String[]) - Static method in class com.tangosol.net.CacheFactory
-
Invoke the Coherence command line tool.
- main(String[]) - Static method in class com.tangosol.net.ClusterPermission
-
Unit test allows to compare the specified permissions.
- main(String[]) - Static method in class com.tangosol.net.DefaultCacheServer
-
Entry point: start the cache server under two possible contexts:
With a "coherence-cache-config.xsd" compliant configuration file.
- main(String[]) - Static method in class com.tangosol.net.LoadBalancer
-
Command-line capability to start the load balancer.
- main(String[]) - Static method in class com.tangosol.net.management.MBeanConnector
-
Start a Coherence cluster node that enables JMX agents such as a web
browser or JConsole to connect to the in-process JMX MBeanServer and
manage Coherence MBeans.
- main(String[]) - Static method in class com.tangosol.net.Ping
-
Check if the specified address is reachable.
- main(String[]) - Static method in class com.tangosol.net.security.DefaultController
-
Standalone permission check utility.
- main(String[]) - Static method in class com.tangosol.persistence.GUIDHelper
-
Utility that outputs information about a given GUID.
- main(String[]) - Static method in class com.tangosol.run.xml.SaxParser
-
Unit test: create a simple parser, parse and output the result.
- main(String[]) - Static method in class com.tangosol.run.xml.SimpleParser
-
Unit test.
- main(String[]) - Static method in class com.tangosol.util.ExternalizableHelper
-
Parse a hex string representing a serialized object.
- main(String[]) - Static method in class com.tangosol.util.SafeLinkedList
-
Self-test for SafeLinkedList.
- main(String[]) - Static method in class com.tangosol.util.UID
-
Allow UID identifiers to be generated or parsed at the command line.
- main(String[]) - Static method in class com.tangosol.util.UUID
-
Allow UUID identifiers to be generated or parsed at the command line.
- makeAdapter(Class, String, String, XmlElement) - Method in class com.tangosol.run.xml.XmlBean.BeanInfo
-
Generate a property adapter instance that will work on this bean class
and will adapt for a property of the specified class and of the
specified name.
- makeByteArrayPrivate() - Method in class com.tangosol.io.ByteArrayWriteBuffer
-
Make sure that the underlying byte[] will be treated as private data.
- makeConnection(SocketChannel) - Method in class com.tangosol.net.NonBlockingTcpDatagramSocket.Impl
-
Make a connection from an existing channel.
- makeConnection(SocketAddress) - Method in class com.tangosol.net.NonBlockingTcpDatagramSocket.Impl
-
Produce a new Connection for the specified destination address.
- makeConnection(SocketAddress) - Method in class com.tangosol.net.TcpDatagramSocket.Impl
-
Produce a new Connection for the specified destination address.
- makeEntry(Map<K, V>, K) - Static method in class com.tangosol.util.InvocableMapHelper
-
Create a SimpleEntry object for the specified map and the key.
- makeEntrySet(Map<K, V>, Collection<? extends K>, boolean) - Static method in class com.tangosol.util.InvocableMapHelper
-
Create a set of SimpleEntry objects for the specified map and
the key collection.
- makeEntrySet(Collection<? extends Map.Entry<K, V>>) - Static method in class com.tangosol.util.InvocableMapHelper
-
Create a set of read-only SimpleEntry objects for the specified collection
of Map.Entry objects.
- makeExtractor(NodeTerm) - Method in class com.tangosol.coherence.dslquery.FilterBuilder
-
Process the AST Tree using the given Term that represents getter.
- makeExtractor(Term, Term, TermWalker) - Method in class com.tangosol.coherence.dslquery.operator.BaseOperator
-
- makeExtractor(Object, Object) - Method in class com.tangosol.coherence.dslquery.operator.BaseOperator
-
- makeFilter() - Method in class com.tangosol.coherence.dslquery.FilterBuilder
-
Make a new Filter from the set AST.
- makeFilter(Term) - Method in class com.tangosol.coherence.dslquery.FilterBuilder
-
Make a new Filter from the given AST.
- makeFilter(Term, Object[]) - Method in class com.tangosol.coherence.dslquery.FilterBuilder
-
Make a new Filter from the given AST using given array for Bind vars.
- makeFilter(Term, Object[], Map) - Method in class com.tangosol.coherence.dslquery.FilterBuilder
-
Make a new Filter from the given AST using the given bind variables.
- makeFilter(Term, List, ParameterResolver) - Method in class com.tangosol.coherence.dslquery.FilterBuilder
-
Make a new Filter from the given AST using the given bind variables.
- makeFilter(Object, Object) - Method in class com.tangosol.coherence.dslquery.operator.AndOperator
-
- makeFilter(Term, Term, TermWalker) - Method in class com.tangosol.coherence.dslquery.operator.BaseOperator
-
- makeFilter(Object, Object) - Method in class com.tangosol.coherence.dslquery.operator.BaseOperator
-
- makeFilter(Object, Object) - Method in class com.tangosol.coherence.dslquery.operator.BetweenOperator
-
- makeFilter(Term, Term, TermWalker) - Method in class com.tangosol.coherence.dslquery.operator.ComparisonOperator
-
- makeFilter(Object, Object) - Method in class com.tangosol.coherence.dslquery.operator.ContainsAllOperator
-
- makeFilter(Object, Object) - Method in class com.tangosol.coherence.dslquery.operator.ContainsAnyOperator
-
- makeFilter(Object, Object) - Method in class com.tangosol.coherence.dslquery.operator.ContainsOperator
-
- makeFilter(Term, Term, TermWalker) - Method in class com.tangosol.coherence.dslquery.operator.EqualsOperator
-
- makeFilter(Object, Object) - Method in class com.tangosol.coherence.dslquery.operator.EqualsOperator
-
- makeFilter(Object, Object) - Method in class com.tangosol.coherence.dslquery.operator.GreaterEqualsOperator
-
- makeFilter(Object, Object) - Method in class com.tangosol.coherence.dslquery.operator.GreaterOperator
-
- makeFilter(Object, Object) - Method in class com.tangosol.coherence.dslquery.operator.InOperator
-
- makeFilter(Object, Object) - Method in class com.tangosol.coherence.dslquery.operator.LessEqualsOperator
-
- makeFilter(Object, Object) - Method in class com.tangosol.coherence.dslquery.operator.LessOperator
-
- makeFilter(Object, Object) - Method in class com.tangosol.coherence.dslquery.operator.LikeOperator
-
- makeFilter(Object, Object) - Method in class com.tangosol.coherence.dslquery.operator.NotEqualsOperator
-
- makeFilter(Object, Object) - Method in class com.tangosol.coherence.dslquery.operator.OrOperator
-
- makeFilter(Object, Object) - Method in class com.tangosol.coherence.dslquery.operator.XorOperator
-
- makeFilterForCache(String, Term, List, ParameterResolver) - Method in class com.tangosol.coherence.dslquery.FilterBuilder
-
Make a new Filter from the given AST using given array for Bind vars.
- makeInteger(int) - Static method in class com.tangosol.util.Base
-
- makeListLiteral(Object[]) - Method in class com.tangosol.coherence.dslquery.internal.UpdateSetListMaker
-
Create an ArrayList from the given arguments.
- makeLong(long) - Static method in class com.tangosol.util.Base
-
- makeMapLiteral(Object[]) - Method in class com.tangosol.coherence.dslquery.internal.UpdateSetListMaker
-
Create an Map from the given arguments.
- makeMBeanName(PartitionedService) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
Create a name for the MBean representing this strategy.
- makeName(String, int) - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
-
Format a synthetic name for a partition-specific backing map.
- makeObject(NodeTerm) - Method in class com.tangosol.coherence.dslquery.internal.UpdateSetListMaker
-
Process the AST Tree using the given Term that that is to be turned
into an Object.
- makeObjectForKey(NodeTerm, Object) - Method in class com.tangosol.coherence.dslquery.internal.UpdateSetListMaker
-
Process the AST Tree using the given Term that that is to be turned
into an Object to be used as a key for the given context Object.
- makePairLiteral(Object[]) - Method in class com.tangosol.coherence.dslquery.internal.UpdateSetListMaker
-
Create an Object[] from the given arguments.
- makePathString(Object) - Method in class com.tangosol.coherence.dslquery.internal.UpdateSetListMaker
-
Make a . separated String out of the given Object.
- makeProvider(XmlElement) - Static method in class com.tangosol.net.ConfigurableAddressProvider
-
Deprecated.
- makeSelectsForCache(String, NodeTerm) - Method in class com.tangosol.coherence.dslquery.internal.SelectListMaker
-
Process the AST Tree using the given Term
- makeSetList() - Method in class com.tangosol.coherence.dslquery.internal.UpdateSetListMaker
-
Process the AST Tree using the already set AST Tree
- makeSetList(NodeTerm) - Method in class com.tangosol.coherence.dslquery.internal.UpdateSetListMaker
-
Process the AST Tree using the given Term
- makeSetLiteral(Object[]) - Method in class com.tangosol.coherence.dslquery.internal.UpdateSetListMaker
-
Create an HashSet from the given arguments.
- makeSetOrMapLiteral(Object[]) - Method in class com.tangosol.coherence.dslquery.internal.UpdateSetListMaker
-
Create a Set or Map from the given arguments.
- makeSimpleName(String, String) - Method in class com.tangosol.coherence.dslquery.internal.PropertyBuilder
-
Make a camel case String by prefixing a given String with a given
prefix.
- makeThread(ThreadGroup, Runnable, String) - Static method in class com.tangosol.util.Base
-
Create a Thread with the specified group, runnable, and name, using
the configured ThreadFactory, as specified by the
tangosol.coherence.threadfactory system property.
- makeThread(ThreadGroup, Runnable, String) - Method in class com.tangosol.util.DaemonThreadFactory
-
Create a Thread with the specified group, runnable, and name.
- makeThread(ThreadGroup, Runnable, String) - Method in interface com.tangosol.util.ThreadFactory
-
Create a Thread with the specified group, runnable, and name.
- makeTrint(long) - Static method in class com.tangosol.util.ExternalizableHelper
-
Convert a long integer to a trint.
- makeValueExtractor(Object) - Method in class com.tangosol.coherence.dslquery.internal.UpdateSetListMaker
-
Make a ValueExtractor out of the given Object.
- makeValueUpdater(Object) - Method in class com.tangosol.coherence.dslquery.internal.UpdateSetListMaker
-
Make a ValueUpdater out of the given Object.
- MANAGEMENT_TYPE - Static variable in interface com.tangosol.net.management.Registry
-
String representing the "type" part of ObjectName for the
ManagementMBean.
- Manager() - Constructor for class com.tangosol.net.DefaultConfigurableCacheFactory.Manager
-
Deprecated.
- Manager(ExtensibleConfigurableCacheFactory) - Constructor for class com.tangosol.net.ExtensibleConfigurableCacheFactory.Manager
-
Construct the backing map manager.
- manipulate(String) - Static method in class com.tangosol.util.Processors
-
Construct a property manipulate processor for the specified property name.
- manipulate(String, boolean) - Static method in class com.tangosol.util.Processors
-
Construct a property manipulate processor for the specified property name.
- map(ValueExtractor<? super V_BACK, ? extends V_FRONT>) - Method in class com.tangosol.net.ViewBuilder
-
The
ValueExtractor
that this
view
will use to transform the results from
the underlying cache prior to storing them locally.
- map(DoubleUnaryOperator) - Method in interface com.tangosol.util.stream.RemoteDoubleStream
-
Returns a stream consisting of the results of applying the given
function to the elements of this stream.
- map(Remote.DoubleUnaryOperator) - Method in interface com.tangosol.util.stream.RemoteDoubleStream
-
Returns a stream consisting of the results of applying the given
function to the elements of this stream.
- map(IntUnaryOperator) - Method in interface com.tangosol.util.stream.RemoteIntStream
-
Returns a stream consisting of the results of applying the given
function to the elements of this stream.
- map(Remote.IntUnaryOperator) - Method in interface com.tangosol.util.stream.RemoteIntStream
-
Returns a stream consisting of the results of applying the given
function to the elements of this stream.
- map(LongUnaryOperator) - Method in interface com.tangosol.util.stream.RemoteLongStream
-
Returns a stream consisting of the results of applying the given
function to the elements of this stream.
- map(Remote.LongUnaryOperator) - Method in interface com.tangosol.util.stream.RemoteLongStream
-
Returns a stream consisting of the results of applying the given
function to the elements of this stream.
- map(Function<? super T, ? extends R>) - Method in interface com.tangosol.util.stream.RemoteStream
-
Returns a stream consisting of the results of applying the given function
to the elements of this stream.
- map(Remote.Function<? super T, ? extends R>) - Method in interface com.tangosol.util.stream.RemoteStream
-
Returns a stream consisting of the results of applying the given function
to the elements of this stream.
- map(ValueExtractor<? super T, ? extends R>) - Method in interface com.tangosol.util.stream.RemoteStream
-
Returns a stream consisting of the results of applying the given extractor
to the elements of this stream.
- MAP_FIXED_SIZES - Static variable in class com.tangosol.net.cache.SimpleMemoryCalculator
-
An immutable map of fixed-sized classes to instance size (in bytes).
- MAP_OVERHEAD - Static variable in class com.tangosol.util.SimpleMapIndex.IndexCalculator
-
The memory cost of a SegmentedHashMap used as the Forward Index.
- MAP_PRIMITIVE_SIZES - Static variable in class com.tangosol.net.cache.SimpleMemoryCalculator
-
An imutable map of primitive types to their size (in bytes).
- MAP_SCHEMETYPE_BY_SCHEMENAME - Static variable in class com.tangosol.net.ExtensibleConfigurableCacheFactory
-
The mappings from scheme name to scheme type.
- MapAdapter - Class in com.tangosol.run.xml
-
A MapAdapter supports properties whose types implement the java.util.Map
interface.
- MapAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.MapAdapter
-
Construct a MapAdapter.
- MapArray(int) - Constructor for class com.tangosol.net.partition.PartitionSplittingBackingMap.MapArray
-
Construct an empty MapArray for a given partition count.
- MapBuilder - Interface in com.tangosol.coherence.config.builder
-
The
MapBuilder
interface is used by a builder to create an instance
of a
Map
that is a local to a Java process.
- MapBuilder.Dependencies - Class in com.tangosol.coherence.config.builder
-
- MapCacheStore<K,V> - Class in com.tangosol.net.cache
-
A CacheStore that sits directly on top of a Map.
- MapCacheStore(Map<K, V>) - Constructor for class com.tangosol.net.cache.MapCacheStore
-
Create a CacheStore that delegates to a Map.
- MapCodec(Class<? extends Map<Object, Object>>) - Constructor for class com.tangosol.io.pof.reflect.Codecs.MapCodec
-
Construct a MapCodec.
- MapEntry() - Constructor for class com.tangosol.util.SafeSortedMap.EntryNode.MapEntry
-
- MapEntryIteratorToCacheEntryIteratorAdapter<K,V> - Class in com.tangosol.coherence.jcache.common
-
- MapEntryIteratorToCacheEntryIteratorAdapter(Iterator<Map.Entry<K, V>>) - Constructor for class com.tangosol.coherence.jcache.common.MapEntryIteratorToCacheEntryIteratorAdapter
-
- MapEvent<K,V> - Class in com.tangosol.util
-
An event which indicates that the content of a map has changed:
an entry has been added
an entry has been removed
an entry has been changed
A MapEvent object is sent as an argument to the MapListener interface
methods.
- MapEvent() - Constructor for class com.tangosol.util.MapEvent
-
Default constructor for serialization.
- MapEvent(ObservableMap<K, V>, int, K, V, V) - Constructor for class com.tangosol.util.MapEvent
-
Constructs a new MapEvent.
- MapEventFilter<K,V> - Class in com.tangosol.util.filter
-
Filter which evaluates the content of a MapEvent object according to the
specified criteria.
- MapEventFilter() - Constructor for class com.tangosol.util.filter.MapEventFilter
-
Default constructor (necessary for the ExternalizableLite interface).
- MapEventFilter(int) - Constructor for class com.tangosol.util.filter.MapEventFilter
-
Construct a MapEventFilter that evaluates MapEvent objects based on the
specified combination of event types.
- MapEventFilter(Filter<V>) - Constructor for class com.tangosol.util.filter.MapEventFilter
-
- MapEventFilter(int, Filter<V>) - Constructor for class com.tangosol.util.filter.MapEventFilter
-
Construct a MapEventFilter that evaluates MapEvent objects
based on the specified combination of event types.
- MapEventOutput<K,V> - Class in com.tangosol.coherence.rest.events
-
MapListener
implementation that converts Coherence
MapEvents
into Jersey Server Sent Events (SSE).
- MapEventOutput(NamedCache<K, V>, boolean) - Constructor for class com.tangosol.coherence.rest.events.MapEventOutput
-
Construct MapEventOutput instance.
- MapEventTransformer<K,V,U> - Interface in com.tangosol.util
-
MapEventTransformer interface is used to allow an event consumer to change
the content of a
MapEvent
destined for the corresponding
MapListener
.
- MapEventTransformerFilter<T> - Class in com.tangosol.util.filter
-
MapEventTransformerFilter is a generic multiplexing wrapper that combines two
implementations: a Filter (most commonly a
MapEventFilter
) and a
MapEventTransformer and is used to register event listeners that allow to
change the content of a MapEvent.
- MapEventTransformerFilter() - Constructor for class com.tangosol.util.filter.MapEventTransformerFilter
-
No-argument constructor for lite deserialization.
- MapEventTransformerFilter(Filter<T>, MapEventTransformer) - Constructor for class com.tangosol.util.filter.MapEventTransformerFilter
-
Construct a MapEventTransformerFilter based on the specified Filter
and MapEventTransformer.
- MapIndex<K,V,E> - Interface in com.tangosol.util
-
MapIndex is used to correlate values stored in an indexed Map (or
attributes of those values) to the corresponding keys in the indexed Map.
- MapListener<K,V> - Interface in com.tangosol.util
-
The listener interface for receiving MapEvents.
- MapListenerProcessor - Class in com.tangosol.coherence.config.xml.processor
-
- MapListenerProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.MapListenerProcessor
-
- MapListenerSupport - Class in com.tangosol.util
-
This class provides support for advanced MapListener functionality.
- MapListenerSupport() - Constructor for class com.tangosol.util.MapListenerSupport
-
Constructs a new MapListenerSupport object.
- MapListenerSupport.FilterEvent - Class in com.tangosol.util
-
An extension of the CacheEvent which may carry no values (old or new), but
instead holds on an array of Filter objects being the "cause" of the event.
- MapListenerSupport.PrimingListener<K,V> - Interface in com.tangosol.util
-
A tag interface indicating that this listener is registered as a
synchronous listener for lite events (carrying only a key) and generates
a "priming" event when registered.
- MapListenerSupport.SynchronousListener<K,V> - Interface in com.tangosol.util
-
A tag interface indicating that tagged MapListener implementation
has to receive the MapEvent notifications in a synchronous manner.
- MapListenerSupport.WrapperListener<K,V> - Class in com.tangosol.util
-
A base class for various wrapper listener classes.
- MapListenerSupport.WrapperPrimingListener - Class in com.tangosol.util
-
A wrapper class that turns the specified MapListener into
a priming listener.
- MapListenerSupport.WrapperSynchronousListener<K,V> - Class in com.tangosol.util
-
A wrapper class that turns the specified MapListener into
a synchronous listener.
- mapMerger(Remote.BinaryOperator<V>) - Static method in interface com.tangosol.util.function.Remote.BinaryOperator
-
BinaryOperator<Map>
that merges the contents of its right
argument into its left argument, using the provided merge function to
handle duplicate keys.
- mapMerger(BinaryOperator<V>) - Static method in interface com.tangosol.util.function.Remote.BinaryOperator
-
BinaryOperator<Map>
that merges the contents of its right
argument into its left argument, using the provided merge function to
handle duplicate keys.
- MapNotFoundException - Exception in com.tangosol.util
-
An exception to indicate that a required map does not exist.
- MapNotFoundException(String) - Constructor for exception com.tangosol.util.MapNotFoundException
-
- MappedBufferManager - Class in com.tangosol.io.nio
-
Manages a ByteBuffer on a file.
- MappedBufferManager() - Constructor for class com.tangosol.io.nio.MappedBufferManager
-
Construct a MappedBufferManager using defaults.
- MappedBufferManager(int, int, File) - Constructor for class com.tangosol.io.nio.MappedBufferManager
-
Construct a MappedBufferManager that supports a buffer of a certain
initial and maximum size.
- MappedStoreManager - Class in com.tangosol.io.nio
-
- MappedStoreManager(int, int, File) - Constructor for class com.tangosol.io.nio.MappedStoreManager
-
Construct a DirectStoreManager that uses BinaryMap objests built on
the MappedBufferManager(s) with certain initial and maximum size.
- mapping(Remote.Function<? super T, ? extends U>, RemoteCollector<? super U, A, R>) - Static method in class com.tangosol.util.stream.RemoteCollectors
-
Adapts a Collector
accepting elements of type U
to one
accepting elements of type T
by applying a mapping function to
each input element before accumulation.
- MapSet - Class in com.tangosol.util
-
An ExternalizableLite implementation of java.util.Set that uses an
underlying Map object to store its data in, just as the Java HashSet
implementation uses an underlying HashMap for its element storage.
- MapSet() - Constructor for class com.tangosol.util.MapSet
-
Default constructor.
- MapSet(Map) - Constructor for class com.tangosol.util.MapSet
-
Construct a MapSet that uses the given Map for its underlying storage.
- mapToDouble(IntToDoubleFunction) - Method in interface com.tangosol.util.stream.RemoteIntStream
-
Returns a DoubleStream
consisting of the results of applying the
given function to the elements of this stream.
- mapToDouble(Remote.IntToDoubleFunction) - Method in interface com.tangosol.util.stream.RemoteIntStream
-
Returns a DoubleStream
consisting of the results of applying the
given function to the elements of this stream.
- mapToDouble(LongToDoubleFunction) - Method in interface com.tangosol.util.stream.RemoteLongStream
-
Returns a DoubleStream
consisting of the results of applying the
given function to the elements of this stream.
- mapToDouble(Remote.LongToDoubleFunction) - Method in interface com.tangosol.util.stream.RemoteLongStream
-
Returns a DoubleStream
consisting of the results of applying the
given function to the elements of this stream.
- mapToDouble(ToDoubleFunction<? super T>) - Method in interface com.tangosol.util.stream.RemoteStream
-
Returns a DoubleStream
consisting of the results of applying the
given function to the elements of this stream.
- mapToDouble(Remote.ToDoubleFunction<? super T>) - Method in interface com.tangosol.util.stream.RemoteStream
-
Returns a DoubleStream
consisting of the results of applying the
given function to the elements of this stream.
- mapToDouble(ValueExtractor<? super T, ? extends Number>) - Method in interface com.tangosol.util.stream.RemoteStream
-
Returns an DoubleStream
consisting of the results of applying the
given extractor to the elements of this stream.
- mapToInt(DoubleToIntFunction) - Method in interface com.tangosol.util.stream.RemoteDoubleStream
-
Returns an IntStream
consisting of the results of applying the
given function to the elements of this stream.
- mapToInt(Remote.DoubleToIntFunction) - Method in interface com.tangosol.util.stream.RemoteDoubleStream
-
Returns an IntStream
consisting of the results of applying the
given function to the elements of this stream.
- mapToInt(LongToIntFunction) - Method in interface com.tangosol.util.stream.RemoteLongStream
-
Returns an IntStream
consisting of the results of applying the
given function to the elements of this stream.
- mapToInt(Remote.LongToIntFunction) - Method in interface com.tangosol.util.stream.RemoteLongStream
-
Returns an IntStream
consisting of the results of applying the
given function to the elements of this stream.
- mapToInt(ToIntFunction<? super T>) - Method in interface com.tangosol.util.stream.RemoteStream
-
Returns an IntStream
consisting of the results of applying the
given function to the elements of this stream.
- mapToInt(Remote.ToIntFunction<? super T>) - Method in interface com.tangosol.util.stream.RemoteStream
-
Returns an IntStream
consisting of the results of applying the
given function to the elements of this stream.
- mapToInt(ValueExtractor<? super T, ? extends Number>) - Method in interface com.tangosol.util.stream.RemoteStream
-
Returns an IntStream
consisting of the results of applying the
given extractor to the elements of this stream.
- mapToLong(DoubleToLongFunction) - Method in interface com.tangosol.util.stream.RemoteDoubleStream
-
Returns a LongStream
consisting of the results of applying the
given function to the elements of this stream.
- mapToLong(Remote.DoubleToLongFunction) - Method in interface com.tangosol.util.stream.RemoteDoubleStream
-
Returns a LongStream
consisting of the results of applying the
given function to the elements of this stream.
- mapToLong(IntToLongFunction) - Method in interface com.tangosol.util.stream.RemoteIntStream
-
Returns a LongStream
consisting of the results of applying the
given function to the elements of this stream.
- mapToLong(Remote.IntToLongFunction) - Method in interface com.tangosol.util.stream.RemoteIntStream
-
Returns a LongStream
consisting of the results of applying the
given function to the elements of this stream.
- mapToLong(ToLongFunction<? super T>) - Method in interface com.tangosol.util.stream.RemoteStream
-
Returns a LongStream
consisting of the results of applying the
given function to the elements of this stream.
- mapToLong(Remote.ToLongFunction<? super T>) - Method in interface com.tangosol.util.stream.RemoteStream
-
Returns a LongStream
consisting of the results of applying the
given function to the elements of this stream.
- mapToLong(ValueExtractor<? super T, ? extends Number>) - Method in interface com.tangosol.util.stream.RemoteStream
-
Returns an LongStream
consisting of the results of applying the
given extractor to the elements of this stream.
- mapToObj(DoubleFunction<? extends U>) - Method in interface com.tangosol.util.stream.RemoteDoubleStream
-
Returns an object-valued Stream
consisting of the results of
applying the given function to the elements of this stream.
- mapToObj(Remote.DoubleFunction<? extends U>) - Method in interface com.tangosol.util.stream.RemoteDoubleStream
-
Returns an object-valued Stream
consisting of the results of
applying the given function to the elements of this stream.
- mapToObj(IntFunction<? extends U>) - Method in interface com.tangosol.util.stream.RemoteIntStream
-
Returns an object-valued Stream
consisting of the results of
applying the given function to the elements of this stream.
- mapToObj(Remote.IntFunction<? extends U>) - Method in interface com.tangosol.util.stream.RemoteIntStream
-
Returns an object-valued Stream
consisting of the results of
applying the given function to the elements of this stream.
- mapToObj(LongFunction<? extends U>) - Method in interface com.tangosol.util.stream.RemoteLongStream
-
Returns an object-valued Stream
consisting of the results of
applying the given function to the elements of this stream.
- mapToObj(Remote.LongFunction<? extends U>) - Method in interface com.tangosol.util.stream.RemoteLongStream
-
Returns an object-valued Stream
consisting of the results of
applying the given function to the elements of this stream.
- MapTrigger<K,V> - Interface in com.tangosol.util
-
MapTrigger represents a functional agent that allows to validate, reject or
modify mutating operations against an underlying map.
- MapTrigger.Entry<K,V> - Interface in com.tangosol.util
-
A MapTrigger Entry represents a pending change to an Entry that is about
to committed to the underlying Map.
- MapTriggerListener - Class in com.tangosol.util
-
MapTriggerListener is a special purpose MapListener implementation that is
used to register a
MapTrigger
on a corresponding ObservableMap.
- MapTriggerListener(MapTrigger) - Constructor for class com.tangosol.util.MapTriggerListener
-
Construct a MapTriggerListener that can be used to register the specified
MapTrigger.
- mark(int) - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
-
Marks the current read position in the InputStream in order to
support the stream to be later "rewound" (using the InputStreaming.reset()
method) to the current position.
- mark(int) - Method in class com.tangosol.io.MultiByteArrayInputStream
-
Marks the current position in this input stream.
- mark(int) - Method in class com.tangosol.io.nio.ByteBufferInputStream
-
Marks the current position in this input stream.
- mark(int) - Method in class com.tangosol.io.nio.ByteBufferReadBuffer.ByteBufferInput
-
Marks the current read position in the InputStream in order to
support the stream to be later "rewound" (using the InputStreaming.reset()
method) to the current position.
- mark(int) - Method in class com.tangosol.io.pof.PofInputStream
-
Marks the current read position in the InputStream in order to support
the stream to be later "rewound" (using the
PofInputStream.reset()
method) to
the current position.
- mark(int) - Method in interface com.tangosol.io.ReadBuffer.BufferInput
-
Marks the current read position in the InputStream in order to
support the stream to be later "rewound" (using the InputStreaming.reset()
method) to the current position.
- mark(int) - Method in class com.tangosol.io.Utf8Reader
-
Mark the present position in the stream.
- mark(int) - Method in class com.tangosol.io.WrapperDataInputStream
-
Marks the current read position in the InputStream in order to support
the stream to be later "rewound" (using the
WrapperDataInputStream.reset()
method) to
the current position.
- mark(int) - Method in class com.tangosol.io.WrapperInputStream
-
Marks the current read position in the InputStream in order to support
the stream to be later "rewound" (using the
WrapperInputStream.reset()
method) to
the current position.
- mark() - Method in class com.tangosol.run.xml.SimpleParser
-
Marks the current position and returns it as a token.
- mark(int) - Method in class com.tangosol.util.NullImplementation.NullReader
- MARK_UNSET - Static variable in class com.tangosol.io.MultiByteArrayInputStream
-
Marker position indicating that stream is not marked.
- markConverted() - Method in class com.tangosol.util.filter.InKeySetFilter
-
Mark the underlying keys set as converted.
- MARKED_ALL - Static variable in class com.tangosol.net.partition.PartitionSet
-
Serialization format indicator: Indicates that all partitions are
marked; MARKED_ALL requires no additional data.
- MARKED_FEW - Static variable in class com.tangosol.net.partition.PartitionSet
-
Serialization format indicator: Indicates that a small number of
partitions are marked; followed by stream of packed integers indicating
gaps between each marked partition, terminated with a -1.
- MARKED_MANY - Static variable in class com.tangosol.net.partition.PartitionSet
-
Serialization format indicator: Indicates that a large number of
partitions are marked; followed by a sequence of 64-bit values
sufficient to represent the cardinality of the PartitionSet.
- MARKED_NONE - Static variable in class com.tangosol.net.partition.PartitionSet
-
Serialization format indicator: Indicates that no partitions are
marked; MARKED_NONE requires no additional data.
- markForDelete(SafeSortedMap.EntryNode) - Method in class com.tangosol.util.SafeSortedMap.EntryNode
-
Attempt to mark this EntryNode for deletion by appending a delete
marker to follow this EntryNode, assuming that the expected nex
EntryNode is the next.
- markPosition(int, SafeLinkedList.Node) - Method in class com.tangosol.util.SafeLinkedList
-
Remember that a certain Node occurs at a certain index.
- markServicesStarted() - Method in class com.tangosol.net.DefaultCacheServer
-
Set the "services started" flag.
- markSupported() - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
-
- markSupported() - Method in class com.tangosol.io.MultiByteArrayInputStream
-
Tests if this input stream supports the mark
and
reset
methods.
- markSupported() - Method in class com.tangosol.io.nio.ByteBufferInputStream
-
Tests if this input stream supports the mark
and
reset
methods.
- markSupported() - Method in class com.tangosol.io.pof.PofInputStream
-
- markSupported() - Method in interface com.tangosol.io.ReadBuffer.BufferInput
-
- markSupported() - Method in class com.tangosol.io.Utf8Reader
-
Tell whether this stream supports the mark() operation.
- markSupported() - Method in class com.tangosol.io.WrapperDataInputStream
-
- markSupported() - Method in class com.tangosol.io.WrapperInputStream
-
- markSupported() - Method in class com.tangosol.util.NullImplementation.NullReader
- marshal(Binary, OutputStream, MultivaluedMap<String, Object>) - Method in class com.tangosol.coherence.rest.io.BinaryMarshaller
-
- marshal(T, OutputStream, MultivaluedMap<String, Object>) - Method in class com.tangosol.coherence.rest.io.JacksonJsonMarshaller
-
- marshal(T, OutputStream, MultivaluedMap<String, Object>) - Method in class com.tangosol.coherence.rest.io.JaxbXmlMarshaller
-
- marshal(Object, OutputStream, MultivaluedMap<String, Object>) - Method in class com.tangosol.coherence.rest.io.KeyConverterAdapter
-
- marshal(T, OutputStream, MultivaluedMap<String, Object>) - Method in interface com.tangosol.coherence.rest.io.Marshaller
-
Write the specified object into the given stream.
- marshal(StaticContent, OutputStream, MultivaluedMap<String, Object>) - Method in class com.tangosol.coherence.rest.io.StaticContentMarshaller
-
- marshal(String, OutputStream, MultivaluedMap<String, Object>) - Method in class com.tangosol.coherence.rest.io.StringMarshaller
-
- marshalAsFragment(T, OutputStream, MultivaluedMap<String, Object>) - Method in class com.tangosol.coherence.rest.io.JaxbXmlMarshaller
-
- marshalAsFragment(T, OutputStream, MultivaluedMap<String, Object>) - Method in interface com.tangosol.coherence.rest.io.Marshaller
-
Write the specified object into the given stream as a fragment.
- Marshaller<T> - Interface in com.tangosol.coherence.rest.io
-
An interface that must be implemented by REST marshallers.
- MarshallerRegistry - Class in com.tangosol.coherence.rest.io
-
Registry for marshaller instances.
- MarshallerRegistry() - Constructor for class com.tangosol.coherence.rest.io.MarshallerRegistry
-
Construct a MarshallerRegistry instance.
- MASK_CONNECT - Static variable in class com.tangosol.coherence.config.builder.ProxyQuorumPolicyBuilder
-
Connect quorum mask.
- MASK_CONNECT - Static variable in class com.tangosol.net.ConfigurableQuorumPolicy.ProxyQuorumPolicy
-
Bitmask used to encode a client connection action.
- MASK_DISTRIBUTION - Static variable in class com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy
-
Bitmask used to encode a distribution action.
- MASK_LAST - Static variable in class com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy
-
The highest used bitmask value.
- MASK_READ - Static variable in class com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy
-
Bitmask used to encode a read action.
- MASK_RECOVER - Static variable in class com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy
-
Bitmask used to encode a recover action.
- MASK_RESTORE - Static variable in class com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy
-
Bitmask used to encode a partition restore action.
- MASK_WRITE - Static variable in class com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy
-
Bitmask used to encode a write action.
- MaskedPartitionMap(PartitionSet) - Constructor for class com.tangosol.net.partition.PartitionSplittingBackingMap.MaskedPartitionMap
-
Construct MaskedPartitionMap based on the specified PartitionSet.
- match(String) - Method in class com.tangosol.coherence.dsltools.base.BaseToken
-
Answer whether this token matches the given string.
- match(String, boolean) - Method in class com.tangosol.coherence.dsltools.base.BaseToken
-
Answer whether this token matches the given string.
- match(String, boolean) - Method in class com.tangosol.coherence.dsltools.base.CompoundBaseToken
-
Answer whether this token matches the given string.
- match(String, boolean) - Method in class com.tangosol.coherence.dsltools.base.LeafBaseToken
-
Answer whether this token matches the given string.
- match(int) - Method in class com.tangosol.run.xml.SimpleParser
-
Verifies that the current token matches the passed token id and, if so,
advances to the next token.
- match(String) - Method in class com.tangosol.run.xml.SimpleParser
-
Verifies that the current token is a name token whose name matches
the passed String and, if so, advances to the next token.
- matches(String) - Method in class com.tangosol.coherence.dsltools.precedence.OPScanner
-
Test to see if the current BaseToken's string matches the given string.
- matches(String, boolean) - Method in class com.tangosol.coherence.dsltools.precedence.OPScanner
-
Test to see if the current BaseToken's string matches the given string.
- MAX - Static variable in class com.tangosol.util.SimpleLongArray
-
Maximum index value.
- max() - Method in interface com.tangosol.util.stream.RemoteDoubleStream
-
Returns an OptionalDouble
describing the maximum element of this
stream, or an empty OptionalDouble if this stream is empty.
- max() - Method in interface com.tangosol.util.stream.RemoteIntStream
-
Returns an OptionalInt
describing the maximum element of this
stream, or an empty optional if this stream is empty.
- max() - Method in interface com.tangosol.util.stream.RemoteLongStream
-
Returns an OptionalLong
describing the maximum element of this
stream, or an empty optional if this stream is empty.
- max(Comparator<? super T>) - Method in interface com.tangosol.util.stream.RemoteStream
-
Returns the maximum element of this stream according to the provided
Comparator
.
- max(Remote.Comparator<? super T>) - Method in interface com.tangosol.util.stream.RemoteStream
-
Returns the maximum element of this stream according to the provided
Comparator
.
- max(ValueExtractor<? super U, ? extends Comparable>) - Method in interface com.tangosol.util.stream.RemoteStream
-
Returns the maximum element of this stream according to the attribute
extracted by the provided ValueExtractor
.
- MAX_DECIMAL128_SCALE - Static variable in interface com.tangosol.io.pof.PofConstants
-
Maximum scale for the IEEE-754r 128-bit decimal format.
- MAX_DECIMAL128_UNSCALED - Static variable in interface com.tangosol.io.pof.PofConstants
-
Maximum unscaled value for the IEEE-754r 128-bit decimal format.
- MAX_DECIMAL32_SCALE - Static variable in interface com.tangosol.io.pof.PofConstants
-
Maximum scale for the IEEE-754r 32-bit decimal format.
- MAX_DECIMAL32_UNSCALED - Static variable in interface com.tangosol.io.pof.PofConstants
-
Maximum unscaled value for the IEEE-754r 32-bit decimal format.
- MAX_DECIMAL64_SCALE - Static variable in interface com.tangosol.io.pof.PofConstants
-
Maximum scale for the IEEE-754r 64-bit decimal format.
- MAX_DECIMAL64_UNSCALED - Static variable in interface com.tangosol.io.pof.PofConstants
-
Maximum unscaled value for the IEEE-754r 64-bit decimal format.
- MAX_DECO_HEADER_BYTES - Static variable in class com.tangosol.util.ExternalizableHelper
-
The maximum number of bytes the header of the binary-decorated value
may contain.
- MAX_LOCK_WAIT - Static variable in class com.tangosol.net.cache.VersionedBackingMap
-
Deprecated.
The length of time (in millis) to wait on a lock; keep this value low
to avoid causing timing problems since some calls will be on the
distributed cache thread.
- MAX_OPEN_BLOCKS - Static variable in class com.tangosol.io.nio.BinaryMap
-
Maximum number of simultaneously open blocks to support.
- MAX_PACKED_INT_SIZE - Static variable in interface com.tangosol.io.WriteBuffer.BufferOutput
-
Maximum encoding length for a packed int value.
- MAX_PACKED_LONG_SIZE - Static variable in interface com.tangosol.io.WriteBuffer.BufferOutput
-
Maximum encoding length for a packed long value.
- MAX_PARTITION_MAP_UNIT_FACTOR - Static variable in class com.tangosol.net.partition.ObservableSplittingBackingCache
-
The maximum unit factor for partition maps.
- MAX_PORT - Static variable in class com.tangosol.coherence.config.builder.LocalAddressProviderBuilder
-
- MAX_SIZE_CODES - Static variable in class com.tangosol.io.nio.BinaryMap
-
Number of size codes for free blocks.
- maxBy(Remote.Comparator<? super T>) - Static method in interface com.tangosol.util.function.Remote.BinaryOperator
-
Returns a
BinaryOperator
which returns the greater of two
elements according to the specified
Comparator
.
- maxBy(Comparator<? super T>) - Static method in interface com.tangosol.util.function.Remote.BinaryOperator
-
Returns a
BinaryOperator
which returns the greater of two
elements according to the specified
Comparator
.
- maxBy(Remote.Comparator<? super T>) - Static method in class com.tangosol.util.stream.RemoteCollectors
-
Returns a Collector
that produces the maximal element according
to a given Comparator
, described as an Optional<T>
.
- MBeanAccessor - Class in com.tangosol.net.management
-
MBeanAccessor provides a means to access JMX MBeans via the Coherence
Management Server (a single MBeanServer with an aggregated view of MBeans
for the entire cluster).
- MBeanAccessor() - Constructor for class com.tangosol.net.management.MBeanAccessor
-
Default Constructor.
- MBeanAccessor(MBeanServerProxy) - Constructor for class com.tangosol.net.management.MBeanAccessor
-
Create an instance of MBeanAccessor.
- MBeanAccessor.GetAttributes - Class in com.tangosol.net.management
-
- MBeanAccessor.Invoke - Class in com.tangosol.net.management
-
- MBeanAccessor.QueryBuilder - Class in com.tangosol.net.management
-
The Query Builder for generating Coherence MBean queries.
- MBeanAccessor.QueryBuilder.ParsedQuery - Class in com.tangosol.net.management
-
- MBeanAccessor.SetAttributes - Class in com.tangosol.net.management
-
- MBeanConnector - Class in com.tangosol.net.management
-
Utility class to expose Coherence JMX MBeans via the Sun JMX reference
implementation
HtmlAdaptorServer or a JMX Remote
JMXConnectorServer
.
- MBeanConnector() - Constructor for class com.tangosol.net.management.MBeanConnector
-
- MBeanHelper - Class in com.tangosol.net.management
-
Helper class providing various functionality related to aggregation of
attributes and methods exposed by Coherence JMX framework MBeans.
- MBeanHelper() - Constructor for class com.tangosol.net.management.MBeanHelper
-
- MBeanHelper.QueryExpFilter - Class in com.tangosol.net.management
-
- MBeanReference - Class in com.tangosol.net.management
-
MBeanReference holds all necessary information to uniquely identify an MBean.
- MBeanReference(ObjectName, MBeanServer) - Constructor for class com.tangosol.net.management.MBeanReference
-
Construct an instance of MBeanReference.
- MBeanServerFinder - Interface in com.tangosol.net.management
-
MBeanServerFinder represents a facility that allows a pluggable run-time
selection of an MBeanServer to be used by the Coherence JMX framework.
- MBeanServerProxy - Interface in com.tangosol.net.management
-
MBeanServerProxy allows any cluster node that runs the Management service
to obtain and set attributes or invoke methods on registered MBeans.
- MBeanServerRegistrationUtility - Class in com.tangosol.coherence.jcache.common
-
A convenience class for registering CacheStatisticsMBeans with an MBeanServer.
- MBeanServerRegistrationUtility.ObjectNameType - Enum in com.tangosol.coherence.jcache.common
-
The type of registered Object
- Megabytes - Class in com.tangosol.coherence.config.unit
-
Megabytes
is a specialized
MemorySize
whose default constructor
assumes that the specified units (when a they are not specified) are
measured in megabytes.
- Megabytes(int) - Constructor for class com.tangosol.coherence.config.unit.Megabytes
-
Constructs a
Megabytes
representing a
MemorySize
measured in megabytes.
- Megabytes(MemorySize) - Constructor for class com.tangosol.coherence.config.unit.Megabytes
-
Constructs a
Megabytes
based on another
MemorySize
.
- Megabytes(String) - Constructor for class com.tangosol.coherence.config.unit.Megabytes
-
Constructs a
Megabytes
representing a
MemorySize
measured in megabytes.
- MEMBER - Static variable in class com.tangosol.net.management.MBeanAccessor
-
The "member" key in the ObjectName.
- Member - Interface in com.tangosol.net
-
The Member interface represents a cluster member.
- MEMBER_IDENTITY_LIMIT - Static variable in interface com.tangosol.net.MemberIdentity
-
The member identity limit used to restrict the size of various fields.
- MEMBER_JOINED - Static variable in class com.tangosol.net.MemberEvent
-
This event indicates that a Member has joined.
- MEMBER_LEAVING - Static variable in class com.tangosol.net.MemberEvent
-
This event indicates that a Member is leaving.
- MEMBER_LEFT - Static variable in class com.tangosol.net.MemberEvent
-
This event indicates that a Member has left.
- memberCompleted(Member, Object) - Method in interface com.tangosol.net.InvocationObserver
-
This method is called by the
InvocationService
to inform the
InvocationObserver that a member has finished running the
Invocable
object; the result of the invocation, if any, is
provided to the InvocationObserver.
- MemberEvent - Class in com.tangosol.net
-
An event which indicates that membership has changed:
a Member has joined
a Member is leaving
a Member has left
A MemberEvent object is sent as an argument to the MemberListener
interface methods.
- MemberEvent(Object, int, Member) - Constructor for class com.tangosol.net.MemberEvent
-
Constructs a new MemberEvent.
- memberFailed(Member, Throwable) - Method in interface com.tangosol.net.InvocationObserver
-
This method is called by the
InvocationService
to inform the
InvocationObserver that a member has thrown an exception while
running the
Invocable
object.
- MEMBERID_COMPARATOR - Static variable in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
Comparator used to provide arbitrary (equals-compatible) comparisons
between members.
- MemberIdentity - Interface in com.tangosol.net
-
The MemberIdentity interface represents the identity of a cluster member.
- memberJoined(MemberEvent) - Method in class com.tangosol.net.cache.ContinuousQueryCache.ServiceListener
-
- memberJoined(MemberEvent) - Method in class com.tangosol.net.cache.NearCache.BackServiceListener
-
Invoked when a Member has joined the service.
- memberJoined(MemberEvent) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumListener
-
Invoked when a Member has joined the service.
- memberJoined(MemberEvent) - Method in interface com.tangosol.net.MemberListener
-
Invoked when a Member has joined the service.
- memberJoined(MemberEvent) - Method in class com.tangosol.net.partition.FailoverAccessPolicy.MembershipListener
-
Invoked when a Member has joined the service.
- memberLeaving(MemberEvent) - Method in class com.tangosol.net.cache.ContinuousQueryCache.ServiceListener
-
- memberLeaving(MemberEvent) - Method in class com.tangosol.net.cache.NearCache.BackServiceListener
-
Invoked when a Member is leaving the service.
- memberLeaving(MemberEvent) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumListener
-
Invoked when a Member is leaving the service.
- memberLeaving(MemberEvent) - Method in interface com.tangosol.net.MemberListener
-
Invoked when a Member is leaving the service.
- memberLeaving(MemberEvent) - Method in class com.tangosol.net.partition.FailoverAccessPolicy.MembershipListener
-
Invoked when a Member is leaving the service.
- memberLeft(MemberEvent) - Method in class com.tangosol.net.cache.ContinuousQueryCache.ServiceListener
-
- memberLeft(MemberEvent) - Method in class com.tangosol.net.cache.NearCache.BackServiceListener
-
Invoked when a Member has left the service.
- memberLeft(MemberEvent) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumListener
-
Invoked when a Member has left the service.
- memberLeft(Member) - Method in interface com.tangosol.net.InvocationObserver
-
This method is called by the
InvocationService
to inform the
InvocationObserver that a member that the
Invocable
object was
intended for execution upon has left the service (or the cluster).
- memberLeft(MemberEvent) - Method in interface com.tangosol.net.MemberListener
-
Invoked when a Member has left the service.
- memberLeft(MemberEvent) - Method in class com.tangosol.net.partition.FailoverAccessPolicy.MembershipListener
-
Invoked when a Member has left the service.
- MemberListener - Interface in com.tangosol.net
-
The listener interface for receiving MemberEvents.
- MemberListenerProcessor - Class in com.tangosol.coherence.config.xml.processor
-
An ElementProcessor to process a <member-listener> to produce a
List containing a single MemberListener.
- MemberListenerProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.MemberListenerProcessor
-
- MembershipListener() - Constructor for class com.tangosol.net.partition.FailoverAccessPolicy.MembershipListener
-
- MembershipQuorumPolicy() - Constructor for class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy
-
Create a MembershipQuorumPolicy.
- memchr(byte[], int, int, byte) - Static method in class com.tangosol.util.Binary
-
Find the specified byte (a "needle") in the specified binary region
("the haystack").
- memchr(byte[], int, int, byte, boolean) - Static method in class com.tangosol.util.Binary
-
Find the specified byte (a "needle") in the specified binary region
("the haystack").
- memcmp(byte[], int, int, byte[], int, int) - Static method in class com.tangosol.util.Binary
-
Compare two binary regions.
- memcpy(byte[], int, byte[], int, int) - Static method in class com.tangosol.util.Binary
-
Copy binary data from one binary region to another.
- memmem(byte[], int, int, byte[], int, int) - Static method in class com.tangosol.util.Binary
-
Find the second binary region (a "needle") in the first binary region
("the haystack").
- memmem(byte[], int, int, byte[], int, int, boolean) - Static method in class com.tangosol.util.Binary
-
Find the second binary region (a "needle") in the first binary region
("the haystack").
- MemorySizeProcessor - Class in com.tangosol.coherence.config.xml.processor
-
A
MemorySizeProcessor
is responsible for processing Coherence
memory sizes and returning them in bytes.
- MemorySizeProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.MemorySizeProcessor
-
- merge() - Method in class com.tangosol.io.nio.BinaryMap.Block
-
Merge a free block with any free blocks that it borders.
- merge(K, V, Remote.BiFunction<? super V, ? super V, ? extends V>) - Method in interface com.tangosol.net.AsyncNamedCache
-
If the specified key is not already associated with a value or is
associated with null, associates it with the given non-null value.
- merge(TopNAggregator.PartialResult<E>) - Method in class com.tangosol.util.aggregator.TopNAggregator.PartialResult
-
Merge single PartialResult into this PartialResult.
- merge(TK, TV, Remote.BiFunction<? super TV, ? super TV, ? extends TV>) - Method in class com.tangosol.util.ConverterCollections.ConverterInvocableMap
-
- merge(TK, TV, BiFunction<? super TV, ? super TV, ? extends TV>) - Method in class com.tangosol.util.ConverterCollections.ConverterInvocableMap
-
- merge(TK, TV, Remote.BiFunction<? super TV, ? super TV, ? extends TV>) - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
-
- merge(TK, TV, BiFunction<? super TV, ? super TV, ? extends TV>) - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
-
- merge(ValueExtractor[], ValueExtractor[]) - Static method in class com.tangosol.util.extractor.ChainedExtractor
-
Return a
ValueExtractor
array with the provided arrays merged
into a single array.
- merge(K, V, Remote.BiFunction<? super V, ? super V, ? extends V>) - Method in interface com.tangosol.util.InvocableMap
-
If the specified key is not already associated with a value or is
associated with null, associates it with the given non-null value.
- merge(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in interface com.tangosol.util.InvocableMap
-
- merge(QueryRecord.PartialResult) - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult
-
Merge the given result with this one.
- merge(QueryRecord.PartialResult.Step) - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.Step
-
Merge the given step with this one.
- merge(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperMap
- merge(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- mergeEvents(MapEvent, MapEvent) - Static method in class com.tangosol.net.cache.OverflowMap
-
Merge two events that have been raised in sequence from a given
map.
- mergeEvents(MapEvent, MapEvent) - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
-
Merge two events that have been raised in sequence from a given
map.
- mergeFilter(Filter) - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
- mergeIncludes(String, XmlElement, ClassLoader) - Static method in class com.tangosol.io.pof.ConfigurablePofContext
-
Merge all included POF configuration files into the given xml configuration.
- mergeResults(Collection) - Method in class com.tangosol.util.SimpleQueryRecord
-
Merge the partial results from the associated record.
- Message - Variable in class com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy.Notification
-
- MessageDeliveryModeProcessor - Class in com.tangosol.coherence.config.xml.processor
-
- MessageDeliveryModeProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.MessageDeliveryModeProcessor
-
- META_EXTENT - Static variable in class com.tangosol.persistence.CachePersistenceHelper
-
The extent-id used to store cache metadata.
- META_FILENAME - Static variable in class com.tangosol.persistence.CachePersistenceHelper
-
Persistence metadata filename.
- META_IMPL_VERSION - Static variable in class com.tangosol.persistence.CachePersistenceHelper
-
Persistence metadata property: implementation version.
- META_PARTITION_COUNT - Static variable in class com.tangosol.persistence.CachePersistenceHelper
-
Persistence metadata property: partition count.
- META_SERVICE_VERSION - Static variable in class com.tangosol.persistence.CachePersistenceHelper
-
Persistence metadata property: service version.
- META_STORAGE_FORMAT - Static variable in class com.tangosol.persistence.CachePersistenceHelper
-
Persistence metadata property: storage format.
- META_STORAGE_VERSION - Static variable in class com.tangosol.persistence.CachePersistenceHelper
-
Persistence metadata property: storage version.
- METHOD_CALL_FUNCTION_BUILDER - Static variable in class com.tangosol.coherence.dslquery.function.FunctionBuilders
-
- METHOD_SUFFIX - Static variable in class com.tangosol.util.extractor.UniversalExtractor
-
- METHOD_SUFFIX - Static variable in class com.tangosol.util.extractor.UniversalUpdater
-
- MethodInvocationProcessor<K,V,R> - Class in com.tangosol.util.processor
-
An entry processor that invokes specified method on a value of a cache entry
and optionally updates the entry with a modified value.
- MethodInvocationProcessor() - Constructor for class com.tangosol.util.processor.MethodInvocationProcessor
-
Deserialization constructor.
- MethodInvocationProcessor(String, boolean, Object...) - Constructor for class com.tangosol.util.processor.MethodInvocationProcessor
-
Construct MethodInvocationProcessor instance.
- MethodInvocationProcessor(Remote.Supplier<V>, String, boolean, Object...) - Constructor for class com.tangosol.util.processor.MethodInvocationProcessor
-
Construct MethodInvocationProcessor instance.
- METHODS - Static variable in class com.tangosol.coherence.rest.DefaultKeyConverter
-
Method names that should be tried in order when looking for a method
that can be used for conversion from string.
- MetricsLabels - Annotation Type in com.tangosol.net.management.annotation
-
The MetricsLabels descriptor annotation adds a
metrics.labels
field
and its value to the
descriptor
for a method on an MBean.
- MetricsScope - Annotation Type in com.tangosol.net.management.annotation
-
The MetricsScope descriptor annotation adds a metrics.scope field and its
value to the
descriptor
for an MBean.
- MetricsTag - Annotation Type in com.tangosol.net.management.annotation
-
The MetricsTag descriptor annotation adds a
metrics.tag
field
and its value to the
descriptor
for a method on an MBean.
- MetricsValue - Annotation Type in com.tangosol.net.management.annotation
-
The MetricsValue descriptor annotation adds a metrics.value field
and its value to the
descriptor
for a method on an MBean.
- MGR_CONTEXT - Static variable in class com.tangosol.net.DefaultConfigurableCacheFactory
-
Deprecated.
The name of the replaceable parameter representing the backing map
manager context.
- MGR_CONTEXT - Static variable in class com.tangosol.net.ExtensibleConfigurableCacheFactory
-
The name of the replaceable parameter representing the backing map
manager context.
- Millis - Class in com.tangosol.coherence.config.unit
-
Millis
is a specialized
Duration
whose default constructor
assumes that the specified units of time (when the unit magnitude is not
specified) are milliseconds.
- Millis(Duration) - Constructor for class com.tangosol.coherence.config.unit.Millis
-
Constructs a
Millis
based on another
Duration
.
- Millis(String) - Constructor for class com.tangosol.coherence.config.unit.Millis
-
Constructs a
Millis
representing a
Duration
measured in milliseconds.
- MillisProcessor - Class in com.tangosol.coherence.config.xml.processor
-
A
MillisProcessor
is responsible for processing Coherence time values
and returning them in milliseconds.
- MillisProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.MillisProcessor
-
- min() - Method in interface com.tangosol.util.stream.RemoteDoubleStream
-
Returns an OptionalDouble
describing the minimum element of this
stream, or an empty OptionalDouble if this stream is empty.
- min() - Method in interface com.tangosol.util.stream.RemoteIntStream
-
Returns an OptionalInt
describing the minimum element of this
stream, or an empty optional if this stream is empty.
- min() - Method in interface com.tangosol.util.stream.RemoteLongStream
-
Returns an OptionalLong
describing the minimum element of this
stream, or an empty optional if this stream is empty.
- min(Comparator<? super T>) - Method in interface com.tangosol.util.stream.RemoteStream
-
Returns the minimum element of this stream according to the provided
Comparator
.
- min(Remote.Comparator<? super T>) - Method in interface com.tangosol.util.stream.RemoteStream
-
Returns the minimum element of this stream according to the provided
Comparator
.
- min(ValueExtractor<? super U, ? extends Comparable>) - Method in interface com.tangosol.util.stream.RemoteStream
-
Returns the minimum element of this stream according to the attribute
extracted by the provided ValueExtractor
.
- MIN_BLOCK - Static variable in class com.tangosol.io.BinaryDeltaCompressor
-
Minimum length of an "extract" block to encode.
- MIN_DECIMAL128_SCALE - Static variable in interface com.tangosol.io.pof.PofConstants
-
Minimum scale for the IEEE-754r 128-bit decimal format.
- MIN_DECIMAL32_SCALE - Static variable in interface com.tangosol.io.pof.PofConstants
-
Minimum scale for the IEEE-754r 32-bit decimal format.
- MIN_DECIMAL64_SCALE - Static variable in interface com.tangosol.io.pof.PofConstants
-
Minimum scale for the IEEE-754r 64-bit decimal format.
- MIN_ENTRY - Static variable in class com.tangosol.io.nio.BinaryMap.Block
-
Minimum size of an Entry block.
- MIN_FREE - Static variable in class com.tangosol.io.nio.BinaryMap.Block
-
Minimum size of a free block.
- MIN_PORT - Static variable in class com.tangosol.coherence.config.builder.LocalAddressProviderBuilder
-
- MIN_REQUEUE_DELAY - Static variable in class com.tangosol.net.cache.ReadWriteBackingMap
-
The minimum "retry after requeue" time interval.
- MIN_SEGMENT_CAPACITY - Static variable in class com.tangosol.util.SegmentedHashMap
-
The minimum segment capacity.
- MIN_SPLIT - Static variable in class com.tangosol.io.nio.BinaryMap.Block
-
Minimum size of a block to split off a free block.
- minBy(Remote.Comparator<? super T>) - Static method in interface com.tangosol.util.function.Remote.BinaryOperator
-
Returns a
BinaryOperator
which returns the lesser of two
elements according to the specified
Comparator
.
- minBy(Comparator<? super T>) - Static method in interface com.tangosol.util.function.Remote.BinaryOperator
-
Returns a
BinaryOperator
which returns the lesser of two
elements according to the specified
Comparator
.
- minBy(Remote.Comparator<? super T>) - Static method in class com.tangosol.util.stream.RemoteCollectors
-
Returns a Collector
that produces the minimal element according
to a given Comparator
, described as an Optional<T>
.
- MirroringAssignmentStrategy - Class in com.tangosol.net.partition
-
A PartitionAssignmentStrategy used by a service to attempt to co-locate the
primary ownership of partitions on the same members as another service.
- MirroringAssignmentStrategy(String) - Constructor for class com.tangosol.net.partition.MirroringAssignmentStrategy
-
Construct a MirroringAssignmentStrategy to be associated the specified
service.
- mod(int, int) - Static method in class com.tangosol.util.Base
-
Calculate a modulo of two integer numbers.
- mod(long, long) - Static method in class com.tangosol.util.Base
-
Calculate a modulo of two long numbers.
- MODE_DEBUG - Static variable in class com.tangosol.io.nio.BinaryMap
-
True to enable debug mode.
- MODE_DEBUG - Static variable in class com.tangosol.io.nio.DirectBufferManager
-
Deprecated.
Set to true to use on-heap storage, false to use off-heap.
- Model<S extends Enum<S>> - Interface in com.tangosol.util.fsm
-
- modified(long, ExpiryPolicy) - Method in class com.tangosol.coherence.jcache.common.JCacheEntryMetaInf
-
Update the
JCacheEntryMetaInf
based on the associated entry
being modified at the specified time.
- monitorServices(long) - Method in class com.tangosol.net.DefaultCacheServer
-
Check the ServiceMonitor status ensuring it is monitoring services.
- monitorServices(long) - Method in class com.tangosol.net.SimpleServiceMonitor
-
Check the service status periodically (keep alive interval), restarting
any stopped services.
- MONTH_NAME - Static variable in class com.tangosol.coherence.dslquery.statement.persistence.AbstractSnapshotStatement
-
Format month name.
- moveDir(File, File) - Static method in class com.tangosol.io.FileHelper
-
Move the specified directory to the specified destination path.
- moveExtent(long, long) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
-
Move the specified extent from the old extent id to the new extent id.
- moveExtent(long, long) - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistentStore
-
Move the specified extent from the old extent id to the new extent id.
- moveExtent(long, long) - Method in class com.tangosol.util.NullImplementation.NullPersistentStore
-
- moveExtentInternal(long, long) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
-
Move the specified extent from the old extent id to the new extent id.
- moveExtents(PersistentStore, long, long) - Static method in class com.tangosol.persistence.CachePersistenceHelper
-
Move the old extent to the new extent in the specified store
including all associated extents (meta extents).
- moveFile(File, File) - Static method in class com.tangosol.io.FileHelper
-
Move the specified file to the specified destination path.
- moveOffset(int) - Method in class com.tangosol.io.ByteArrayWriteBuffer.ByteArrayBufferOutput
-
Move the offset within the stream forward.
- moveOffset(int) - Method in class com.tangosol.io.DelegatingWriteBuffer.DelegatingBufferOutput
-
Move the offset within the stream forward.
- MSG_NO_PENDING - Static variable in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
The message returned by SimpleStrategyMBean when all suggested distributions have completed
and none are in-progress or scheduled.
- MSG_NO_RESULT - Static variable in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
The message returned by SimpleStrategyMBean when the distribution coordinator has not done its
first analysis yet.
- multi(String...) - Static method in class com.tangosol.util.Extractors
-
Returns an extractor that extracts the specified fields
and returns the extracted values in a
List
.
- multi(ValueExtractor<T, ?>...) - Static method in class com.tangosol.util.Extractors
-
Returns an extractor that extracts values using the specified
ValueExtractor
s and returns the extracted values in a
List
.
- MultiBufferInput() - Constructor for class com.tangosol.io.MultiBufferReadBuffer.MultiBufferInput
-
Default constructor.
- MultiBufferInput(boolean) - Constructor for class com.tangosol.io.MultiBufferReadBuffer.MultiBufferInput
-
Default constructor.
- MultiBufferOutput(int) - Constructor for class com.tangosol.io.MultiBufferWriteBuffer.MultiBufferOutput
-
Construct an AbstractBufferOutput that will begin writing at the
specified offset within the containing WriteBuffer.
- MultiBufferReadBuffer - Class in com.tangosol.io
-
The MultiBufferReadBuffer is a ReadBuffer implementation that presents a
view across any number of underlying ReadBuffer objects, as if they were
appended end-to-end into a single ReadBuffer.
- MultiBufferReadBuffer(ReadBuffer[]) - Constructor for class com.tangosol.io.MultiBufferReadBuffer
-
Construct a MultiBufferReadBuffer from an array of underlying
ReadBuffer objects.
- MultiBufferReadBuffer.MultiBufferInput - Class in com.tangosol.io
-
An implementation of the BufferInput interface that is backed by a
series of the underlying ReadBuffer BufferInput objects.
- MultiBufferWriteBuffer - Class in com.tangosol.io
-
The MultiBufferWriteBuffer is used to present a single WriteBuffer that
collects together a sequence of underlying WriteBuffer objects, and which
grows by allocating additional WriteBuffer objects as necessary.
- MultiBufferWriteBuffer(MultiBufferWriteBuffer.WriteBufferPool) - Constructor for class com.tangosol.io.MultiBufferWriteBuffer
-
Construct a MultiBufferWriteBuffer that will use the passed
WriteBufferPool to allocate WriteBuffer objects from.
- MultiBufferWriteBuffer(MultiBufferWriteBuffer.WriteBufferPool, int) - Constructor for class com.tangosol.io.MultiBufferWriteBuffer
-
Construct a MultiBufferWriteBuffer that will use the passed
WriteBufferPool to allocate WriteBuffer objects from.
- MultiBufferWriteBuffer.MultiBufferOutput - Class in com.tangosol.io
-
The MultiBufferOutput implementation extends the AbstractBufferOutput
to provide "pass through" operations to the underlying buffer if the
operation is guaranteed to fit in the underlying buffer; otherwise,
it virtualizes the operation onto the MultiBufferWriteBuffer itself so
that the over-run of one underlying WriteBuffer will end up being
written to the next underlying WriteBuffer.
- MultiBufferWriteBuffer.WriteBufferPool - Interface in com.tangosol.io
-
A WriteBufferPool is used to dynamically allocate WriteBuffer
objects as the MultiBufferWriteBuffer requires them.
- MultiByteArrayInputStream - Class in com.tangosol.io
-
Reads binary data from a series of byte arrays.
- MultiByteArrayInputStream(byte[][]) - Constructor for class com.tangosol.io.MultiByteArrayInputStream
-
Construct a MultiByteArrayInputStream.
- MultiByteArrayInputStream(byte[][], boolean) - Constructor for class com.tangosol.io.MultiByteArrayInputStream
-
Construct a MultiByteArrayInputStream.
- MultiByteArrayOutputStream - Class in com.tangosol.io
-
An OutputStream that accumulates the written data to a series of byte
arrays that do not exceed a specified size.
- MultiByteArrayOutputStream(int) - Constructor for class com.tangosol.io.MultiByteArrayOutputStream
-
Construct a MultiByteArrayOutputStream to write to byte arrays of the
specified length.
- MultiByteArrayOutputStream(int, int, int) - Constructor for class com.tangosol.io.MultiByteArrayOutputStream
-
Construct a MultiByteArrayOutputStream to write to byte arrays of the
specified length, leaving the specified amount of padding at the front
and back of each byte array.
- MultiExtractor - Class in com.tangosol.util.extractor
-
Composite ValueExtractor implementation based on an array of extractors.
- MultiExtractor() - Constructor for class com.tangosol.util.extractor.MultiExtractor
-
Default constructor (necessary for the ExternalizableLite interface).
- MultiExtractor(ValueExtractor[]) - Constructor for class com.tangosol.util.extractor.MultiExtractor
-
Construct a MultiExtractor.
- MultiExtractor(String) - Constructor for class com.tangosol.util.extractor.MultiExtractor
-
Construct a MultiExtractor for a specified method name list.
- MultiIterator(int) - Constructor for class com.tangosol.util.ImmutableMultiList.MultiIterator
-
- MultiplexingMapListener<K,V> - Class in com.tangosol.util
-
A base class that simplifies the implementation of a MapListener by
multiplexing all events into a single listener method.
- MultiplexingMapListener() - Constructor for class com.tangosol.util.MultiplexingMapListener
-
- MultiplicationOperator - Class in com.tangosol.coherence.dslquery.operator
-
An operator representing the mathematical multiplication operation.
- MultiplicationOperator() - Constructor for class com.tangosol.coherence.dslquery.operator.MultiplicationOperator
-
Construct a MultiplicationOperator.
- multiply(String, N, boolean) - Static method in class com.tangosol.util.Processors
-
Construct a multiply processor that will multiply a property
value by a specified factor, returning either the old or the new value
as specified.
- multiply(PropertyManipulator<V, N>, N, boolean) - Static method in class com.tangosol.util.Processors
-
Construct a multiply processor that will multiply a property
value by a specified factor, returning either the old or the new value
as specified.
- MvelExtractor - Class in com.tangosol.coherence.rest.util.extractor
-
MVEL-based ValueExtractor implementation.
- MvelExtractor() - Constructor for class com.tangosol.coherence.rest.util.extractor.MvelExtractor
-
Default constructor (necessary for the ExternalizableLite and
PortableObject interfaces).
- MvelExtractor(String) - Constructor for class com.tangosol.coherence.rest.util.extractor.MvelExtractor
-
Construct a MvelExtractor based on an MVEL expression.
- MvelExtractor(String, int) - Constructor for class com.tangosol.coherence.rest.util.extractor.MvelExtractor
-
Construct a MvelExtractor based on an MVEL expression and an entry
extraction target.
- MvelManipulator - Class in com.tangosol.coherence.rest.util
-
MVEL-based ValueManipulator implementation.
- MvelManipulator() - Constructor for class com.tangosol.coherence.rest.util.MvelManipulator
-
Default constructor (necessary for the ExternalizableLite and
PortableObject interfaces).
- MvelManipulator(String) - Constructor for class com.tangosol.coherence.rest.util.MvelManipulator
-
Construct a MvelManipulator based on an MVEL expression.
- MvelUpdater - Class in com.tangosol.coherence.rest.util.updater
-
MVEL-based ValueUpdater implementation.
- MvelUpdater() - Constructor for class com.tangosol.coherence.rest.util.updater.MvelUpdater
-
Default constructor (necessary for the ExternalizableLite and
PortableObject interfaces).
- MvelUpdater(String) - Constructor for class com.tangosol.coherence.rest.util.updater.MvelUpdater
-
Construct a MvelUpdater based on an MVEL expression.
- myValueOf(String) - Static method in enum com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.NameListDependencies.USAGE
-