Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- abort(Object) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
-
Abort an atomic sequence of mutating operations.
- 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
- 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.
- 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, - Class in com.tangosol.util.aggregatorT, E, R> -
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, - Class in com.tangosol.util.aggregatorP, R> -
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, - Class in com.tangosol.util.processorR, T> -
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.
- AbstractAsyncRepository<ID,
T> - Class in com.oracle.coherence.repository -
Abstract base class for asynchronous Coherence repository implementations.
- AbstractAsyncRepository() - Constructor for class com.oracle.coherence.repository.AbstractAsyncRepository
- 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 aBigDecimal
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
- 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.
- AbstractCacheInterceptor - Class in com.oracle.coherence.cdi
-
Abstract base class for caching CDI interceptors.
- AbstractCacheInterceptor(Coherence, CoherenceExtension) - Constructor for class com.oracle.coherence.cdi.AbstractCacheInterceptor
-
Construct cache interceptor.
- 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> - Class in com.tangosol.coherence.config.scheme
-
An
AbstractCachingScheme
is a base implementation for anCachingScheme
. - AbstractCachingScheme() - Constructor for class com.tangosol.coherence.config.scheme.AbstractCachingScheme
- AbstractCertificateLoader - Class in com.tangosol.net.ssl
-
A base class for
CertificateLoader
implementations. - AbstractCertificateLoader(String) - Constructor for class com.tangosol.net.ssl.AbstractCertificateLoader
-
Create an
AbstractCertificateLoader
. - AbstractCodec() - Constructor for class com.tangosol.io.pof.reflect.Codecs.AbstractCodec
- AbstractCoherenceBasedCache<K,
V, - Class in com.tangosol.coherence.jcacheC> -
The base implementation of a
CoherenceBasedCache
. - AbstractCoherenceBasedCache(CoherenceBasedCacheManager, String, C) - Constructor for class com.tangosol.coherence.jcache.AbstractCoherenceBasedCache
-
Constructs an
AbstractCoherenceBasedCache
. - AbstractCoherenceBasedCompleteConfiguration<K,
V> - Class in com.tangosol.coherence.jcache -
A base implementation of a
CoherenceBasedCompleteConfiguration
. - AbstractCoherenceBasedCompleteConfiguration() - Constructor for class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
-
Constructs an
AbstractCoherenceBasedCompleteConfiguration
. - AbstractCoherenceBasedCompleteConfiguration(CompleteConfiguration<K, V>) - Constructor for class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
-
Constructs an
AbstractCoherenceBasedCompleteConfiguration
based on anotherCompleteConfiguration
. - 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
-
A
ConditionalElementProcessor
that provides defined behaviors for processing emptyXmlElement
s. - AbstractEmptyElementProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.AbstractEmptyElementProcessor
-
Constructs an
AbstractEmptyElementProcessor
that will attempt to process emptyXmlElement
s. - AbstractEmptyElementProcessor(AbstractEmptyElementProcessor.EmptyElementBehavior) - Constructor for class com.tangosol.coherence.config.xml.processor.AbstractEmptyElementProcessor
-
Constructs an
AbstractEmptyElementProcessor
with the specified behavior for processing emptyXmlElement
s (with a default value ofnull
). - AbstractEmptyElementProcessor(T) - Constructor for class com.tangosol.coherence.config.xml.processor.AbstractEmptyElementProcessor
-
Constructs an
AbstractEmptyElementProcessor
that will return the specified default value when it encounters an emptyXmlElement
. - AbstractEmptyElementProcessor.EmptyElementBehavior - Enum Class in com.tangosol.coherence.config.xml.processor
-
The behavior of the
ConditionalElementProcessor
when it encounters an emptyXmlElement
. - 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, - Class in com.tangosol.util.processorR> -
An Evolvable AbstractProcessor that is a partial EntryProcessor implementation that provides the default implementation of the
AbstractEvolvableProcessor.processAll(java.util.Set<? extends com.tangosol.util.InvocableMap.Entry<K, V>>)
method. - AbstractEvolvableProcessor() - Constructor for class com.tangosol.util.processor.AbstractEvolvableProcessor
- AbstractExtractor<T,
E> - Class in com.tangosol.util.extractor -
Abstract base for ValueExtractor implementations.
- AbstractExtractor() - Constructor for class com.tangosol.util.extractor.AbstractExtractor
- 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
-
The
AbstractJournalScheme
contains functionality common to all Journal schemes. - AbstractJournalScheme() - Constructor for class com.tangosol.coherence.config.scheme.AbstractJournalScheme
- AbstractKeyBasedMap<K,
V> - Class in com.tangosol.util -
AbstractKeyBasedMap is a base class for Map implementations.
- AbstractKeyBasedMap() - Constructor for class com.tangosol.util.AbstractKeyBasedMap
- AbstractKeyBasedMap.DeferredCacheEvent<K,
V> - Class in com.tangosol.util -
A DeferredCacheEvent is a
CacheEvent
object that defers the loading of theold value
. - AbstractKeyBasedMap.EntrySet - Class in com.tangosol.util
-
A set of entries backed by this map.
- AbstractKeyBasedMap.EntrySet.Entry - Class in com.tangosol.util
-
A Map Entry implementation that defers its value acquisition from the containing map (via
Map.get(Object)
) if the Entry is constructed with a null value. - AbstractKeyBasedMap.EntrySet.EntrySetIterator - Class in com.tangosol.util
-
An Iterator over the EntrySet that is backed by the Map.
- AbstractKeyBasedMap.KeySet - Class in com.tangosol.util
-
A set of keys backed by this map.
- AbstractKeyBasedMap.ValuesCollection - Class in com.tangosol.util
-
A Collection of values backed by this map.
- AbstractKeyBasedMap.ValuesCollection.ValuesIterator - Class in com.tangosol.util
-
An Iterator over the values Collection that is backed by the AbstractKeyBasedMap.
- AbstractKeyBundler - Class in com.tangosol.net.cache
-
An abstract key-based bundler serves as a base for NamedCache get() and remove() operation bundling as well as the CacheStore load() and erase() operation bundling.
- AbstractKeyBundler() - Constructor for class com.tangosol.net.cache.AbstractKeyBundler
- AbstractKeyBundler.Bundle - Class in com.tangosol.net.cache
-
Bundle represents a unit of optimized execution.
- AbstractKeySetBasedMap<K,
V> - Class in com.tangosol.util -
AbstractKeySetBasedMap is an extension to the AbstractKeyBasedMap that has a full awareness of the set of keys upon which the Map is based.
- AbstractKeySetBasedMap() - Constructor for class com.tangosol.util.AbstractKeySetBasedMap
- AbstractKeySetBasedMap.EntrySet - Class in com.tangosol.util
-
A set of entries backed by this map.
- AbstractKeySetBasedMap.KeyIterator - Class in com.tangosol.util
-
An iterator over the keys from the internal key Set that implements element removal via the Map's removeBlind method.
- AbstractKeySetBasedMap.KeySet - Class in com.tangosol.util
-
A set of keys backed by this map.
- AbstractKeySetBasedMap.ValuesCollection - Class in com.tangosol.util
-
A Collection of values backed by this map.
- AbstractKeyStoreLoader - Class in com.tangosol.net.ssl
-
A base class for
KeyStoreLoader
implementations. - AbstractKeyStoreLoader(String) - Constructor for class com.tangosol.net.ssl.AbstractKeyStoreLoader
- AbstractLocalCachingScheme<T> - Class in com.tangosol.coherence.config.scheme
-
The
AbstractLocalCachingScheme
is provides common functionality for local caching schemes, including local-scheme, external-scheme, etc. - AbstractLocalCachingScheme() - Constructor for class com.tangosol.coherence.config.scheme.AbstractLocalCachingScheme
- AbstractLongAggregator<T> - Class in com.tangosol.util.aggregator
-
Abstract aggregator that processes numeric values extracted from a set of entries in a Map.
- AbstractLongAggregator() - Constructor for class com.tangosol.util.aggregator.AbstractLongAggregator
-
Default constructor (necessary for the ExternalizableLite interface).
- AbstractLongAggregator(ValueExtractor<? super T, ? extends Number>) - Constructor for class com.tangosol.util.aggregator.AbstractLongAggregator
-
Construct an AbstractLongAggregator object.
- AbstractLongAggregator(String) - Constructor for class com.tangosol.util.aggregator.AbstractLongAggregator
-
Construct an AbstractLongAggregator object.
- AbstractLongArray<V> - Class in com.tangosol.util
-
An implementation of portions of the LongArray interface.
- AbstractLongArray() - Constructor for class com.tangosol.util.AbstractLongArray
- AbstractMapListener - Class in com.tangosol.util
-
A base class that simplifies the implementation of a MapListener, particularly inner classes that only implement one or two of the three event methods.
- AbstractMapListener() - Constructor for class com.tangosol.util.AbstractMapListener
- AbstractMarshaller<T> - Class in com.tangosol.coherence.rest.io
-
Abstract base class for built-in marshallers.
- AbstractMarshaller(Class<T>) - Constructor for class com.tangosol.coherence.rest.io.AbstractMarshaller
-
Construct a marshaller instance.
- AbstractNamespaceHandler - Class in com.tangosol.config.xml
-
An
AbstractNamespaceHandler
provides a base implementation of aNamespaceHandler
with support for implicit and explicit registration ofElementProcessor
s andAttributeProcessor
s for those xml attributes and elements occurring in the associated xml namespace. - AbstractNamespaceHandler() - Constructor for class com.tangosol.config.xml.AbstractNamespaceHandler
-
Construct an
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 BerkeleyDBEnvironment that manages a singleton BerkeleyDBManager with the specified directories: data - active persistence snapshot - location for snapshots trash - optional location trashed stores events - optional location for event storage
- AbstractPersistenceEnvironment(File, File, File, File) - Constructor for class com.tangosol.persistence.AbstractPersistenceEnvironment
-
Create a new BerkeleyDBEnvironment that manages a singleton BerkeleyDBManager with the specified directories: data - active persistence snapshot - location for snapshots trash - optional location trashed stores events - optional location for event storage backup - optional location for backup storage
- AbstractPersistenceEnvironment(File, File, File, File, File) - Constructor for class com.tangosol.persistence.AbstractPersistenceEnvironment
-
Create a new BerkeleyDBEnvironment that manages a singleton BerkeleyDBManager with the specified directories: data - active persistence backup - optional location for backup storage events - optional location for event storage snapshot - location for snapshots trash - optional location trashed stores
- AbstractPersistenceEnvironment.DefaultFailureContinuation - Class in com.tangosol.persistence
-
Continuation implementation that accepts a Throwable and throws a PersistenceException.
- AbstractPersistenceManager<PS> - 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.BatchTasks - Class in com.tangosol.persistence
-
A collection of tasks to execute in a loop.
- AbstractPersistenceManager.Task - Class in com.tangosol.persistence
-
Runnable extension that adds the ability to notify the task that it has been canceled.
- AbstractPersistenceSnapshotTools(File, OfflinePersistenceInfo) - Constructor for class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistenceSnapshotTools
-
Construct an abstract implementation for a given snapshot directory.
- AbstractPersistenceTools - Class in com.tangosol.persistence
-
Abstract implementation of PersistenceTools which can be extended for either local or archived snapshot operations.
- AbstractPersistenceTools(OfflinePersistenceInfo) - Constructor for class com.tangosol.persistence.AbstractPersistenceTools
-
Constructs an abstract implementation of
PersistenceTools
that can be utilized for both local or archived snapshot operations. - AbstractPersistenceTools.StatsVisitor - Class in com.tangosol.persistence
-
An implementation of a
CachePersistenceHelper.Visitor
to collect details statistics from the snapshot we are analysing. - AbstractPersistentStore(String) - Constructor for class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
-
Create a new AbstractPersistentStore with the given identifier.
- AbstractPofHandler - Class in com.tangosol.io.pof
-
An abstract implementation of PofHandler that delegates to a PofHandler.
- AbstractPofHandler(PofHandler) - Constructor for class com.tangosol.io.pof.AbstractPofHandler
-
Construct a delegating PofHandler.
- AbstractPofPath - Class in com.tangosol.io.pof.reflect
-
Abstract base class for static, path-based implementations of
PofNavigator
interface. - AbstractPofPath() - Constructor for class com.tangosol.io.pof.reflect.AbstractPofPath
- AbstractPofValue - Class in com.tangosol.io.pof.reflect
-
An abstract base class that implements common functionality for all PofValue types.
- AbstractPofValue(PofValue, ReadBuffer, PofContext, int, int) - Constructor for class com.tangosol.io.pof.reflect.AbstractPofValue
-
Construct a PofValue instance wrapping the supplied buffer.
- AbstractPriorityTask - Class in com.tangosol.net
-
An abstract base for PriorityTask implementations.
- AbstractPriorityTask() - Constructor for class com.tangosol.net.AbstractPriorityTask
- AbstractPrivateKeyLoader - Class in com.tangosol.net.ssl
-
A base class for
PrivateKeyLoader
implementations. - AbstractPrivateKeyLoader(String) - Constructor for class com.tangosol.net.ssl.AbstractPrivateKeyLoader
-
Create a
AbstractPrivateKeyLoader
. - AbstractProcessor<K,
V, - Class in com.tangosol.util.processorR> -
An AbstractProcessor is a partial EntryProcessor implementation that provides the default implementation of the
AbstractProcessor.processAll(java.util.Set<? extends com.tangosol.util.InvocableMap.Entry<K, V>>)
method. - AbstractProcessor() - Constructor for class com.tangosol.util.processor.AbstractProcessor
- AbstractQueryEngine - Class in com.tangosol.coherence.rest.query
-
Abstract base class for QueryEngine implementations.
- AbstractQueryEngine() - Constructor for class com.tangosol.coherence.rest.query.AbstractQueryEngine
- AbstractQueryEngine.ParsedQuery - Class in com.tangosol.coherence.rest.query
-
Immutable helper class that wraps both final query string and a map of parameter types, keyed by parameter name.
- AbstractQueryPlusStatementBuilder - Class in com.tangosol.coherence.dslquery.queryplus
-
This is the base class for command builders that are specific to the QueryPlus tool rather than general CohQL statements.
- AbstractQueryPlusStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.queryplus.AbstractQueryPlusStatementBuilder
-
Construct a AbstractQueryPlusStatementBuilder.
- AbstractQueryPlusStatementBuilder.AbstractOPToken - Class in com.tangosol.coherence.dslquery.queryplus
-
An
OPToken
implementation that holds the name of the functor associated to an OPToken. - AbstractQueryPlusStatementBuilder.AbstractStatement - Class in com.tangosol.coherence.dslquery.queryplus
-
An abstract base class that allows sub classes to implement the applicable methods on
Statement
. - AbstractQueryRecorderFilter<T> - Class in com.tangosol.util.filter
-
Abstract base class implementation of
QueryRecorderFilter
. - AbstractQueryRecorderFilter() - Constructor for class com.tangosol.util.filter.AbstractQueryRecorderFilter
- AbstractReadBuffer - Class in com.tangosol.io
-
Abstract base implementation of the ReadBuffer interface.
- AbstractReadBuffer() - Constructor for class com.tangosol.io.AbstractReadBuffer
- AbstractReadBuffer.AbstractBufferInput - Class in com.tangosol.io
-
This is an implementation of the BufferInput interface that delegates its work back to its ReadBuffer.
- AbstractRecordableStep(Filter) - Constructor for class com.tangosol.util.SimpleQueryRecord.PartialResult.AbstractRecordableStep
-
Construct an AbstractRecordableStep.
- AbstractRepository<ID,
T> - Class in com.oracle.coherence.repository -
Abstract base class for Coherence repository implementations.
- AbstractRepository() - Constructor for class com.oracle.coherence.repository.AbstractRepository
- AbstractRepositoryBase<ID,
T, - Class in com.oracle.coherence.repositoryM> -
Base functionality for all Coherence repository implementations.
- AbstractRepositoryBase() - Constructor for class com.oracle.coherence.repository.AbstractRepositoryBase
- AbstractRepositoryBase.Listener<T> - Interface in com.oracle.coherence.repository
-
An interface that should be implemented by the clients interested in repository events.
- AbstractRepositoryBase.Listener.Builder<T> - Class in com.oracle.coherence.repository
-
A builder for a simple, lambda-based
AbstractRepositoryBase.Listener
. - AbstractRepositoryBase.MapListenerAdapter<ID,
T> - Class in com.oracle.coherence.repository -
Adapter from
AbstractRepositoryBase.Listener
toMapListener
that can be registered with the backingNamedMap
. - 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
-
The
AbstractScheme
is the base implementation of aScheme
. - 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, 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.
- 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.
- AbstractServiceLoadBalancer<S,
T> - Class in com.tangosol.net -
An abstract base for ServiceLoadBalancer implementations.
- AbstractServiceLoadBalancer() - Constructor for class com.tangosol.net.AbstractServiceLoadBalancer
- AbstractServiceScheme<D> - Class in com.tangosol.coherence.config.scheme
-
The
AbstractServiceScheme
provides functionality common to all schemes that use services. - AbstractServiceScheme() - Constructor for class com.tangosol.coherence.config.scheme.AbstractServiceScheme
- AbstractSnapshotArchiver - Class in com.tangosol.persistence
-
An abstract implementation of a
SnapshotArchiver
which must be extended to create a specific implementation. - AbstractSnapshotArchiver(String, String) - Constructor for class com.tangosol.persistence.AbstractSnapshotArchiver
-
Create a new AbstractSnapshotArchiver which is used to archive and retrieve snapshot parts to/from a common archive location.
There will be one instance of a AbstractSnapshotArchiver implementation per storage node / per configured Persistence service. - AbstractSnapshotStatement - Class in com.tangosol.coherence.dslquery.statement.persistence
-
Abstract implementation of an
AbstractStatement
providing functionality useful for generic snapshot statements. - AbstractSnapshotStatement(String, String) - Constructor for class com.tangosol.coherence.dslquery.statement.persistence.AbstractSnapshotStatement
-
Create a AbstractSnapshotStatement that will prove base functionality for other snapshot commands.
- AbstractSparseArray<V> - Class in com.tangosol.util
-
A data structure resembling an array indexed by long values, stored as an AVL tree.
- AbstractSparseArray() - Constructor for class com.tangosol.util.AbstractSparseArray
-
Default constructor.
- AbstractSparseArray.Crawler - Class in com.tangosol.util
-
A tree node iterator.
- AbstractSparseArray.Node<V> - Class in com.tangosol.util
-
An AVL tree node.
- AbstractSQLSnapshotOPToken - Class in com.tangosol.coherence.dslquery.token.persistence
-
An abstract implementation of a snapshot operation which can be extended to support different persistence operations.
- AbstractSQLSnapshotOPToken(String) - Constructor for class com.tangosol.coherence.dslquery.token.persistence.AbstractSQLSnapshotOPToken
-
Construct a new AbstractSQLSnapshotOPToken.
- AbstractSQLSnapshotOPToken(String, String) - Constructor for class com.tangosol.coherence.dslquery.token.persistence.AbstractSQLSnapshotOPToken
-
Construct a new AbstractSQLSnapshotOPToken.
- AbstractStableIterator - Class in com.tangosol.util
-
Deprecated.
- AbstractStableIterator() - Constructor for class com.tangosol.util.AbstractStableIterator
-
Deprecated.
- AbstractStatement - Class in com.tangosol.coherence.dslquery.statement
-
A base class for
Statement
implementations. - AbstractStatement() - Constructor for class com.tangosol.coherence.dslquery.queryplus.AbstractQueryPlusStatementBuilder.AbstractStatement
- AbstractStatement() - Constructor for class com.tangosol.coherence.dslquery.statement.AbstractStatement
- AbstractStatementBuilder<T> - Class in com.tangosol.coherence.dslquery.statement
-
A base class for
StatementBuilder
implementations. - AbstractStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.statement.AbstractStatementBuilder
- AbstractStoreManager - Class in com.tangosol.io.nio
-
A base implementation of BinaryStoreManager interface that uses
BinaryMap
objects built on aByteBufferManager
to provideBinaryStore
objects. - AbstractStoreManager(int, int) - Constructor for class com.tangosol.io.nio.AbstractStoreManager
-
Construct a AbstractStoreManager that uses BinaryMap objests built on the ByteBufferManager(s) with certain initial and maximum size.
- AbstractStoreManagerBuilder<T> - Class in com.tangosol.coherence.config.builder.storemanager
-
The AbstractStoreManagerBuilder class builds an instance of a BinaryStoreManager.
- AbstractStoreManagerBuilder() - Constructor for class com.tangosol.coherence.config.builder.storemanager.AbstractStoreManagerBuilder
- AbstractUpdater<K,
V, - Class in com.tangosol.util.extractorU> -
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.
- Accelerated - Annotation Interface in com.oracle.coherence.repository
-
Repository implementations annotated with this class will keep deserialized entities in memory, in addition to a serialized binary form, of all entities in the repository.
- 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() - Method in class com.tangosol.net.CompositeAddressProvider
-
This method should be called by the client immediately after it determines that it can successfully use an address returned by the
SocketAddressProvider.getNextAddress()
method. - accept() - Method in class com.tangosol.net.CompositeAddressProvider.SingleProvider
-
This method should be called by the client immediately after it determines that it can successfully use an address returned by the
SocketAddressProvider.getNextAddress()
method. - accept() - Method in class com.tangosol.net.CompositeSocketAddressProvider
-
This method should be called by the client immediately after it determines that it can successfully use an address returned by the
SocketAddressProvider.getNextAddress()
method. - accept() - Method in class com.tangosol.net.ConfigurableAddressProvider
-
This method should be called by the client immediately after it determines that it can successfully use an address returned by the
SocketAddressProvider.getNextAddress()
method. - accept() - Method in class com.tangosol.net.RefreshableAddressProvider
-
This method should be called by the client immediately after it determines that it can successfully use an address returned by the
SocketAddressProvider.getNextAddress()
method. - accept() - Method in interface com.tangosol.net.SocketAddressProvider
-
This method should be called by the client immediately after it determines that it can successfully use an address returned by the
SocketAddressProvider.getNextAddress()
method. - accept() - Method in class com.tangosol.util.NullImplementation.NullAddressProvider
-
This method should be called by the client immediately after it determines that it can successfully use an address returned by the
SocketAddressProvider.getNextAddress()
method. - 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(File) - Method in class com.tangosol.persistence.ArchiverHelper.DirectoryFileFilter
-
Deprecated.Accept the given file only if it is a directory.
- 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 aFilter
or aValueExtractor
. - acceptIdentifier(String) - Method in class com.tangosol.coherence.dslquery.FilterBuilder
- acceptList(NodeTerm) - Method in class com.tangosol.coherence.dslquery.FilterBuilder
- acceptNode(String, NodeTerm) - Method in interface com.tangosol.coherence.dsltools.termtrees.TermWalker
-
The receiver has been dispatched to from the given node.
- AcceptorDependenciesProcessor - Class in com.tangosol.coherence.config.xml.processor
-
An
ElementProcessor
that will parse an <acceptor-config> and produce anAcceptorDependencies
. - AcceptorDependenciesProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.AcceptorDependenciesProcessor
- acceptPath(NodeTerm) - Method in class com.tangosol.coherence.dslquery.FilterBuilder
- 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. - 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
- 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(InvocableMap.Entry) - Method in class com.tangosol.util.aggregator.CompositeAggregator
- accumulate(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.Count
- 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(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(InvocableMap.Entry<? extends K, ? extends V>) - Method in interface com.tangosol.util.InvocableMap.StreamingAggregator
-
Accumulate one entry into the result.
- accumulate(Streamer<? extends InvocableMap.Entry<? extends K, ? extends V>>) - Method in class com.tangosol.util.aggregator.AbstractAggregator
- accumulate(Streamer<? extends 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(Streamer<? extends InvocableMap.Entry<? extends K, ? extends V>>) - Method in class com.tangosol.util.aggregator.QueryRecorder
- accumulate(Streamer<? extends InvocableMap.Entry<? extends K, ? extends V>>) - Method in interface com.tangosol.util.InvocableMap.StreamingAggregator
-
Accumulate multiple entries into the result.
- accumulateAndGet(int, Remote.IntBinaryOperator) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicInteger
-
Atomically updates the current value with the results of applying the given function to the current and given values, returning the updated value.
- accumulateAndGet(int, Remote.IntBinaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicInteger
- accumulateAndGet(int, Remote.IntBinaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicInteger
- accumulateAndGet(int, Remote.IntBinaryOperator) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicInteger
-
Atomically updates the current value with the results of applying the given function to the current and given values, returning the updated value.
- accumulateAndGet(int, Remote.IntBinaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicInteger
- accumulateAndGet(int, Remote.IntBinaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicInteger
- accumulateAndGet(int, IntBinaryOperator) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicInteger
-
Atomically updates the current value with the results of applying the given function to the current and given values, returning the updated value.
- accumulateAndGet(int, IntBinaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicInteger
- accumulateAndGet(int, IntBinaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicInteger
- accumulateAndGet(int, IntBinaryOperator) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicInteger
-
Atomically updates the current value with the results of applying the given function to the current and given values, returning the updated value.
- accumulateAndGet(int, IntBinaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicInteger
- accumulateAndGet(int, IntBinaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicInteger
- accumulateAndGet(long, Remote.LongBinaryOperator) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicLong
-
Atomically updates the current value with the results of applying the given function to the current and given values, returning the updated value.
- accumulateAndGet(long, Remote.LongBinaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicLong
- accumulateAndGet(long, Remote.LongBinaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicLong
- accumulateAndGet(long, Remote.LongBinaryOperator) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicLong
-
Atomically updates the current value with the results of applying the given function to the current and given values, returning the updated value.
- accumulateAndGet(long, Remote.LongBinaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicLong
- accumulateAndGet(long, Remote.LongBinaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicLong
- accumulateAndGet(long, LongBinaryOperator) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicLong
-
Atomically updates the current value with the results of applying the given function to the current and given values, returning the updated value.
- accumulateAndGet(long, LongBinaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicLong
- accumulateAndGet(long, LongBinaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicLong
- accumulateAndGet(long, LongBinaryOperator) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicLong
-
Atomically updates the current value with the results of applying the given function to the current and given values, returning the updated value.
- accumulateAndGet(long, LongBinaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicLong
- accumulateAndGet(long, LongBinaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicLong
- accumulateAndGet(V, Remote.BinaryOperator<V>) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicReference
-
Atomically updates the current value with the results of applying the given function to the current and given values, returning the updated value.
- accumulateAndGet(V, Remote.BinaryOperator<V>) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicReference
- accumulateAndGet(V, Remote.BinaryOperator<V>) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicReference
- accumulateAndGet(V, Remote.BinaryOperator<V>) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicReference
-
Atomically updates the current value with the results of applying the given function to the current and given values, returning the updated value.
- accumulateAndGet(V, Remote.BinaryOperator<V>) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicReference
- accumulateAndGet(V, Remote.BinaryOperator<V>) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicReference
- accumulateAndGet(V, BinaryOperator<V>) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicReference
-
Atomically updates the current value with the results of applying the given function to the current and given values, returning the updated value.
- accumulateAndGet(V, BinaryOperator<V>) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicReference
- accumulateAndGet(V, BinaryOperator<V>) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicReference
- accumulateAndGet(V, BinaryOperator<V>) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicReference
-
Atomically updates the current value with the results of applying the given function to the current and given values, returning the updated value.
- accumulateAndGet(V, BinaryOperator<V>) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicReference
- accumulateAndGet(V, BinaryOperator<V>) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicReference
- acquire() - Method in class com.oracle.coherence.concurrent.LocalSemaphore
- acquire() - Method in class com.oracle.coherence.concurrent.RemoteSemaphore
-
Acquires a permit from this semaphore, blocking until one is available, or the thread is interrupted.
- acquire() - Method in interface com.oracle.coherence.concurrent.Semaphore
-
Acquires a permit from this semaphore, blocking until one is available, or the thread is interrupted.
- acquire(int) - Method in class com.oracle.coherence.concurrent.LocalSemaphore
- acquire(int) - Method in class com.oracle.coherence.concurrent.RemoteSemaphore
-
Acquires the given number of permits from this semaphore, blocking until all are available, or the thread is interrupted.
- acquire(int) - Method in interface com.oracle.coherence.concurrent.Semaphore
-
Acquires the given number of permits from this semaphore, blocking until all are available, or the thread is interrupted.
- 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
- acquireUninterruptibly() - Method in class com.oracle.coherence.concurrent.LocalSemaphore
- acquireUninterruptibly() - Method in class com.oracle.coherence.concurrent.RemoteSemaphore
-
Acquires a permit from this semaphore, blocking until one is available.
- acquireUninterruptibly() - Method in interface com.oracle.coherence.concurrent.Semaphore
-
Acquires a permit from this semaphore, blocking until one is available.
- acquireUninterruptibly(int) - Method in class com.oracle.coherence.concurrent.LocalSemaphore
- acquireUninterruptibly(int) - Method in class com.oracle.coherence.concurrent.RemoteSemaphore
-
Acquires the given number of permits from this semaphore, blocking until all are available.
- acquireUninterruptibly(int) - Method in interface com.oracle.coherence.concurrent.Semaphore
-
Acquires the given number of permits from this semaphore, blocking until all are available.
- 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_ALLOW - Static variable in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder
-
The value of the hostname-verifier action to allow all connections.
- 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 buildingActionPolicy
's instances and defers cache configuration validation until the instance is realized. - ActionPolicyBuilder() - Constructor for class com.tangosol.coherence.config.builder.ActionPolicyBuilder
- ActionPolicyBuilder.ActionPolicyParameterizedBuilder - Class in com.tangosol.coherence.config.builder
-
ActionPolicyBuilder
wrapper for a ParameterizedBuilder. - ActionPolicyBuilder.NullImplementationBuilder - Class in com.tangosol.coherence.config.builder
-
ActionPolicy Null Implementation
- ActionPolicyBuilder.QuorumRule - Class in com.tangosol.coherence.config.builder
-
Intermediate QuorumRule with enough information to report a ConfigurationException at instantiation time.
- ActionPolicyParameterizedBuilder(ParameterizedBuilder<ActionPolicy>) - Constructor for class com.tangosol.coherence.config.builder.ActionPolicyBuilder.ActionPolicyParameterizedBuilder
- activate() - Method in class com.tangosol.net.CoherenceSession
- 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.
- activate() - Method in interface com.tangosol.net.Session
-
Activate this
Session
. - Activated - Annotation Interface in com.oracle.coherence.cdi.events
-
A qualifier annotation used for any ACTIVATED event.
- ACTIVATED - Enum constant in enum class com.tangosol.net.events.application.LifecycleEvent.Type
-
This
LifecycleEvent
is dispatched when aConfigurableCacheFactory
has been activated. - Activated.Literal - Class in com.oracle.coherence.cdi.events
-
An annotation literal for the
Activated
annotation. - Activating - Annotation Interface in com.oracle.coherence.cdi.events
-
A qualifier annotation used for any ACTIVATING event.
- ACTIVATING - Enum constant in enum class com.tangosol.net.events.application.LifecycleEvent.Type
-
This
LifecycleEvent
is dispatched prior to the activation of aConfigurableCacheFactory
. - Activating.Literal - Class in com.oracle.coherence.cdi.events
-
An annotation literal for the
Activating
annotation. - ADAPTER_INIT_PARAMS - Static variable in class com.tangosol.run.xml.XmlBean.BeanInfo
-
Parameters for finding the default adapter constructor.
- add(int) - Method in class com.tangosol.net.partition.PartitionSet
-
Add the specified partition to the set.
- add(int, E) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperList
- add(int, Object) - Method in class com.tangosol.run.xml.SimpleElement.ElementList
-
Inserts the specified element at the specified position in this list.
- add(int, Object) - Method in class com.tangosol.util.CircularArrayList
-
Insert the element at the specified position in this list.
- add(int, Object) - Method in class com.tangosol.util.InflatableList
- 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(int, Object) - Method in class com.tangosol.util.SafeLinkedList
-
Inserts the specified element at the specified position in this List.
- add(int, T) - Method in class com.tangosol.util.ConverterCollections.ConverterList
- add(int, T) - Method in class com.tangosol.util.SubList
- add(JCacheStatistics) - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
- add(JCacheStatistics) - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
-
add
JCacheStatistics
stats to this instance. - add(JCacheStatistics) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
- add(PropertySpec) - Method in class com.tangosol.coherence.rest.util.PropertySet
-
Add a property to this property set.
- add(Parameter) - Method in interface com.tangosol.coherence.config.ParameterList
-
Adds a
Parameter
to the end of theParameterList
or replaces an existingParameter
in theParameterList
. - add(Parameter) - Method in class com.tangosol.coherence.config.ResolvableParameterList
-
Adds a
Parameter
to the end of theParameterList
or replaces an existingParameter
in theParameterList
. - add(Parameter) - Method in class com.tangosol.coherence.config.SimpleParameterList
-
Adds a
Parameter
to the end of theParameterList
or replaces an existingParameter
in theParameterList
. - add(Parameter) - Method in class com.tangosol.config.expression.ScopedParameterResolver
-
Adds the specified
Parameter
to the outerParameterResolver
. - add(ReadWriteBackingMap.Entry, long) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.WriteQueue
-
Add an entry to the queue.
- 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(PartitionSet) - Method in class com.tangosol.net.partition.PartitionSet
-
Add the specified PartitionSet to this set.
- add(BinaryEntry) - Method in class com.tangosol.net.cache.AbstractBinaryEntryBundler.Bundle
-
Add the specified binary entry to the Bundle.
- add(E) - Method in class com.tangosol.util.aggregator.TopNAggregator.PartialResult
- add(E) - Method in class com.tangosol.util.ChainedCollection
- add(E) - Method in class com.tangosol.util.ChainedSet
- add(E) - Method in class com.tangosol.util.LiteSet
-
Ensures that this Set contains the specified element.
- add(E) - Method in class com.tangosol.util.OpenHashSet
- add(E) - Method in class com.tangosol.util.SortedBag
- add(E) - Method in class com.tangosol.util.SortedBag.ViewBag
- add(E) - Method in class com.tangosol.util.SubSet
- add(E) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperCollection
- add(E) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperListIterator
- add(E) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperCollection
- add(Comparable) - Method in class com.tangosol.util.Tree
-
Add the passed key to the tree.
- add(Object) - Method in class com.tangosol.coherence.config.SimpleParameterList
-
Adds the specified object to the end of the
ParameterList
as an anonymousParameter
. - 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(Object) - Method in class com.tangosol.net.CompositeAddressProvider
-
Ensures that this collection contains the specified element (optional operation).
- add(Object) - Method in class com.tangosol.net.LoadBalancer.Queue
-
Add an object to the end of the queue.
- add(Object) - Method in class com.tangosol.run.xml.SimpleElement.ElementList
-
Appends the specified element to the end of this list.
- 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(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(Object) - Method in class com.tangosol.util.MapSet
-
Ensures that this Set contains the specified element.
- add(Object) - Method in class com.tangosol.util.NullImplementation.NullSet
-
Ensures that this Collection contains the specified element.
- 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(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(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(Object, Object) - Method in class com.tangosol.net.cache.AbstractEntryBundler.Bundle
-
Add the specified entry to the Bundle.
- add(Runnable) - Method in class com.oracle.coherence.grpc.proxy.TracingDaemonPool
- add(String) - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.NameListDependencies
- add(String) - Method in class com.tangosol.util.StringTable
-
Add the passed string to the table.
- add(String, int) - Method in class com.tangosol.coherence.config.builder.ListBasedAddressProviderBuilder
-
Add an address and port.
- 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(EventListener) - Method in class com.tangosol.util.Listeners
-
Add a listener.
- add(Map.Entry<TK, TV>) - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet
- add(T) - Method in class com.tangosol.util.ConverterCollections.ConverterCollection
- add(T) - Method in class com.tangosol.util.ConverterCollections.ConverterListIterator
- add(T) - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray
- add(T) - Method in class com.tangosol.util.SubList
- add(V) - Method in interface com.oracle.coherence.common.base.Collector
-
Notify the collector of a item of interest.
- 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(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(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(V) - Method in class com.tangosol.util.NullImplementation.NullCollector
-
Notify the collector of a item of interest.
- add(V) - Method in class com.tangosol.util.NullImplementation.NullLongArray
- add(V) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
- addAddress(InetSocketAddress) - Method in class com.tangosol.net.CompositeAddressProvider
-
Add an address.
- addAddress(SocketAddress) - Method in class com.tangosol.net.CompositeSocketAddressProvider
-
Add a
SocketAddress
. - addAliases(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.BaseOperator
-
Add any aliases of this operator to the specified token table.
- 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(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(int, Collection) - Method in class com.tangosol.util.InflatableList
- 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(int, Collection<? extends E>) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperList
- addAll(int, Collection<? extends T>) - Method in class com.tangosol.util.ConverterCollections.ConverterList
- addAll(int, Collection<? extends T>) - Method in class com.tangosol.util.SubList
- addAll(Listeners) - Method in class com.tangosol.util.Listeners
-
Add all listeners from another Listeners object.
- 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(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) - 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(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(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(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(Collection<? extends E>) - Method in class com.tangosol.util.ChainedCollection
- addAll(Collection<? extends E>) - Method in class com.tangosol.util.ChainedSet
- 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<? extends E>) - Method in class com.tangosol.util.SubSet
- addAll(Collection<? extends E>) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperCollection
- addAll(Collection<? extends E>) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperCollection
- addAll(Collection<? extends Map.Entry<TK, TV>>) - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet
- addAll(Collection<? extends T>) - Method in class com.tangosol.util.ConverterCollections.ConverterCollection
- addAll(Collection<? extends T>) - Method in class com.tangosol.util.SubList
- addAll(Iterator<E>) - Method in class com.tangosol.util.aggregator.TopNAggregator.PartialResult
-
Add all specified values to this PartialResult.
- addAll(Map) - Method in class com.tangosol.net.cache.AbstractEntryBundler.Bundle
-
Add the specified collection of entries to the Bundle.
- addAll(Set) - Method in class com.tangosol.net.cache.AbstractBinaryEntryBundler.Bundle
-
Add the specified set of binary entries to the Bundle.
- addAlterSessionStatement() - Method in class com.tangosol.coherence.dslquery.QueryPlus
-
Add the QueryPlus ALTER SESSION statements
- addAndGet(int) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicInteger
-
Atomically adds the given value to the current value.
- addAndGet(int) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicInteger
- addAndGet(int) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicInteger
- addAndGet(int) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicInteger
-
Atomically adds the given value to the current value.
- addAndGet(int) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicInteger
- addAndGet(int) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicInteger
- addAndGet(long) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicLong
-
Atomically adds the given value to the current value.
- addAndGet(long) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicLong
- addAndGet(long) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicLong
- addAndGet(long) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicLong
-
Atomically adds the given value to the current value.
- addAndGet(long) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicLong
- addAndGet(long) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicLong
- addAttribute(String) - Method in class com.tangosol.run.xml.SimpleElement
-
Provides a means to add a new attribute value.
- addAttribute(String) - Method in interface com.tangosol.run.xml.XmlElement
-
Provides a means to add a new attribute value.
- addAuthorizedHostsToFilter(String, String) - Method in class com.tangosol.coherence.config.builder.InetAddressRangeFilterBuilder
-
Add an authorized host range to the filter.
- addBuffer() - Method in class com.tangosol.io.MultiBufferWriteBuffer
-
Once the current buffer is full, allocate a new one and make it the current buffer.
- addCacheEntryListenerConfiguration(CacheEntryListenerConfiguration<K, V>) - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
- addCacheEntryListenerConfiguration(CacheEntryListenerConfiguration<K, V>) - Method in interface com.tangosol.coherence.jcache.CoherenceBasedCompleteConfiguration
-
Add a configuration for a
CacheEntryListener
. - addCacheMappingRegistry(SchemeMappingRegistry) - Method in class com.tangosol.coherence.config.CacheConfig
-
Add cache scheme mappings to the
SchemeMappingRegistry
. - addConfig(BundleManager.BundleConfig) - Method in class com.tangosol.coherence.config.scheme.BundleManager
-
Add the BundleConfig to the list of bundle configurations.
- addCookie(Class<T>, String, T) - Method in class com.tangosol.config.xml.DefaultProcessingContext
-
Adds the specified named and typed cookie to the
ProcessingContext
. - addCookie(Class<T>, String, T) - Method in interface com.tangosol.config.xml.ProcessingContext
-
Adds the specified named and typed cookie to the
ProcessingContext
. - addCookie(Class<T>, T) - Method in class com.tangosol.config.xml.DefaultProcessingContext
-
Adds the specified cookie to the
ProcessingContext
. - addCookie(Class<T>, T) - Method in interface com.tangosol.config.xml.ProcessingContext
-
Adds the specified cookie to the
ProcessingContext
. - addDefaultDefinition(String, String) - Method in class com.tangosol.coherence.config.xml.preprocessor.CacheDefaultsPreprocessor
-
Adds a requirement that the specified "default" element must be added to (if not already defined) in the element specified by the defined parent path.
- addDefaultsDefinition(String, XmlElement) - Method in class com.tangosol.coherence.config.xml.preprocessor.OperationalDefaultsPreprocessor
-
Defines that elements matching the specified path must contain the child elements defined by the default element.
- addElement(Object) - Method in class com.tangosol.util.Dequeue
-
Adds an element to the dequeue.
- 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.
- 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
-
Add an
EventInterceptor
to this dispatcher to be used to processEvent
s. - addEventInterceptor(String, EventInterceptor<E>) - Method in interface com.tangosol.net.events.EventDispatcher
-
Add a uniquely identified
EventInterceptor
to this dispatcher to be used to processEvent
s. - addEventInterceptor(String, EventInterceptor<E>, Set<T>, boolean) - Method in interface com.tangosol.net.events.EventDispatcher
-
Add a uniquely identified
EventInterceptor
to this dispatcher to be used to processEvent
s. - addFilterMapListener(String, String, String, ByteString, long, boolean, boolean, ByteString) - Static method in class com.oracle.coherence.grpc.Requests
-
Create a
MapListenerRequest
that will subscribe toMapEvents
for all entries in a cache matching a filter. - addForwardEntry(Object, Object) - Method in class com.tangosol.util.SimpleMapIndex
-
Add a new mapping to the forward index map.
- addFunction(String, ParameterizedBuilder) - Method in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
-
Map the specified CohQL
ParameterizedBuilder
to the specified function name. - addIndex(AddIndexRequest) - Method in interface com.oracle.coherence.grpc.proxy.NamedCacheService
-
Add an index to a cache.
- addIndex(AddIndexRequest) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- addIndex(AddIndexRequest, StreamObserver<Empty>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceGrpcImpl
- addIndex(CacheRequestHolder<AddIndexRequest, Void>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
-
Execute the
AddIndexRequest
request. - addIndex(ValueExtractor<? super T, ? extends E>) - Method in interface com.tangosol.util.QueryMap
-
Add an unordered index to this QueryMap.
- addIndex(ValueExtractor<? super T, ? extends E>, boolean, Comparator<? super E>) - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
If
ContinuousQueryCache.isCacheValues()
istrue
, the index will be created locally as well as on theNamedCache
thisContinuousQueryCache
wraps, otherwise, the index will be created on the wrappedNamedCache
only. - addIndex(ValueExtractor<? super T, ? extends E>, boolean, Comparator<? super E>) - Method in class com.tangosol.net.cache.NearCache
-
Add an index to this QueryMap.
- addIndex(ValueExtractor<? super T, ? extends E>, boolean, Comparator<? super E>) - Method in class com.tangosol.net.cache.WrapperNamedCache
-
Add an index to this QueryMap.
- addIndex(ValueExtractor<? super T, ? extends E>, boolean, Comparator<? super E>) - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
-
Add an index to this QueryMap.
- addIndex(ValueExtractor<? super T, ? extends E>, boolean, Comparator<? super E>) - Method in class com.tangosol.util.ConverterCollections.ConverterQueryMap
-
Add an index to this QueryMap.
- addIndex(ValueExtractor<? super T, ? extends E>, boolean, Comparator<? super E>) - Method in interface com.tangosol.util.QueryMap
-
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(String, String, String, ByteString) - Static method in class com.oracle.coherence.grpc.Requests
-
Create a
AddIndexRequest
. - addIndex(String, String, String, ByteString, boolean) - Static method in class com.oracle.coherence.grpc.Requests
-
Create a
AddIndexRequest
. - addIndex(String, String, String, ByteString, boolean, ByteString) - Static method in class com.oracle.coherence.grpc.Requests
-
Create a
AddIndexRequest
. - 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.
- addKeyMapListener(String, String, String, ByteString, boolean, boolean, ByteString) - Static method in class com.oracle.coherence.grpc.Requests
-
Create a
MapListenerRequest
that will subscribe toMapEvents
for a single entry in a cache. - addLifecycleListener(LifecycleListener) - Method in class com.tangosol.net.DefaultCacheServer
-
Add a
LifecycleListener
that will be notified of lifecycle events for thisDefaultCacheServer
. - 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(boolean, String) - Method in class com.tangosol.coherence.rest.CacheResource
-
Register SSE event listener for this cache.
- addListener(AbstractRepositoryBase.Listener<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepositoryBase
-
Register a listener that will observe all repository events.
- addListener(Filter<?>, long, boolean, boolean) - Method in class com.oracle.coherence.grpc.proxy.MapListenerProxy
-
Add this MapListenerProxy as a filter-based listener of the given NamedCache.
- addListener(Filter<?>, AbstractRepositoryBase.Listener<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepositoryBase
-
Register a listener that will observe all events for entities that satisfy the specified criteria.
- addListener(FiniteStateMachineListener<S>) - Method in interface com.tangosol.util.fsm.FiniteStateMachine
-
Add a
FiniteStateMachineListener
to theFiniteStateMachine
. - addListener(FiniteStateMachineListener<S>) - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine
-
Add a
FiniteStateMachineListener
to theFiniteStateMachine
. - addListener(MapListener, Filter, boolean) - Method in class com.tangosol.util.MapListenerSupport
-
Add a map listener that receives events based on a filter evaluation.
- addListener(MapListener, Object, boolean) - Method in class com.tangosol.util.MapListenerSupport
-
Add a map listener for a specific key.
- addListener(MapListener, Set, boolean) - Method in class com.tangosol.util.MapListenerSupport
-
Add a map listener for a set of keys.
- addListener(ID, AbstractRepositoryBase.Listener<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepositoryBase
-
Register a listener that will observe all events for a specific entity.
- addListener(Object, boolean, boolean) - Method in class com.oracle.coherence.grpc.proxy.MapListenerProxy
-
Add this MapListenerProxy as a key-based listener of the given NamedCache.
- addListener(Object, boolean, boolean, boolean) - Method in class com.oracle.coherence.grpc.proxy.MapListenerProxy
-
Add this MapListenerProxy as a key-based listener of the given NamedCache.
- AddListener() - Constructor for class com.tangosol.net.cache.ContinuousQueryCache.AddListener
- 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.
- addLocalServiceProvider(String, ClusterDependencies.ServiceProvider) - Method in interface com.tangosol.net.ClusterDependencies
-
Register a
ClusterDependencies.ServiceProvider
. - addLookupCallback(NameService.LookupCallback) - Method in interface com.tangosol.net.NameService
-
Register a
NameService.LookupCallback
to be used to perform lookups on names that are not bound to theNameService
's directory. - addMap(int, Map) - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.MapArray
-
Add a new mapping between a partition ID and its backing map.
- addMapListener(AnnotatedMapListener<?, ?>) - Method in class com.oracle.coherence.cdi.events.AnnotatedMapListenerManager
-
Add specified listener to the collection of discovered observer-based listeners.
- addMapListener(MapListener) - Method in class com.oracle.coherence.caffeine.CaffeineCache
- 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) - Method in class com.tangosol.net.cache.LocalCache
- 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) - 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) - 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) - Method in class com.tangosol.util.ObservableHashMap
- addMapListener(MapListener<? super K, ? super V_FRONT>) - 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_FRONT>, K, 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>) - 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>) - 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>, Filter, boolean) - Method in class com.tangosol.net.cache.NearCache
-
Add a map listener that receives events based on a filter evaluation.
- addMapListener(MapListener<? super K, ? super V>, Filter, boolean) - Method in class com.tangosol.util.ObservableHashMap
- 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>, Filter, boolean) - Method in class com.tangosol.util.WrapperObservableMap
-
Add a map listener that receives events based on a filter evaluation.
- 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>, K, boolean) - Method in class com.tangosol.util.ObservableHashMap
- 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>, K, boolean) - Method in class com.tangosol.util.WrapperObservableMap
-
Add a map listener for a specific key.
- 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>, Filter, boolean) - Method in class com.tangosol.util.ConverterCollections.ConverterObservableMap
-
Add a map listener that receives events based on a filter evaluation.
- 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, Filter, boolean) - Method in class com.oracle.coherence.caffeine.CaffeineCache
- 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, Filter, boolean) - Method in class com.tangosol.net.cache.LocalCache
- 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, Filter, boolean) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Add a map listener that receives events based on a filter evaluation.
- 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, Filter, boolean) - Method in class com.tangosol.util.NullImplementation.NullObservableMap
-
Add a map listener that receives events based on a filter evaluation.
- addMapListener(MapListener, Object, boolean) - Method in class com.oracle.coherence.caffeine.CaffeineCache
- addMapListener(MapListener, Object, boolean) - Method in class com.tangosol.net.cache.AbstractSerializationCache
-
Add a map listener for a specific key.
- addMapListener(MapListener, Object, boolean) - Method in class com.tangosol.net.cache.LocalCache
- addMapListener(MapListener, Object, boolean) - Method in class com.tangosol.net.cache.OverflowMap
-
Add a map listener for a specific key.
- addMapListener(MapListener, Object, boolean) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
-
Add a map listener for a specific key.
- addMapListener(MapListener, Object, boolean) - Method in class com.tangosol.net.partition.ObservableSplittingBackingMap
-
Add a map listener for a specific key.
- addMapListener(MapListener, Object, boolean) - Method in class com.tangosol.util.NullImplementation.NullObservableMap
-
Add a map listener for a specific key.
- 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.
- addMessageDuration(long) - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
-
Add a timing sample to the metrics.
- addNamedProviderType(String, SocketProviderFactory.Dependencies.ProviderType) - Method in class com.tangosol.net.SocketProviderFactory.DefaultDependencies
-
Add
SocketProviderFactory.Dependencies.ProviderType
forsId
identifier to this SocketProviderFactory's Dependency mapping. - addNamedQuery(NamedQuery) - Method in class com.tangosol.coherence.rest.config.QueryConfig
-
Add named query to this config.
- addNamedSSLDependencies(String, SSLSocketProvider.Dependencies) - Method in class com.tangosol.net.SocketProviderFactory.DefaultDependencies
-
Add
SSLSocketProvider.Dependencies
forsId
identifier to this SocketProviderFactory's Dependency mapping. - addNamedSSLDependenciesBuilder(String, SSLSocketProviderDependenciesBuilder) - Method in class com.tangosol.net.SocketProviderFactory.DefaultDependencies
- addNamedTCPDatagramDependencies(String, TcpDatagramSocketProvider.Dependencies) - Method in class com.tangosol.net.SocketProviderFactory.DefaultDependencies
-
Add
TcpDatagramSocketProvider.Dependencies
forsId
identifier to this SocketProviderFactory's Dependency mapping. - 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
- addNotificationListener(NotificationListener, NotificationFilter, Object) - Method in class com.tangosol.net.management.AnnotatedStandardEmitterMBean.SilentEmitter
- 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
- addOPToken(String, OPToken) - Method in class com.tangosol.coherence.dsltools.precedence.PeekOPToken
- 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
-
Add a
SocketAddressProvider
. - addQuorumRule(String, int, int) - Method in class com.tangosol.coherence.config.builder.PartitionedCacheQuorumPolicyBuilder
- addQuorumRule(String, int, int, float) - 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. - addRequestDuration(long) - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
-
Add a timing sample to the metrics.
- address - Variable in class com.tangosol.net.LoadBalancer.AddressPort
-
The address.
- AddressHolder(String, int) - Constructor for class com.tangosol.net.ConfigurableAddressProvider.AddressHolder
-
Construct an AddressHolder for the specified host and port.
- AddressIterator(List) - Constructor for class com.tangosol.net.CompositeAddressProvider.AddressIterator
- AddressPort(InetAddress, int) - Constructor for class com.tangosol.net.LoadBalancer.AddressPort
-
Construct an AddressPort object.
- AddressProvider - Interface in com.tangosol.net
-
The AddressProvider is a subclass interface of
SocketAddressProvider
which returnsInetSocketAddress
fromAddressProvider.getNextAddress()
. - AddressProviderBuilder - Interface in com.tangosol.coherence.config.builder
-
AddressProviderBuilder interface
- AddressProviderBuilderProcessor - Class in com.tangosol.coherence.config.xml.processor
-
An
ElementProcessor
that will parse and produce a ParameterizedBuilder<AddressProvider> based on an address-provider configuration element, that of which is defined as such (with support for foreign-namespaces) - AddressProviderBuilderProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.AddressProviderBuilderProcessor
- AddressProviderFactory - Interface in com.tangosol.net
-
A factory for
AddressProvider
objects. - addSafeListener(Map, 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.
- 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.
- 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.
- addSession(SessionConfiguration) - Method in class com.tangosol.net.Coherence
- addSessionIfAbsent(SessionConfiguration) - Method in class com.tangosol.net.Coherence
- addSessionIfAbsent(String, Supplier<SessionConfiguration>) - Method in class com.tangosol.net.Coherence
- addStateEntryAction(S, StateEntryAction<S>) - Method in class com.tangosol.util.fsm.SimpleModel
-
Adds/overrides the
StateEntryAction
for the specified state in theModel
. - addStateExitAction(S, StateExitAction<S>) - Method in class com.tangosol.util.fsm.SimpleModel
-
Adds/overrides the
StateExitAction
for the specified state in theModel
. - addStatement(AbstractQueryPlusStatementBuilder) - Method in class com.tangosol.coherence.dslquery.QueryPlus
-
Add a new QueryPlus statement.
- addStatement(String, StatementBuilder<?>) - Method in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
-
Register the given
StatementBuilder
to the specified functor name. - addTask(AbstractPersistenceManager.Task) - Method in class com.tangosol.persistence.AbstractPersistenceManager
-
Add the provided task to the set of tasks.
- 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
- 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
- addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.AdditionOperator
- addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.AndOperator
- addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.BaseOperator
-
Add this operator to the given
TokenTable
. - addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.BetweenOperator
- addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.ContainsAllOperator
- addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.ContainsAnyOperator
- addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.ContainsOperator
- addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.DivisionOperator
-
Add this operator to the given
TokenTable
. - addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.EqualsOperator
- addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.GreaterEqualsOperator
- addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.GreaterOperator
- addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.ILikeOperator
- addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.InOperator
- addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.LessEqualsOperator
- addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.LessOperator
- addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.LikeOperator
- addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.MultiplicationOperator
-
Add this operator to the given
TokenTable
. - addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.NotEqualsOperator
- addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.OrOperator
- addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.SubtractionOperator
-
Add this operator to the given
TokenTable
. - addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.XorOperator
- addTransition(Transition<S>) - Method in class com.tangosol.util.fsm.SimpleModel
-
Adds the specified
Transition
to theModel
. - addType(T) - Method in class com.oracle.coherence.cdi.events.EventObserverSupport.EventHandler
-
Add specified event type to a set of types this interceptor should handle.
- adjust() - Method in class com.tangosol.net.cache.AbstractBundler
-
Adjust this Bundler's parameters according to the available statistical information.
- 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.
- 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.LocalCache
-
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(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
- adopt(Object[]) - Method in class com.tangosol.run.xml.XmlBean
-
Helper to adopt a collection 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(Map) - Method in class com.tangosol.run.xml.XmlBean
-
Helper to adopt a Map of XmlBean objects.
- advance() - Method in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
-
Advance to the next character.
- 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() - Method in class com.tangosol.net.cache.OverflowMap.EntrySet.EntrySetIterator
-
Advance to the next object.
- advance() - Method in class com.tangosol.net.cache.OverflowMap.InternalKeySet.InternalKeySetIterator
-
Advance to the next object.
- advance() - Method in class com.tangosol.net.cache.SimpleOverflowMap.KeyIterator
-
Advance to the next key.
- advance() - Method in class com.tangosol.net.CompositeAddressProvider.AddressIterator
-
Advance to the next object.
- advance() - Method in class com.tangosol.net.partition.AbstractPartitionedIterator
- advance() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.PartitionedIterator
-
Advance to the next object.
- advance() - Method in class com.tangosol.util.AbstractKeySetBasedMap.KeyIterator
-
Advance to the next object.
- advance() - Method in class com.tangosol.util.SafeHashMap.EntrySet.EntrySetIterator
-
Advance to the next object.
- advance() - Method in class com.tangosol.util.SegmentedHashMap.EntrySet.EntrySetIterator
-
Advance to the next object in the iteration.
- 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(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.
- advanceCurrentPage(SerializationPagedCache.WrapperBinaryStore) - Method in class com.tangosol.net.cache.SerializationPagedCache.PagedBinaryStore
-
Advance the current page, using the passed BinaryStore as the store for the new current page, and returning the oldest active page, if the maximum number of active pages is exceeded by the advancing of the current page.
- advancePage() - Method in class com.tangosol.net.cache.SerializationPagedCache
-
Advance to a new current page, and deactivate the oldest page is the maximum number of active pages has been reached.
- advanceTo(int) - Method in class com.tangosol.io.pof.PofBufferReader
-
Advance through the POF stream until the specified property is found.
- advanceTo(int) - Method in class com.tangosol.io.pof.PofBufferReader.UserTypeReader
-
Advance through the POF stream until the specified property is found.
- advanceToStmt(OPScanner) - Method in class com.tangosol.coherence.dslquery.token.SQLExplainOPToken
-
Advance the scanner past any tokens preceding the statement.
- advanceToStmt(OPScanner) - Method in class com.tangosol.coherence.dslquery.token.SQLTraceOPToken
- advanceWhenMatching(String) - Method in class com.tangosol.coherence.dsltools.precedence.OPScanner
-
Test to see if the current BaseToken's string matches the given string and advance if true. * The token table's ignoringCase flag is consulted to see if case matters.
- after(long) - Static method in class com.oracle.coherence.common.base.Timeout
-
Specify a new timeout.
- after(long, TimeUnit) - Static method in class com.oracle.coherence.common.base.Timeout
-
Specify a new timeout.
- aggregate(AggregateRequest) - Method in interface com.oracle.coherence.grpc.proxy.NamedCacheService
-
Execute an
AggregateRequest
against a cache and return the result serialized in aBytesValue
. - aggregate(AggregateRequest) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- aggregate(AggregateRequest, StreamObserver<BytesValue>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceGrpcImpl
- aggregate(MBeanAccessor.QueryBuilder.ParsedQuery, String, String, String) - Method in class com.tangosol.net.management.MBeanAccessor
-
Process the request for MBean attributes.
- aggregate(Filter<?>, InvocableMap.EntryAggregator<? super K, ? super V, R>) - Method in interface com.tangosol.net.AsyncNamedMap
-
Perform an aggregating operation asynchronously against the set of entries that are selected by the given Filter.
- aggregate(Filter, InvocableMap.EntryAggregator<? super K, ? super V_FRONT, R>) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 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(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(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(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(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.net.AsyncNamedMap
-
Perform an aggregating operation asynchronously against all the entries.
- aggregate(InvocableMap.EntryAggregator<? super K, ? super V, R>) - Method in interface com.tangosol.util.InvocableMap
-
Perform an aggregating operation against all 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(String) - Method in class com.tangosol.coherence.rest.EntrySetResource
-
Perform an aggregating operation against the entries.
- 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, String, String, ByteString, ByteString) - Static method in class com.oracle.coherence.grpc.Requests
-
Create a
AggregateRequest
. - aggregate(String, String, String, Iterable<ByteString>, ByteString) - Static method in class com.oracle.coherence.grpc.Requests
-
Create a
AggregateRequest
. - aggregate(Collection<? extends K>, 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 interface com.tangosol.net.AsyncNamedMap
-
Perform an aggregating operation asynchronously against the entries specified by the passed keys.
- 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(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(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(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(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(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.AbstractAsynchronousAggregator
-
Not supported.
- 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(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.
- aggregateWithFilter(AggregateRequest) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
-
Execute the filtered
AggregateRequest
request. - aggregateWithFilter(CacheRequestHolder<AggregateRequest, Void>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
-
Execute the filtered
AggregateRequest
request. - aggregateWithKeys(AggregateRequest) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
-
Execute the key-based
AggregateRequest
request. - aggregateWithKeys(CacheRequestHolder<AggregateRequest, Void>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
-
Execute the filtered
AggregateRequest
request. - 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, - Interface in com.tangosol.coherence.rest.util.aggregatorR> -
A factory for aggregators.
- AggregatorRegistry - Class in com.tangosol.coherence.rest.util.aggregator
-
A registry for
AggregatorFactory
instances. - AggregatorRegistry() - Constructor for class com.tangosol.coherence.rest.util.aggregator.AggregatorRegistry
-
Construct an AggregatorRegistry.
- AggregatorRegistry(Collection<AggregatorConfig>) - Constructor for class com.tangosol.coherence.rest.util.aggregator.AggregatorRegistry
-
Construct an AggregatorRegistry that includes built-in aggregators in addition to the specified aggregators.
- Aggregators - Class in com.tangosol.util
-
Simple Aggregator DSL.
- Aggregators() - Constructor for class com.tangosol.util.Aggregators
- alias(String, String) - Method in class com.tangosol.coherence.dsltools.precedence.TokenTable
-
Add a token alias under the given name for a token already installed
- all(Filter<? super T>...) - Static method in class com.tangosol.util.Filters
-
Return a composite filter representing logical AND of all specified filters.
- ALL - Static variable in class com.tangosol.net.ClusterPermission
-
All actions.
- ALL - Static variable in interface com.tangosol.net.partition.VersionAwareMapListener
-
A constant that suggests to an event source to send all known versions (subject to the event source's retention policy) and all future versions.
- 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.
- allHealthChecksLive() - Method in interface com.tangosol.net.management.Registry
-
Returns
true
if the all the registeredhealth checks
are live. - allHealthChecksReady() - Method in interface com.tangosol.net.management.Registry
-
Returns
true
if the all the registeredhealth checks
are ready. - allHealthChecksSafe() - Method in interface com.tangosol.net.management.Registry
-
Returns
true
if the all the registeredhealth checks
are safe. - allHealthChecksStarted() - Method in interface com.tangosol.net.management.Registry
-
Returns
true
if the all the registeredhealth checks
are started. - allMatch(Remote.DoublePredicate) - Method in interface com.tangosol.util.stream.RemoteDoubleStream
-
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(Remote.LongPredicate) - Method in interface com.tangosol.util.stream.RemoteLongStream
-
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.
- allMatch(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(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.
- 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.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
- allowEndangered() - Method in class com.tangosol.coherence.config.xml.processor.HealthProcessor.XMLHealthCheckDependencies
- AlreadyCommitted - Enum constant in enum class com.tangosol.net.topic.Subscriber.CommitResultStatus
-
The position was already committed.
- always() - Static method in class com.tangosol.util.Filters
-
Return a filter that always evaluates to true.
- Always - Static variable in interface com.tangosol.net.ssl.RefreshPolicy
-
A
RefreshPolicy
that always returnstrue
. - ALWAYS - Enum constant in enum class com.tangosol.util.RegistrationBehavior
-
Specifies that registration must always occur.
- ALWAYS - Static variable in class com.oracle.coherence.common.base.Logger
-
Severity 0 will always be logged.
- AlwaysFilter<T> - Class in com.tangosol.util.filter
-
Filter which always evaluates to true.
- AlwaysFilter - Annotation Interface in com.oracle.coherence.cdi
-
A
FilterBinding
annotation representing anAlwaysFilter
. - AlwaysFilter() - Constructor for class com.tangosol.util.filter.AlwaysFilter
-
Construct an AlwaysFilter.
- AlwaysFilter.Literal - Class in com.oracle.coherence.cdi
-
An annotation literal for the
AlwaysFilter
annotation. - AlwaysFilterSupplier() - Constructor for class com.oracle.coherence.cdi.FilterProducer.AlwaysFilterSupplier
- 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() - 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() - Method in class com.tangosol.util.NullImplementation.NullPartitionAssignmentStrategy
-
Analyze the distribution and return the desired time interval before the next distribution analysis.
- analyzeDistribution(SimpleAssignmentStrategy.AnalysisContext) - Method in class com.tangosol.net.partition.MirroringAssignmentStrategy
-
Analyze the distribution and suggest the resulting distribution to distribution manager.
- analyzeDistribution(SimpleAssignmentStrategy.AnalysisContext) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
-
Analyze the distribution and suggest the resulting distribution to distribution manager.
- 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(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 theafter
operation. - 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 theafter
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 theafter
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.BiFunction
-
Returns a composed function that first applies this function to its input, and then applies the
after
function 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 theafter
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 theafter
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 theafter
transformation. - andThen(ValueExtractor<? super E, ? extends V>) - Method in class com.tangosol.util.extractor.ChainedExtractor
- 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. - AnnotatedMapListener<K,
V> - Class in com.oracle.coherence.cdi.events -
MapListener
implementation that dispatchesMapEvent
s to a CDI observer. - AnnotatedMapListener(AnnotatedMapListener.MapEventObserver<K, V>, Set<Annotation>) - Constructor for class com.oracle.coherence.cdi.events.AnnotatedMapListener
- AnnotatedMapListener.FilterProducer - Interface in com.oracle.coherence.cdi.events
-
A producer of
Filter
instances. - AnnotatedMapListener.MapEventObserver<K,
V> - Interface in com.oracle.coherence.cdi.events - AnnotatedMapListener.MapEventTransformerProducer - Interface in com.oracle.coherence.cdi.events
-
A producer of
MapEventTransformer
instances. - AnnotatedMapListenerManager - Class in com.oracle.coherence.cdi.events
-
Registers discovered CDI observer-based
MapListener
s when the cache is created, and unregisters them when it's destroyed. - AnnotatedMapListenerManager(AnnotatedMapListener.FilterProducer, AnnotatedMapListener.MapEventTransformerProducer) - Constructor for class com.oracle.coherence.cdi.events.AnnotatedMapListenerManager
- AnnotatedStandardEmitterMBean - Class in com.tangosol.net.management
-
AnnotatedStandardEmitterMBean is an extension of a
StandardEmitterMBean
that uses theDescription
andNotification
annotations to describe the MBean and any attributes, operations and notifications it declares. - AnnotatedStandardEmitterMBean(T, Class<T>) - Constructor for class com.tangosol.net.management.AnnotatedStandardEmitterMBean
-
Make a DynamicMBean out of the MBean implementation, using the specified mbeanInterface class.
- AnnotatedStandardEmitterMBean.SilentEmitter - Class in com.tangosol.net.management
-
A silent
NotificationEmitter
implementation for all NotificationEmitter methods exceptgetNotificationInfo()
. - AnnotatedStandardMBean - Class in com.tangosol.net.management
-
AnnotatedStandardMBean is an extension of a
StandardMBean
that uses theDescription
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> - Class in com.tangosol.util.fsm
-
An
AnnotationDrivenModel
is aModel
created through extracting information defined byTransitions
annotation. - AnnotationDrivenModel(Class<S>, Object) - Constructor for class com.tangosol.util.fsm.AnnotationDrivenModel
-
Constructs an
AnnotationDrivenModel
based on the specified annotated class. - AnnotationInstance - Class in com.oracle.coherence.cdi
-
A representation of an
Annotation
that can be used for equality tests where methods in theAnnotation
annotated withNonbinding
are ignored. - AnnotationLiteral<T> - Class in com.oracle.coherence.cdi
-
Supports inline instantiation of annotation type instances.
- AnnotationLiteral() - Constructor for class com.oracle.coherence.cdi.AnnotationLiteral
- annotationType() - Method in class com.oracle.coherence.cdi.AnnotationLiteral
-
Method returns the type of the annotation literal.
- any(Filter<? super T>...) - Static method in class com.tangosol.util.Filters
-
Return a composite filter representing logical OR of all specified filters.
- ANY - Static variable in interface com.tangosol.net.AsyncNamedMap
-
A trivial consumer.
- 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(Remote.DoublePredicate) - Method in interface com.tangosol.util.stream.RemoteDoubleStream
-
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(Remote.LongPredicate) - Method in interface com.tangosol.util.stream.RemoteLongStream
-
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.
- anyMatch(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(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.
- 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 interface com.tangosol.net.management.annotation.MetricsScope
-
The full descriptor value to use for vendor scoped metrics.
- applicationProtocolNegotiator() - Method in class com.oracle.coherence.grpc.RefreshableSslContext
- apply(F) - Method in interface com.oracle.coherence.common.base.Converter
- apply(String) - Method in class com.oracle.coherence.grpc.proxy.ConfigurableCacheFactorySuppliers.DefaultCacheFactorySupplier
- apply(String) - Method in class com.oracle.coherence.grpc.proxy.ConfigurableCacheFactorySuppliers.FixedCacheFactorySupplier
- 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(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(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(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(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(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<? extends ValueExtractor<? extends V, ?>, ? extends MapIndex<? extends K, ? extends V, ?>>, Set<? extends K>) - Method in interface com.tangosol.util.filter.IndexAwareFilter
-
Filter remaining keys using a Map of available indexes.
- applyIndex(Map, Set) - Method in class com.tangosol.util.filter.AlwaysFilter
-
Filter remaining keys using a Map of available indexes.
- applyIndex(Map, Set) - Method in class com.tangosol.util.filter.ArrayFilter
-
Filter remaining keys using a Map of available indexes.
- 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, 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.AllFilter
-
Apply the specified IndexAwareFilter to the specified keySet.
- 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, 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.XorFilter
-
Apply the specified IndexAwareFilter to the specified keySet.
- applySortedIndex(Set, SortedMap<Object, Set>) - Method in class com.tangosol.util.filter.BetweenFilter
-
Called by the
BetweenFilter.applyIndex(java.util.Map, java.util.Set)
method if the index corresponding to this filter's value extractor is a sorted index. - archive(Snapshot, PersistenceEnvironment<ReadBuffer>) - Method in class com.tangosol.persistence.AbstractSnapshotArchiver
- archive(Snapshot, PersistenceEnvironment<ReadBuffer>) - Method in interface com.tangosol.persistence.SnapshotArchiver
-
Archive the specified snapshot.
- ARCHIVE_SNAPSHOT_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.
- archiveInternal(Snapshot, PersistenceManager<ReadBuffer>) - Method in class com.tangosol.persistence.AbstractSnapshotArchiver
-
Internal implementation to Archive the specified snapshot.
- archiveInternal(Snapshot, PersistenceManager<ReadBuffer>) - Method in class com.tangosol.persistence.DirectorySnapshotArchiver
- ArchiverHelper - Class in com.tangosol.persistence
-
Deprecated.this API is intended for internal purposes only and will be removed in a future version of Coherence
- ArchiverHelper() - Constructor for class com.tangosol.persistence.ArchiverHelper
-
Deprecated.
- ArchiverHelper.DirectoryFileFilter - Class in com.tangosol.persistence
-
Deprecated.FileFilter implementation that only includes directories.
- archiveSnapshot(String) - Method in interface com.tangosol.persistence.PersistenceManagerMBean
-
Archive the snapshot to a centralized location.
- ArchiveSnapshotStatement(String, String) - Constructor for class com.tangosol.coherence.dslquery.statement.persistence.ArchiveSnapshotStatementBuilder.ArchiveSnapshotStatement
-
Create a new ArchiveSnapshotStatement for the snapshot and service name.
- ArchiveSnapshotStatementBuilder - Class in com.tangosol.coherence.dslquery.statement.persistence
-
An implementation of a
StatementBuilder
that parses a CohQL term tree to produce an instance of aArchiveSnapshotStatementBuilder.ArchiveSnapshotStatement
. - ArchiveSnapshotStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.statement.persistence.ArchiveSnapshotStatementBuilder
- ArchiveSnapshotStatementBuilder.ArchiveSnapshotStatement - Class in com.tangosol.coherence.dslquery.statement.persistence
-
Implementation of the CohQL "ARCHIVE SNAPSHOT" command.
- ArrayAdapter - Class in com.tangosol.run.xml
-
An ArrayAdapter supports properties of Java array types (not including arrays of primitive types).
- ArrayAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.ArrayAdapter
-
Construct a ArrayAdapter.
- ArrayCodec(Class<?>) - Constructor for class com.tangosol.io.pof.reflect.Codecs.ArrayCodec
-
Construct an ArrayCodec.
- arrayContains(ValueExtractor<T, E[]>, E) - Static method in class com.tangosol.util.Filters
-
Return a filter that tests if the extracted array contains the specified value.
- arrayContainsAll(ValueExtractor<T, E[]>, 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[]>, 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.
- 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.
- 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.
- 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.
- Arrived - Annotation Interface in com.oracle.coherence.cdi.events
-
A qualifier annotation used for any ARRIVED event.
- ARRIVED - Enum constant in enum class com.tangosol.net.events.partition.TransferEvent.Type
-
This
TransferEvent
is dispatched when a set ofentries
have been transferred to thelocal member
or restored from backup. - Arrived.Literal - Class in com.oracle.coherence.cdi.events
-
An annotation literal for the
Arrived
annotation. - as(Class<C>) - Method in interface com.tangosol.net.NamedCache
-
Request a specific type of reference to a
NamedCache
that thisNamedCache
may additionally implement or support. - as(Class<T>) - Method in class com.tangosol.config.expression.Value
-
Attempts to return the value of the
Value
coerced to a specified type. - 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.
- asBinaryEntry() - Method in interface com.tangosol.util.InvocableMap.Entry
-
Return this entry as a
BinaryEntry
. - asc(ValueExtractor) - Method in class com.tangosol.coherence.rest.util.ComparatorBuilder
-
Add comparator to this builder.
- asc(String) - 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 todouble
. - asDoubleStream() - Method in interface com.tangosol.util.stream.RemoteLongStream
-
Returns a
DoubleStream
consisting of the elements of this stream, converted todouble
. - 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 tolong
. - 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 Class in com.tangosol.util
-
An AssertionException is thrown when an assertion fails.
- AssertionException() - Constructor for exception class com.tangosol.util.AssertionException
-
Constructs a AssertionException with no detail message.
- AssertionException(String) - Constructor for exception class com.tangosol.util.AssertionException
-
Constructs a AssertionException with the specified detail message.
- Assertions - Class in com.oracle.coherence.common.base
-
Class for providing assertion functionality.
- Assertions() - Constructor for class com.oracle.coherence.common.base.Assertions
- assertNotDisposed() - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
-
Throws
IllegalStateException
if this factory has been disposed via invocation ofExtensibleConfigurableCacheFactory.dispose()
. - assertNotDisposed() - Method in class com.tangosol.net.SimpleServiceMonitor
-
Throws
IllegalStateException
if this monitor has been disposed via invocation ofSimpleServiceMonitor.dispose()
. - 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 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.
- Assigned - Annotation Interface in com.oracle.coherence.cdi.events
-
A qualifier annotation used for any ASSIGNED event.
- ASSIGNED - Enum constant in enum class com.tangosol.net.events.partition.TransferEvent.Type
-
This
TransferEvent
is dispatched when a partition has been assigned to thelocal member
. - Assigned.Literal - Class in com.oracle.coherence.cdi.events
-
An annotation literal for the
Assigned
annotation. - assignStores(Map<Integer, Object[]>, int) - Static method in class com.tangosol.persistence.GUIDHelper
-
Return a Map containing assignments of member id to stores based on the given constraints.
- Associated<T> - Interface in com.oracle.coherence.common.base
-
The Associated interface facilitates the creation of a very generic equivalence relation between different objects and allows to group them based on the equality of the "association key" object returned by the
Associated.getAssociatedKey()
method. - associatedWith(K) - Method in interface com.tangosol.util.Filter
-
Return a key associated filter based on this filter and a specified key.
- Associator - Interface in com.oracle.coherence.common.base
-
The Associator interface facilitates the creation of a very generic equivalence relation between different objects and allows to group them based on the equality of the "association key" object returned by the
Associator.getAssociatedKey(java.lang.Object)
method. - async() - Method in interface com.oracle.coherence.concurrent.atomic.AtomicBoolean
-
Return non-blocking API for this atomic value.
- async() - Method in interface com.oracle.coherence.concurrent.atomic.AtomicInteger
-
Return non-blocking API for this atomic value.
- async() - Method in interface com.oracle.coherence.concurrent.atomic.AtomicLong
-
Return non-blocking API for this atomic value.
- async() - Method in interface com.oracle.coherence.concurrent.atomic.AtomicMarkableReference
-
Return non-blocking API for this atomic reference.
- async() - Method in interface com.oracle.coherence.concurrent.atomic.AtomicReference
-
Return non-blocking API for this atomic reference.
- async() - Method in interface com.oracle.coherence.concurrent.atomic.AtomicStampedReference
-
Return non-blocking API for this atomic reference.
- async() - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicBoolean
- async() - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicInteger
- async() - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicLong
- async() - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicMarkableReference
- async() - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicReference
- async() - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicStampedReference
- async() - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicBoolean
- async() - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicInteger
- async() - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicLong
- async() - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicMarkableReference
- async() - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicReference
- async() - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicStampedReference
- async() - Method in interface com.tangosol.net.NamedCache
-
Return an asynchronous wrapper for this NamedCache.
- async(AsyncNamedMap.Option...) - Method in class com.tangosol.net.cache.NearCache
- async(AsyncNamedMap.Option...) - Method in interface com.tangosol.net.NamedCache
-
Return an asynchronous wrapper for this NamedCache.
- async(AsyncNamedMap.Option...) - Method in interface com.tangosol.net.NamedMap
-
Return an asynchronous wrapper for this NamedMap.
- AsyncAtomicBoolean - Interface in com.oracle.coherence.concurrent.atomic
-
A
boolean
value that may be updated atomically. - AsyncAtomicInteger - Interface in com.oracle.coherence.concurrent.atomic
-
A
int
value that may be updated atomically. - AsyncAtomicLong - Interface in com.oracle.coherence.concurrent.atomic
-
A
long
value that may be updated atomically. - AsyncAtomicMarkableReference<V> - Interface in com.oracle.coherence.concurrent.atomic
-
An
AtomicMarkableReference
maintains an object reference along with a mark bit, that can be updated atomically. - AsyncAtomicReference<V> - Interface in com.oracle.coherence.concurrent.atomic
-
An object reference that may be updated atomically.
- AsyncAtomicStampedReference<V> - Interface in com.oracle.coherence.concurrent.atomic
-
An
AtomicStampedReference
maintains an object reference along with an integer "stamp", that can be updated atomically. - AsyncBackupProcessor - Class in com.tangosol.coherence.config.xml.processor
-
An
ElementProcessor
for an <async-backup> Configuration. - AsyncBackupProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.AsyncBackupProcessor
- 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.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.
- 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 - Static variable in interface com.tangosol.util.MapListener
-
A flag that indicates this MapListener can be fired asynchronously.
- 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, - Class in com.tangosol.util.aggregatorP, R> -
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, - Class in com.tangosol.util.processorR> -
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.
- AsyncLocalAtomicBoolean - Class in com.oracle.coherence.concurrent.atomic
-
Local implementation of
AsyncAtomicBoolean
interface, that simply wrapsjava.util.concurrent.atomic.AtomicBoolean
instance and returns an already completed future from each method. - AsyncLocalAtomicBoolean(AtomicBoolean) - Constructor for class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicBoolean
-
Construct
LocalAtomicBoolean
instance. - AsyncLocalAtomicInteger - Class in com.oracle.coherence.concurrent.atomic
-
Local implementation of
AsyncAtomicInteger
interface, that simply wrapsjava.util.concurrent.atomic.AtomicInteger
instance and returns an already completed future from each method. - AsyncLocalAtomicInteger(AtomicInteger) - Constructor for class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicInteger
-
Construct
LocalAtomicInteger
instance. - AsyncLocalAtomicLong - Class in com.oracle.coherence.concurrent.atomic
-
Local implementation of
AsyncAtomicLong
interface, that simply wrapsjava.util.concurrent.atomic.AtomicLong
instance and returns an already completed future from each method. - AsyncLocalAtomicLong(AtomicLong) - Constructor for class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicLong
-
Construct
LocalAtomicLong
instance. - AsyncLocalAtomicMarkableReference<V> - Class in com.oracle.coherence.concurrent.atomic
-
Local implementation of
AsyncAtomicMarkableReference
interface, that simply wrapsjava.util.concurrent.atomic.AtomicMarkableReference
instance and returns an already completed future from each method. - AsyncLocalAtomicMarkableReference(AtomicMarkableReference<V>) - Constructor for class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicMarkableReference
-
Construct
AsyncLocalAtomicMarkableReference
instance. - AsyncLocalAtomicReference<V> - Class in com.oracle.coherence.concurrent.atomic
-
Local implementation of
AsyncAtomicReference
interface, that simply wrapsjava.util.concurrent.atomic.AtomicReference
instance and returns an already completed future from each method. - AsyncLocalAtomicReference(AtomicReference<V>) - Constructor for class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicReference
-
Construct
LocalAtomicReference<V>
instance. - AsyncLocalAtomicStampedReference<V> - Class in com.oracle.coherence.concurrent.atomic
-
Local implementation of
AsyncAtomicStampedReference
interface, that simply wrapsjava.util.concurrent.atomic.AtomicStampedReference
instance and returns an already completed future from each method. - AsyncLocalAtomicStampedReference(AtomicStampedReference<V>) - Constructor for class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicStampedReference
-
Construct
AsyncLocalAtomicStampedReference
instance. - AsyncNamedCache<K,
V> - Interface in com.tangosol.net -
Asynchronous
NamedCache
. - AsyncNamedMap<K,
V> - Interface in com.tangosol.net -
Asynchronous
NamedMap
. - AsyncNamedMap.Option - Interface in com.tangosol.net
-
An immutable option for creating and configuring
AsyncNamedMap
s. - AsyncNamedMap.OrderBy - Class in com.tangosol.net
-
A configuration option which determines the ordering of async operations.
- AsyncRemoteAtomicBoolean - Class in com.oracle.coherence.concurrent.atomic
-
The remote implementation of
AsyncAtomicBoolean
, backed by a CoherenceNamedMap
entry. - AsyncRemoteAtomicBoolean(AsyncNamedMap<String, AtomicBoolean>, String) - Constructor for class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicBoolean
-
Constructs a new
AsyncRemoteAtomicBoolean
. - AsyncRemoteAtomicInteger - Class in com.oracle.coherence.concurrent.atomic
-
The remote implementation of
AsyncAtomicInteger
, backed by a CoherenceNamedMap
entry. - AsyncRemoteAtomicInteger(AsyncNamedMap<String, AtomicInteger>, String) - Constructor for class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicInteger
-
Constructs a new
AsyncRemoteAtomicInteger
. - AsyncRemoteAtomicLong - Class in com.oracle.coherence.concurrent.atomic
-
The remote implementation of
AsyncAtomicLong
, backed by a CoherenceNamedMap
entry. - AsyncRemoteAtomicLong(AsyncNamedMap<String, AtomicLong>, String) - Constructor for class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicLong
-
Constructs a new
AsyncRemoteAtomicLong
. - AsyncRemoteAtomicMarkableReference<V> - Class in com.oracle.coherence.concurrent.atomic
-
The remote implementation of
AsyncAtomicMarkableReference
, backed by a CoherenceNamedMap
entry. - AsyncRemoteAtomicMarkableReference(AsyncNamedMap<String, AtomicMarkableReference<V>>, String) - Constructor for class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicMarkableReference
-
Constructs a new
AsyncRemoteAtomicMarkableReference
. - AsyncRemoteAtomicReference<V> - Class in com.oracle.coherence.concurrent.atomic
-
The remote implementation of
AsyncAtomicReference
, backed by a CoherenceNamedMap
entry. - AsyncRemoteAtomicReference(AsyncNamedMap<String, AtomicReference<V>>, String) - Constructor for class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicReference
-
Constructs a new
AsyncRemoteAtomicReference
. - AsyncRemoteAtomicStampedReference<V> - Class in com.oracle.coherence.concurrent.atomic
-
The remote implementation of
AsyncAtomicStampedReference
, backed by a CoherenceNamedMap
entry. - AsyncRemoteAtomicStampedReference(AsyncNamedMap<String, AtomicStampedReference<V>>, String) - Constructor for class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicStampedReference
-
Constructs a new
AsyncRemoteAtomicStampedReference
. - 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
- AtomicBoolean - Interface in com.oracle.coherence.concurrent.atomic
-
A
boolean
value that may be updated atomically. - AtomicBoolean.Serializer - Class in com.oracle.coherence.concurrent.atomic
-
POF serializer implementation.
- AtomicInteger - Interface in com.oracle.coherence.concurrent.atomic
-
An
int
value that may be updated atomically. - AtomicInteger.Serializer - Class in com.oracle.coherence.concurrent.atomic
-
POF serializer implementation.
- AtomicLong - Interface in com.oracle.coherence.concurrent.atomic
-
A
long
value that may be updated atomically. - AtomicLong.Serializer - Class in com.oracle.coherence.concurrent.atomic
-
POF serializer implementation.
- AtomicMarkableReference<V> - Interface in com.oracle.coherence.concurrent.atomic
-
An
AtomicMarkableReference
maintains an object reference along with a mark bit, that can be updated atomically. - AtomicMarkableReference.Serializer<V> - Class in com.oracle.coherence.concurrent.atomic
-
POF serializer implementation.
- AtomicReference<V> - Interface in com.oracle.coherence.concurrent.atomic
-
An object reference that may be updated atomically.
- AtomicReference.Serializer<V> - Class in com.oracle.coherence.concurrent.atomic
-
POF serializer implementation.
- Atomics - Class in com.oracle.coherence.concurrent.atomic
-
Factory methods for various atomic value implementations.
- Atomics.SerializableAtomicMarkableReference<V> - Class in com.oracle.coherence.concurrent.atomic
-
Extension to
AtomicMarkableReference
to allow Java serialization. - Atomics.SerializableAtomicStampedReference<V> - Class in com.oracle.coherence.concurrent.atomic
-
Extension to
AtomicStampedReference
to allow Java serialization. - AtomicStampedReference<V> - Interface in com.oracle.coherence.concurrent.atomic
-
An
AtomicStampedReference
maintains an object reference along with an integer "stamp", that can be updated atomically. - AtomicStampedReference.Serializer<V> - Class in com.oracle.coherence.concurrent.atomic
-
POF serializer implementation.
- 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.
- attemptMark(V, boolean) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicMarkableReference
-
Atomically sets the value of the mark to the given update value if the current reference is equal to the expected reference.
- attemptMark(V, boolean) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicMarkableReference
- attemptMark(V, boolean) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicMarkableReference
- attemptMark(V, boolean) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicMarkableReference
-
Atomically sets the value of the mark to the given update value if the current reference is equal to the expected reference.
- attemptMark(V, boolean) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicMarkableReference
- attemptMark(V, boolean) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicMarkableReference
- attemptStamp(V, int) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicStampedReference
-
Atomically sets the value of the stamp to the given update value if the current reference is equal to the expected reference.
- attemptStamp(V, int) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicStampedReference
- attemptStamp(V, int) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicStampedReference
- attemptStamp(V, int) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicStampedReference
-
Atomically sets the value of the stamp to the given update value if the current reference is
==
to the expected reference. - attemptStamp(V, int) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicStampedReference
- attemptStamp(V, int) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicStampedReference
- AttributeMap() - Constructor for class com.tangosol.run.xml.SimpleElement.AttributeMap
- AttributeProcessor<T> - Interface in com.tangosol.config.xml
-
An
AttributeProcessor
is responsible for processingXmlAttribute
content to return a strongly-typed value. - AuditingAuthorizer - Class in com.tangosol.net.security
-
Simple StorageAccessAuthorizer implementation that logs the authorization requests and allows operations to proceed.
- AuditingAuthorizer() - Constructor for class com.tangosol.net.security.AuditingAuthorizer
-
Construct a non-strict AuditingAuthorizer.
- AuditingAuthorizer(boolean) - Constructor for class com.tangosol.net.security.AuditingAuthorizer
-
Construct an AuditingAuthorizer.
- authorize(Subject, ClusterPermission) - Method in interface com.tangosol.net.security.Authorizer
-
Authorize the caller to perform the action specified by the permission.
- AuthorizedHostsProcessor - Class in com.tangosol.coherence.config.xml.processor
-
An
ElementProcessor
for <authorized-hosts> Configuration Elements. - AuthorizedHostsProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.AuthorizedHostsProcessor
- Authorizer - 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.
- 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
- 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.
- availablePermits() - Method in class com.oracle.coherence.concurrent.LocalSemaphore
- availablePermits() - Method in class com.oracle.coherence.concurrent.RemoteSemaphore
-
Returns the current number of permits available in this semaphore.
- availablePermits() - Method in interface com.oracle.coherence.concurrent.Semaphore
-
Returns the current number of permits available in this semaphore.
- 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. - average(Filter<?>, Remote.ToBigDecimalFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
-
Return the average of the specified function.
- average(Filter<?>, Remote.ToBigDecimalFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepository
-
Return the average of the specified function.
- average(Filter<?>, Remote.ToDoubleFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
-
Return the average of the specified function.
- average(Filter<?>, Remote.ToDoubleFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepository
-
Return the average of the specified function.
- average(Filter<?>, Remote.ToIntFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
-
Return the average of the specified function.
- average(Filter<?>, Remote.ToIntFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepository
-
Return the average of the specified function.
- average(Filter<?>, Remote.ToLongFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
-
Return the average of the specified function.
- average(Filter<?>, Remote.ToLongFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepository
-
Return the average of the specified function.
- average(Remote.ToBigDecimalFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
-
Return the average of the specified function.
- average(Remote.ToBigDecimalFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepository
-
Return the average of the specified function.
- average(Remote.ToBigDecimalFunction<? super T>) - Static method in class com.tangosol.util.Aggregators
-
Return an aggregator that calculates an average of the BigDecimal values extracted from a set of entries in a Map.
- average(Remote.ToDoubleFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
-
Return the average of the specified function.
- average(Remote.ToDoubleFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepository
-
Return the average of the specified function.
- average(Remote.ToDoubleFunction<? super T>) - Static method in class com.tangosol.util.Aggregators
-
Return an aggregator that calculates an average of the double values extracted from a set of entries in a Map.
- average(Remote.ToIntFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
-
Return the average of the specified function.
- average(Remote.ToIntFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepository
-
Return the average of the specified function.
- average(Remote.ToIntFunction<? super T>) - Static method in class com.tangosol.util.Aggregators
-
Return an aggregator that calculates an average of the int values extracted from a set of entries in a Map.
- average(Remote.ToLongFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
-
Return the average of the specified function.
- average(Remote.ToLongFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepository
-
Return the average of the specified function.
- average(Remote.ToLongFunction<? super T>) - Static method in class com.tangosol.util.Aggregators
-
Return an aggregator that calculates an average of the long values extracted from a set of entries in a Map.
- 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.
- averagingDouble(ValueExtractor<? super U, ? extends Number>) - Static method in class com.tangosol.util.stream.RemoteCollectors
-
Returns a
Collector
that produces the arithmetic mean of a double-valued function applied to the input elements. - averagingInt(ValueExtractor<? super U, ? extends Number>) - Static method in class com.tangosol.util.stream.RemoteCollectors
-
Returns a
Collector
that produces the arithmetic mean of an integer-valued function applied to the input elements. - averagingLong(ValueExtractor<? super U, ? extends Number>) - Static method in class com.tangosol.util.stream.RemoteCollectors
-
Returns a
Collector
that produces the arithmetic mean of a long-valued function applied to the input elements. - await() - Method in interface com.oracle.coherence.common.base.Notifier
-
Wait for a notification.
- await() - Method in interface com.oracle.coherence.concurrent.CountDownLatch
-
Causes the current thread to wait until the latch has counted down to zero, unless the thread is interrupted.
- await() - Method in class com.oracle.coherence.concurrent.LocalCountDownLatch
- await() - Method in class com.oracle.coherence.concurrent.RemoteCountDownLatch
-
Causes the current thread to wait until the latch has counted down to zero, unless the thread is interrupted.
- await(long) - Method in class com.oracle.coherence.common.base.ConcurrentNotifier
- await(long) - Method in interface com.oracle.coherence.common.base.Notifier
-
Wait for a notification.
- await(long) - Method in class com.oracle.coherence.common.base.SingleWaiterCooperativeNotifier
- await(long) - Method in class com.oracle.coherence.common.base.SingleWaiterMultiNotifier
- await(long, TimeUnit) - Method in interface com.oracle.coherence.concurrent.CountDownLatch
-
Causes the current thread to wait until the latch has counted down to zero, unless the thread is interrupted, or the specified waiting time elapses.
- await(long, TimeUnit) - Method in class com.oracle.coherence.concurrent.LocalCountDownLatch
- await(long, TimeUnit) - Method in class com.oracle.coherence.concurrent.RemoteCountDownLatch
-
Causes the current thread to wait until the latch has counted down to zero, unless the thread is interrupted, or the specified waiting time elapses.
- await(Condition) - Static method in class com.oracle.coherence.common.base.Blocking
-
Await for the Condition to be signaled while still respecting the calling thread's
timeout
. - await(Condition, long) - Static method in class com.oracle.coherence.common.base.Blocking
-
Await for the Condition to be signaled while still respecting the calling thread's
timeout
. - await(Condition, long, TimeUnit) - Static method in class com.oracle.coherence.common.base.Blocking
-
Await for the Condition to be signaled while still respecting the calling thread's
timeout
. - awaitTermination(long, TimeUnit) - Method in interface com.oracle.coherence.concurrent.executor.RemoteExecutor
-
Blocks until all tasks have completed execution after a shutdown request, or the timeout occurs, or the current thread is interrupted, whichever happens first.
- azzert() - Static method in class com.oracle.coherence.common.base.Assertions
-
Definite assertion failure.
- azzert() - Static method in class com.tangosol.util.Base
-
Definite assertion failure.
- azzert(boolean) - Static method in class com.oracle.coherence.common.base.Assertions
-
Test an assertion.
- azzert(boolean) - Static method in class com.tangosol.util.Base
-
Test an assertion.
- azzert(boolean, String) - Static method in class com.oracle.coherence.common.base.Assertions
-
Test an assertion, and print the specified message if the assertion fails.
- 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.oracle.coherence.common.base.Assertions
-
Throw an assertion exception.
- azzertFailed(String) - Static method in class com.tangosol.util.Base
-
Throw an assertion exception.
B
- BACKING_MAP - Static variable in class com.tangosol.net.security.LocalPermission
-
"BackingMapManagerContext.getBackingMap" permission.
- BackingMapBinaryEntry - Class in com.tangosol.net.cache
-
An implementation of the BinaryEntry interface that is based on specified binary key, binary value and BackingMapManagerContext.
- BackingMapBinaryEntry(Binary, Binary, Binary, long, BackingMapManagerContext) - Constructor for class com.tangosol.net.cache.BackingMapBinaryEntry
-
Construct a BackingMapBinaryEntry with the specified binary key, values and BackingMapManagerContext.
- BackingMapBinaryEntry(Binary, Binary, Binary, BackingMapManagerContext) - Constructor for class com.tangosol.net.cache.BackingMapBinaryEntry
-
Construct a BackingMapBinaryEntry with the specified binary key, values and BackingMapManagerContext.
- BackingMapContext - Interface in com.tangosol.net
-
The BackingMapContext provides an execution context to server side agents such as
EntryProcessors
andEntryAggregators
. - BackingMapManager - Interface in com.tangosol.net
-
A callback interface used by CacheService implementations.
- BackingMapManagerBuilder - Interface in com.tangosol.coherence.config.builder
-
A
BackingMapManagerBuilder
realizesBackingMapManager
s. - BackingMapManagerContext - Interface in com.tangosol.net
-
The BackingMapManager context is used by the CacheService to pass information to the BackingMapManager during the service initialization.
- BackingMapScheme - Class in com.tangosol.coherence.config.scheme
-
The
BackingMapScheme
class is responsible for building a fully configured instance of a backing map. - BackingMapScheme() - Constructor for class com.tangosol.coherence.config.scheme.BackingMapScheme
- BackingMapSchemeProcessor - Class in com.tangosol.coherence.config.xml.processor
-
A BackingMapSchemeProcessor is responsible for processing a backing-map-scheme
XmlElement
to produce aBackingMapScheme
. - BackingMapSchemeProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.BackingMapSchemeProcessor
- Backlog - Annotation Interface in com.oracle.coherence.cdi.events
-
A qualifier annotation used for any BACKLOG event.
- Backlog.Literal - Class in com.oracle.coherence.cdi.events
-
An annotation literal for the
Backlog
annotation. - Backlog.Type - Enum Class in com.oracle.coherence.cdi.events
-
The backlog event type.
- BackMapListener() - Constructor for class com.tangosol.net.cache.OverflowMap.BackMapListener
- BackServiceListener() - Constructor for class com.tangosol.net.cache.NearCache.BackServiceListener
- BackupConfig() - Constructor for class com.tangosol.coherence.config.scheme.DistributedScheme.BackupConfig
- BackupMapConfig - Interface in com.tangosol.coherence.config.scheme
-
The
BackupMapConfig
interface exposes the configuration needed to create an instance of a backup map, which is used by the distributed cache to store backup data. - BackupStatement(String, String) - Constructor for class com.tangosol.coherence.dslquery.statement.BackupStatementBuilder.BackupStatement
-
Construct a BackupStatement that backs the specified cache up to the specified file.
- BackupStatementBuilder - Class in com.tangosol.coherence.dslquery.statement
-
An implementation of a
StatementBuilder
that parses a CohQL term tree to produce an instance of aBackupStatementBuilder.BackupStatement
. - BackupStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.statement.BackupStatementBuilder
- BackupStatementBuilder.BackupStatement - Class in com.tangosol.coherence.dslquery.statement
-
Implementation of the CohQL "BACKUP" command.
- BackupStrength(int, Set, Set, Set) - Constructor for class com.tangosol.net.partition.SimpleAssignmentStrategy.BackupStrength
-
Construct a BackupStrength of the specified strength.
- balance - Variable in class com.tangosol.util.AbstractSparseArray.Node
-
The AVL balance factor of the sub-tree.
- balancedInsertion(AbstractSparseArray.Node<V>, AbstractSparseArray.Node<V>) - Method in class com.tangosol.util.AbstractSparseArray
-
Insert a node into a tree and rebalance.
- balancePostRemove(AbstractSparseArray.Node<V>, boolean) - Method in class com.tangosol.util.AbstractSparseArray
-
Rebalance the tree following the removal of a node.
- Bar(Thread) - Constructor for class com.tangosol.util.ThreadGateLite.Bar
-
Construct a Bar for the specified thread.
- barEntry(long) - Method in class com.tangosol.util.ThreadGateLite
-
Bar entry to the thread gate by other threads, but do not wait for the gate to close.
- barEntry(long) - Method in class com.tangosol.util.WrapperReentrantGate
-
Bar entry to the thread gate by other threads, but do not wait for the gate to close.
- Base - Class in com.tangosol.util
-
Base class for providing standard functionality.
- Base() - Constructor for class com.tangosol.util.Base
- BASE - Static variable in annotation interface com.tangosol.net.management.annotation.MetricsScope
-
The full descriptor value to use for base scoped metrics.
- Base.LoggingWriter - Class in com.tangosol.util
-
Inner class for over-riding the destination of log(), out() and err() calls.
- BASE64_ALPHABET - Static variable in class com.tangosol.io.Base64OutputStream
-
Base64 encodes into this "alphabet" of 64 characters.
- BASE64_LF - Static variable in class com.tangosol.io.Base64OutputStream
-
The Base64 line feed character.
- BASE64_PAD - Static variable in class com.tangosol.io.Base64OutputStream
-
The Base64 padding character.
- Base64InputStream - Class in com.tangosol.io
-
Reads binary data from a Reader using IETF RFC 2045 Base64 Content Transfer Encoding.
- Base64InputStream(Reader) - Constructor for class com.tangosol.io.Base64InputStream
-
Construct a Base64InputStream on a Reader object.
- Base64OutputStream - Class in com.tangosol.io
-
Writes binary data into a Writer using IETF RFC 2045 Base64 Content Transfer Encoding.
- Base64OutputStream(Writer) - Constructor for class com.tangosol.io.Base64OutputStream
-
Construct a Base64OutputStream on a Writer object.
- Base64OutputStream(Writer, boolean) - Constructor for class com.tangosol.io.Base64OutputStream
-
Construct a Base64OutputStream on a Writer object and specifying a line-break option.
- BaseGrpcCacheScheme<S> - Class in com.tangosol.coherence.config.scheme
-
The
BaseGrpcCacheScheme
is responsible for building a remote gRPC cache service. - BaseGrpcCacheScheme() - Constructor for class com.tangosol.coherence.config.scheme.BaseGrpcCacheScheme
-
Constructs a
BaseGrpcCacheScheme
. - BaseGrpcScheme<T,
S> - Class in com.tangosol.coherence.config.scheme -
The
BaseGrpcScheme
is responsible for building a remote gRPC service. - BaseGrpcScheme(T) - Constructor for class com.tangosol.coherence.config.scheme.BaseGrpcScheme
-
Constructs a
BaseGrpcScheme
. - BaseGrpcServiceImpl - Class in com.oracle.coherence.grpc.proxy
-
A base class for gRPC services.
- BaseGrpcServiceImpl(BaseGrpcServiceImpl.Dependencies, String, String) - Constructor for class com.oracle.coherence.grpc.proxy.BaseGrpcServiceImpl
-
Create a
BaseGrpcServiceImpl
. - BaseGrpcServiceImpl.DefaultDependencies - Class in com.oracle.coherence.grpc.proxy
-
The default
BaseGrpcServiceImpl.Dependencies
implementation. - BaseGrpcServiceImpl.Dependencies - Interface in com.oracle.coherence.grpc.proxy
-
The dependencies to configure a
BaseGrpcServiceImpl
. - BaseOperator<F> - Class in com.tangosol.coherence.dslquery.operator
-
A base class for CohQL Operator implementations.
- BaseOperator(String, boolean, String...) - Constructor for class com.tangosol.coherence.dslquery.operator.BaseOperator
-
Create an instance of a BaseOperator with the specified symbol, conditional flag and aliases.
- BaseRemoteStream<T,
S> - Interface in com.tangosol.util.stream -
An extension of
BaseStream
that adds support for theRemotePipeline
retrieval. - BaseToken - Class in com.tangosol.coherence.dsltools.base
-
BaseToken is the abstract base class for all tokens processed by the low level BaseTokenScanner.
- BaseToken() - Constructor for class com.tangosol.coherence.dsltools.base.BaseToken
- BaseTokenScanner - Class in com.tangosol.coherence.dsltools.base
-
BaseTokenScanner gives clients a streaming api that returns a next BaseToken by processing either a java.lang.String or a java.io.Reader.
- BaseTokenScanner(Reader) - Constructor for class com.tangosol.coherence.dsltools.base.BaseTokenScanner
-
Construct a new BaseTokenScanner with the given Reader.
- BaseTokenScanner(String) - Constructor for class com.tangosol.coherence.dsltools.base.BaseTokenScanner
-
Construct a new BaseTokenScanner with the given String.
- BaseTokenScannerException - Exception Class in com.tangosol.coherence.dsltools.base
-
BaseTokenScannerExpression is the RuntimeException thrown by the BaseTokenScanner when expectations are not met.
- BaseTokenScannerException() - Constructor for exception class com.tangosol.coherence.dsltools.base.BaseTokenScannerException
-
Construct a new BaseTokenException.
- BaseTokenScannerException(String) - Constructor for exception class com.tangosol.coherence.dsltools.base.BaseTokenScannerException
-
Construct a new BaseTokenException with the given string.
- BaseTokenStream - Class in com.tangosol.coherence.dsltools.base
-
Since BaseTokens can nest, BaseTokenStream creates for clients a utility interface that allows streaming (atEnd(), next()) over a CompoundBaseToken.
- BaseTokenStream(CompoundBaseToken) - Constructor for class com.tangosol.coherence.dsltools.base.BaseTokenStream
-
Constructor a new BaseTokenStream on the CompoundBaseToken.
- BatchTask(Object, Collector<Object>, Object) - Constructor for class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore.BatchTask
-
Create a new BatchTask.
- BatchTasks(List<Runnable>) - Constructor for class com.tangosol.persistence.AbstractPersistenceManager.BatchTasks
-
Construct a BatchTasks instance with the given list of tasks to execute.
- BdbStoreManagerBuilder - Class in com.tangosol.coherence.config.builder.storemanager
-
The BdbStoreManagerBuilder class builds an instance of a BerkeleyDBBinaryStoreManager.
- BdbStoreManagerBuilder() - Constructor for class com.tangosol.coherence.config.builder.storemanager.BdbStoreManagerBuilder
- BEAN_ACCESSOR_PREFIXES - Static variable in class com.tangosol.util.extractor.UniversalExtractor
-
JavaBean accessor prefixes.
- BEAN_MODIFIER_PREFIX - Static variable in class com.tangosol.util.extractor.UniversalUpdater
-
JavaBean property modifier prefix.
- BeanBuilder - Class in com.oracle.coherence.cdi.server
-
Element processor for
<cdi:bean>
XML element. - BeanInfo(Class, XmlElement) - Constructor for class com.tangosol.run.xml.XmlBean.BeanInfo
-
Construct a BeanInfo.
- beanManager(BeanManager) - Method in class com.oracle.coherence.cdi.SerializerProducer.Builder
-
Set the Coherence
BeanManager
that theSerializerProducer
will use to discover namedSerializer
s beans. - BeanProcessor - Class in com.oracle.coherence.cdi.server
-
Element processor for
<cdi:bean/>
XML element. - BeanProcessor() - Constructor for class com.oracle.coherence.cdi.server.BeanProcessor
- begin() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
-
Begin a new sequence of mutating operations that should be committed to the store as an atomic unit.
- begin() - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistentStore
-
Begin a new sequence of mutating operations that should be committed to the store as an atomic unit.
- begin() - Method in class com.tangosol.util.NullImplementation.NullPersistentStore
- begin() - Method in interface com.tangosol.util.TransactionMap
-
Start a transaction for this TransactionMap.
- begin(int, String) - Method in class com.tangosol.io.pof.LoggingPofHandler
-
Begin a complex data structure, such as a user type or a collection.
- begin(Collector<Object>, Object) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
-
Begin a new sequence of mutating operations that should be committed to the store asynchronously as an atomic unit.
- begin(Collector<Object>, Object) - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistentStore
-
Begin a new sequence of mutating operations that should be committed to the store asynchronously as an atomic unit.
- begin(Collector<Object>, Object) - Method in class com.tangosol.util.NullImplementation.NullPersistentStore
- beginArray(int, int) - Method in class com.tangosol.io.pof.AbstractPofHandler
-
Report that an array of values has been encountered in the POF stream.
- beginArray(int, int) - Method in class com.tangosol.io.pof.DuplexingPofHandler
-
Report that an array of values has been encountered in the POF stream.
- beginArray(int, int) - Method in class com.tangosol.io.pof.LoggingPofHandler
-
Report that an array of values has been encountered in the POF stream.
- beginArray(int, int) - Method in interface com.tangosol.io.pof.PofHandler
-
Report that an array of values has been encountered in the POF stream.
- beginArray(int, int) - Method in class com.tangosol.io.pof.ValidatingPofHandler
-
Report that an array of values has been encountered in the POF stream.
- beginArray(int, int) - Method in class com.tangosol.io.pof.WritingPofHandler
-
Report that an array of values has been encountered in the POF stream.
- beginArray(int, int) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
-
Report that an array of values has been encountered in the POF stream.
- beginBulkKeyProcess(Object[]) - Method in class com.tangosol.net.cache.SimpleOverflowMap
-
Begin key-level procecessing for any number of keys.
- beginCollection(int, int) - Method in class com.tangosol.io.pof.AbstractPofHandler
-
Report that a collection of values has been encountered in the POF stream.
- beginCollection(int, int) - Method in class com.tangosol.io.pof.DuplexingPofHandler
-
Report that a collection of values has been encountered in the POF stream.
- beginCollection(int, int) - Method in class com.tangosol.io.pof.LoggingPofHandler
-
Report that a collection of values has been encountered in the POF stream.
- beginCollection(int, int) - Method in interface com.tangosol.io.pof.PofHandler
-
Report that a collection of values has been encountered in the POF stream.
- beginCollection(int, int) - Method in class com.tangosol.io.pof.ValidatingPofHandler
-
Report that a collection of values has been encountered in the POF stream.
- beginCollection(int, int) - Method in class com.tangosol.io.pof.WritingPofHandler
-
Report that a collection of values has been encountered in the POF stream.
- beginCollection(int, int) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
-
Report that a collection of values has been encountered in the POF stream.
- beginInternal() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
-
Begin a sequence of mutating operations that should be committed atomically and return a token that represents the atomic unit.
- beginKeyProcess(Object) - Method in class com.tangosol.net.cache.OverflowMap
-
Block until a key is available for processing, and return the Status object for that key.
- beginKeyProcess(Object) - Method in class com.tangosol.net.cache.SimpleOverflowMap
-
Block until a key is available for processing, and return the Status object for that key.
- beginMap(int, int) - Method in class com.tangosol.io.pof.AbstractPofHandler
-
Report that a map of key/value pairs has been encountered in the POF stream.
- beginMap(int, int) - Method in class com.tangosol.io.pof.DuplexingPofHandler
-
Report that a map of key/value pairs has been encountered in the POF stream.
- beginMap(int, int) - Method in class com.tangosol.io.pof.LoggingPofHandler
-
Report that a map of key/value pairs has been encountered in the POF stream.
- beginMap(int, int) - Method in interface com.tangosol.io.pof.PofHandler
-
Report that a map of key/value pairs has been encountered in the POF stream.
- beginMap(int, int) - Method in class com.tangosol.io.pof.ValidatingPofHandler
-
Report that a map of key/value pairs has been encountered in the POF stream.
- beginMap(int, int) - Method in class com.tangosol.io.pof.WritingPofHandler
-
Report that a map of key/value pairs has been encountered in the POF stream.
- beginMap(int, int) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
-
Report that a map of key/value pairs has been encountered in the POF stream.
- beginMapProcess() - Method in class com.tangosol.net.cache.OverflowMap
-
Block until this thread has exclusive access to perform operations against the OverflowMap.
- beginMapProcess() - Method in class com.tangosol.net.cache.SimpleOverflowMap
-
Block until this thread has exclusive access to perform operations against the OverflowMap.
- beginProperty(int) - Method in class com.tangosol.io.pof.PofBufferWriter
-
Report that a POF property is about to be written to the POF stream.
- beginProperty(int) - Method in class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
-
Report that a POF property is about to be written to the POF stream.
- beginSparseArray(int, int) - Method in class com.tangosol.io.pof.AbstractPofHandler
-
Report that a sparse array of values has been encountered in the POF stream.
- beginSparseArray(int, int) - Method in class com.tangosol.io.pof.DuplexingPofHandler
-
Report that a sparse array of values has been encountered in the POF stream.
- beginSparseArray(int, int) - Method in class com.tangosol.io.pof.LoggingPofHandler
-
Report that a sparse array of values has been encountered in the POF stream.
- beginSparseArray(int, int) - Method in interface com.tangosol.io.pof.PofHandler
-
Report that a sparse array of values has been encountered in the POF stream.
- beginSparseArray(int, int) - Method in class com.tangosol.io.pof.ValidatingPofHandler
-
Report that a sparse array of values has been encountered in the POF stream.
- beginSparseArray(int, int) - Method in class com.tangosol.io.pof.WritingPofHandler
-
Report that a sparse array of values has been encountered in the POF stream.
- beginSparseArray(int, int) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
-
Report that a sparse array of values has been encountered in the POF stream.
- beginUniformArray(int, int, int) - Method in class com.tangosol.io.pof.AbstractPofHandler
-
Report that a uniform array of values has been encountered in the POF stream.
- beginUniformArray(int, int, int) - Method in class com.tangosol.io.pof.DuplexingPofHandler
-
Report that a uniform array of values has been encountered in the POF stream.
- beginUniformArray(int, int, int) - Method in class com.tangosol.io.pof.LoggingPofHandler
-
Report that a uniform array of values has been encountered in the POF stream.
- beginUniformArray(int, int, int) - Method in interface com.tangosol.io.pof.PofHandler
-
Report that a uniform array of values has been encountered in the POF stream.
- beginUniformArray(int, int, int) - Method in class com.tangosol.io.pof.ValidatingPofHandler
-
Report that a uniform array of values has been encountered in the POF stream.
- beginUniformArray(int, int, int) - Method in class com.tangosol.io.pof.WritingPofHandler
-
Report that a uniform array of values has been encountered in the POF stream.
- beginUniformArray(int, int, int) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
-
Report that a uniform array of values has been encountered in the POF stream.
- beginUniformCollection(int, int, int) - Method in class com.tangosol.io.pof.AbstractPofHandler
-
Report that a uniform collection of values has been encountered in the POF stream.
- beginUniformCollection(int, int, int) - Method in class com.tangosol.io.pof.DuplexingPofHandler
-
Report that a uniform collection of values has been encountered in the POF stream.
- beginUniformCollection(int, int, int) - Method in class com.tangosol.io.pof.LoggingPofHandler
-
Report that a uniform collection of values has been encountered in the POF stream.
- beginUniformCollection(int, int, int) - Method in interface com.tangosol.io.pof.PofHandler
-
Report that a uniform collection of values has been encountered in the POF stream.
- beginUniformCollection(int, int, int) - Method in class com.tangosol.io.pof.ValidatingPofHandler
-
Report that a uniform collection of values has been encountered in the POF stream.
- beginUniformCollection(int, int, int) - Method in class com.tangosol.io.pof.WritingPofHandler
-
Report that a uniform collection of values has been encountered in the POF stream.
- beginUniformCollection(int, int, int) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
-
Report that a uniform collection of values has been encountered in the POF stream.
- beginUniformKeysMap(int, int, int) - Method in class com.tangosol.io.pof.AbstractPofHandler
-
Report that a map of key/value pairs (with the keys being of a uniform type) has been encountered in the POF stream.
- beginUniformKeysMap(int, int, int) - Method in class com.tangosol.io.pof.DuplexingPofHandler
-
Report that a map of key/value pairs (with the keys being of a uniform type) has been encountered in the POF stream.
- beginUniformKeysMap(int, int, int) - Method in class com.tangosol.io.pof.LoggingPofHandler
-
Report that a map of key/value pairs (with the keys being of a uniform type) has been encountered in the POF stream.
- beginUniformKeysMap(int, int, int) - Method in interface com.tangosol.io.pof.PofHandler
-
Report that a map of key/value pairs (with the keys being of a uniform type) has been encountered in the POF stream.
- beginUniformKeysMap(int, int, int) - Method in class com.tangosol.io.pof.ValidatingPofHandler
-
Report that a map of key/value pairs (with the keys being of a uniform type) has been encountered in the POF stream.
- beginUniformKeysMap(int, int, int) - Method in class com.tangosol.io.pof.WritingPofHandler
-
Report that a map of key/value pairs (with the keys being of a uniform type) has been encountered in the POF stream.
- beginUniformKeysMap(int, int, int) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
-
Report that a map of key/value pairs (with the keys being of a uniform type) has been encountered in the POF stream.
- beginUniformMap(int, int, int, int) - Method in class com.tangosol.io.pof.AbstractPofHandler
-
Report that a map of key/value pairs (with the keys being of a uniform type and the values being of a uniform type) has been encountered in the POF stream.
- beginUniformMap(int, int, int, int) - Method in class com.tangosol.io.pof.DuplexingPofHandler
-
Report that a map of key/value pairs (with the keys being of a uniform type and the values being of a uniform type) has been encountered in the POF stream.
- beginUniformMap(int, int, int, int) - Method in class com.tangosol.io.pof.LoggingPofHandler
-
Report that a map of key/value pairs (with the keys being of a uniform type and the values being of a uniform type) has been encountered in the POF stream.
- beginUniformMap(int, int, int, int) - Method in interface com.tangosol.io.pof.PofHandler
-
Report that a map of key/value pairs (with the keys being of a uniform type and the values being of a uniform type) has been encountered in the POF stream.
- beginUniformMap(int, int, int, int) - Method in class com.tangosol.io.pof.ValidatingPofHandler
-
Report that a map of key/value pairs (with the keys being of a uniform type and the values being of a uniform type) has been encountered in the POF stream.
- beginUniformMap(int, int, int, int) - Method in class com.tangosol.io.pof.WritingPofHandler
-
Report that a map of key/value pairs (with the keys being of a uniform type and the values being of a uniform type) has been encountered in the POF stream.
- beginUniformMap(int, int, int, int) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
-
Report that a map of key/value pairs (with the keys being of a uniform type and the values being of a uniform type) has been encountered in the POF stream.
- beginUniformSparseArray(int, int, int) - Method in class com.tangosol.io.pof.AbstractPofHandler
-
Report that a uniform sparse array of values has been encountered in the POF stream.
- beginUniformSparseArray(int, int, int) - Method in class com.tangosol.io.pof.DuplexingPofHandler
-
Report that a uniform sparse array of values has been encountered in the POF stream.
- beginUniformSparseArray(int, int, int) - Method in class com.tangosol.io.pof.LoggingPofHandler
-
Report that a uniform sparse array of values has been encountered in the POF stream.
- beginUniformSparseArray(int, int, int) - Method in interface com.tangosol.io.pof.PofHandler
-
Report that a uniform sparse array of values has been encountered in the POF stream.
- beginUniformSparseArray(int, int, int) - Method in class com.tangosol.io.pof.ValidatingPofHandler
-
Report that a uniform sparse array of values has been encountered in the POF stream.
- beginUniformSparseArray(int, int, int) - Method in class com.tangosol.io.pof.WritingPofHandler
-
Report that a uniform sparse array of values has been encountered in the POF stream.
- beginUniformSparseArray(int, int, int) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
-
Report that a uniform sparse array of values has been encountered in the POF stream.
- beginUserType(int, int, int) - Method in class com.tangosol.io.pof.AbstractPofHandler
-
Report that a value of a "user type" has been encountered in the POF stream.
- beginUserType(int, int, int) - Method in class com.tangosol.io.pof.DuplexingPofHandler
-
Report that a value of a "user type" has been encountered in the POF stream.
- beginUserType(int, int, int) - Method in class com.tangosol.io.pof.LoggingPofHandler
-
Report that a value of a "user type" has been encountered in the POF stream.
- beginUserType(int, int, int) - Method in interface com.tangosol.io.pof.PofHandler
-
Report that a value of a "user type" has been encountered in the POF stream.
- beginUserType(int, int, int) - Method in class com.tangosol.io.pof.ValidatingPofHandler
-
Report that a value of a "user type" has been encountered in the POF stream.
- beginUserType(int, int, int) - Method in class com.tangosol.io.pof.WritingPofHandler
-
Report that a value of a "user type" has been encountered in the POF stream.
- beginUserType(int, int, int) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
-
Report that a value of a "user type" has been encountered in the POF stream.
- beginUserType(int, int, int, int) - Method in class com.tangosol.io.pof.WritingPofHandler
-
Report that a value of a "user type" has been encountered in the POF stream.
- BerkeleyDBBinaryStore - Class in com.tangosol.io.bdb
-
An implementation of the BinaryStore interface using Sleepycat Berkeley DB Java Edition.
- BerkeleyDBBinaryStore(String, DatabaseFactory) - Constructor for class com.tangosol.io.bdb.BerkeleyDBBinaryStore
-
Create a new Berkeley DB BinaryStore using the supplied DatabaseFactory.
- BerkeleyDBBinaryStore.DatabaseHolder - Class in com.tangosol.io.bdb
-
The DatabaseHolder class is used as a wrapper around a Berkeley DB Database object.
- BerkeleyDBBinaryStoreManager - Class in com.tangosol.io.bdb
-
An implementation of the BinaryStoreManager interface using Sleepycat Berkeley DB Java Edition.
- BerkeleyDBBinaryStoreManager() - Constructor for class com.tangosol.io.bdb.BerkeleyDBBinaryStoreManager
-
Default constructor.
- BerkeleyDBBinaryStoreManager(File, String) - Constructor for class com.tangosol.io.bdb.BerkeleyDBBinaryStoreManager
-
Construct a Berkeley DB BinaryStoreManager for the specified directory.
- between(ValueExtractor<T, ? extends E>, E, E) - Static method in class com.tangosol.util.Filters
-
Return a filter that tests if the extracted value is between the specified values (inclusive).
- BetweenFilter<T,
E> - Class in com.tangosol.util.filter -
Filter which compares the result of a method invocation with a value for "Between" condition.
- BetweenFilter() - Constructor for class com.tangosol.util.filter.BetweenFilter
-
Default constructor (necessary for serialization).
- BetweenFilter(ValueExtractor<? super T, ? extends E>, E, E) - Constructor for class com.tangosol.util.filter.BetweenFilter
-
Construct a BetweenFilter for testing "Between" condition.
- BetweenFilter(ValueExtractor<? super T, ? extends E>, E, E, boolean, boolean) - Constructor for class com.tangosol.util.filter.BetweenFilter
-
Construct a BetweenFilter for testing "Between" condition.
- BetweenFilter(String, E, E) - Constructor for class com.tangosol.util.filter.BetweenFilter
-
Construct a BetweenFilter for testing "Between" condition.
- BetweenFilter(String, E, E, boolean, boolean) - Constructor for class com.tangosol.util.filter.BetweenFilter
-
Construct a BetweenFilter for testing "Between" condition.
- BetweenOperator - Class in com.tangosol.coherence.dslquery.operator
-
An operator representing the "between" conditional operator.
- BetweenOperator() - Constructor for class com.tangosol.coherence.dslquery.operator.BetweenOperator
-
Construct a BetweenOperator.
- BetweenOPToken - Class in com.tangosol.coherence.dsltools.precedence
-
BetweenOPToken is used to parse a SQl like between statment.
- BetweenOPToken(String, int) - Constructor for class com.tangosol.coherence.dsltools.precedence.BetweenOPToken
-
Construct a new BetweenOPToken with the given parameters.
- BetweenOPToken(String, int, String) - Constructor for class com.tangosol.coherence.dsltools.precedence.BetweenOPToken
-
Construct a new BetweenOPToken with the given parameters.
- biConsumer(Remote.BiConsumer<T, U>) - Static method in class com.tangosol.util.function.Remote
-
Capture serializable BiConsumer.
- biFunction(Remote.BiFunction<T, U, R>) - Static method in class com.tangosol.util.function.Remote
-
Capture serializable BiFunction.
- BIG_DECIMAL_AVERAGE_FUNCTION_BUILDER - Static variable in class com.tangosol.coherence.dslquery.function.FunctionBuilders
-
This builder will realize instances of the
BigDecimalAverage
aggregator. - BIG_DECIMAL_MAX_FUNCTION_BUILDER - Static variable in class com.tangosol.coherence.dslquery.function.FunctionBuilders
-
This builder will realize instances of the
BigDecimalMax
aggregator. - BIG_DECIMAL_MIN_FUNCTION_BUILDER - Static variable in class com.tangosol.coherence.dslquery.function.FunctionBuilders
-
This builder will realize instances of the
BigDecimalMin
aggregator. - BIG_DECIMAL_SUM_FUNCTION_BUILDER - Static variable in class com.tangosol.coherence.dslquery.function.FunctionBuilders
-
This builder will realize instances of the
BigDecimalSum
aggregator. - BIGDECIMAL_ZERO - Static variable in class com.tangosol.io.pof.PofHelper
-
The default BigDecimal value.
- BigDecimalAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.SimpleAdapter.BigDecimalAdapter
-
Construct a SimpleAdapter.
- bigDecimalAverage(ValueExtractor<? super T, ? extends Number>) - Static method in class com.tangosol.util.Aggregators
-
Return an aggregator that calculates a average of the numeric values extracted from a set of entries in a Map.
- bigDecimalAverage(String) - Static method in class com.tangosol.util.Aggregators
-
Return an aggregator that calculates a average of the numeric values extracted from a set of entries in a Map.
- BigDecimalAverage<T> - Class in com.tangosol.util.aggregator
-
Calculates an average for values of any numeric type extracted from a set of entries in a Map in a form of a
BigDecimal
value. - BigDecimalAverage() - Constructor for class com.tangosol.util.aggregator.BigDecimalAverage
-
Default constructor (necessary for the ExternalizableLite interface).
- BigDecimalAverage(ValueExtractor<? super T, ? extends Number>) - Constructor for class com.tangosol.util.aggregator.BigDecimalAverage
-
Construct a BigDecimalAverage aggregator.
- BigDecimalAverage(String) - Constructor for class com.tangosol.util.aggregator.BigDecimalAverage
-
Construct an BigDecimalAverage object.
- bigDecimalMax(ValueExtractor<? super T, ? extends Number>) - Static method in class com.tangosol.util.Aggregators
-
Return an aggregator that calculates a maximum of the numeric values extracted from a set of entries in a Map.
- bigDecimalMax(String) - Static method in class com.tangosol.util.Aggregators
-
Return an aggregator that calculates a maximum of the numeric values extracted from a set of entries in a Map.
- BigDecimalMax<T> - Class in com.tangosol.util.aggregator
-
Calculates a maximum of numeric values extracted from a set of entries in a Map in a form of a
BigDecimal
value. - BigDecimalMax() - Constructor for class com.tangosol.util.aggregator.BigDecimalMax
-
Default constructor (necessary for the ExternalizableLite interface).
- BigDecimalMax(ValueExtractor<? super T, ? extends Number>) - Constructor for class com.tangosol.util.aggregator.BigDecimalMax
-
Construct a BigDecimalMax aggregator.
- BigDecimalMax(String) - Constructor for class com.tangosol.util.aggregator.BigDecimalMax
-
Construct a BigDecimalMax aggregator.
- bigDecimalMin(ValueExtractor<? super T, ? extends Number>) - Static method in class com.tangosol.util.Aggregators
-
Return an aggregator that calculates a minimum of the numeric values extracted from a set of entries in a Map.
- bigDecimalMin(String) - Static method in class com.tangosol.util.Aggregators
-
Return an aggregator that calculates a minimum of the numeric values extracted from a set of entries in a Map.
- BigDecimalMin<T> - Class in com.tangosol.util.aggregator
-
Calculates a minimum of numeric values extracted from a set of entries in a Map in a form of a
BigDecimal
value. - BigDecimalMin() - Constructor for class com.tangosol.util.aggregator.BigDecimalMin
-
Default constructor (necessary for the ExternalizableLite interface).
- BigDecimalMin(ValueExtractor<? super T, ? extends Number>) - Constructor for class com.tangosol.util.aggregator.BigDecimalMin
-
Construct a BigDecimalMin aggregator.
- BigDecimalMin(String) - Constructor for class com.tangosol.util.aggregator.BigDecimalMin
-
Construct a BigDecimalMin aggregator.
- bigDecimalSum(ValueExtractor<? super T, ? extends Number>) - Static method in class com.tangosol.util.Aggregators
-
Return an aggregator that calculates a sum of the numeric values extracted from a set of entries in a Map.
- bigDecimalSum(String) - Static method in class com.tangosol.util.Aggregators
-
Return an aggregator that calculates a sum of the numeric values extracted from a set of entries in a Map.
- BigDecimalSum<T> - Class in com.tangosol.util.aggregator
-
Calculates an sum for values of any numberic type extracted from a set of entries in a Map in a form of a
BigDecimal
value. - BigDecimalSum() - Constructor for class com.tangosol.util.aggregator.BigDecimalSum
-
Default constructor (necessary for the ExternalizableLite interface).
- BigDecimalSum(ValueExtractor<? super T, ? extends Number>) - Constructor for class com.tangosol.util.aggregator.BigDecimalSum
-
Construct a BigDecimalSum aggregator.
- BigDecimalSum(String) - Constructor for class com.tangosol.util.aggregator.BigDecimalSum
-
Construct an BigDecimalSum object.
- BIGGEST_MODULO - Static variable in class com.tangosol.util.SafeHashMap
-
Biggest possible modulo.
- BIGGEST_MODULO - Static variable in class com.tangosol.util.SegmentedHashMap
-
Biggest possible modulo.
- BIGINTEGER_MAX_LONG - Static variable in class com.tangosol.io.pof.PofHelper
-
The BigInteger representation of Long.MAX_VALUE.
- BIGINTEGER_MIN_LONG - Static variable in class com.tangosol.io.pof.PofHelper
-
The BigInteger representation of Long.MIN_VALUE.
- BigIntegerAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.SimpleAdapter.BigIntegerAdapter
-
Construct a SimpleAdapter.
- bin(String) - Static method in class com.tangosol.io.nio.BinaryMap
-
Internal debugging support: Turn a String into a Binary.
- BIN_DECO_ONLY - Static variable in class com.tangosol.io.DecorationOnlyDeltaCompressor
-
A place-holder Binary value used by the compressor to indicate a decoration-only update.
- BIN_STORE_PENDING - Static variable in class com.tangosol.net.cache.ReadWriteBackingMap
-
The binary form of the decoration indicating that the CacheStore on the primary member has not yet written the value.
- Binary - Class in com.tangosol.util
-
A thread-safe immutable binary object.
- Binary() - Constructor for class com.tangosol.util.Binary
-
Default constructor for a binary object.
- Binary(byte[]) - Constructor for class com.tangosol.util.Binary
-
Construct a binary object from a byte array.
- Binary(byte[], int, int) - Constructor for class com.tangosol.util.Binary
-
Construct a binary object from a portion of a byte array.
- Binary(Binary) - Constructor for class com.tangosol.util.Binary
-
Construct a Binary object from a Binary object.
- Binary(ByteArrayOutputStream) - Constructor for class com.tangosol.util.Binary
-
Construct a Binary object from the contents of a ByteArrayOutputStream.
- Binary(DataInput) - Constructor for class com.tangosol.util.Binary
-
Construct a binary object from a DataInput interface.
- BINARY_EMPTY - Static variable in class com.tangosol.io.pof.PofHelper
-
An empty Binary value.
- BINARY_OPERATOR_NODE - Static variable in class com.tangosol.coherence.dsltools.precedence.OPToken
-
The AST node name for a Binary Operator node.
- BINARY_SIZE - Static variable in class com.tangosol.util.ExternalizableHelper
-
Binary overhead.
- binaryConsumer(StreamObserver<BytesValue>) - Method in class com.oracle.coherence.grpc.CacheRequestHolder
- BinaryDeltaCompressor - Class in com.tangosol.io
-
A DeltaCompressor implementation that works with opaque (binary) values.
- BinaryDeltaCompressor() - Constructor for class com.tangosol.io.BinaryDeltaCompressor
-
Default constructor.
- BinaryElementCalculator - Class in com.tangosol.net.topic
-
A
NamedTopic.ElementCalculator
that calculates size of an element based on the size of the serialized binary value. - BinaryElementCalculator() - Constructor for class com.tangosol.net.topic.BinaryElementCalculator
- BinaryEntry<K,
V> - Interface in com.tangosol.util -
Map.Entry that internally stores both key and value in a Binary format and uses an underlying Serializer to convert it to and from an Object view.
- BinaryEntryStore<K,
V> - Interface in com.tangosol.net.cache -
BinaryEntryStore is analogous to the
CacheStore
, but operates onBinaryEntry
objects. - BinaryEntryStoreWrapper(BinaryEntryStore) - Constructor for class com.tangosol.net.cache.ReadWriteBackingMap.BinaryEntryStoreWrapper
-
Construct a BinaryEntryStoreWrapper.
- BinaryHelper - Class in com.oracle.coherence.grpc
-
A helper class of methods to convert between
Binary
instances and proto-buffer byte values. - BinaryMap - Class in com.tangosol.io.nio
-
Implements the Map interface to store Binary objects using Java's NIO buffers.
- BinaryMap() - Constructor for class com.tangosol.io.nio.BinaryMap
-
Construct a BinaryMap.
- BinaryMap(ByteBufferManager) - Constructor for class com.tangosol.io.nio.BinaryMap
-
Construct a BinaryMap using a buffer from the specified ByteBufferManager, and using the default modulo growth and shrinkage (load factor) settings.
- BinaryMap(ByteBufferManager, double, double, boolean) - Constructor for class com.tangosol.io.nio.BinaryMap
-
Construct a BinaryMap using a buffer from the specified ByteBufferManager, and using the specified modulo growth and shrinkage (load factor) settings.
- BinaryMap(ByteBuffer) - Constructor for class com.tangosol.io.nio.BinaryMap
-
Construct a BinaryMap on a specific buffer with the default modulo growth and shrinkage (load factor) settings.
- BinaryMap(ByteBuffer, double, double, boolean) - Constructor for class com.tangosol.io.nio.BinaryMap
-
Construct a BinaryMap on a specific buffer with the specified modulo growth and shrinkage (load factor) settings.
- BinaryMap.Block - Class in com.tangosol.io.nio
-
A Block is the unit of storage within a Buffer.
- BinaryMap.Entry - Class in com.tangosol.io.nio
-
A map entry (key-value pair).
- BinaryMap.EntrySet - Class in com.tangosol.io.nio
-
A set of entries backed by this map.
- BinaryMap.KeySet - Class in com.tangosol.io.nio
-
A set of entries backed by this map.
- BinaryMap.ValuesCollection - Class in com.tangosol.io.nio
-
A collection of values backed by this map.
- BinaryMapStore - Class in com.tangosol.io.nio
-
An implementation of BinaryStore backed by a BinaryMap.
- BinaryMapStore(BinaryMap) - Constructor for class com.tangosol.io.nio.BinaryMapStore
-
Construct a BinaryMapStore object, which is an implementation of the BinaryStore interface backed by a BinaryMap.
- BinaryMarshaller - Class in com.tangosol.coherence.rest.io
-
A pass-through marshaller that simply converts HTTP entities into a
Binary
and vice versa. - BinaryMarshaller() - Constructor for class com.tangosol.coherence.rest.io.BinaryMarshaller
- BinaryMemoryCalculator - Class in com.tangosol.net.cache
-
A UnitCalculator implementation that weighs a cache entry based upon the amount of physical memory (in bytes) required to store the entry.
- BinaryMemoryCalculator() - Constructor for class com.tangosol.net.cache.BinaryMemoryCalculator
- binaryOperator(Remote.BinaryOperator<T>) - Static method in class com.tangosol.util.function.Remote
-
Capture serializable BinaryOperator.
- BinaryStore - Interface in com.tangosol.io
-
A simple mapping of CacheStore operations for Binary objects into a Java interface.
- BinaryStore.KeySetAware - Interface in com.tangosol.io
-
If a BinaryStore is aware of which keys that it stores, then it should implement this optional interface in order to allow that information to be efficiently communicated to an intelligent consumer of the BinaryStore interface.
- BinaryStore.SizeAware - Interface in com.tangosol.io
-
If a BinaryStore is aware of the number of keys that it stores, then it should implement this optional interface in order to allow that information to be efficiently communicated to an intelligent consumer of the BinaryStore interface.
- BinaryStoreCacheStore<K,
V> - Class in com.tangosol.net.cache -
A CacheStore that sits directly on top of a BinaryStore.
- BinaryStoreCacheStore(BinaryStore) - Constructor for class com.tangosol.net.cache.BinaryStoreCacheStore
-
Create a CacheStore that delegates to a BinaryStore.
- BinaryStoreCacheStore(BinaryStore, boolean) - Constructor for class com.tangosol.net.cache.BinaryStoreCacheStore
-
Create a CacheStore that delegates to a BinaryStore, optionally storing only Binary keys and values.
- BinaryStoreCacheStore(BinaryStore, ClassLoader) - Constructor for class com.tangosol.net.cache.BinaryStoreCacheStore
-
Create a CacheStore that delegates to a BinaryStore, using the passed ClassLoader for deserialization.
- BinaryStoreManager - Interface in com.tangosol.io
-
A manager that is capable of creating and destroying BinaryStore objects.
- BinaryStoreManagerBuilder - Interface in com.tangosol.coherence.config.builder.storemanager
-
A
BinaryStoreManagerBuilder
is responsible for realizingBinaryStoreManager
s. - BinaryStoreManagerBuilderCustomization - Interface in com.tangosol.coherence.config.builder.storemanager
-
A
BinaryStoreManagerBuilderCustomization
class is one that allows or potentially requires, aBinaryStoreManagerBuilder
for the purposes of realizing aBinaryStoreManager
. - BinaryWriteBuffer - Class in com.tangosol.util
-
a WriteBuffer implementation whose primary purpose is to be used to create Binary objects.
- BinaryWriteBuffer(int) - Constructor for class com.tangosol.util.BinaryWriteBuffer
-
Construct an BinaryWriteBuffer with a certain initial capacity.
- BinaryWriteBuffer(int, int) - Constructor for class com.tangosol.util.BinaryWriteBuffer
-
Construct an BinaryWriteBuffer with a certain initial capacity and a certain maximum capacity.
- bind(int, InetAddress) - Method in class com.tangosol.net.TcpDatagramSocket.Impl
- bind(FlowControl) - Method in class com.tangosol.net.cache.ContinuousQueryCache.ConverterAsynchronousProcessor
- bind(FlowControl) - Method in class com.tangosol.util.AsynchronousAgent
-
Bind this agent with the specified underlying FlowControl object.
- bind(ObservableSplittingBackingCache) - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache.CapacityAwareMap
-
Bind to the given
ObservableSplittingBackingMap
instance. - bind(String, Object) - Method in interface com.tangosol.net.NameService
-
Binds a name to an object.
- bind(SocketAddress) - Method in class com.tangosol.net.TcpDatagramSocket.Impl
-
Bind the socket to the specified address.
- BindableGrpcProxyService - Interface in com.oracle.coherence.grpc.proxy
-
An interface implemented by bindable gRPC proxy services.
- BINDING_NODE - Static variable in class com.tangosol.coherence.dsltools.precedence.OPToken
-
The AST node name for a Binding Node.
- bindService(String) - Method in class com.tangosol.net.partition.MirroringAssignmentStrategy
-
Bind this assignment strategy to the specified partitioned service, and return the bound service.
- biPredicate(Remote.BiPredicate<T, U>) - Static method in class com.tangosol.util.function.Remote
-
Capture serializable BiPredicate.
- BitHelper - Class in com.tangosol.util
-
A collection of methods for bit-based operations.
- BitHelper() - Constructor for class com.tangosol.util.BitHelper
- BLACK_LIST - Enum constant in enum class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.NameListDependencies.USAGE
- Block() - Constructor for class com.tangosol.io.nio.BinaryMap.Block
-
Construct a Block.
- Blocking - Class in com.oracle.coherence.common.base
-
Blocking provides a set of helper methods related to blocking a thread.
- Blocking() - Constructor for class com.oracle.coherence.common.base.Blocking
- BOOLEAN_ARRAY_EMPTY - Static variable in class com.tangosol.io.pof.PofHelper
-
An empty array of bytes.
- BooleanAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.SimpleAdapter.BooleanAdapter
-
Construct a SimpleAdapter.
- BooleanArrayAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.PrimitiveArrayAdapter.BooleanArrayAdapter
-
Construct a BooleanArrayAdapter.
- BOOLEANLITERAL - Static variable in class com.tangosol.coherence.dsltools.base.LiteralBaseToken
-
The numberic code for a boolean literal
- BOOLEANLITERAL - Static variable in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
-
The numberic code for a boolean literal
- booleanSupplier(Remote.BooleanSupplier) - Static method in class com.tangosol.util.function.Remote
-
Capture serializable BooleanSupplier.
- boxed() - Method in interface com.tangosol.util.stream.RemoteDoubleStream
-
Returns a
Stream
consisting of the elements of this stream, boxed toDouble
. - boxed() - Method in interface com.tangosol.util.stream.RemoteIntStream
-
Returns a
Stream
consisting of the elements of this stream, each boxed to anInteger
. - boxed() - Method in interface com.tangosol.util.stream.RemoteLongStream
-
Returns a
Stream
consisting of the elements of this stream, each boxed to aLong
. - breakLines(String, int, String) - Static method in class com.oracle.coherence.common.base.Formatting
-
Breaks the specified string into a multi-line string.
- breakLines(String, int, String) - Static method in class com.tangosol.util.Base
-
Breaks the specified string into a multi-line string.
- breakLines(String, int, String, boolean) - Static method in class com.oracle.coherence.common.base.Formatting
-
Breaks the specified string into a multi-line string.
- breakLines(String, int, String, boolean) - Static method in class com.tangosol.util.Base
-
Breaks the specified string into a multi-line string.
- BroadKeyPartitioningStrategy - Class in com.tangosol.net.partition
-
The BroadKeyPartitioningStrategy is a strategy that could be used in cases when the standard key association-based strategy produces very uneven partition distribution - some partitions having significantly larger amount of data than others.
- BroadKeyPartitioningStrategy(int) - Constructor for class com.tangosol.net.partition.BroadKeyPartitioningStrategy
-
Construct the BroadKeyPartitioningStrategy based on the specified span.
- BUCKET_COUNTS - Static variable in class com.tangosol.io.nio.BinaryMap
-
These are potential bucket counts.
- buffercopy(ByteBuffer, int, int, int, byte[]) - Static method in class com.tangosol.io.nio.BinaryMap
-
Copy from one part of the buffer to another.
- BufferTypeProcessor - Class in com.tangosol.coherence.config.xml.processor
-
An
ElementProcessor
for the <buffer-type> Cache Configuration element. - BufferTypeProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.BufferTypeProcessor
- build() - Method in class com.oracle.coherence.cdi.SerializerProducer.Builder
-
Build a new instance of a
SerializerProducer
. - build() - Method in class com.oracle.coherence.repository.AbstractRepositoryBase.Listener.Builder
-
Build
AbstractRepositoryBase.Listener
instance. - build() - Method in class com.tangosol.coherence.rest.util.ComparatorBuilder
-
Build comparator.
- build() - Method in class com.tangosol.net.Coherence.Builder
-
Build a
Coherence
instance. - build() - Method in class com.tangosol.net.CoherenceConfiguration.Builder
-
Build a
CoherenceConfiguration
from thisCoherenceConfiguration.Builder
. - build() - Method in class com.tangosol.net.management.MBeanAccessor.QueryBuilder
-
Build and return the MBean query.
- build() - Method in class com.tangosol.net.MapViewBuilder
-
Construct a
view
of theNamedMap
provided to this builder. - build() - Method in class com.tangosol.net.SessionConfiguration.Builder
-
Build the
SessionConfiguration
. - build() - Method in class com.tangosol.net.ViewBuilder
-
Construct a
view
of theNamedCache
provided to this builder. - build(boolean) - Method in class com.tangosol.net.Coherence.Builder
- builder() - Static method in class com.oracle.coherence.cdi.SerializerProducer
-
Create an instance of a
SerializerProducer.Builder
. - builder() - Static method in interface com.oracle.coherence.repository.AbstractRepositoryBase.Listener
-
Create new
AbstractRepositoryBase.Listener.Builder
instance. - builder() - Static method in interface com.tangosol.net.CoherenceConfiguration
-
Returns a
CoherenceConfiguration.Builder
that can configure and build instances ofCoherenceConfiguration
. - builder() - Static method in interface com.tangosol.net.SessionConfiguration
-
Create a
SessionConfiguration
builder. - builder(int) - Static method in class com.tangosol.net.ConfigurableLocalAddressProvider
-
Return a builder which will produce Providers for all local addresses and the specified port
- builder(CoherenceConfiguration) - Static method in class com.tangosol.net.Coherence
-
Returns a
Coherence.Builder
instance that can build aCoherence
instance using the specifiedCoherenceConfiguration
. - builder(CoherenceConfiguration, Coherence.Mode) - Static method in class com.tangosol.net.Coherence
-
Returns a
Coherence.Builder
instance that can build aCoherence
instance using the specifiedCoherenceConfiguration
. - Builder<T> - Interface in com.tangosol.util
-
A
Builder
provides a mechanism for realizing a specific class of object as required. - Builder() - Constructor for class com.oracle.coherence.repository.AbstractRepositoryBase.Listener.Builder
- Builder() - Constructor for class com.tangosol.net.CoherenceConfiguration.Builder
- BuilderCustomization<T> - Interface in com.tangosol.coherence.config.builder
-
A class that implements
BuilderCustomization
is one that allows an alternate builder, as aParameterizedBuilder
, to be provided so that the said class may use it for realizing objects. - BuilderHelper - Class in com.tangosol.util
-
Provides a collection of helper methods for working with
Builder
s. - BuilderHelper() - Constructor for class com.tangosol.util.BuilderHelper
- BuilderRegistration(String, Class<?>, ParameterizedBuilder<?>) - Constructor for class com.tangosol.coherence.config.builder.SimpleParameterizedBuilderRegistry.BuilderRegistration
- buildFactory(String, ClassLoader) - Method in class com.tangosol.net.ScopedCacheFactoryBuilder
-
Construct and configure a
ConfigurableCacheFactory
for the specified cache config URI andClassLoader
. - buildFactory(String, ClassLoader, ParameterResolver) - Method in class com.tangosol.net.ScopedCacheFactoryBuilder
-
Construct and configure a
ConfigurableCacheFactory
for the specified cache config URI andClassLoader
. - buildPlan() - Method in class com.tangosol.util.filter.LikeFilter
-
Build a plan for processing the LIKE functionality.
- bundle(Collection) - Method in class com.tangosol.net.cache.AbstractKeyBundler
-
The bundle operation to be performed against a collected set of keys by the concrete AbstractKeyBundler implementations.
- bundle(Collection) - Method in class com.tangosol.net.cache.BundlingNamedCache.GetBundler
-
A pass through the the underlying getAll operation.
- bundle(Collection) - Method in class com.tangosol.net.cache.BundlingNamedCache.RemoveBundler
-
A pass through the the underlying keySet().removeAll() operation.
- bundle(Map) - Method in class com.tangosol.net.cache.AbstractEntryBundler
-
The bundle operation to be performed against a collected map of entries by the concrete AbstractEntryBundler implementations.
- bundle(Map) - Method in class com.tangosol.net.cache.BundlingNamedCache.PutBundler
-
A pass through the the underlying putAll() operation.
- bundle(Set) - Method in class com.tangosol.net.cache.AbstractBinaryEntryBundler
-
The bundle operation to be performed against a collected set of binary entries by the concrete AbstractEntryBundler implementations.
- Bundle() - Constructor for class com.tangosol.net.cache.AbstractBinaryEntryBundler.Bundle
-
Default constructor.
- Bundle() - Constructor for class com.tangosol.net.cache.AbstractBundler.Bundle
-
Default constructor.
- Bundle() - Constructor for class com.tangosol.net.cache.AbstractEntryBundler.Bundle
-
Default constructor.
- Bundle() - Constructor for class com.tangosol.net.cache.AbstractKeyBundler.Bundle
-
Default constructor.
- BundleConfig() - Constructor for class com.tangosol.coherence.config.scheme.BundleManager.BundleConfig
- BundleManager - Class in com.tangosol.coherence.config.scheme
-
The
BundleManager
class is responsible for configuring caches to use bundling. - BundleManager() - Constructor for class com.tangosol.coherence.config.scheme.BundleManager
- BundleManager.BundleConfig - Class in com.tangosol.coherence.config.scheme
-
The BundleConfig class contains the configuration for a Bundle.
- BundlingNamedCache - Class in com.tangosol.net.cache
-
Bundling NamedCache implementation.
- BundlingNamedCache(NamedCache) - Constructor for class com.tangosol.net.cache.BundlingNamedCache
-
Construct a BundlingNamedCache based on the specified NamedCache.
- BundlingNamedCache.GetBundler - Class in com.tangosol.net.cache
- BundlingNamedCache.PutBundler - Class in com.tangosol.net.cache
- BundlingNamedCache.RemoveBundler - Class in com.tangosol.net.cache
- BundlingScheme - Interface in com.tangosol.coherence.config.scheme
-
BundlingScheme
s define how the bundling (batching) of operations will occur and theBundleManager
used to configure said bundling. - by(Filter<? super V>) - Static method in class com.tangosol.net.topic.Subscriber.Filtered
-
Return a Filtered option with the specified filter.
- BY_MEMBER - Static variable in interface com.tangosol.util.InvocableMap.StreamingAggregator
-
A flag specifying that it might be beneficial to execute this aggregator member-by-member.
- BY_PARTITION - Static variable in interface com.tangosol.util.InvocableMap.StreamingAggregator
-
A flag specifying that it might be beneficial to execute this aggregator partition-by-partition.
- BYTE_ARRAY_EMPTY - Static variable in class com.tangosol.io.pof.PofHelper
-
An empty array of bytes.
- ByteAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.SimpleAdapter.ByteAdapter
-
Construct a SimpleAdapter.
- ByteArrayAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.PrimitiveArrayAdapter.ByteArrayAdapter
-
Construct a ByteArrayAdapter.
- ByteArrayBufferInput() - Constructor for class com.tangosol.io.AbstractByteArrayReadBuffer.ByteArrayBufferInput
-
Default constructor.
- ByteArrayBufferOutput() - Constructor for class com.tangosol.io.ByteArrayWriteBuffer.ByteArrayBufferOutput
-
Construct an ByteArrayBufferOutput that will begin writing at the start of the containing WriteBuffer.
- ByteArrayBufferOutput(int) - Constructor for class com.tangosol.io.ByteArrayWriteBuffer.ByteArrayBufferOutput
-
Construct an ByteArrayBufferOutput that will begin writing at the specified offset within the containing WriteBuffer.
- ByteArrayReadBuffer - Class in com.tangosol.io
-
A ReadBuffer on top of a byte array.
- ByteArrayReadBuffer() - Constructor for class com.tangosol.io.ByteArrayReadBuffer
-
Default constructor provided for subclasses.
- ByteArrayReadBuffer(byte[]) - Constructor for class com.tangosol.io.ByteArrayReadBuffer
-
Construct a ByteArrayReadBuffer object from a byte array.
- ByteArrayReadBuffer(byte[], int, int) - Constructor for class com.tangosol.io.ByteArrayReadBuffer
-
Construct a ByteArrayReadBuffer object from a portion of a byte array.
- ByteArrayReadBuffer(byte[], int, int, boolean, boolean, boolean) - Constructor for class com.tangosol.io.ByteArrayReadBuffer
-
Construct a ByteArrayReadBuffer object from a portion of a byte array.
- ByteArrayWriteBuffer - Class in com.tangosol.io
-
ByteArrayWriteBuffer is an implementation of WriteBuffer on a byte array.
- ByteArrayWriteBuffer() - Constructor for class com.tangosol.io.ByteArrayWriteBuffer
-
Default constructor; intended only for use by subclasses.
- ByteArrayWriteBuffer(byte[]) - Constructor for class com.tangosol.io.ByteArrayWriteBuffer
-
Construct a ByteArrayWriteBuffer on a byte array.
- ByteArrayWriteBuffer(int) - Constructor for class com.tangosol.io.ByteArrayWriteBuffer
-
Construct an ByteArrayWriteBuffer with a certain initial capacity.
- ByteArrayWriteBuffer(int, int) - Constructor for class com.tangosol.io.ByteArrayWriteBuffer
-
Construct an ByteArrayWriteBuffer with a certain initial capacity and a certain maximum capacity.
- ByteArrayWriteBuffer(WriteBuffer, int, int) - Constructor for class com.tangosol.io.ByteArrayWriteBuffer
-
Create a new ByteArrayWriteBuffer based on a region of an already existing WriteBuffer.
- ByteArrayWriteBuffer.Allocator - Class in com.tangosol.io
-
Allocator is a WriteBufferPool implementation which allocates a new ByteArrayWriteBuffer on each request to the pool, and does not retain the returned buffer.
- ByteArrayWriteBuffer.ByteArrayBufferOutput - Class in com.tangosol.io
-
ByteArrayBufferOutput is an implementation of BufferOutput optimized for writing to the buffer's underlying byte array.
- byteAt(int) - Method in class com.tangosol.io.AbstractByteArrayReadBuffer
-
Returns the byte at the specified offset.
- byteAt(int) - Method in class com.tangosol.io.MultiBufferReadBuffer
-
Returns the byte at the specified offset.
- byteAt(int) - Method in class com.tangosol.io.nio.ByteBufferReadBuffer
-
Returns the byte at the specified offset.
- byteAt(int) - Method in interface com.tangosol.io.ReadBuffer
-
Returns the byte at the specified offset.
- byteAt(int) - Method in class com.tangosol.util.AbstractByteSequence.AggregateByteSequence
-
Determine the n-th byte of the byte sequence.
- byteAt(int) - Method in class com.tangosol.util.AbstractByteSequence.PartialByteSequence
-
Determine the n-th byte of the byte sequence.
- byteAt(int) - Method in interface com.tangosol.util.ByteSequence
-
Determine the n-th byte of the byte sequence.
- ByteBufferInput(ByteBuffer) - Constructor for class com.tangosol.io.nio.ByteBufferReadBuffer.ByteBufferInput
-
Default constructor.
- ByteBufferInputStream - Class in com.tangosol.io.nio
-
An InputStream implementation on top of a Java NIO ByteBuffer.
- ByteBufferInputStream(ByteBuffer) - Constructor for class com.tangosol.io.nio.ByteBufferInputStream
-
Construct a ByteBufferInputStream on a ByteBuffer object.
- ByteBufferManager - Interface in com.tangosol.io.nio
-
An interface for managing a ByteBuffer.
- ByteBufferOutput(int) - Constructor for class com.tangosol.io.nio.ByteBufferWriteBuffer.ByteBufferOutput
-
Construct a ByteBufferOutput on top of an NIO ByteBuffer.
- ByteBufferOutputStream - Class in com.tangosol.io.nio
-
An OutputStream implementation on top of a Java NIO ByteBuffer.
- ByteBufferOutputStream(ByteBuffer) - Constructor for class com.tangosol.io.nio.ByteBufferOutputStream
-
Construct a ByteBufferOutputStream on a ByteBuffer object.
- ByteBufferReadBuffer - Class in com.tangosol.io.nio
-
A ReadBuffer implementation on top of a Java NIO ByteBuffer.
- ByteBufferReadBuffer(ByteBuffer) - Constructor for class com.tangosol.io.nio.ByteBufferReadBuffer
-
Construct a ByteBufferReadBuffer on an NIO ByteBuffer.
- ByteBufferReadBuffer.ByteBufferInput - Class in com.tangosol.io.nio
-
This is a simple implementation of the BufferInput interface on top of a ByteBuffer.
- ByteBufferWriteBuffer - Class in com.tangosol.io.nio
-
A WriteBuffer implementation on top of a Java NIO ByteBuffer.
- ByteBufferWriteBuffer(ByteBufferWriteBuffer) - Constructor for class com.tangosol.io.nio.ByteBufferWriteBuffer
-
Perform a shallow clone of the supplied ByteBufferWriteBuffer.
- ByteBufferWriteBuffer(ByteBuffer) - Constructor for class com.tangosol.io.nio.ByteBufferWriteBuffer
-
Construct a ByteBufferWriteBuffer on an NIO ByteBuffer.
- ByteBufferWriteBuffer.ByteBufferOutput - Class in com.tangosol.io.nio
-
This is a simple implementation of the BufferOutput interface on top of a ByteBuffer.
- Bytes - Class in com.tangosol.coherence.config.unit
-
Bytes
is a specializedMemorySize
whose default constructor assumes that the specified units (when a magnitude is not specified) are always bytes. - Bytes(int) - Constructor for class com.tangosol.coherence.config.unit.Bytes
-
Constructs a
Bytes
representing aMemorySize
measured in bytes. - Bytes(MemorySize) - Constructor for class com.tangosol.coherence.config.unit.Bytes
-
Constructs a
Bytes
based on anotherMemorySize
. - Bytes(String) - Constructor for class com.tangosol.coherence.config.unit.Bytes
-
Constructs a
Bytes
representing aMemorySize
measured in bytes. - ByteSequence - Interface in com.tangosol.util
-
Represents a sequence of bytes.
- byteValue() - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicInteger
-
Returns the current value of this
AsyncAtomicInteger
as abyte
after a narrowing primitive conversion. - byteValue() - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicLong
-
Returns the value of the specified number as a
byte
. - byteValue() - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicInteger
- byteValue() - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicLong
- byteValue() - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicInteger
- byteValue() - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicLong
- byteValue() - Method in interface com.oracle.coherence.concurrent.atomic.AtomicInteger
-
Returns the current value of this
AtomicInteger
as abyte
after a narrowing primitive conversion. - byteValue() - Method in interface com.oracle.coherence.concurrent.atomic.AtomicLong
-
Returns the current value of this
AtomicLong
as abyte
after a narrowing primitive conversion. - byteValue() - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicInteger
- byteValue() - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicLong
C
- CACHE_FACTORY - Static variable in class com.tangosol.net.ExtensibleConfigurableCacheFactory
-
The name of the replaceable parameter representing a cache factory.
- 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.
- cacheAdd(InvocationContext) - Method in class com.oracle.coherence.cdi.CacheAddInterceptor
-
Always invokes target method and caches invocation result before returning it.
- CacheAdd - Annotation Interface in com.oracle.coherence.cdi
-
Never get the value from cache, get it from method and cache the result.
- CacheAdd.Literal - Class in com.oracle.coherence.cdi
-
An annotation literal for the
CacheAdd
annotation. - CacheAddInterceptor - Class in com.oracle.coherence.cdi
-
A CDI interceptor that always invokes target method and then caches invocation result before returning it.
- CacheAddInterceptor(Coherence, CoherenceExtension) - Constructor for class com.oracle.coherence.cdi.CacheAddInterceptor
-
Create the
CacheAddInterceptor
. - CacheCollator - Class in com.tangosol.util
-
Implements a collator which caches its keys.
- CacheCollator(Collator) - Constructor for class com.tangosol.util.CacheCollator
-
Construct this collator to cache the results of another collator.
- CacheConfig - Class in com.tangosol.coherence.config
-
A
CacheConfig
is the top-level container for Coherence Cache Configuration, that of which is used at runtime to establish caches and services. - CacheConfig(ParameterResolver) - Constructor for class com.tangosol.coherence.config.CacheConfig
-
Construct a
CacheConfig
. - CacheConfigNamespaceHandler - Class in com.tangosol.coherence.config.xml
-
The
CacheConfigNamespaceHandler
is responsible for capturing and creating Coherence Cache Configurations when processing a Coherence Configuration file. - CacheConfigNamespaceHandler() - Constructor for class com.tangosol.coherence.config.xml.CacheConfigNamespaceHandler
-
Standard Constructor.
- CacheConfigNamespaceHandler.Extension - Interface in com.tangosol.coherence.config.xml
-
A class that can add extensions to the
CacheConfigNamespaceHandler
. - CacheConfigOverrideProcessor - Class in com.tangosol.coherence.config.xml.processor
-
Implementation of
OverrideProcessor
that process cache configuration override file. - CacheConfigOverrideProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.CacheConfigOverrideProcessor
- CacheDefaultsPreprocessor - Class in com.tangosol.coherence.config.xml.preprocessor
-
A
CacheDefaultsPreprocessor
is anDocumentElementPreprocessor.ElementPreprocessor
that introduces (via cloning) default xml content for xml elements where the said content is missing. - CacheDefaultsPreprocessor(String) - Constructor for class com.tangosol.coherence.config.xml.preprocessor.CacheDefaultsPreprocessor
-
Constructs a
CacheDefaultsPreprocessor
with a specific path to where default element content can be located. - CacheEvent<K,
V> - Class in com.tangosol.net.cache -
An extension of the MapEvent which allows to differentiate between client driven (natural) events and cache internal (synthetic) events.
- CacheEvent(ObservableMap<K, V>, int, K, V, V, boolean) - Constructor for class com.tangosol.net.cache.CacheEvent
-
Constructs a new CacheEvent.
- CacheEvent(ObservableMap<K, V>, int, K, V, V, boolean, boolean) - Constructor for class com.tangosol.net.cache.CacheEvent
-
Constructs a new CacheEvent.
- CacheEvent(ObservableMap<K, V>, int, K, V, V, boolean, CacheEvent.TransformationState) - Constructor for class com.tangosol.net.cache.CacheEvent
-
Constructs a new CacheEvent.
- CacheEvent(ObservableMap<K, V>, int, K, V, V, boolean, CacheEvent.TransformationState, boolean) - Constructor for class com.tangosol.net.cache.CacheEvent
-
Constructs a new CacheEvent.
- CacheEvent(ObservableMap<K, V>, int, K, V, V, boolean, CacheEvent.TransformationState, boolean, boolean) - Constructor for class com.tangosol.net.cache.CacheEvent
-
Constructs a new CacheEvent.
- CacheEvent.TransformationState - Enum Class 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(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.
- CacheEventFilter(Filter<V>, int) - Constructor for class com.tangosol.util.filter.CacheEventFilter
-
Construct a CacheEventFilter that evaluates MapEvent objects that would affect the results of a keySet filter issued by a previous call to
QueryMap.keySet(com.tangosol.util.Filter)
. - 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.
- cacheGet(InvocationContext) - Method in class com.oracle.coherence.cdi.CacheGetInterceptor
-
Returns cached value if available; otherwise invokes target method and stores invocation result in the cache before returning it.
- CacheGet - Annotation Interface in com.oracle.coherence.cdi
-
Get the value from cache if present, invoke the method and cache the result otherwise.
- CacheGet.Literal - Class in com.oracle.coherence.cdi
-
An annotation literal for the
CacheGet
annotation. - CacheGetInterceptor - Class in com.oracle.coherence.cdi
-
A CDI interceptor that returns cached value if present; otherwise it returns and caches result of target method invocation.
- CacheGetInterceptor(Coherence, CoherenceExtension) - Constructor for class com.oracle.coherence.cdi.CacheGetInterceptor
-
Create the
CacheGetInterceptor
- CacheInfo(String, String, Map) - Constructor for class com.tangosol.net.DefaultConfigurableCacheFactory.CacheInfo
-
Deprecated.Construct a CacheInfo object.
- CacheKey - Annotation Interface in com.oracle.coherence.cdi
-
Parameters annotated with this annotation are considered part of the key.
- 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 Class in com.tangosol.net.events.partition.cache
-
The emitted event types for a
CacheLifecycleEvent
. - CacheLifecycleEventDispatcher - Interface in com.tangosol.net.events.partition.cache
-
A CacheLifecycleEventDispatcher raises
CacheLifecycleEvent
s. - CacheLifecycleEventHandler(EventObserverSupport.EventObserver<CacheLifecycleEvent>) - Constructor for class com.oracle.coherence.cdi.events.EventObserverSupport.CacheLifecycleEventHandler
- CacheLifecycleEvents - Annotation Interface in com.tangosol.net.events.annotation
-
CacheLifecycleEvents is an annotation that should be applied to
EventInterceptor
implementations that want to receiveCacheLifecycleEvent
s. - 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) - Constructor for class com.tangosol.net.cache.ReadWriteBackingMap.CacheLoaderCacheStore
-
Construct a CacheLoaderCacheStore.
- CacheLoaderCacheStore(CacheLoader<K, V>) - Constructor for class com.tangosol.net.cache.CacheLoaderCacheStore
-
The CacheLoader to delegate to.
- 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 proposedNamedCache
name to a caching scheme. - CacheMapping(String, String) - Constructor for class com.tangosol.coherence.config.CacheMapping
-
Construct a
CacheMapping
for caches that will use rawtypes by default. - CacheMappingProcessor - Class in com.tangosol.coherence.config.xml.processor
-
An
CacheMappingProcessor
is responsible for processing <cache-mapping>XmlElement
s to produce aCacheMapping
. - CacheMappingProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.CacheMappingProcessor
- CacheMappingRegistry - Class in com.tangosol.coherence.config
-
Deprecated.As Coherence 14.1.1, use
ResourceMappingRegistry
. - CacheMappingRegistry() - Constructor for class com.tangosol.coherence.config.CacheMappingRegistry
-
Deprecated.Construct a
CacheMappingRegistry
. - CacheMappingRegistry(ResourceMappingRegistry) - Constructor for class com.tangosol.coherence.config.CacheMappingRegistry
-
Deprecated.CacheMappingRegistry delegates to
ResourceMappingRegistry
. - CacheName - Annotation Interface in com.oracle.coherence.cdi.events
-
A qualifier annotation used to indicate a specific cache name.
- CacheName.Literal - Class in com.oracle.coherence.cdi.events
-
An annotation literal for the
CacheName
annotation. - 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.
- cachePut(InvocationContext) - Method in class com.oracle.coherence.cdi.CachePutInterceptor
-
Stores parameter annotated with
CacheValue
into cache, invokes target method and returns result of the invocation. - CachePut - Annotation Interface in com.oracle.coherence.cdi
-
Put a value to cache AND call the method.
- CachePut.Literal - Class in com.oracle.coherence.cdi
-
An annotation literal for the
CachePut
annotation. - CachePutInterceptor - Class in com.oracle.coherence.cdi
-
A CDI interceptor that stores parameter value in the Coherence cache.
- CachePutInterceptor(Coherence, CoherenceExtension) - Constructor for class com.oracle.coherence.cdi.CachePutInterceptor
-
Create the
CachePutInterceptor
- CacheRefExpression(Expression<?>, ClassLoader, CacheMappingRegistry) - Constructor for class com.tangosol.coherence.config.xml.processor.InitParamProcessor.CacheRefExpression
-
Deprecated.As of Coherence 14.1.1, use
CacheRefExpression(Expression, ClassLoader, ResourceMappingRegistry)
. - CacheRefExpression(Expression<?>, ClassLoader, ResourceMappingRegistry) - Constructor for class com.tangosol.coherence.config.xml.processor.InitParamProcessor.CacheRefExpression
-
Constructs a CacheRefExpression.
- cacheRemove(InvocationContext) - Method in class com.oracle.coherence.cdi.CacheRemoveInterceptor
-
Removes cached value.
- CacheRemove - Annotation Interface in com.oracle.coherence.cdi
-
Remove the value from the cache and call the method.
- CacheRemove.Literal - Class in com.oracle.coherence.cdi
-
An annotation literal for the
CacheRemove
annotation. - CacheRemoveInterceptor - Class in com.oracle.coherence.cdi
-
A CDI interceptor that removes value from the cache and invokes target method.
- CacheRemoveInterceptor(Coherence, CoherenceExtension) - Constructor for class com.oracle.coherence.cdi.CacheRemoveInterceptor
-
Create the
CacheRemoveInterceptor
- CacheRequestHolder<Req,
Res> - Class in com.oracle.coherence.grpc -
A class that holds a gRPC request, an associated
NamedCache
andBinary
converters. - CacheRequestHolder(Req, AsyncNamedCache<Binary, Binary>, Supplier<NamedCache<?, ?>>, String, Serializer, Executor) - Constructor for class com.oracle.coherence.grpc.CacheRequestHolder
-
Create a
CacheRequestHolder
. - CacheResource - Class in com.tangosol.coherence.rest
-
RESTful wrapper around a Coherence
NamedCache
. - CacheResource(NamedCache, Class, Class, KeyConverter, QueryConfig, int) - Constructor for class com.tangosol.coherence.rest.CacheResource
-
Construct a new CacheResource.
- CacheService - Interface in com.tangosol.net
-
A CacheService is a clustered service providing a collection of named Maps that hold resources shared among members of a cluster.
- CacheService.CacheAction - Interface in com.tangosol.net
-
CacheAction represents a type of action taken by a CacheService.
- CacheServiceProxyProcessor - Class in com.tangosol.coherence.config.xml.processor
-
An
ElementProcessor
that will parse cache-service-proxy configuration element tp produce aDefaultCacheServiceProxyDependencies
object. - CacheServiceProxyProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.CacheServiceProxyProcessor
- CacheStatistics - Interface in com.tangosol.net.cache
-
An interface for exposing Cache statistics.
- CacheStatisticsExtractor() - Constructor for class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics.CacheStatisticsExtractor
- CacheStatisticsExtractor(JCacheIdentifier) - Constructor for class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics.CacheStatisticsExtractor
-
Constructs
PartitionedJCacheStatistics.CacheStatisticsExtractor
to get JCacheStatistics associated with id. - CacheStore<K,
V> - Interface in com.tangosol.net.cache -
A JCache cache store.
- CacheStoreMap - Class in com.tangosol.net.cache
-
A backing Map implementation that delegates all operations to a CacheStore.
- CacheStoreMap(BackingMapManagerContext, 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(BackingMapManagerContext, IterableCacheLoader) - Constructor for class com.tangosol.net.cache.CacheStoreMap
-
Construct a read-only 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.
- CacheValue - Annotation Interface in com.oracle.coherence.cdi
-
Marks a parameter as the cache value.
- cacheValues() - Element in annotation interface com.oracle.coherence.cdi.View
-
A flag that is
true
to cache both the keys and values of the materialized view locally, orfalse
to only cache the keys (the default value istrue
). - cacheValues() - Method in class com.oracle.coherence.cdi.View.Literal
-
Obtain the flag that is
true
to cache both the keys and values of the materialized view locally, orfalse
to only cache the keys (the default value istrue
). - CachingMap<K,
V> - Class in com.tangosol.net.cache -
Map implementation that wraps two maps - a front map (assumed to be "inexpensive" and probably "incomplete") and a back map (assumed to be "complete" and "correct", but more "expensive") - using a read-through/write-through approach.
- CachingMap(Map<K, V>, Map<K, V>) - Constructor for class com.tangosol.net.cache.CachingMap
-
Construct a CachingMap using two specified maps: FrontMap (aka "cache", "near" or "shallow") and BackMap (aka "actual", "real" or "deep").
- CachingMap(Map<K, V>, Map<K, V>, int) - Constructor for class com.tangosol.net.cache.CachingMap
-
Construct a CachingMap using two specified maps: FrontMap (aka "cache", "near" or "shallow") and BackMap (aka "actual", "real" or "deep") and using the specified front map invalidation strategy.
- CachingMap.DeactivationListener - Class in com.tangosol.net.cache
-
DeactivationListener for the back NamedCache.
- CachingMap.FrontMapListener - Class in com.tangosol.net.cache
-
MapListener for front map responsible for deregistering back map listeners upon front map eviction.
- CachingMap.PrimingListener - Class in com.tangosol.net.cache
-
MapListener for back map responsible for keeping the front map coherent with the back map.
- CachingMap.SimpleListener - Class in com.tangosol.net.cache
-
MapListener for back map responsible for keeping the front map coherent with the back map.
- CachingScheme - Interface in com.tangosol.coherence.config.scheme
-
The
CachingScheme
is a multi-builder for cache-based infrastructure. - CachingSchemeMappingProcessor - Class in com.tangosol.coherence.config.xml.processor
-
An
CachingSchemeMappingProcessor
is responsible for processing <caching-scheme-mapping>XmlElement
s to update theResourceMappingRegistry
withCacheMapping
s. - CachingSchemeMappingProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.CachingSchemeMappingProcessor
- CachingSchemesProcessor - Class in com.tangosol.coherence.config.xml.processor
-
A
CachingSchemesProcessor
is anElementProcessor
for the <caching-schemes%gt; element of Coherence Cache Configuration files. - CachingSchemesProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.CachingSchemesProcessor
- CaffeineCache - Class in com.oracle.coherence.caffeine
-
A
ConfigurableCacheMap
backed by Caffeine. - CaffeineCache() - Constructor for class com.oracle.coherence.caffeine.CaffeineCache
-
Create
CaffeineCache
instance. - CaffeineScheme - Class in com.tangosol.coherence.config.scheme
-
The
CaffeineScheme
class is responsible for building a fully configured instance of aCaffeineCache
. - CaffeineScheme() - Constructor for class com.tangosol.coherence.config.scheme.CaffeineScheme
- 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<? extends ValueExtractor<? extends V, ?>, ? extends MapIndex<? extends K, ? extends V, ?>>, Set<? extends K>) - Method in interface com.tangosol.util.filter.IndexAwareFilter
-
Given a Map of available indexes, determine if this IndexAwareFilter can use any of the indexes to assist in its processing, and if so, determine how effective the use of that index would be.
- calculateEffectiveness(Map, Set) - Method in class com.tangosol.util.filter.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, Set) - Method in class com.tangosol.util.filter.InFilter
-
Given a Map of available indexes, determine if this IndexAwareFilter can use any of the indexes to assist in its processing, and if so, determine how effective the use of that index would be.
- calculateEffectiveness(Map, Set) - Method in class com.tangosol.util.filter.InKeySetFilter
-
Given a Map of available indexes, determine if this IndexAwareFilter can use any of the indexes to assist in its processing, and if so, determine how effective the use of that index would be.
- calculateEffectiveness(Map, Set) - Method in class com.tangosol.util.filter.KeyFilter
-
Given a Map of available indexes, determine if this IndexAwareFilter can use any of the indexes to assist in its processing, and if so, determine how effective the use of that index would be.
- calculateEffectiveness(Map, Set) - Method in class com.tangosol.util.filter.LessEqualsFilter
-
Given a Map of available indexes, determine if this IndexAwareFilter can use any of the indexes to assist in its processing, and if so, determine how effective the use of that index would be.
- calculateEffectiveness(Map, Set) - Method in class com.tangosol.util.filter.LessFilter
-
Given a Map of available indexes, determine if this IndexAwareFilter can use any of the indexes to assist in its processing, and if so, determine how effective the use of that index would be.
- calculateEffectiveness(Map, Set) - Method in class com.tangosol.util.filter.LikeFilter
-
Given a Map of available indexes, determine if this IndexAwareFilter can use any of the indexes to assist in its processing, and if so, determine how effective the use of that index would be.
- calculateEffectiveness(Map, Set) - Method in class com.tangosol.util.filter.LimitFilter
-
Given a Map of available indexes, determine if this IndexAwareFilter can use any of the indexes to assist in its processing, and if so, determine how effective the use of that index would be.
- calculateEffectiveness(Map, Set) - Method in class com.tangosol.util.filter.NeverFilter
-
Given a Map of available indexes, determine if this IndexAwareFilter can use any of the indexes to assist in its processing, and if so, determine how effective the use of that index would be.
- calculateEffectiveness(Map, Set) - Method in class com.tangosol.util.filter.NotEqualsFilter
-
Given a Map of available indexes, determine if this IndexAwareFilter can use any of the indexes to assist in its processing, and if so, determine how effective the use of that index would be.
- calculateEffectiveness(Map, Set) - Method in class com.tangosol.util.filter.NotFilter
-
Given a Map of available indexes, determine if this IndexAwareFilter can use any of the indexes to assist in its processing, and if so, determine how effective the use of that index would be.
- calculateEffectiveness(Map, Set) - Method in class com.tangosol.util.filter.PresentFilter
-
Given a Map of available indexes, determine if this IndexAwareFilter can use any of the indexes to assist in its processing, and if so, determine how effective the use of that index would be.
- calculateEffectiveness(Map, Set) - Method in class com.tangosol.util.filter.PriorityFilter
-
Given a Map of available indexes, determine if this IndexAwareFilter can use any of the indexes to assist in its processing, and if so, determine how effective the use of that index would be.
- calculateEffectiveness(Map, Set) - Method in class com.tangosol.util.filter.XorFilter
-
Given a Map of available indexes, determine if this IndexAwareFilter can use any of the indexes to assist in its processing, and if so, determine how effective the use of that index would be.
- calculateExpiry(long) - Static method in class com.tangosol.net.cache.BackingMapBinaryEntry
-
Calculate the expiry timestamp based on the expiry delay value.
- calculateFairShare(boolean) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
-
Return the "fair share" (F) load.
- calculateIteratorEffectiveness(int) - Static method in class com.tangosol.util.filter.ExtractorFilter
-
Helper method to calculate effectiveness (or rather ineffectiveness) of a simple iteration against a key set that has to be performed due to an absence of corresponding index.
- calculateJMXPartitionStats() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.JMXPartitionStats
-
Calculate MBean attribute values for partition statistics.
- calculateKeyPartition(PartitionedService, Object) - Static method in class com.tangosol.net.partition.DefaultKeyPartitioningStrategy
-
Determine the partition to which the given key should be assigned for the specified PartitionService, taking into consideration the associations provided by the service's KeyAssociator.
- calculateKeyPartitionHash(PartitionedService, Object) - Static method in class com.tangosol.net.partition.DefaultKeyPartitioningStrategy
-
Determine the partition-hash of the given key.
- calculateMatchEffectiveness(Map, Set) - Method in class com.tangosol.util.filter.ComparisonFilter
-
Helper method to calculate effectiveness for ComparisonFilters that need no more than a single index match in order to retrieve all necessary keys to perform the applyIndex() operation.
- 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, float) - 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(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>"
- 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>"
- calculatePackedLength(int) - Static method in class com.tangosol.util.ExternalizableHelper
-
Calculate the number of bytes needed to store a packed integer using a variable-length format.
- calculatePackedLength(long) - Static method in class com.tangosol.util.ExternalizableHelper
-
Calculate the number of bytes needed to store a packed long using a variable-length format.
- calculatePartition(PartitionedService, int) - Static method in class com.tangosol.net.partition.DefaultKeyPartitioningStrategy
-
Return the partition associated with the specified hash value in the specified PartitionedService.
- calculatePreviousBucket(int) - Method in class com.tangosol.io.nio.BinaryMap
-
Calculate the old bucket for the specified hash code.
- calculateRangeEffectiveness(Map, Set) - Method in class com.tangosol.util.filter.ComparisonFilter
-
Helper method to calculate effectiveness for ComparisonFilters that need a range of values from an index in order to retrieve all necessary keys to perform the applyIndex() operation.
- calculateRequeueDelay(ReadWriteBackingMap.WriteQueue) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
-
Calculate the requeue delay after a store operation failed.
- calculateShallowSize(Class) - Static method in class com.tangosol.net.cache.SimpleMemoryCalculator
-
Calculate the approximate number of bytes required to store an instance of the given class and its non-static fields in memory.
- calculateSize() - Method in interface com.tangosol.util.Sizable
-
Calculate the memory footprint for this instance.
- calculateSizeCode(int) - Static method in class com.tangosol.io.nio.BinaryMap
-
Determine which "free bucket" a block of a particular size would go into.
- calculateTotalLength(Object[][]) - Static method in class com.tangosol.util.ImmutableMultiList
-
Calculate the total number of element in the array of arrays.
- calculateUnits(Binary) - Method in class com.tangosol.net.topic.BinaryElementCalculator
- calculateUnits(Binary) - Method in class com.tangosol.net.topic.FixedElementCalculator
- calculateUnits(Binary) - Method in interface com.tangosol.net.topic.NamedTopic.ElementCalculator
-
Calculate cost for the specified element.
- calculateUnits(Object) - Method in class com.tangosol.net.cache.LocalCache.Entry
-
Calculate a cache cost for the specified object.
- 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, Object) - Method in class com.tangosol.net.cache.LocalCache.InternalUnitCalculator
- 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() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.ReadLatch
-
Cancel the load operation.
- cancel(boolean) - Method in class com.tangosol.net.cache.ContinuousQueryCache.ConverterAsynchronousProcessor
- cancel(boolean) - Method in class com.tangosol.util.AsynchronousAgent
- 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.
- 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.
- CanonicallyNamed - Interface in com.oracle.coherence.common.base
-
CanonicallyNamed provides a way for objects to identify themselves by name.
- canProcess(String) - Method in class com.tangosol.config.expression.ValueMacroExpression.DefaultDelimiterExpansionProcessor
- canProcess(String) - Method in class com.tangosol.config.expression.ValueMacroExpression.MacroExpansionProcessor
-
Return true iff
sMacro
contains the delimiter that this processor handles. - canProcess(String) - Method in class com.tangosol.config.expression.ValueMacroExpression.OffsetLengthSubstringExpansionProcessor
- canProcess(String) - Method in class com.tangosol.config.expression.ValueMacroExpression.SpaceDefaultDelimiterExpansionProcessor
- canUseGlobal() - Method in class com.tangosol.coherence.config.builder.SocketProviderBuilder
-
Returns
true
if theSocketProviderFactory
can use the global provider builder over this builder, if a global builder is present. - 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.oracle.coherence.common.base.Formatting
-
Capitalize a string.
- 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.
- castProcessor(InvocableMap.EntryProcessor<Binary, Binary, ?>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- castReturnValue(MethodNode) - Static method in class com.tangosol.coherence.rest.util.PartialObject
-
Cast a return value into an appropriate type.
- casValueInternal(Object, Object) - Method in class com.tangosol.util.SegmentedConcurrentMap.LockableEntry
-
Set the value of this entry to the specified value iff the current value matches the assumed value.
- CdiConfigSourceProvider - Class in com.oracle.coherence.mp.config
-
Bridges the gap between
ServiceLoader
and CDI, by registering itself as a service and using CDI to discover available CDI-managedConfigSource
s. - CdiConfigSourceProvider() - Constructor for class com.oracle.coherence.mp.config.CdiConfigSourceProvider
- CdiEventObserver<E> - Class in com.oracle.coherence.cdi
-
An observer of events that wraps a CDI
ProcessObserverMethod
. - CdiEventObserver(ObserverMethod<E>) - Constructor for class com.oracle.coherence.cdi.CdiEventObserver
-
Create a
CdiEventObserver
from anObserverMethod
- CdiEventObserver(ProcessObserverMethod<E, ?>) - Constructor for class com.oracle.coherence.cdi.CdiEventObserver
-
Create a
CdiEventObserver
from an observed method event. - CdiInjector - Class in com.oracle.coherence.cdi
-
An implementation of
Injector
that uses the CDI bean manager to inject dependencies. - CdiInjector() - Constructor for class com.oracle.coherence.cdi.CdiInjector
- CdiInterceptorMetadataResolver - Class in com.oracle.coherence.cdi
-
An implementation of
InterceptorMetadataResolver
that knows how to extract interceptor metadata from a Weld proxy. - CdiInterceptorMetadataResolver() - Constructor for class com.oracle.coherence.cdi.CdiInterceptorMetadataResolver
- CdiMapEventObserver<K,
V> - Class in com.oracle.coherence.cdi -
An implementation of a
AnnotatedMapListener.MapEventObserver
that wraps a CDIObserverMethod
that observesMapEvent
. - CdiMapEventObserver(ObserverMethod<MapEvent<K, V>>) - Constructor for class com.oracle.coherence.cdi.CdiMapEventObserver
-
Create a
CdiMapEventObserver
from anObserverMethod
- CdiMapEventObserver(ProcessObserverMethod<MapEvent<K, V>, ?>) - Constructor for class com.oracle.coherence.cdi.CdiMapEventObserver
-
Create a
CdiMapEventObserver
from an observed method event. - CdiMapListenerManager - Class in com.oracle.coherence.cdi
-
Registers discovered CDI observer-based
MapListener
s when the cache is created, and unregisters them when it's destroyed. - CdiMapListenerManager(FilterProducer, MapEventTransformerProducer, CoherenceExtension) - Constructor for class com.oracle.coherence.cdi.CdiMapListenerManager
- CdiMetricsRegistryAdapter - Class in com.oracle.coherence.mp.metrics
-
Bridges the gap between
ServiceLoader
and CDI, by registering itself as a service and delegating to all discovered CDI beans that implementMetricsRegistryAdapter
interface. - CdiMetricsRegistryAdapter() - Constructor for class com.oracle.coherence.mp.metrics.CdiMetricsRegistryAdapter
- CdiNamespaceHandler - Class in com.oracle.coherence.cdi.server
-
Custom namespace handler for
cdi
namespace. - CdiNamespaceHandler() - Constructor for class com.oracle.coherence.cdi.server.CdiNamespaceHandler
-
Construct
CdiNamespaceHandler
instance. - 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.NullImplementation.NullLongArray
- ceiling(long) - Method in class com.tangosol.util.SimpleLongArray
- ceiling(long) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
- ceiling(Object) - Method in class com.tangosol.util.SafeSortedMap.KeySet
- ceilingEntry(Object) - Method in class com.tangosol.util.SafeSortedMap.SubMap
- ceilingIndex(long) - Method in class com.tangosol.util.AbstractSafeLongArray
- ceilingIndex(long) - Method in class com.tangosol.util.AbstractSparseArray
-
Return the "first" index which is greater than or equal to the specified index.
- ceilingIndex(long) - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray
- ceilingIndex(long) - Method in interface com.tangosol.util.LongArray
-
Return the "first" index which is greater than or equal to the specified index.
- ceilingIndex(long) - Method in class com.tangosol.util.NullImplementation.NullLongArray
- ceilingIndex(long) - Method in class com.tangosol.util.SimpleLongArray
- ceilingIndex(long) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
- ceilingKey(Object) - Method in class com.tangosol.util.SafeSortedMap.SubMap
- cEntries - Variable in class com.tangosol.util.SegmentedHashMap.Segment
-
The number of Entry objects (including synthetics) in this segment.
- CertificateLoader - Interface in com.tangosol.net.ssl
-
A class that can load an array of
certificates
. - 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(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.
- 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.
- ChainedCollection<E> - Class in com.tangosol.util
-
An unmodifiable Collection that provides access to many collections in the given order.
- ChainedCollection(ChainedCollection<E>, Collection<E>) - Constructor for class com.tangosol.util.ChainedCollection
-
Construct a ChainedCollection from the existing ChainedCollection and an additional Collection object.
- ChainedCollection(ChainedCollection<E>, Collection<E>...) - Constructor for class com.tangosol.util.ChainedCollection
-
Construct a ChainedCollection from the existing ChainedCollection and an array of Collection objects.
- ChainedCollection(Collection<E>...) - Constructor for class com.tangosol.util.ChainedCollection
-
Construct a ChainedCollection with the provided array of Collection objects.
- ChainedCollection(Collection<Collection<E>>) - Constructor for class com.tangosol.util.ChainedCollection
-
Construct a ChainedCollection with the provided Collection 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(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(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) - Constructor for class com.tangosol.util.ChainedEnumerator
-
Construct an enumerator that will first enumerate the passed Iterator.
- 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.
- 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.
- ChainedExtractor<T,
E> - Class in com.tangosol.util.extractor -
Composite ValueExtractor implementation based on an array of extractors.
- ChainedExtractor - Annotation Interface in com.oracle.coherence.cdi
-
A
ExtractorBinding
annotation representing aChainedExtractor
. - 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.
- ChainedExtractor.Extractors - Annotation Interface in com.oracle.coherence.cdi
-
A holder for the repeatable
ChainedExtractor
annotation. - ChainedExtractor.Extractors.Literal - Class in com.oracle.coherence.cdi
-
An annotation literal for the
ChainedExtractor.Extractors
annotation. - ChainedExtractor.Literal - Class in com.oracle.coherence.cdi
-
An annotation literal for the
ChainedExtractor
annotation. - ChainedExtractorBuilder - Class in com.tangosol.coherence.dslquery
-
An
ExtractorBuilder
implementation that delegates buildingValueExtractor
s to a chain of ExtractorBuilders and returns the result from the first ExtractorBuilder to return a non-null value from itsChainedExtractorBuilder.realize(String, int, String)
method. - ChainedExtractorBuilder(ExtractorBuilder...) - Constructor for class com.tangosol.coherence.dslquery.ChainedExtractorBuilder
-
Construct a ChainedExtractorBuilder that uses the specified chain of
ExtractorBuilder
s to realize instances ofValueExtractor
s. - ChainedExtractorsSupplier() - Constructor for class com.oracle.coherence.cdi.ExtractorProducer.ChainedExtractorsSupplier
- ChainedExtractorSupplier() - Constructor for class com.oracle.coherence.cdi.ExtractorProducer.ChainedExtractorSupplier
- ChainedFragmentExtractor<T,
E> - Class in com.tangosol.util.extractor -
A
ValueExtractor
that extracts aFragment
from a nested property of the target object. - ChainedFragmentExtractor() - Constructor for class com.tangosol.util.extractor.ChainedFragmentExtractor
-
Deserialization constructor.
- ChainedFragmentExtractor(ValueExtractor<? super T, ? extends E>, ValueExtractor<? super E, ?>...) - Constructor for class com.tangosol.util.extractor.ChainedFragmentExtractor
-
Construct
ChainedFragmentExtractor
instance. - 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.
- ChainedParameterResolver - Class in com.tangosol.config.expression
-
A
ChainedParameterResolver
is aParameterResolver
that consults zero or more providedParameterResolver
s in the order in which they were defined or added to resolve aParameter
. - ChainedParameterResolver() - Constructor for class com.tangosol.config.expression.ChainedParameterResolver
-
Default constructor needed for serialization.
- ChainedParameterResolver(ParameterResolver...) - Constructor for class com.tangosol.config.expression.ChainedParameterResolver
-
Construct a
ChainedParameterResolver
based on the specifiedParameterResolver
s. - ChainedResourceResolver - Class in com.tangosol.util
-
A
ChainedResourceResolver
is aResourceResolver
that chains together one or more otherResourceResolver
s, those of which will be queried (in the order in which they are added to theChainedResourceResolver
) when attempting to resolve a resource. - ChainedResourceResolver(ResourceResolver...) - Constructor for class com.tangosol.util.ChainedResourceResolver
-
Constructs a
ChainedResourceResolver
. - ChainedSet<E> - Class in com.tangosol.util
-
An unmodifiable Set that provides access to many sets in the given order.
- ChainedSet(ChainedSet<E>, Set<E>) - Constructor for class com.tangosol.util.ChainedSet
-
Construct a ChainedSet from the existing ChainedSet and an additional Set object.
- ChainedSet(ChainedSet<E>, Set<E>...) - Constructor for class com.tangosol.util.ChainedSet
-
Construct a ChainedSet from the existing ChainedSet and an array of Set objects.
- ChainedSet(Collection<Set<E>>) - Constructor for class com.tangosol.util.ChainedSet
-
Construct a ChainedSet with the provided Collection of Set objects.
- ChainedSet(Set<E>...) - Constructor for class com.tangosol.util.ChainedSet
-
Construct a ChainedSet with the provided array of Set objects.
- ChangeRecord<K,
V> - Interface in com.tangosol.coherence.federation -
Provides a mechanism to represent and mutate a Cache Entry that was changed in a Federated Cache.
- ChangeRecord.Entry<K,
V> - Interface in com.tangosol.coherence.federation -
Represents the key, value and name of the Participant from which the entry originated.
- ChangeRecordUpdater<K,
V> - Interface in com.tangosol.coherence.federation -
ChangeRecordUpdater allows to update the given
ChangeRecord
while processing theFederatedChangeEvent
. - 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.
- Channels - Search tag in interface com.tangosol.net.topic.Publisher
- Section
- Channels - Search tag in interface com.tangosol.net.topic.Subscriber
- Section
- 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 interface com.tangosol.util.MapListener
-
A bit mask representing the set of characteristics of this listener.
- characteristics() - Method in interface com.tangosol.util.MapListenerSupport.SynchronousListener
- characteristics() - Method in class com.tangosol.util.MapListenerSupport.WrapperListener
- 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() - Method in class com.tangosol.net.GuardSupport
-
Check the registered Guardable objects for timeout, taking appropriate action and calculate the timestamp when the next check should be performed.
- check() - Method in class com.tangosol.util.ThreadLocalObject
-
Deprecated.as of Coherence 3.3 this method is a no-op
- check(String) - Method in class com.tangosol.io.nio.BinaryMap
-
Debugging support: Validate the buffer's data structures, the hash buckets, free lists, etc.
- 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(Object, Object) - Method in class com.tangosol.net.cache.ContinuousQueryCache
-
Check the passed value to verify that it does belong in this ContinuousQueryCache.
- checkEntry(Map.Entry) - 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.LocalCache
-
Deprecated.as of Coherence 3.5, use
LocalCache.evict()
- 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<?>, int, DataInput) - Static method in class com.tangosol.util.ExternalizableHelper
-
Return true if the provided class is allowed to be deserialized.
- checkObjectInputFilter(Class<?>, DataInput) - Static method in class com.tangosol.util.ExternalizableHelper
-
Return true if the provided class is allowed to be deserialized.
- checkObjectInputFilter(Class<?>, 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(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.
- 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.
- 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.
- checkReadOnly(String) - Static method in class com.tangosol.net.management.MBeanHelper
-
Checks whether "write" operations are allowed.
- 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.
- CHUNK_SIZE - Static variable in class com.tangosol.util.ExternalizableHelper
-
When using the chunking algorithm each chunk is constrained to 64MB by default.
- CHUNK_THRESHOLD - Static variable in class com.tangosol.util.ExternalizableHelper
-
A threshold used to decide whether to perform deserialization using a chunking algorithm; default is greater than 128MB.
- cipherSuites() - Method in class com.oracle.coherence.grpc.RefreshableSslContext
- 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.
- Classes - Class in com.oracle.coherence.common.base
-
This abstract class contains dynamic (reflect-based) class, method, and field manipulation methods.
- Classes() - Constructor for class com.oracle.coherence.common.base.Classes
- 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.
- className() - Element in annotation interface com.tangosol.net.management.annotation.Notification
-
The fully qualified class name of the notification object the MBean may emit.
- ClassScheme - Class in com.tangosol.coherence.config.scheme
-
The
ClassScheme
class is responsible for building customCachingScheme
s and customCacheStoreScheme
s. - ClassScheme() - Constructor for class com.tangosol.coherence.config.scheme.ClassScheme
- Clean-Up - Search tag in interface com.tangosol.net.topic.Subscriber
- Section
- clear() - Method in class com.oracle.coherence.caffeine.CaffeineCache
- clear() - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
- clear() - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
- clear() - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
- clear() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
- clear() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
- clear() - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
- clear() - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
- clear() - Method in class com.tangosol.io.AbstractWriteBuffer
-
Set the length of the buffer as indicated by the
WriteBuffer.length()
method to zero. - clear() - Method in class com.tangosol.io.DelegatingWriteBuffer
-
Set the length of the buffer as indicated by the
WriteBuffer.length()
method to zero. - clear() - Method in class com.tangosol.io.nio.BinaryMap.Block
-
Zero the block.
- clear() - Method in class com.tangosol.io.nio.BinaryMap
-
Removes all mappings from this map.
- clear() - Method in class com.tangosol.io.nio.BinaryMap.EntrySet
-
Removes all of the elements from this set of Keys by clearing the underlying Map.
- clear() - Method in class com.tangosol.io.nio.BinaryMap.KeySet
-
Removes all of the elements from this set of Keys by clearing the underlying Map.
- clear() - Method in class com.tangosol.io.nio.BinaryMap.ValuesCollection
-
Removes all of the elements from this Collection of values by clearing the underlying Map.
- clear() - Method in class com.tangosol.io.pof.PofHelper.ReadableEntrySetMap
-
Removes all mappings from this map.
- clear() - Method in interface com.tangosol.io.WriteBuffer
-
Set the length of the buffer as indicated by the
WriteBuffer.length()
method to zero. - clear() - Method in interface com.tangosol.net.AsyncNamedMap
-
Removes all of the mappings from this map.
- 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
- 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.NamedMap
-
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.ChainedSet
- clear() - Method in class com.tangosol.util.CircularArrayList
- clear() - Method in interface com.tangosol.util.ConcurrentMap
-
Removes all mappings from this map.
- clear() - Method in class com.tangosol.util.ConverterCollections.ConverterCollection
- clear() - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet
- clear() - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray
- clear() - Method in class com.tangosol.util.ConverterCollections.ConverterMap
- clear() - Method in class com.tangosol.util.CopyOnWriteLongArray
-
Remove all nodes from the LongArray.
- clear() - Method in class com.tangosol.util.CopyOnWriteMap
- clear() - Method in class com.tangosol.util.CopyOnWriteMap.EntrySet
- clear() - Method in class com.tangosol.util.CopyOnWriteMap.KeySet
- clear() - Method in class com.tangosol.util.DeltaSet
-
Removes all of the elements from this Collection.
- clear() - Method in class com.tangosol.util.InflatableCollection
- clear() - Method in class com.tangosol.util.LiteSet
-
Removes all of the elements from this Set.
- clear() - Method in interface com.tangosol.util.LongArray
-
Remove all nodes from the LongArray.
- clear() - Method in class com.tangosol.util.MapListenerSupport
-
Remove all signed up listeners.
- clear() - Method in class com.tangosol.util.MapSet
-
Removes all of the elements from this Set.
- clear() - Method in class com.tangosol.util.NullImplementation.NullLongArray
- 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() - Method in class com.tangosol.util.OpenHashMap
-
Clear all key/value mappings.
- clear() - Method in class com.tangosol.util.OpenHashSet
- clear() - Method in class com.tangosol.util.RestrictedCollections.RestrictedCollection
-
Removes all of the elements from this Collection.
- clear() - Method in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet
-
Removes all of the elements from this Collection.
- clear() - Method in class com.tangosol.util.RestrictedCollections.RestrictedMap
-
Removes all mappings from this map.
- clear() - Method in class com.tangosol.util.SafeHashMap
-
Removes all mappings from this map.
- clear() - Method in class com.tangosol.util.SafeHashMap.EntrySet
-
Removes all of the elements from this set of Keys by clearing the underlying Map.
- clear() - Method in class com.tangosol.util.SafeHashMap.KeySet
-
Removes all of the elements from this set of Keys by clearing the underlying Map.
- clear() - Method in class com.tangosol.util.SafeHashMap.ValuesCollection
-
Removes all of the elements from this Collection of values by clearing the underlying Map.
- clear() - Method in class com.tangosol.util.SafeLinkedList
-
Removes all of the elements from this List.
- clear() - Method in class com.tangosol.util.SafeSortedMap.SubMap
- clear() - Method in class com.tangosol.util.SafeSortedMap.Values
- clear() - Method in class com.tangosol.util.SegmentedConcurrentMap
-
Removes all mappings from this map.
- clear() - Method in class com.tangosol.util.SegmentedHashMap
-
Removes all mappings from this map.
- clear() - Method in class com.tangosol.util.SegmentedHashMap.EntrySet
-
Removes all of the elements from this set of Keys by clearing the underlying Map.
- clear() - Method in class com.tangosol.util.SegmentedHashMap.KeySet
-
Removes all of the elements from this set of Keys by clearing the underlying Map.
- clear() - Method in class com.tangosol.util.SegmentedHashMap.ValuesCollection
-
Removes all of the elements from this Collection of values by clearing the underlying Map.
- clear() - Method in class com.tangosol.util.SetMap
- clear() - Method in class com.tangosol.util.SimpleLongArray
-
Remove all nodes from the LongArray.
- clear() - Method in class com.tangosol.util.StringTable
-
Remove all strings from the table.
- clear() - Method in class com.tangosol.util.SubList
- clear() - Method in class com.tangosol.util.SubSet
- clear() - Method in class com.tangosol.util.Tree
-
Remove all nodes from the tree.
- clear() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperCollection
- clear() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
- clear() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperMap
- clear() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperCollection
- clear() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- clear() - Method in class com.tangosol.util.WrapperConcurrentMap
-
Clear all key/value mappings.
- clear() - Method in class com.tangosol.util.WrapperObservableMap
-
Clear all key/value mappings.
- clear(boolean) - Method in class com.tangosol.util.ObservableHashMap
- clear(ClearRequest) - Method in interface com.oracle.coherence.grpc.proxy.NamedCacheService
-
Clear a cache.
- clear(ClearRequest) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- clear(ClearRequest, StreamObserver<Empty>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceGrpcImpl
- clear(String, String) - Static method in class com.oracle.coherence.grpc.Requests
-
Create a
ClearRequest
. - 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 method in class com.tangosol.net.Coherence
-
Return the default
Coherence
client instance, creating it if it does not already exist. - client(Coherence.Mode) - Static method in class com.tangosol.net.Coherence
-
Return the default
Coherence
client instance, creating it if it does not already exist. - client(CoherenceConfiguration) - Static method in class com.tangosol.net.Coherence
-
Create a client
Coherence
instance from the specifiedCoherenceConfiguration
. - Client - Enum constant in enum class com.tangosol.net.Coherence.Mode
-
The
Coherence
instance should run as a non-cluster member Extend client. - CLIENT - Static variable in class com.tangosol.coherence.config.xml.processor.ServiceLoadBalancerProcessor
-
Client option for the service load balancer.
- clientBuilder(CoherenceConfiguration) - Static method in class com.tangosol.net.Coherence
-
Returns a
Coherence.Builder
instance that can build aCoherence
instance using the specifiedCoherenceConfiguration
. - clientBuilder(CoherenceConfiguration, Coherence.Mode) - Static method in class com.tangosol.net.Coherence
-
Returns a
Coherence.Builder
instance that can build aCoherence
instance using the specifiedCoherenceConfiguration
. - clientDirect() - Method in class com.tangosol.net.SessionConfiguration.Builder
-
Set the session's
coherence.client
parameter to "direct". - clientFixed() - Method in class com.tangosol.net.SessionConfiguration.Builder
-
Set the session's
coherence.client
parameter to "remote-fixed". - ClientFixed - Enum constant in enum class com.tangosol.net.Coherence.Mode
-
The
Coherence
instance should run as a non-cluster member Extend client, configured with a fixed address and port. - clientRemote() - Method in class com.tangosol.net.SessionConfiguration.Builder
-
Set the session's
coherence.client
parameter to "remote". - clone() - Method in interface com.oracle.coherence.common.base.Cloneable
-
Create and return a copy of this object as described by the
Object.clone()
contract. - clone() - 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() - 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() - 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() - 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.NullImplementation.NullLongArray
- clone() - Method in class com.tangosol.util.ReadHeavyLongArray
- clone() - Method in class com.tangosol.util.RecyclingLinkedList
-
Create a deep clone of the list.
- clone() - Method in class com.tangosol.util.SafeHashMap
-
Create a clone of the SafeHashMap.
- clone() - Method in class com.tangosol.util.SafeHashMap.Entry
-
Clone the Entry.
- clone() - Method in class com.tangosol.util.SafeLinkedList
-
Create a clone of the SafeLinkedList.
- clone() - Method in class com.tangosol.util.SafeLinkedList.Node
- clone() - Method in class com.tangosol.util.SafeLongArray
- clone() - Method in class com.tangosol.util.SafeSortedMap
- clone() - Method in class com.tangosol.util.SafeSortedMap.SubMap
- clone() - Method in class com.tangosol.util.SimpleLongArray
-
Make a clone of the LongArray.
- clone() - Method in class com.tangosol.util.SimpleMapEntry
-
Clone the Entry.
- clone() - Method in class com.tangosol.util.SparseArray
- clone() - Method in class com.tangosol.util.StringTable
-
Make a new string table with a copy of the tree and a copy of the collator.
- clone() - Method in class com.tangosol.util.SubSet
-
Clone the subset.
- clone() - Method in class com.tangosol.util.Tree
-
Make a shallow copy of the tree and its nodes.
- clone() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
- clone(byte[], int, int) - Static method in class com.tangosol.util.Binary
-
Create a clone of the specified binary region.
- 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(Object) - Method in class com.tangosol.run.xml.XmlSerializableAdapter
-
Make a clone of the passed object.
- clone(T) - Method in interface com.oracle.coherence.common.base.Cloner
-
Return a copy of the specified object.
- clone(T) - Method in class com.oracle.coherence.common.base.NaturalCloner
- Cloneable - Interface in com.oracle.coherence.common.base
-
This interface is meant to "fix" the usability issues related to the
Cloneable
method-less interface. - cloneEntryList(SafeHashMap.Entry) - Method in class com.tangosol.util.SafeHashMap
-
Clone an entire linked list of entries.
- Cloner - Interface in com.oracle.coherence.common.base
-
A Cloner provides an external means for producing copies of objects as prescribed by the
Object.clone()
contract. - close() - Method in interface com.oracle.coherence.common.base.Disposable
-
Default implementation invokes
Disposable.dispose()
, it is not recommended that this be overridden. - close() - Method in interface com.oracle.coherence.common.base.Lockable.Unlockable
-
Release the acquired exclusive access to this Lockable.
- close() - Method in class com.oracle.coherence.common.base.NonBlocking
- close() - Method in class com.oracle.coherence.common.base.Timeout
-
As part of closing the Timeout resource any former timeout will be restored.
- close() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCache
- close() - Method in class com.tangosol.coherence.jcache.CoherenceBasedCacheManager
- close() - Method in class com.tangosol.coherence.jcache.CoherenceBasedCachingProvider
- close() - 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
-
Deprecated.use the Disposable interface instead
- close() - Method in class com.tangosol.io.nio.ByteBufferInputStream
-
Close the stream, flushing any accumulated bytes.
- close() - Method in class com.tangosol.io.nio.ByteBufferOutputStream
-
Close the stream, flushing any accumulated bytes.
- close() - Method in class com.tangosol.io.nio.MappedBufferManager
-
Close the underlying resources.
- close() - Method in class com.tangosol.io.pof.PofInputStream
-
Close the InputStream and release any system resources associated with it.
- close() - Method in class com.tangosol.io.pof.PofOutputStream
-
Closes this OutputStream and releases any associated system resources.
- close() - Method in interface com.tangosol.io.ReadBuffer.BufferInput
-
Close the InputStream and release any system resources associated with it.
- close() - Method in class com.tangosol.io.SizeEstimatingBufferOutput
- close() - Method in class com.tangosol.io.Utf8Reader
-
Close the stream.
- close() - Method in class com.tangosol.io.Utf8Writer
-
Close the stream, flushing it first.
- close() - Method in class com.tangosol.io.WrapperBufferOutput
-
Close the OutputStream and release any system resources associated with it.
- close() - Method in class com.tangosol.io.WrapperDataInputStream
-
Close the InputStream and release any system resources associated with it.
- close() - Method in class com.tangosol.io.WrapperDataOutputStream
-
Closes this OutputStream and releases any associated system resources.
- close() - Method in class com.tangosol.io.WrapperInputStream
-
Close the InputStream and release any system resources associated with it.
- close() - Method in class com.tangosol.io.WrapperObjectInputStream
-
Close the InputStream and release any system resources associated with it.
- close() - Method in class com.tangosol.io.WrapperOutputStream
-
Closes this OutputStream and releases any associated system resources.
- close() - Method in interface com.tangosol.io.WriteBuffer.BufferOutput
-
Close the OutputStream and release any system resources associated with it.
- close() - Method in class com.tangosol.io.WriterPrintStream
-
Close the stream.
- close() - Method in class com.tangosol.net.cache.SerializationPagedCache.PagedBinaryStore
-
Release underlying resources.
- close() - Method in class com.tangosol.net.cache.SerializationPagedCache.WrapperBinaryStore
-
Used to specify that the page is no longer current.
- close() - Method in class com.tangosol.net.Coherence
-
Close this
Coherence
instance. - 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 interface com.tangosol.net.SessionProvider
-
Optionally close all of the
Session
instances provided by thisSessionProvider
. - close() - Method in class com.tangosol.net.TcpDatagramSocket.Impl
- close() - Method in interface com.tangosol.net.topic.Publisher
-
Close this
Publisher
. - close() - Method in interface com.tangosol.net.topic.Subscriber
-
Close the Subscriber.
- close() - 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() - 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() - Method in class com.tangosol.util.WrapperReentrantGate
- 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(ClassLoader) - Method in class com.tangosol.coherence.jcache.CoherenceBasedCachingProvider
- 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(String) - Method in class com.tangosol.util.NullImplementation.NullPersistenceManager
-
Close the associated PersistentStore and release exclusive access to the associated resources.
- close(URI, ClassLoader) - Method in class com.tangosol.coherence.jcache.CoherenceBasedCachingProvider
- closeAll() - Static method in class com.tangosol.net.Coherence
-
Close all
Coherence
instances. - closeDb() - Method in class com.tangosol.io.bdb.BerkeleyDBBinaryStore.DatabaseHolder
-
Close the Database.
- closeEnvironment(boolean) - Method in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
-
Close an Environment.
- closeInbound(TcpDatagramSocket.Impl.ConnectionStatus, SocketChannel) - Method in class com.tangosol.net.TcpDatagramSocket.Impl
-
Close the inbound
channel
. - closeNested() - Method in class com.tangosol.io.pof.PofBufferReader.UserTypeReader
-
Notify the UserTypeReader that it is being "closed".
- closeNested() - Method in class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
-
Notify the UserTypeWriter that it is being "closed".
- closeOutbound(SocketAddress) - Method in class com.tangosol.net.TcpDatagramSocket.Impl
-
Close the outbound socket.
- closeProcessing() - Method in class com.tangosol.net.cache.OverflowMap.Status
-
Finish the processing of the entry for which this Status exists and proceed to the commit phase.
- closeProcessing() - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
-
Finish the processing of the entry for which this Status exists and proceed to the commit phase.
- CLOSEST - Static variable in class com.tangosol.coherence.config.builder.ReadLocatorBuilder
-
A BiFunction implementation that returns a member that is 'closest' to this member based on provided metadata (member, machine, rack, or site).
- 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_TYPE - Static variable in interface com.tangosol.net.management.Registry
-
String representation of the ObjectName for the ClusterMBean.
- 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).
- ClusterDependencies - Interface in com.tangosol.net
-
The ClusterDependencies interface defines externally provided dependencies for a
Cluster
. - ClusterDependencies.ServiceProvider - Interface in com.tangosol.net
-
A provider of nw service instances.
- ClusteredCachingScheme - Interface in com.tangosol.coherence.config.scheme
-
The ClusteredCachingScheme interface represents schemes that are used for clustered caches.
- ClusterException - Exception Class in com.tangosol.net
-
Deprecated.As of release 3.4, replaced by
PortableException
- ClusterException() - Constructor for exception class com.tangosol.net.ClusterException
-
Deprecated.Constructs a ClusterException with no detail message.
- ClusterException(String) - Constructor
AbstractStableIterator